You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by ha...@apache.org on 2017/11/15 05:52:22 UTC

[01/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Repository: hive
Updated Branches:
  refs/heads/master de78ddb77 -> afa9ffee8


http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_windowspec4.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_windowspec4.q.out b/ql/src/test/results/clientpositive/vector_windowing_windowspec4.q.out
deleted file mode 100644
index f04b4e1..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_windowspec4.q.out
+++ /dev/null
@@ -1,214 +0,0 @@
-PREHOOK: query: drop table if exists smalltable_windowing
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table if exists smalltable_windowing
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table smalltable_windowing(
-      i int,
-      type string)
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@smalltable_windowing
-POSTHOOK: query: create table smalltable_windowing(
-      i int,
-      type string)
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@smalltable_windowing
-PREHOOK: query: insert into smalltable_windowing values(3, 'a'), (1, 'a'), (2, 'a')
-PREHOOK: type: QUERY
-PREHOOK: Output: default@smalltable_windowing
-POSTHOOK: query: insert into smalltable_windowing values(3, 'a'), (1, 'a'), (2, 'a')
-POSTHOOK: type: QUERY
-POSTHOOK: Output: default@smalltable_windowing
-POSTHOOK: Lineage: smalltable_windowing.i EXPRESSION [(values__tmp__table__1)values__tmp__table__1.FieldSchema(name:tmp_values_col1, type:string, comment:), ]
-POSTHOOK: Lineage: smalltable_windowing.type SIMPLE [(values__tmp__table__1)values__tmp__table__1.FieldSchema(name:tmp_values_col2, type:string, comment:), ]
-_col0	_col1
-PREHOOK: query: explain vectorization detail
-select type, i,
-max(i) over (partition by type order by i rows between 1 preceding and 7 following),
-min(i) over (partition by type order by i rows between 1 preceding and 7 following),
-first_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-last_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-avg(i) over (partition by type order by i rows between 1 preceding and 7 following),
-sum(i) over (partition by type order by i rows between 1 preceding and 7 following),
-collect_set(i) over (partition by type order by i rows between 1 preceding and 7 following),
-count(i) over (partition by type order by i rows between 1 preceding and 7 following)
-from smalltable_windowing
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select type, i,
-max(i) over (partition by type order by i rows between 1 preceding and 7 following),
-min(i) over (partition by type order by i rows between 1 preceding and 7 following),
-first_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-last_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-avg(i) over (partition by type order by i rows between 1 preceding and 7 following),
-sum(i) over (partition by type order by i rows between 1 preceding and 7 following),
-collect_set(i) over (partition by type order by i rows between 1 preceding and 7 following),
-count(i) over (partition by type order by i rows between 1 preceding and 7 following)
-from smalltable_windowing
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: smalltable_windowing
-            Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1]
-                projectedColumns: [i:int, type:string]
-            Reduce Output Operator
-              key expressions: type (type: string), i (type: int)
-              sort order: ++
-              Map-reduce partition columns: type (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 2
-              includeColumns: [0, 1]
-              dataColumns: i:int, type:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col0, _col1
-          Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: int, _col1: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col0 ASC NULLS FIRST
-                  partition by: _col1
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: max_window_0
-                        arguments: _col0
-                        name: max
-                        window function: GenericUDAFMaxEvaluator
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-                      window function definition
-                        alias: min_window_1
-                        arguments: _col0
-                        name: min
-                        window function: GenericUDAFMinEvaluator
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-                      window function definition
-                        alias: first_value_window_2
-                        arguments: _col0
-                        name: first_value
-                        window function: GenericUDAFFirstValueEvaluator
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-                      window function definition
-                        alias: last_value_window_3
-                        arguments: _col0
-                        name: last_value
-                        window function: GenericUDAFLastValueEvaluator
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-                      window function definition
-                        alias: avg_window_4
-                        arguments: _col0
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-                      window function definition
-                        alias: sum_window_5
-                        arguments: _col0
-                        name: sum
-                        window function: GenericUDAFSumLong
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-                      window function definition
-                        alias: collect_set_window_6
-                        arguments: _col0
-                        name: collect_set
-                        window function: GenericUDAFMkCollectionEvaluator
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-                      window function definition
-                        alias: count_window_7
-                        arguments: _col0
-                        name: count
-                        window function: GenericUDAFCountEvaluator
-                        window frame: ROWS PRECEDING(1)~FOLLOWING(7)
-            Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col1 (type: string), _col0 (type: int), max_window_0 (type: int), min_window_1 (type: int), first_value_window_2 (type: int), last_value_window_3 (type: int), avg_window_4 (type: double), sum_window_5 (type: bigint), collect_set_window_6 (type: array<int>), count_window_7 (type: bigint)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9
-              Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select type, i,
-max(i) over (partition by type order by i rows between 1 preceding and 7 following),
-min(i) over (partition by type order by i rows between 1 preceding and 7 following),
-first_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-last_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-avg(i) over (partition by type order by i rows between 1 preceding and 7 following),
-sum(i) over (partition by type order by i rows between 1 preceding and 7 following),
-collect_set(i) over (partition by type order by i rows between 1 preceding and 7 following),
-count(i) over (partition by type order by i rows between 1 preceding and 7 following)
-from smalltable_windowing
-PREHOOK: type: QUERY
-PREHOOK: Input: default@smalltable_windowing
-#### A masked pattern was here ####
-POSTHOOK: query: select type, i,
-max(i) over (partition by type order by i rows between 1 preceding and 7 following),
-min(i) over (partition by type order by i rows between 1 preceding and 7 following),
-first_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-last_value(i) over (partition by type order by i rows between 1 preceding and 7 following),
-avg(i) over (partition by type order by i rows between 1 preceding and 7 following),
-sum(i) over (partition by type order by i rows between 1 preceding and 7 following),
-collect_set(i) over (partition by type order by i rows between 1 preceding and 7 following),
-count(i) over (partition by type order by i rows between 1 preceding and 7 following)
-from smalltable_windowing
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@smalltable_windowing
-#### A masked pattern was here ####
-type	i	max_window_0	min_window_1	first_value_window_2	last_value_window_3	avg_window_4	sum_window_5	collect_set_window_6	count_window_7
-a	1	3	1	1	3	2.0	6	[1,2,3]	3
-a	2	3	1	1	3	2.0	6	[1,2,3]	3
-a	3	3	2	2	3	2.5	5	[2,3]	2

http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vectorization_input_format_excludes.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vectorization_input_format_excludes.q.out b/ql/src/test/results/clientpositive/vectorization_input_format_excludes.q.out
deleted file mode 100644
index 4441b12..0000000
--- a/ql/src/test/results/clientpositive/vectorization_input_format_excludes.q.out
+++ /dev/null
@@ -1,1340 +0,0 @@
-PREHOOK: query: create table if not exists alltypes_parquet (
-  cint int,
-  ctinyint tinyint,
-  csmallint smallint,
-  cfloat float,
-  cdouble double,
-  cstring1 string) stored as parquet
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@alltypes_parquet
-POSTHOOK: query: create table if not exists alltypes_parquet (
-  cint int,
-  ctinyint tinyint,
-  csmallint smallint,
-  cfloat float,
-  cdouble double,
-  cstring1 string) stored as parquet
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@alltypes_parquet
-PREHOOK: query: insert overwrite table alltypes_parquet
-  select cint,
-    ctinyint,
-    csmallint,
-    cfloat,
-    cdouble,
-    cstring1
-  from alltypesorc
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypesorc
-PREHOOK: Output: default@alltypes_parquet
-POSTHOOK: query: insert overwrite table alltypes_parquet
-  select cint,
-    ctinyint,
-    csmallint,
-    cfloat,
-    cdouble,
-    cstring1
-  from alltypesorc
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypesorc
-POSTHOOK: Output: default@alltypes_parquet
-POSTHOOK: Lineage: alltypes_parquet.cdouble SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cdouble, type:double, comment:null), ]
-POSTHOOK: Lineage: alltypes_parquet.cfloat SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cfloat, type:float, comment:null), ]
-POSTHOOK: Lineage: alltypes_parquet.cint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cint, type:int, comment:null), ]
-POSTHOOK: Lineage: alltypes_parquet.csmallint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:csmallint, type:smallint, comment:null), ]
-POSTHOOK: Lineage: alltypes_parquet.cstring1 SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cstring1, type:string, comment:null), ]
-POSTHOOK: Lineage: alltypes_parquet.ctinyint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:ctinyint, type:tinyint, comment:null), ]
-PREHOOK: query: explain vectorization select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_parquet
-            Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (cint = 528534767) (type: boolean)
-              Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: 528534767 (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-                Limit
-                  Number of rows: 10
-                  Statistics: Num rows: 10 Data size: 60 Basic stats: COMPLETE Column stats: NONE
-                  File Output Operator
-                    compressed: false
-                    Statistics: Num rows: 10 Data size: 60 Basic stats: COMPLETE Column stats: NONE
-                    table:
-                        input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                        output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vectorized.input.format IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-POSTHOOK: query: select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-528534767	-11	-15431	-11.0	-15431.0	cvLH6Eat2yFsyy7p
-528534767	-28	-15813	-28.0	-15813.0	cvLH6Eat2yFsyy7p
-528534767	-34	15007	-34.0	15007.0	cvLH6Eat2yFsyy7p
-528534767	-50	-13326	-50.0	-13326.0	cvLH6Eat2yFsyy7p
-528534767	27	-7824	27.0	-7824.0	cvLH6Eat2yFsyy7p
-528534767	29	7021	29.0	7021.0	cvLH6Eat2yFsyy7p
-528534767	31	-9566	31.0	-9566.0	cvLH6Eat2yFsyy7p
-528534767	31	4963	31.0	4963.0	cvLH6Eat2yFsyy7p
-528534767	61	-15549	61.0	-15549.0	cvLH6Eat2yFsyy7p
-528534767	NULL	-4213	NULL	-4213.0	cvLH6Eat2yFsyy7p
-PREHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_parquet
-            Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: cint (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-              outputColumnNames: cint, ctinyint, csmallint, cfloat, cdouble, cstring1
-              Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: max(cint), min(csmallint), count(cstring1), avg(cfloat), stddev_pop(cdouble)
-                keys: ctinyint (type: tinyint)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: tinyint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: tinyint)
-                  Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: int), _col2 (type: smallint), _col3 (type: bigint), _col4 (type: struct<count:bigint,sum:double,input:float>), _col5 (type: struct<count:bigint,sum:double,variance:double>)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vectorized.input.format IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: max(VALUE._col0), min(VALUE._col1), count(VALUE._col2), avg(VALUE._col3), stddev_pop(VALUE._col4)
-          keys: KEY._col0 (type: tinyint)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-          Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-POSTHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
--1	626923679	-15441	36	-1.0486250072717667	8786.246963933321
--10	626923679	-15384	28	-10.0	8850.451610567823
--11	626923679	-15659	32	-11.0	10453.738567408038
--12	626923679	-16373	22	-12.0	10173.15707541171
--13	626923679	-15446	30	-13.0	8907.942987576693
--14	626923679	-13884	22	-14.0	10125.818731386042
--15	626923679	-16036	24	-15.0	9450.506254395024
--16	626923679	-15154	21	-16.0	8884.207393686478
--17	626923679	-15922	19	-17.0	9944.104273894172
--18	626923679	-14863	24	-18.0	9638.430684071413
--19	626923679	-15935	25	-19.0	9967.22240685782
--2	626923679	-16277	20	-2.0	10800.090249507177
--20	626923679	-16126	24	-20.0	9868.92268080106
--21	626923679	-16017	27	-21.0	9480.349236669877
--22	626923679	-14701	22	-22.0	8809.230165774987
--23	626923679	-16355	36	-23.345263230173213	9401.831290253447
--24	626923679	-16311	26	-24.0	9386.736402961187
--25	626923679	-15862	24	-25.0	9778.256724727018
--26	626923679	-15686	15	-26.0	10874.523900405318
--27	626923679	-14984	20	-27.0	8465.29660255097
--28	626923679	-15813	20	-28.0	9616.869413270924
--29	626923679	-14747	26	-29.0	9052.945656011721
--3	626923679	-13632	16	-3.0	8836.215573422822
--30	626923679	-14863	23	-30.0	9193.941914019653
--31	626923679	-15915	22	-31.0	9187.596784112568
--32	626923679	-15866	25	-32.0	9535.546396775915
--33	626923679	-12779	21	-33.0	8854.331159704514
--34	626923679	-15450	29	-34.0	8708.243526705026
--35	626923679	-16059	23	-35.0	10136.580492864763
--36	626923679	-16208	23	-36.0	8773.547684436919
--37	626923679	-14780	17	-37.0	10368.905538788269
--38	626923679	-14914	28	-38.0	8767.375358291503
--39	626923679	-15612	19	-39.0	9765.551806305297
--4	626923679	-16207	21	-4.0	9682.726604102581
--40	626923679	-14678	23	-40.0	9883.334986561835
--41	626923679	-12606	21	-41.0	9034.40949481481
--42	626923679	-16025	14	-42.0	9692.646755759979
--43	626923679	-15607	27	-43.0	8715.255026265124
--44	626923679	-15667	21	-44.0	10334.01810499552
--45	626923679	-15027	21	-45.0	8567.489593562543
--46	626923679	-12427	21	-46.0	9182.943188188632
--47	626923679	-16096	19	-47.0	9011.009178780589
--48	626923679	-15462	26	-48.0	9913.883371354861
--49	626923679	-14831	23	-49.0	9894.429191738676
--5	626923679	-15780	24	-5.0	10599.227726422314
--50	626923679	-14320	27	-50.0	8548.827748002343
--51	1073680599	-15734	1028	-51.0	9531.569305177045
--52	626923679	-16369	30	-52.0	8625.06871423408
--53	626923679	-15445	19	-53.0	9387.739325499799
--54	626923679	-14815	23	-54.0	9614.154026896626
--55	626923679	-13381	26	-55.0	9157.562103946742
--56	626923679	-11999	33	-56.0	9490.842152672341
--57	626923679	-14893	32	-57.0	8572.083461570477
--58	626923679	-15169	20	-58.0	9549.096672008198
--59	626923679	-15789	28	-59.0	9829.790704244733
--6	626923679	-15980	30	-6.0	10262.829252317424
--60	626923679	-15792	24	-60.0	9892.656196775464
--61	626923679	-15142	22	-61.0	9357.236187870849
--62	626923679	-15992	24	-62.0	9004.593091474135
--63	626923679	-12516	16	-63.0	9263.605837223322
--64	626923679	-15920	21	-64.0	9254.456539277186
--7	626923679	-14584	23	-7.0	9946.605446407746
--8	626923679	-14678	18	-8.0	9976.831992670684
--9	626923679	-15329	31	-9.0	8999.391457373968
-0	626923679	-14254	24	0.0	10057.5018088718
-1	626923679	-14610	30	1.0	10016.486277900643
-10	626923679	-15887	26	10.0	9104.820520135108
-11	1072654057	-14696	1035	11.0	9531.018991371746
-12	626923679	-14642	18	12.0	9696.038286378725
-13	626923679	-14771	26	13.0	8128.265919972384
-14	626923679	-13367	28	14.0	9074.674998750581
-15	626923679	-16339	28	15.0	9770.473400901916
-16	626923679	-14001	26	16.0	10130.883606275334
-17	626923679	-16109	22	16.73235294865627	1353416.3383574807
-18	626923679	-15779	21	18.0	10820.004053788869
-19	626923679	-16049	21	19.0	9423.560227007669
-2	626923679	-16227	25	2.0	10083.276127543355
-20	626923679	-15149	21	20.0	11161.893298093504
-21	626923679	-15931	23	21.0	9683.044864861204
-22	626923679	-16280	26	22.0	9693.155720861765
-23	626923679	-15514	24	23.0	8542.419116415425
-24	626923679	-15086	24	24.0	9661.203790645088
-25	626923679	-11349	23	25.0	8888.959012093468
-26	626923679	-14516	29	26.0	9123.125508880432
-27	626923679	-14965	24	27.0	9802.871860196345
-28	626923679	-14455	20	28.0	9283.289383115296
-29	626923679	-15892	16	29.0	9874.046501817154
-3	626923679	-16339	30	3.0	10483.526375885149
-30	626923679	-14111	27	30.0	10066.520234676527
-31	626923679	-15960	24	31.0	10427.970184550613
-32	626923679	-14044	24	32.0	8376.464579403413
-33	626923679	-14642	29	40.61776386607777	1304429.5939037625
-34	626923679	-15059	28	34.0	8756.731536033676
-35	626923679	-16153	27	35.0	10351.008404963042
-36	626923679	-15912	20	36.0	9475.257975138164
-37	626923679	-12081	24	37.0	9017.860034890362
-38	626923679	-15248	29	38.0	9900.256257785535
-39	626923679	-14887	28	39.0	10513.343644635232
-4	626923679	-15999	29	4.0	9516.189702058042
-40	626923679	-15861	22	40.0	9283.318678549174
-41	626923679	-13480	21	41.0	9016.291129937847
-42	626923679	-15834	28	42.0	10318.01399719996
-43	626923679	-15703	28	43.0	8757.796089055722
-44	626923679	-11185	16	44.0	9425.076634933797
-45	626923679	-15228	18	45.0	9459.968668643689
-46	626923679	-15187	22	46.0	9685.908173160062
-47	626923679	-16324	22	47.0	9822.220821743611
-48	626923679	-16372	29	48.0	10079.286173063345
-49	626923679	-15923	27	49.0	9850.111848934683
-5	626923679	-16169	31	5.0	11114.001902469323
-50	626923679	-16236	21	50.0	9398.176197406601
-51	626923679	-15790	17	51.0	9220.075799194028
-52	626923679	-15450	20	52.0	9261.723648435052
-53	626923679	-16217	30	53.0	9895.247408969733
-54	626923679	-15245	16	54.0	9789.50878424882
-55	626923679	-15887	21	55.0	9826.38569192808
-56	626923679	-12631	21	56.0	8860.917133763547
-57	626923679	-15620	25	57.0	9413.99393840875
-58	626923679	-13627	20	58.0	9083.529665947459
-59	626923679	-16076	17	59.0	10117.44967077967
-6	626923679	-15948	30	6.0	9644.247255286113
-60	626923679	-13606	23	60.0	8346.267436552042
-61	626923679	-15894	29	61.0	8785.714950987198
-62	626923679	-14307	17	62.0	9491.752726667326
-7	626923679	-15839	25	7.0	10077.151640330823
-8	1070764888	-15778	1034	8.0	9562.355155774725
-9	626923679	-13629	25	9.0	10157.217948808622
-NULL	1073418988	-16379	3115	NULL	305051.4870777435
-PREHOOK: query: explain vectorization select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_parquet
-            Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (cint = 528534767) (type: boolean)
-              Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: 528534767 (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-                Limit
-                  Number of rows: 10
-                  Statistics: Num rows: 10 Data size: 60 Basic stats: COMPLETE Column stats: NONE
-                  File Output Operator
-                    compressed: false
-                    Statistics: Num rows: 10 Data size: 60 Basic stats: COMPLETE Column stats: NONE
-                    table:
-                        input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                        output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: hive.vectorized.use.row.serde.deserialize IS true AND hive.vectorized.row.serde.inputformat.excludes NOT CONTAINS org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat IS false, hive.vectorized.use.vectorized.input.format IS true AND hive.vectorized.input.format.excludes NOT CONTAINS org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat IS false
-          inputFileFormats: org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-POSTHOOK: query: select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-528534767	-11	-15431	-11.0	-15431.0	cvLH6Eat2yFsyy7p
-528534767	-28	-15813	-28.0	-15813.0	cvLH6Eat2yFsyy7p
-528534767	-34	15007	-34.0	15007.0	cvLH6Eat2yFsyy7p
-528534767	-50	-13326	-50.0	-13326.0	cvLH6Eat2yFsyy7p
-528534767	27	-7824	27.0	-7824.0	cvLH6Eat2yFsyy7p
-528534767	29	7021	29.0	7021.0	cvLH6Eat2yFsyy7p
-528534767	31	-9566	31.0	-9566.0	cvLH6Eat2yFsyy7p
-528534767	31	4963	31.0	4963.0	cvLH6Eat2yFsyy7p
-528534767	61	-15549	61.0	-15549.0	cvLH6Eat2yFsyy7p
-528534767	NULL	-4213	NULL	-4213.0	cvLH6Eat2yFsyy7p
-PREHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_parquet
-            Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: cint (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-              outputColumnNames: cint, ctinyint, csmallint, cfloat, cdouble, cstring1
-              Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: max(cint), min(csmallint), count(cstring1), avg(cfloat), stddev_pop(cdouble)
-                keys: ctinyint (type: tinyint)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: tinyint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: tinyint)
-                  Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: int), _col2 (type: smallint), _col3 (type: bigint), _col4 (type: struct<count:bigint,sum:double,input:float>), _col5 (type: struct<count:bigint,sum:double,variance:double>)
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: hive.vectorized.use.row.serde.deserialize IS true AND hive.vectorized.row.serde.inputformat.excludes NOT CONTAINS org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat IS false, hive.vectorized.use.vectorized.input.format IS true AND hive.vectorized.input.format.excludes NOT CONTAINS org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat IS false
-          inputFileFormats: org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: max(VALUE._col0), min(VALUE._col1), count(VALUE._col2), avg(VALUE._col3), stddev_pop(VALUE._col4)
-          keys: KEY._col0 (type: tinyint)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-          Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-POSTHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
--1	626923679	-15441	36	-1.0486250072717667	8786.246963933321
--10	626923679	-15384	28	-10.0	8850.451610567823
--11	626923679	-15659	32	-11.0	10453.738567408038
--12	626923679	-16373	22	-12.0	10173.15707541171
--13	626923679	-15446	30	-13.0	8907.942987576693
--14	626923679	-13884	22	-14.0	10125.818731386042
--15	626923679	-16036	24	-15.0	9450.506254395024
--16	626923679	-15154	21	-16.0	8884.207393686478
--17	626923679	-15922	19	-17.0	9944.104273894172
--18	626923679	-14863	24	-18.0	9638.430684071413
--19	626923679	-15935	25	-19.0	9967.22240685782
--2	626923679	-16277	20	-2.0	10800.090249507177
--20	626923679	-16126	24	-20.0	9868.92268080106
--21	626923679	-16017	27	-21.0	9480.349236669877
--22	626923679	-14701	22	-22.0	8809.230165774987
--23	626923679	-16355	36	-23.345263230173213	9401.831290253447
--24	626923679	-16311	26	-24.0	9386.736402961187
--25	626923679	-15862	24	-25.0	9778.256724727018
--26	626923679	-15686	15	-26.0	10874.523900405318
--27	626923679	-14984	20	-27.0	8465.29660255097
--28	626923679	-15813	20	-28.0	9616.869413270924
--29	626923679	-14747	26	-29.0	9052.945656011721
--3	626923679	-13632	16	-3.0	8836.215573422822
--30	626923679	-14863	23	-30.0	9193.941914019653
--31	626923679	-15915	22	-31.0	9187.596784112568
--32	626923679	-15866	25	-32.0	9535.546396775915
--33	626923679	-12779	21	-33.0	8854.331159704514
--34	626923679	-15450	29	-34.0	8708.243526705026
--35	626923679	-16059	23	-35.0	10136.580492864763
--36	626923679	-16208	23	-36.0	8773.547684436919
--37	626923679	-14780	17	-37.0	10368.905538788269
--38	626923679	-14914	28	-38.0	8767.375358291503
--39	626923679	-15612	19	-39.0	9765.551806305297
--4	626923679	-16207	21	-4.0	9682.726604102581
--40	626923679	-14678	23	-40.0	9883.334986561835
--41	626923679	-12606	21	-41.0	9034.40949481481
--42	626923679	-16025	14	-42.0	9692.646755759979
--43	626923679	-15607	27	-43.0	8715.255026265124
--44	626923679	-15667	21	-44.0	10334.01810499552
--45	626923679	-15027	21	-45.0	8567.489593562543
--46	626923679	-12427	21	-46.0	9182.943188188632
--47	626923679	-16096	19	-47.0	9011.009178780589
--48	626923679	-15462	26	-48.0	9913.883371354861
--49	626923679	-14831	23	-49.0	9894.429191738676
--5	626923679	-15780	24	-5.0	10599.227726422314
--50	626923679	-14320	27	-50.0	8548.827748002343
--51	1073680599	-15734	1028	-51.0	9531.569305177045
--52	626923679	-16369	30	-52.0	8625.06871423408
--53	626923679	-15445	19	-53.0	9387.739325499799
--54	626923679	-14815	23	-54.0	9614.154026896626
--55	626923679	-13381	26	-55.0	9157.562103946742
--56	626923679	-11999	33	-56.0	9490.842152672341
--57	626923679	-14893	32	-57.0	8572.083461570477
--58	626923679	-15169	20	-58.0	9549.096672008198
--59	626923679	-15789	28	-59.0	9829.790704244733
--6	626923679	-15980	30	-6.0	10262.829252317424
--60	626923679	-15792	24	-60.0	9892.656196775464
--61	626923679	-15142	22	-61.0	9357.236187870849
--62	626923679	-15992	24	-62.0	9004.593091474135
--63	626923679	-12516	16	-63.0	9263.605837223322
--64	626923679	-15920	21	-64.0	9254.456539277186
--7	626923679	-14584	23	-7.0	9946.605446407746
--8	626923679	-14678	18	-8.0	9976.831992670684
--9	626923679	-15329	31	-9.0	8999.391457373968
-0	626923679	-14254	24	0.0	10057.5018088718
-1	626923679	-14610	30	1.0	10016.486277900643
-10	626923679	-15887	26	10.0	9104.820520135108
-11	1072654057	-14696	1035	11.0	9531.018991371746
-12	626923679	-14642	18	12.0	9696.038286378725
-13	626923679	-14771	26	13.0	8128.265919972384
-14	626923679	-13367	28	14.0	9074.674998750581
-15	626923679	-16339	28	15.0	9770.473400901916
-16	626923679	-14001	26	16.0	10130.883606275334
-17	626923679	-16109	22	16.73235294865627	1353416.3383574807
-18	626923679	-15779	21	18.0	10820.004053788869
-19	626923679	-16049	21	19.0	9423.560227007669
-2	626923679	-16227	25	2.0	10083.276127543355
-20	626923679	-15149	21	20.0	11161.893298093504
-21	626923679	-15931	23	21.0	9683.044864861204
-22	626923679	-16280	26	22.0	9693.155720861765
-23	626923679	-15514	24	23.0	8542.419116415425
-24	626923679	-15086	24	24.0	9661.203790645088
-25	626923679	-11349	23	25.0	8888.959012093468
-26	626923679	-14516	29	26.0	9123.125508880432
-27	626923679	-14965	24	27.0	9802.871860196345
-28	626923679	-14455	20	28.0	9283.289383115296
-29	626923679	-15892	16	29.0	9874.046501817154
-3	626923679	-16339	30	3.0	10483.526375885149
-30	626923679	-14111	27	30.0	10066.520234676527
-31	626923679	-15960	24	31.0	10427.970184550613
-32	626923679	-14044	24	32.0	8376.464579403413
-33	626923679	-14642	29	40.61776386607777	1304429.5939037625
-34	626923679	-15059	28	34.0	8756.731536033676
-35	626923679	-16153	27	35.0	10351.008404963042
-36	626923679	-15912	20	36.0	9475.257975138164
-37	626923679	-12081	24	37.0	9017.860034890362
-38	626923679	-15248	29	38.0	9900.256257785535
-39	626923679	-14887	28	39.0	10513.343644635232
-4	626923679	-15999	29	4.0	9516.189702058042
-40	626923679	-15861	22	40.0	9283.318678549174
-41	626923679	-13480	21	41.0	9016.291129937847
-42	626923679	-15834	28	42.0	10318.01399719996
-43	626923679	-15703	28	43.0	8757.796089055722
-44	626923679	-11185	16	44.0	9425.076634933797
-45	626923679	-15228	18	45.0	9459.968668643689
-46	626923679	-15187	22	46.0	9685.908173160062
-47	626923679	-16324	22	47.0	9822.220821743611
-48	626923679	-16372	29	48.0	10079.286173063345
-49	626923679	-15923	27	49.0	9850.111848934683
-5	626923679	-16169	31	5.0	11114.001902469323
-50	626923679	-16236	21	50.0	9398.176197406601
-51	626923679	-15790	17	51.0	9220.075799194028
-52	626923679	-15450	20	52.0	9261.723648435052
-53	626923679	-16217	30	53.0	9895.247408969733
-54	626923679	-15245	16	54.0	9789.50878424882
-55	626923679	-15887	21	55.0	9826.38569192808
-56	626923679	-12631	21	56.0	8860.917133763547
-57	626923679	-15620	25	57.0	9413.99393840875
-58	626923679	-13627	20	58.0	9083.529665947459
-59	626923679	-16076	17	59.0	10117.44967077967
-6	626923679	-15948	30	6.0	9644.247255286113
-60	626923679	-13606	23	60.0	8346.267436552042
-61	626923679	-15894	29	61.0	8785.714950987198
-62	626923679	-14307	17	62.0	9491.752726667326
-7	626923679	-15839	25	7.0	10077.151640330823
-8	1070764888	-15778	1034	8.0	9562.355155774725
-9	626923679	-13629	25	9.0	10157.217948808622
-NULL	1073418988	-16379	3115	NULL	305051.4870777435
-PREHOOK: query: explain vectorization select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_parquet
-            Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (cint = 528534767) (type: boolean)
-              Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: 528534767 (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-                Limit
-                  Number of rows: 10
-                  Statistics: Num rows: 10 Data size: 60 Basic stats: COMPLETE Column stats: NONE
-                  File Output Operator
-                    compressed: false
-                    Statistics: Num rows: 10 Data size: 60 Basic stats: COMPLETE Column stats: NONE
-                    table:
-                        input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                        output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vectorized.input.format IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-POSTHOOK: query: select *
-  from alltypes_parquet
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-528534767	-11	-15431	-11.0	-15431.0	cvLH6Eat2yFsyy7p
-528534767	-28	-15813	-28.0	-15813.0	cvLH6Eat2yFsyy7p
-528534767	-34	15007	-34.0	15007.0	cvLH6Eat2yFsyy7p
-528534767	-50	-13326	-50.0	-13326.0	cvLH6Eat2yFsyy7p
-528534767	27	-7824	27.0	-7824.0	cvLH6Eat2yFsyy7p
-528534767	29	7021	29.0	7021.0	cvLH6Eat2yFsyy7p
-528534767	31	-9566	31.0	-9566.0	cvLH6Eat2yFsyy7p
-528534767	31	4963	31.0	4963.0	cvLH6Eat2yFsyy7p
-528534767	61	-15549	61.0	-15549.0	cvLH6Eat2yFsyy7p
-528534767	NULL	-4213	NULL	-4213.0	cvLH6Eat2yFsyy7p
-PREHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_parquet
-            Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: cint (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-              outputColumnNames: cint, ctinyint, csmallint, cfloat, cdouble, cstring1
-              Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: max(cint), min(csmallint), count(cstring1), avg(cfloat), stddev_pop(cdouble)
-                keys: ctinyint (type: tinyint)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: tinyint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: tinyint)
-                  Statistics: Num rows: 12288 Data size: 73728 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: int), _col2 (type: smallint), _col3 (type: bigint), _col4 (type: struct<count:bigint,sum:double,input:float>), _col5 (type: struct<count:bigint,sum:double,variance:double>)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vectorized.input.format IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.hive.ql.io.parquet.MapredParquetInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: max(VALUE._col0), min(VALUE._col1), count(VALUE._col2), avg(VALUE._col3), stddev_pop(VALUE._col4)
-          keys: KEY._col0 (type: tinyint)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-          Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            Statistics: Num rows: 6144 Data size: 36864 Basic stats: COMPLETE Column stats: NONE
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
-POSTHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_parquet
-  group by ctinyint
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_parquet
-#### A masked pattern was here ####
--1	626923679	-15441	36	-1.0486250072717667	8786.246963933321
--10	626923679	-15384	28	-10.0	8850.451610567823
--11	626923679	-15659	32	-11.0	10453.738567408038
--12	626923679	-16373	22	-12.0	10173.15707541171
--13	626923679	-15446	30	-13.0	8907.942987576693
--14	626923679	-13884	22	-14.0	10125.818731386042
--15	626923679	-16036	24	-15.0	9450.506254395024
--16	626923679	-15154	21	-16.0	8884.207393686478
--17	626923679	-15922	19	-17.0	9944.104273894172
--18	626923679	-14863	24	-18.0	9638.430684071413
--19	626923679	-15935	25	-19.0	9967.22240685782
--2	626923679	-16277	20	-2.0	10800.090249507177
--20	626923679	-16126	24	-20.0	9868.92268080106
--21	626923679	-16017	27	-21.0	9480.349236669877
--22	626923679	-14701	22	-22.0	8809.230165774987
--23	626923679	-16355	36	-23.345263230173213	9401.831290253447
--24	626923679	-16311	26	-24.0	9386.736402961187
--25	626923679	-15862	24	-25.0	9778.256724727018
--26	626923679	-15686	15	-26.0	10874.523900405318
--27	626923679	-14984	20	-27.0	8465.29660255097
--28	626923679	-15813	20	-28.0	9616.869413270924
--29	626923679	-14747	26	-29.0	9052.945656011721
--3	626923679	-13632	16	-3.0	8836.215573422822
--30	626923679	-14863	23	-30.0	9193.941914019653
--31	626923679	-15915	22	-31.0	9187.596784112568
--32	626923679	-15866	25	-32.0	9535.546396775915
--33	626923679	-12779	21	-33.0	8854.331159704514
--34	626923679	-15450	29	-34.0	8708.243526705026
--35	626923679	-16059	23	-35.0	10136.580492864763
--36	626923679	-16208	23	-36.0	8773.547684436919
--37	626923679	-14780	17	-37.0	10368.905538788269
--38	626923679	-14914	28	-38.0	8767.375358291503
--39	626923679	-15612	19	-39.0	9765.551806305297
--4	626923679	-16207	21	-4.0	9682.726604102581
--40	626923679	-14678	23	-40.0	9883.334986561835
--41	626923679	-12606	21	-41.0	9034.40949481481
--42	626923679	-16025	14	-42.0	9692.646755759979
--43	626923679	-15607	27	-43.0	8715.255026265124
--44	626923679	-15667	21	-44.0	10334.01810499552
--45	626923679	-15027	21	-45.0	8567.489593562543
--46	626923679	-12427	21	-46.0	9182.943188188632
--47	626923679	-16096	19	-47.0	9011.009178780589
--48	626923679	-15462	26	-48.0	9913.883371354861
--49	626923679	-14831	23	-49.0	9894.429191738676
--5	626923679	-15780	24	-5.0	10599.227726422314
--50	626923679	-14320	27	-50.0	8548.827748002343
--51	1073680599	-15734	1028	-51.0	9531.569305177045
--52	626923679	-16369	30	-52.0	8625.06871423408
--53	626923679	-15445	19	-53.0	9387.739325499799
--54	626923679	-14815	23	-54.0	9614.154026896626
--55	626923679	-13381	26	-55.0	9157.562103946742
--56	626923679	-11999	33	-56.0	9490.842152672341
--57	626923679	-14893	32	-57.0	8572.083461570477
--58	626923679	-15169	20	-58.0	9549.096672008198
--59	626923679	-15789	28	-59.0	9829.790704244733
--6	626923679	-15980	30	-6.0	10262.829252317424
--60	626923679	-15792	24	-60.0	9892.656196775464
--61	626923679	-15142	22	-61.0	9357.236187870849
--62	626923679	-15992	24	-62.0	9004.593091474135
--63	626923679	-12516	16	-63.0	9263.605837223322
--64	626923679	-15920	21	-64.0	9254.456539277186
--7	626923679	-14584	23	-7.0	9946.605446407746
--8	626923679	-14678	18	-8.0	9976.831992670684
--9	626923679	-15329	31	-9.0	8999.391457373968
-0	626923679	-14254	24	0.0	10057.5018088718
-1	626923679	-14610	30	1.0	10016.486277900643
-10	626923679	-15887	26	10.0	9104.820520135108
-11	1072654057	-14696	1035	11.0	9531.018991371746
-12	626923679	-14642	18	12.0	9696.038286378725
-13	626923679	-14771	26	13.0	8128.265919972384
-14	626923679	-13367	28	14.0	9074.674998750581
-15	626923679	-16339	28	15.0	9770.473400901916
-16	626923679	-14001	26	16.0	10130.883606275334
-17	626923679	-16109	22	16.73235294865627	1353416.3383574807
-18	626923679	-15779	21	18.0	10820.004053788869
-19	626923679	-16049	21	19.0	9423.560227007669
-2	626923679	-16227	25	2.0	10083.276127543355
-20	626923679	-15149	21	20.0	11161.893298093504
-21	626923679	-15931	23	21.0	9683.044864861204
-22	626923679	-16280	26	22.0	9693.155720861765
-23	626923679	-15514	24	23.0	8542.419116415425
-24	626923679	-15086	24	24.0	9661.203790645088
-25	626923679	-11349	23	25.0	8888.959012093468
-26	626923679	-14516	29	26.0	9123.125508880432
-27	626923679	-14965	24	27.0	9802.871860196345
-28	626923679	-14455	20	28.0	9283.289383115296
-29	626923679	-15892	16	29.0	9874.046501817154
-3	626923679	-16339	30	3.0	10483.526375885149
-30	626923679	-14111	27	30.0	10066.520234676527
-31	626923679	-15960	24	31.0	10427.970184550613
-32	626923679	-14044	24	32.0	8376.464579403413
-33	626923679	-14642	29	40.61776386607777	1304429.5939037625
-34	626923679	-15059	28	34.0	8756.731536033676
-35	626923679	-16153	27	35.0	10351.008404963042
-36	626923679	-15912	20	36.0	9475.257975138164
-37	626923679	-12081	24	37.0	9017.860034890362
-38	626923679	-15248	29	38.0	9900.256257785535
-39	626923679	-14887	28	39.0	10513.343644635232
-4	626923679	-15999	29	4.0	9516.189702058042
-40	626923679	-15861	22	40.0	9283.318678549174
-41	626923679	-13480	21	41.0	9016.291129937847
-42	626923679	-15834	28	42.0	10318.01399719996
-43	626923679	-15703	28	43.0	8757.796089055722
-44	626923679	-11185	16	44.0	9425.076634933797
-45	626923679	-15228	18	45.0	9459.968668643689
-46	626923679	-15187	22	46.0	9685.908173160062
-47	626923679	-16324	22	47.0	9822.220821743611
-48	626923679	-16372	29	48.0	10079.286173063345
-49	626923679	-15923	27	49.0	9850.111848934683
-5	626923679	-16169	31	5.0	11114.001902469323
-50	626923679	-16236	21	50.0	9398.176197406601
-51	626923679	-15790	17	51.0	9220.075799194028
-52	626923679	-15450	20	52.0	9261.723648435052
-53	626923679	-16217	30	53.0	9895.247408969733
-54	626923679	-15245	16	54.0	9789.50878424882
-55	626923679	-15887	21	55.0	9826.38569192808
-56	626923679	-12631	21	56.0	8860.917133763547
-57	626923679	-15620	25	57.0	9413.99393840875
-58	626923679	-13627	20	58.0	9083.529665947459
-59	626923679	-16076	17	59.0	10117.44967077967
-6	626923679	-15948	30	6.0	9644.247255286113
-60	626923679	-13606	23	60.0	8346.267436552042
-61	626923679	-15894	29	61.0	8785.714950987198
-62	626923679	-14307	17	62.0	9491.752726667326
-7	626923679	-15839	25	7.0	10077.151640330823
-8	1070764888	-15778	1034	8.0	9562.355155774725
-9	626923679	-13629	25	9.0	10157.217948808622
-NULL	1073418988	-16379	3115	NULL	305051.4870777435
-PREHOOK: query: create table if not exists alltypes_orc (
-  cint int,
-  ctinyint tinyint,
-  csmallint smallint,
-  cfloat float,
-  cdouble double,
-  cstring1 string) stored as orc
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@alltypes_orc
-POSTHOOK: query: create table if not exists alltypes_orc (
-  cint int,
-  ctinyint tinyint,
-  csmallint smallint,
-  cfloat float,
-  cdouble double,
-  cstring1 string) stored as orc
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@alltypes_orc
-PREHOOK: query: insert overwrite table alltypes_orc
-  select cint,
-    ctinyint,
-    csmallint,
-    cfloat,
-    cdouble,
-    cstring1
-  from alltypesorc
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypesorc
-PREHOOK: Output: default@alltypes_orc
-POSTHOOK: query: insert overwrite table alltypes_orc
-  select cint,
-    ctinyint,
-    csmallint,
-    cfloat,
-    cdouble,
-    cstring1
-  from alltypesorc
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypesorc
-POSTHOOK: Output: default@alltypes_orc
-POSTHOOK: Lineage: alltypes_orc.cdouble SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cdouble, type:double, comment:null), ]
-POSTHOOK: Lineage: alltypes_orc.cfloat SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cfloat, type:float, comment:null), ]
-POSTHOOK: Lineage: alltypes_orc.cint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cint, type:int, comment:null), ]
-POSTHOOK: Lineage: alltypes_orc.csmallint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:csmallint, type:smallint, comment:null), ]
-POSTHOOK: Lineage: alltypes_orc.cstring1 SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cstring1, type:string, comment:null), ]
-POSTHOOK: Lineage: alltypes_orc.ctinyint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:ctinyint, type:tinyint, comment:null), ]
-PREHOOK: query: explain vectorization select *
-  from alltypes_orc
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select *
-  from alltypes_orc
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_orc
-            Statistics: Num rows: 12288 Data size: 1110042 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (cint = 528534767) (type: boolean)
-              Statistics: Num rows: 6144 Data size: 555021 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: 528534767 (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 6144 Data size: 555021 Basic stats: COMPLETE Column stats: NONE
-                Limit
-                  Number of rows: 10
-                  Statistics: Num rows: 10 Data size: 900 Basic stats: COMPLETE Column stats: NONE
-                  File Output Operator
-                    compressed: false
-                    Statistics: Num rows: 10 Data size: 900 Basic stats: COMPLETE Column stats: NONE
-                    table:
-                        input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                        output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: hive.vectorized.use.vectorized.input.format IS true AND hive.vectorized.input.format.excludes NOT CONTAINS org.apache.hadoop.hive.ql.io.orc.OrcInputFormat IS false
-          inputFileFormats: org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select *
-  from alltypes_orc
-  where cint = 528534767
-  limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_orc
-#### A masked pattern was here ####
-POSTHOOK: query: select *
-  from alltypes_orc
-  where cint = 528534767
-  limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_orc
-#### A masked pattern was here ####
-528534767	-11	-15431	-11.0	-15431.0	cvLH6Eat2yFsyy7p
-528534767	-28	-15813	-28.0	-15813.0	cvLH6Eat2yFsyy7p
-528534767	-34	15007	-34.0	15007.0	cvLH6Eat2yFsyy7p
-528534767	-50	-13326	-50.0	-13326.0	cvLH6Eat2yFsyy7p
-528534767	27	-7824	27.0	-7824.0	cvLH6Eat2yFsyy7p
-528534767	29	7021	29.0	7021.0	cvLH6Eat2yFsyy7p
-528534767	31	-9566	31.0	-9566.0	cvLH6Eat2yFsyy7p
-528534767	31	4963	31.0	4963.0	cvLH6Eat2yFsyy7p
-528534767	61	-15549	61.0	-15549.0	cvLH6Eat2yFsyy7p
-528534767	NULL	-4213	NULL	-4213.0	cvLH6Eat2yFsyy7p
-PREHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_orc
-  group by ctinyint
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_orc
-  group by ctinyint
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: alltypes_orc
-            Statistics: Num rows: 12288 Data size: 1110042 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: cint (type: int), ctinyint (type: tinyint), csmallint (type: smallint), cfloat (type: float), cdouble (type: double), cstring1 (type: string)
-              outputColumnNames: cint, ctinyint, csmallint, cfloat, cdouble, cstring1
-              Statistics: Num rows: 12288 Data size: 1110042 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: max(cint), min(csmallint), count(cstring1), avg(cfloat), stddev_pop(cdouble)
-                keys: ctinyint (type: tinyint)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 12288 Data size: 1110042 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: tinyint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: tinyint)
-                  Statistics: Num rows: 12288 Data size: 1110042 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: int), _col2 (type: smallint), _col3 (type: bigint), _col4 (type: struct<count:bigint,sum:double,input:float>), _col5 (type: struct<count:bigint,sum:double,variance:double>)
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: hive.vectorized.use.vectorized.input.format IS true AND hive.vectorized.input.format.excludes NOT CONTAINS org.apache.hadoop.hive.ql.io.orc.OrcInputFormat IS false
-          inputFileFormats: org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: max(VALUE._col0), min(VALUE._col1), count(VALUE._col2), avg(VALUE._col3), stddev_pop(VALUE._col4)
-          keys: KEY._col0 (type: tinyint)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-          Statistics: Num rows: 6144 Data size: 555021 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            Statistics: Num rows: 6144 Data size: 555021 Basic stats: COMPLETE Column stats: NONE
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_orc
-  group by ctinyint
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypes_orc
-#### A masked pattern was here ####
-POSTHOOK: query: select ctinyint,
-  max(cint),
-  min(csmallint),
-  count(cstring1),
-  avg(cfloat),
-  stddev_pop(cdouble)
-  from alltypes_orc
-  group by ctinyint
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypes_orc
-#### A masked pattern was here ####
--1	626923679	-15441	36	-1.0486250072717667	8786.246963933321
--10	626923679	-15384	28	-10.0	8850.451610567823
--11	626923679	-15659	32	-11.0	10453.738567408038
--12	626923679	-16373	22	-12.0	10173.15707541171
--13	626923679	-15446	30	-13.0	8907.942987576693
--14	626923679	-13884	22	-14.0	10125.818731386042
--15	626923679	-16036	24	-15.0	9450.506254395024
--16	626923679	-15154	21	-16.0	8884.207393686478
--17	626923679	-15922	19	-17.0	9944.104273894172
--18	626923679	-14863	24	-18.0	9638.430684071413
--19	626923679	-15935	25	-19.0	9967.22240685782
--2	626923679	-16277	20	-2.0	10800.090249507177
--20	626923679	-16126	24	-20.0	9868.92268080106
--21	626923679	-16017	27	-21.0	9480.349236669877
--22	626923679	-14701	22	-22.0	8809.230165774987
--23	626923679	-16355	36	-23.345263230173213	9401.831290253447
--24	626923679	-16311	26	-24.0	9386.736402961187
--25	626923679	-15862	24	-25.0	9778.256724727018
--26	626923679	-15686	15	-26.0	10874.523900405318
--27	626923679	-14984	20	-27.0	8465.29660255097
--28	626923679	-15813	20	-28.0	9616.869413270924
--29	626923679	-14747	26	-29.0	9052.945656011721
--3	626923679	-13632	16	-3.0	8836.215573422822
--30	626923679	-14863	23	-30.0	9193.941914019653
--31	626923679	-15915	22	-31.0	9187.596784112568
--32	626923679	-15866	25	-32.0	9535.546396775915
--33	626923679	-12779	21	-33.0	8854.331159704514
--34	626923679	-15450	29	-34.0	8708.243526705026
--35	626923679	-16059	23	-35.0	10136.580492864763
--36	626923679	-16208	23	-36.0	8773.547684436919
--37	626923679	-14780	17	-37.0	10368.905538788269
--38	626923679	-14914	28	-38.0	8767.375358291503
--39	626923679	-15612	19	-39.0	9765.551806305297
--4	626923679	-16207	21	-4.0	9682.726604102581
--40	626923679	-14678	23	-40.0	9883.334986561835
--41	626923679	-12606	21	-41.0	9034.40949481481
--42	626923679	-16025	14	-42.0	9692.646755759979
--43	626923679	-15607	27	-43.0	8715.255026265124
--44	626923679	-15667	21	-44.0	10334.01810499552
--45	626923679	-15027	21	-45.0	8567.489593562543
--46	626923679	-12427	21	-46.0	9182.943188188632
--47	626923679	-16096	19	-47.0	9011.009178780589
--48	626923679	-15462	26	-48.0	9913.883371354861
--49	626923679	-14831	23	-49.0	9894.429191738676
--5	626923679	-15780	24	-5.0	10599.227726422314
--50	626923679	-14320	27	-50.0	8548.827748002343
--51	1073680599	-15734	1028	-51.0	9531.569305177045
--52	626923679	-16369	30	-52.0	8625.06871423408
--53	626923679	-15445	19	-53.0	9387.739325499799
--54	626923679	-14815	23	-54.0	9614.154026896626
--55	626923679	-13381	26	-55.0	9157.562103946742
--56	626923679	-11999	33	-56.0	9490.842152672341
--57	626923679	-14893	32	-57.0	8572.083461570477
--58	626923679	-15169	20	-58.0	9549.096672008198
--59	626923679	-15789	28	-59.0	9829.790704244733
--6	626923679	-15980	30	-6.0	10262.829252317424
--60	626923679	-15792	24	-60.0	9892.656196775464
--61	626923679	-15142	22	-61.0	9357.236187870849
--62	626923679	-15992	24	-62.0	9004.593091474135
--63	626923679	-12516	16	-63.0	9263.605837223322
--64	626923679	-15920	21	-64.0	9254.456539277186
--7	626923679	-14584	23	-7.0	9946.605446407746
--8	626923679	-14678	18	-8.0	9976.831992670684
--9	626923679	-15329	31	-9.0	8999.391457373968
-0	626923679	-14254	24	0.0	10057.5018088718
-1	626923679	-14610	30	1.0	10016.486277900643
-10	626923679	-15887	26	10.0	9104.820520135108
-11	1072654057	-14696	1035	11.0	9531.018991371746
-12	626923679	-14642	18	12.0	9696.038286378725
-13	626923679	-14771	26	13.0	8128.265919972384
-14	626923679	-13367	28	14.0	9074.674998750581
-15	626923679	-16339	28	15.0	9770.473400901916
-16	626923679	-14001	26	16.0	10130.883606275334
-17	626923679	-16109	22	16.73235294865627	1353416.3383574807
-18	626923679	-15779	21	18.0	10820.004053788869
-19	626923679	-16049	21	19.0	9423.560227007669
-2	626923679	-16227	25	2.0	10083.276127543355
-20	626923679	-15149	21	20.0	11161.893298093504
-21	626923679	-15931	23	21.0	9683.044864861204
-22	626923679	-16280	26	22.0	9693.155720861765
-23	626923679	-15514	24	23.0	8542.419116415425
-24	626923679	-15086	24	24.0	9661.203790645088
-25	626923679	-11349	23	25.0	8888.959012093468
-26	626923679	-14516	29	26.0	9123.125508880432
-27	626923679	-14965	24	27.0	9802.871860196345
-28	626923679	-14455	20	28.0	9283.289383115296
-29	626923679	-15892	16	29.0	9874.046501817154
-3	626923679	-16339	30	3.0	10483.526375885149
-30	626923679	-14111	27	30.0	10066.520234676527
-31	626923679	-15960	24	31.0	10427.970184550613
-32	626923679	-14044	24	32.0	8376.464579403413
-33	626923679	-14642	29	40.61776386607777	1304429.5939037625
-34	626923679	-15059	28	34.0	8756.731536033676
-35	626923679	-16153	27	35.0	10351.008404963042
-36	626923679	-15912	20	36.0	9475.257975138164
-37	626923679	-12081	24	37.0	9017.860034890362
-38	626923679	-15248	29	38.0	9900.256257785535
-39	626923679	-14887	28	39.0	10513.343644635232
-4	626923679	-15999	29	4.0	9516.189702058042
-40	626923679	-15861	22	40.0	9283.318678549174
-41	626923679	-13480	21	41.0	9016.291129937847
-42	626923679	-15834	28	42.0	10318.01399719996
-43	626923679	-15703	28	43.0	8757.796089055722
-44	626923679	-11185	16	44.0	9425.076634933797
-45	626923679	-15228	18	45.0	9459.968668643689
-46	626923679	-15187	22	46.0	9685.908173160062
-47	626923679	-16324	22	47.0	9822.220821743611
-48	626923679	-16372	29	48.0	10079.286173063345
-49	626923679	-15923	27	49.0	9850.111848934683
-5	626923679	-16169	31	5.0	11114.001902469323
-50	626923679	-16236	21	50.0	9398.176197406601
-51	626923679	-15790	17	51.0	9220.075799194028
-52	626923679	-15450	20	52.0	9261.723648435052
-53	626923679	-16217	30	53.0	9895.247408969733
-54	626923679	-15245	16	54.0	9789.50878424882
-55	626923679	-15887	21	55.0	9826.38569192808
-56	626923679	-12631	21	56.0	8860.917133763547
-57	626923679	-15620	25	57.0	9413.99393840875
-58	626923679	-13627	20	58.0	9083.529665947459
-59	626923679	-16076	17	59.0	10117.44967077967
-6	626923679	-15948	30	6.0	9644.247255286113
-60	626923679	-13606	23	60.0	8346.267436552042
-61	626923679	-15894	29	61.0	8785.714950987198
-62	626923679	-14307	17	62.0	9491.752726667326
-7	626923679	-15839	25	7.0	10077.151640330823
-8	1070764888	-15778	1034	8.0	9562.355155774725
-9	626923679	-13629	25	9.0	10157.217948808622
-NULL	1073418988	-16379	3115	NULL	305051.4870777435


[03/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_streaming.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_streaming.q.out b/ql/src/test/results/clientpositive/vector_windowing_streaming.q.out
deleted file mode 100644
index 9c07d4e..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_streaming.q.out
+++ /dev/null
@@ -1,849 +0,0 @@
-PREHOOK: query: drop table over10k
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table over10k
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@over10k
-POSTHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: explain vectorization detail
-select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), rank_window_0 (type: int)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: explain vectorization detail
-select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a 
-where r < 4
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a 
-where r < 4
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false, No PTF TopN IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              TopN Hash Memory Usage: 0.8
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (rank_window_0 < 4) (type: boolean)
-              Statistics: Num rows: 8 Data size: 968 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col2 (type: string), rank_window_0 (type: int)
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 8 Data size: 968 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 8 Data size: 968 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a 
-where r < 4
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a 
-where r < 4
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-a.p_mfgr	a.r
-Manufacturer#1	1
-Manufacturer#1	1
-Manufacturer#1	3
-Manufacturer#2	1
-Manufacturer#2	2
-Manufacturer#2	3
-Manufacturer#3	1
-Manufacturer#3	2
-Manufacturer#3	3
-Manufacturer#4	1
-Manufacturer#4	2
-Manufacturer#4	3
-Manufacturer#5	1
-Manufacturer#5	2
-Manufacturer#5	3
-PREHOOK: query: select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a 
-where r < 2
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select * 
-from ( select p_mfgr, rank() over(partition by p_mfgr order by p_name) r from part) a 
-where r < 2
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-a.p_mfgr	a.r
-Manufacturer#1	1
-Manufacturer#1	1
-Manufacturer#2	1
-Manufacturer#3	1
-Manufacturer#4	1
-Manufacturer#5	1
-PREHOOK: query: explain vectorization detail
-select * 
-from (select t, f, rank() over(partition by t order by f) r from over10k) a 
-where r < 6 and t < 5
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select * 
-from (select t, f, rank() over(partition by t order by f) r from over10k) a 
-where r < 6 and t < 5
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Filter Operator
-              Filter Vectorization:
-                  className: VectorFilterOperator
-                  native: true
-                  predicateExpression: FilterLongColLessLongScalar(col 0:tinyint, val 5)
-              predicate: (t < 5) (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Reduce Output Operator
-                key expressions: t (type: tinyint), f (type: float)
-                sort order: ++
-                Map-reduce partition columns: t (type: tinyint)
-                Reduce Sink Vectorization:
-                    className: VectorReduceSinkOperator
-                    native: false
-                    nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                    nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false, No PTF TopN IS false
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                TopN Hash Memory Usage: 0.8
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [0, 4]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: tinyint), KEY.reducesinkkey1 (type: float)
-          outputColumnNames: _col0, _col4
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col4: float
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col4
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (rank_window_0 < 6) (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col0 (type: tinyint), _col4 (type: float), rank_window_0 (type: int)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select * 
-from (select t, f, rank() over(partition by t order by f) r from over10k) a 
-where r < 6 and t < 5
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select * 
-from (select t, f, rank() over(partition by t order by f) r from over10k) a 
-where r < 6 and t < 5
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-a.t	a.f	a.r
--3	0.56	1
--3	0.83	2
--3	2.26	3
--3	2.48	4
--3	3.82	5
--2	1.55	1
--2	1.65	2
--2	1.79	3
--2	4.06	4
--2	4.4	5
--1	0.79	1
--1	0.95	2
--1	1.27	3
--1	1.49	4
--1	2.8	5
-0	0.08	1
-0	0.94	2
-0	1.44	3
-0	2.0	4
-0	2.12	5
-1	0.13	1
-1	0.44	2
-1	1.04	3
-1	3.41	4
-1	3.45	5
-2	2.21	1
-2	3.1	2
-2	9.93	3
-2	11.43	4
-2	15.45	5
-3	0.12	1
-3	0.19	2
-3	7.14	3
-3	7.97	4
-3	8.95	5
-4	2.26	1
-4	5.51	2
-4	5.53	3
-4	5.76	4
-4	7.26	5
-PREHOOK: query: select *
-from (select t, f, row_number() over(partition by t order by f) r from over10k) a
-where r < 8 and t < 0
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select *
-from (select t, f, row_number() over(partition by t order by f) r from over10k) a
-where r < 8 and t < 0
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-a.t	a.f	a.r
--3	0.56	1
--3	0.83	2
--3	2.26	3
--3	2.48	4
--3	3.82	5
--3	6.8	6
--3	6.83	7
--2	1.55	1
--2	1.65	2
--2	1.79	3
--2	4.06	4
--2	4.4	5
--2	5.43	6
--2	5.59	7
--1	0.79	1
--1	0.95	2
--1	1.27	3
--1	1.49	4
--1	2.8	5
--1	4.08	6
--1	4.31	7
-PREHOOK: query: explain vectorization detail
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: false
-  enabledConditionsNotMet: [hive.vectorized.execution.enabled IS false]
-
-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: alltypesorc
-            Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-            Reduce Output Operator
-              key expressions: ctinyint (type: tinyint), cdouble (type: double)
-              sort order: ++
-              Map-reduce partition columns: ctinyint (type: tinyint)
-              Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-              TopN Hash Memory Usage: 0.8
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: tinyint), KEY.reducesinkkey1 (type: double)
-          outputColumnNames: _col0, _col5
-          Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col5: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col5 ASC NULLS FIRST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col5
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (rank_window_0 < 5) (type: boolean)
-              Statistics: Num rows: 4096 Data size: 880654 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col0 (type: tinyint), _col5 (type: double), rank_window_0 (type: int)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 4096 Data size: 880654 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 4096 Data size: 880654 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: drop table if exists sB
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table if exists sB
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table sB ROW FORMAT DELIMITED FIELDS TERMINATED BY ','  STORED AS TEXTFILE as  
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-PREHOOK: type: CREATETABLE_AS_SELECT
-PREHOOK: Input: default@alltypesorc
-PREHOOK: Output: database:default
-PREHOOK: Output: default@sB
-POSTHOOK: query: create table sB ROW FORMAT DELIMITED FIELDS TERMINATED BY ','  STORED AS TEXTFILE as  
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-POSTHOOK: type: CREATETABLE_AS_SELECT
-POSTHOOK: Input: default@alltypesorc
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@sB
-POSTHOOK: Lineage: sb.cdouble SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cdouble, type:double, comment:null), ]
-POSTHOOK: Lineage: sb.ctinyint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:ctinyint, type:tinyint, comment:null), ]
-POSTHOOK: Lineage: sb.r SCRIPT [(alltypesorc)alltypesorc.FieldSchema(name:ctinyint, type:tinyint, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:csmallint, type:smallint, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cint, type:int, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cbigint, type:bigint, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cfloat, type:float, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cdouble, type:double, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cstring1, type:string, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cstring2, type:string, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:ctimestamp1, type:timestamp, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:ctimestamp2, type:timestamp, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cboolean1, type:boolean, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cboolean2, type:boolean, comment:null
 ), ]
-a.ctinyint	a.cdouble	a.r
-PREHOOK: query: select * from sB
-where ctinyint is null
-PREHOOK: type: QUERY
-PREHOOK: Input: default@sb
-#### A masked pattern was here ####
-POSTHOOK: query: select * from sB
-where ctinyint is null
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@sb
-#### A masked pattern was here ####
-sb.ctinyint	sb.cdouble	sb.r
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-PREHOOK: query: drop table if exists sD
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table if exists sD
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: explain vectorization detail
-create table sD ROW FORMAT DELIMITED FIELDS TERMINATED BY ','  STORED AS TEXTFILE as  
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-PREHOOK: type: CREATETABLE_AS_SELECT
-POSTHOOK: query: explain vectorization detail
-create table sD ROW FORMAT DELIMITED FIELDS TERMINATED BY ','  STORED AS TEXTFILE as  
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-POSTHOOK: type: CREATETABLE_AS_SELECT
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-  Stage-3 depends on stages: Stage-0
-  Stage-2 depends on stages: Stage-3
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: alltypesorc
-            Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11]
-                projectedColumns: [ctinyint:tinyint, csmallint:smallint, cint:int, cbigint:bigint, cfloat:float, cdouble:double, cstring1:string, cstring2:string, ctimestamp1:timestamp, ctimestamp2:timestamp, cboolean1:boolean, cboolean2:boolean]
-            Reduce Output Operator
-              key expressions: ctinyint (type: tinyint), cdouble (type: double)
-              sort order: ++
-              Map-reduce partition columns: ctinyint (type: tinyint)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false, No PTF TopN IS false
-              Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-              TopN Hash Memory Usage: 0.8
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vectorized.input.format IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 12
-              includeColumns: [0, 5]
-              dataColumns: ctinyint:tinyint, csmallint:smallint, cint:int, cbigint:bigint, cfloat:float, cdouble:double, cstring1:string, cstring2:string, ctimestamp1:timestamp, ctimestamp2:timestamp, cboolean1:boolean, cboolean2:boolean
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: tinyint), KEY.reducesinkkey1 (type: double)
-          outputColumnNames: _col0, _col5
-          Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col5: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col5 ASC NULLS FIRST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col5
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (rank_window_0 < 5) (type: boolean)
-              Statistics: Num rows: 4096 Data size: 880654 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col0 (type: tinyint), _col5 (type: double), rank_window_0 (type: int)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 4096 Data size: 880654 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 4096 Data size: 880654 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
-                      name: default.sD
-
-  Stage: Stage-0
-    Move Operator
-      files:
-          hdfs directory: true
-#### A masked pattern was here ####
-
-  Stage: Stage-3
-      Create Table Operator:
-        Create Table
-          columns: ctinyint tinyint, cdouble double, r int
-          field delimiter: ,
-          input format: org.apache.hadoop.mapred.TextInputFormat
-          output format: org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat
-          serde name: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-          name: default.sD
-
-  Stage: Stage-2
-    Stats Work
-      Basic Stats Work:
-
-PREHOOK: query: create table sD ROW FORMAT DELIMITED FIELDS TERMINATED BY ','  STORED AS TEXTFILE as  
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-PREHOOK: type: CREATETABLE_AS_SELECT
-PREHOOK: Input: default@alltypesorc
-PREHOOK: Output: database:default
-PREHOOK: Output: default@sD
-POSTHOOK: query: create table sD ROW FORMAT DELIMITED FIELDS TERMINATED BY ','  STORED AS TEXTFILE as  
-select * from (select ctinyint, cdouble, rank() over(partition by ctinyint order by cdouble) r from  alltypesorc) a where r < 5
-POSTHOOK: type: CREATETABLE_AS_SELECT
-POSTHOOK: Input: default@alltypesorc
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@sD
-POSTHOOK: Lineage: sd.cdouble SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:cdouble, type:double, comment:null), ]
-POSTHOOK: Lineage: sd.ctinyint SIMPLE [(alltypesorc)alltypesorc.FieldSchema(name:ctinyint, type:tinyint, comment:null), ]
-POSTHOOK: Lineage: sd.r SCRIPT [(alltypesorc)alltypesorc.FieldSchema(name:ctinyint, type:tinyint, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:csmallint, type:smallint, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cint, type:int, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cbigint, type:bigint, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cfloat, type:float, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cdouble, type:double, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cstring1, type:string, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cstring2, type:string, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:ctimestamp1, type:timestamp, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:ctimestamp2, type:timestamp, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cboolean1, type:boolean, comment:null), (alltypesorc)alltypesorc.FieldSchema(name:cboolean2, type:boolean, comment:null
 ), ]
-a.ctinyint	a.cdouble	a.r
-PREHOOK: query: select * from sD
-where ctinyint is null
-PREHOOK: type: QUERY
-PREHOOK: Input: default@sd
-#### A masked pattern was here ####
-POSTHOOK: query: select * from sD
-where ctinyint is null
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@sd
-#### A masked pattern was here ####
-sd.ctinyint	sd.cdouble	sd.r
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1
-NULL	NULL	1


[11/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/mm_exim.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/mm_exim.q.out b/ql/src/test/results/clientpositive/mm_exim.q.out
deleted file mode 100644
index 910a46d..0000000
--- a/ql/src/test/results/clientpositive/mm_exim.q.out
+++ /dev/null
@@ -1,557 +0,0 @@
-PREHOOK: query: drop table intermediate
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table intermediate
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table intermediate(key int) partitioned by (p int) stored as orc
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@intermediate
-POSTHOOK: query: create table intermediate(key int) partitioned by (p int) stored as orc
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@intermediate
-PREHOOK: query: insert into table intermediate partition(p='455') select distinct key from src where key >= 0 order by key desc limit 2
-PREHOOK: type: QUERY
-PREHOOK: Input: default@src
-PREHOOK: Output: default@intermediate@p=455
-POSTHOOK: query: insert into table intermediate partition(p='455') select distinct key from src where key >= 0 order by key desc limit 2
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@src
-POSTHOOK: Output: default@intermediate@p=455
-POSTHOOK: Lineage: intermediate PARTITION(p=455).key EXPRESSION [(src)src.FieldSchema(name:key, type:string, comment:default), ]
-PREHOOK: query: insert into table intermediate partition(p='456') select distinct key from src where key is not null order by key asc limit 2
-PREHOOK: type: QUERY
-PREHOOK: Input: default@src
-PREHOOK: Output: default@intermediate@p=456
-POSTHOOK: query: insert into table intermediate partition(p='456') select distinct key from src where key is not null order by key asc limit 2
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@src
-POSTHOOK: Output: default@intermediate@p=456
-POSTHOOK: Lineage: intermediate PARTITION(p=456).key EXPRESSION [(src)src.FieldSchema(name:key, type:string, comment:default), ]
-PREHOOK: query: insert into table intermediate partition(p='457') select distinct key from src where key >= 100 order by key asc limit 2
-PREHOOK: type: QUERY
-PREHOOK: Input: default@src
-PREHOOK: Output: default@intermediate@p=457
-POSTHOOK: query: insert into table intermediate partition(p='457') select distinct key from src where key >= 100 order by key asc limit 2
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@src
-POSTHOOK: Output: default@intermediate@p=457
-POSTHOOK: Lineage: intermediate PARTITION(p=457).key EXPRESSION [(src)src.FieldSchema(name:key, type:string, comment:default), ]
-PREHOOK: query: drop table intermediate_nonpart
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table intermediate_nonpart
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: drop table intermmediate_part
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table intermmediate_part
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: drop table intermmediate_nonpart
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table intermmediate_nonpart
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table intermediate_nonpart(key int, p int)
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@intermediate_nonpart
-POSTHOOK: query: create table intermediate_nonpart(key int, p int)
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@intermediate_nonpart
-PREHOOK: query: insert into intermediate_nonpart select * from intermediate
-PREHOOK: type: QUERY
-PREHOOK: Input: default@intermediate
-PREHOOK: Input: default@intermediate@p=455
-PREHOOK: Input: default@intermediate@p=456
-PREHOOK: Input: default@intermediate@p=457
-PREHOOK: Output: default@intermediate_nonpart
-POSTHOOK: query: insert into intermediate_nonpart select * from intermediate
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@intermediate
-POSTHOOK: Input: default@intermediate@p=455
-POSTHOOK: Input: default@intermediate@p=456
-POSTHOOK: Input: default@intermediate@p=457
-POSTHOOK: Output: default@intermediate_nonpart
-POSTHOOK: Lineage: intermediate_nonpart.key SIMPLE [(intermediate)intermediate.FieldSchema(name:key, type:int, comment:null), ]
-POSTHOOK: Lineage: intermediate_nonpart.p SIMPLE [(intermediate)intermediate.FieldSchema(name:p, type:int, comment:null), ]
-PREHOOK: query: create table intermmediate_nonpart(key int, p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@intermmediate_nonpart
-POSTHOOK: query: create table intermmediate_nonpart(key int, p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@intermmediate_nonpart
-PREHOOK: query: insert into intermmediate_nonpart select * from intermediate
-PREHOOK: type: QUERY
-PREHOOK: Input: default@intermediate
-PREHOOK: Input: default@intermediate@p=455
-PREHOOK: Input: default@intermediate@p=456
-PREHOOK: Input: default@intermediate@p=457
-PREHOOK: Output: default@intermmediate_nonpart
-POSTHOOK: query: insert into intermmediate_nonpart select * from intermediate
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@intermediate
-POSTHOOK: Input: default@intermediate@p=455
-POSTHOOK: Input: default@intermediate@p=456
-POSTHOOK: Input: default@intermediate@p=457
-POSTHOOK: Output: default@intermmediate_nonpart
-POSTHOOK: Lineage: intermmediate_nonpart.key SIMPLE [(intermediate)intermediate.FieldSchema(name:key, type:int, comment:null), ]
-POSTHOOK: Lineage: intermmediate_nonpart.p SIMPLE [(intermediate)intermediate.FieldSchema(name:p, type:int, comment:null), ]
-PREHOOK: query: create table intermmediate(key int) partitioned by (p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@intermmediate
-POSTHOOK: query: create table intermmediate(key int) partitioned by (p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@intermmediate
-PREHOOK: query: insert into table intermmediate partition(p) select key, p from intermediate
-PREHOOK: type: QUERY
-PREHOOK: Input: default@intermediate
-PREHOOK: Input: default@intermediate@p=455
-PREHOOK: Input: default@intermediate@p=456
-PREHOOK: Input: default@intermediate@p=457
-PREHOOK: Output: default@intermmediate
-POSTHOOK: query: insert into table intermmediate partition(p) select key, p from intermediate
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@intermediate
-POSTHOOK: Input: default@intermediate@p=455
-POSTHOOK: Input: default@intermediate@p=456
-POSTHOOK: Input: default@intermediate@p=457
-POSTHOOK: Output: default@intermmediate@p=455
-POSTHOOK: Output: default@intermmediate@p=456
-POSTHOOK: Output: default@intermmediate@p=457
-POSTHOOK: Lineage: intermmediate PARTITION(p=455).key SIMPLE [(intermediate)intermediate.FieldSchema(name:key, type:int, comment:null), ]
-POSTHOOK: Lineage: intermmediate PARTITION(p=456).key SIMPLE [(intermediate)intermediate.FieldSchema(name:key, type:int, comment:null), ]
-POSTHOOK: Lineage: intermmediate PARTITION(p=457).key SIMPLE [(intermediate)intermediate.FieldSchema(name:key, type:int, comment:null), ]
-PREHOOK: query: export table intermediate_nonpart to 'ql/test/data/exports/intermediate_nonpart'
-PREHOOK: type: EXPORT
-PREHOOK: Input: default@intermediate_nonpart
-#### A masked pattern was here ####
-POSTHOOK: query: export table intermediate_nonpart to 'ql/test/data/exports/intermediate_nonpart'
-POSTHOOK: type: EXPORT
-POSTHOOK: Input: default@intermediate_nonpart
-#### A masked pattern was here ####
-PREHOOK: query: export table intermmediate_nonpart to 'ql/test/data/exports/intermmediate_nonpart'
-PREHOOK: type: EXPORT
-PREHOOK: Input: default@intermmediate_nonpart
-#### A masked pattern was here ####
-POSTHOOK: query: export table intermmediate_nonpart to 'ql/test/data/exports/intermmediate_nonpart'
-POSTHOOK: type: EXPORT
-POSTHOOK: Input: default@intermmediate_nonpart
-#### A masked pattern was here ####
-PREHOOK: query: export table intermediate to 'ql/test/data/exports/intermediate_part'
-PREHOOK: type: EXPORT
-PREHOOK: Input: default@intermediate@p=455
-PREHOOK: Input: default@intermediate@p=456
-PREHOOK: Input: default@intermediate@p=457
-#### A masked pattern was here ####
-POSTHOOK: query: export table intermediate to 'ql/test/data/exports/intermediate_part'
-POSTHOOK: type: EXPORT
-POSTHOOK: Input: default@intermediate@p=455
-POSTHOOK: Input: default@intermediate@p=456
-POSTHOOK: Input: default@intermediate@p=457
-#### A masked pattern was here ####
-PREHOOK: query: export table intermmediate to 'ql/test/data/exports/intermmediate_part'
-PREHOOK: type: EXPORT
-PREHOOK: Input: default@intermmediate@p=455
-PREHOOK: Input: default@intermmediate@p=456
-PREHOOK: Input: default@intermmediate@p=457
-#### A masked pattern was here ####
-POSTHOOK: query: export table intermmediate to 'ql/test/data/exports/intermmediate_part'
-POSTHOOK: type: EXPORT
-POSTHOOK: Input: default@intermmediate@p=455
-POSTHOOK: Input: default@intermmediate@p=456
-POSTHOOK: Input: default@intermmediate@p=457
-#### A masked pattern was here ####
-PREHOOK: query: drop table intermediate_nonpart
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@intermediate_nonpart
-PREHOOK: Output: default@intermediate_nonpart
-POSTHOOK: query: drop table intermediate_nonpart
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@intermediate_nonpart
-POSTHOOK: Output: default@intermediate_nonpart
-PREHOOK: query: drop table intermmediate_part
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table intermmediate_part
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: drop table intermmediate_nonpart
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@intermmediate_nonpart
-PREHOOK: Output: default@intermmediate_nonpart
-POSTHOOK: query: drop table intermmediate_nonpart
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@intermmediate_nonpart
-POSTHOOK: Output: default@intermmediate_nonpart
-PREHOOK: query: drop table import0_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import0_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table import0_mm(key int, p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@import0_mm
-POSTHOOK: query: create table import0_mm(key int, p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import0_mm
-PREHOOK: query: import table import0_mm from 'ql/test/data/exports/intermediate_nonpart'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: default@import0_mm
-POSTHOOK: query: import table import0_mm from 'ql/test/data/exports/intermediate_nonpart'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: default@import0_mm
-PREHOOK: query: select * from import0_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import0_mm
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import0_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import0_mm
-#### A masked pattern was here ####
-0	456
-10	456
-97	455
-98	455
-100	457
-103	457
-PREHOOK: query: drop table import0_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import0_mm
-PREHOOK: Output: default@import0_mm
-POSTHOOK: query: drop table import0_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import0_mm
-POSTHOOK: Output: default@import0_mm
-PREHOOK: query: drop table import1_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import1_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table import1_mm(key int) partitioned by (p int)
-  stored as orc tblproperties("transactional"="true", "transactional_properties"="insert_only")
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@import1_mm
-POSTHOOK: query: create table import1_mm(key int) partitioned by (p int)
-  stored as orc tblproperties("transactional"="true", "transactional_properties"="insert_only")
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import1_mm
-PREHOOK: query: import table import1_mm from 'ql/test/data/exports/intermediate_part'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: default@import1_mm
-POSTHOOK: query: import table import1_mm from 'ql/test/data/exports/intermediate_part'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: default@import1_mm
-POSTHOOK: Output: default@import1_mm@p=455
-POSTHOOK: Output: default@import1_mm@p=456
-POSTHOOK: Output: default@import1_mm@p=457
-PREHOOK: query: select * from import1_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import1_mm
-PREHOOK: Input: default@import1_mm@p=455
-PREHOOK: Input: default@import1_mm@p=456
-PREHOOK: Input: default@import1_mm@p=457
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import1_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import1_mm
-POSTHOOK: Input: default@import1_mm@p=455
-POSTHOOK: Input: default@import1_mm@p=456
-POSTHOOK: Input: default@import1_mm@p=457
-#### A masked pattern was here ####
-0	456
-10	456
-97	455
-98	455
-100	457
-103	457
-PREHOOK: query: drop table import1_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import1_mm
-PREHOOK: Output: default@import1_mm
-POSTHOOK: query: drop table import1_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import1_mm
-POSTHOOK: Output: default@import1_mm
-PREHOOK: query: drop table import2_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import2_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: import table import2_mm from 'ql/test/data/exports/intermmediate_nonpart'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: database:default
-POSTHOOK: query: import table import2_mm from 'ql/test/data/exports/intermmediate_nonpart'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import2_mm
-PREHOOK: query: desc import2_mm
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@import2_mm
-POSTHOOK: query: desc import2_mm
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@import2_mm
-key                 	int                 	                    
-p                   	int                 	                    
-PREHOOK: query: select * from import2_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import2_mm
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import2_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import2_mm
-#### A masked pattern was here ####
-0	456
-10	456
-97	455
-98	455
-100	457
-103	457
-PREHOOK: query: drop table import2_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import2_mm
-PREHOOK: Output: default@import2_mm
-POSTHOOK: query: drop table import2_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import2_mm
-POSTHOOK: Output: default@import2_mm
-PREHOOK: query: drop table import3_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import3_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: import table import3_mm from 'ql/test/data/exports/intermmediate_part'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: database:default
-POSTHOOK: query: import table import3_mm from 'ql/test/data/exports/intermmediate_part'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import3_mm
-POSTHOOK: Output: default@import3_mm@p=455
-POSTHOOK: Output: default@import3_mm@p=456
-POSTHOOK: Output: default@import3_mm@p=457
-PREHOOK: query: desc import3_mm
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@import3_mm
-POSTHOOK: query: desc import3_mm
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@import3_mm
-key                 	int                 	                    
-p                   	int                 	                    
-	 	 
-# Partition Information	 	 
-# col_name            	data_type           	comment             
-	 	 
-p                   	int                 	                    
-PREHOOK: query: select * from import3_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import3_mm
-PREHOOK: Input: default@import3_mm@p=455
-PREHOOK: Input: default@import3_mm@p=456
-PREHOOK: Input: default@import3_mm@p=457
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import3_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import3_mm
-POSTHOOK: Input: default@import3_mm@p=455
-POSTHOOK: Input: default@import3_mm@p=456
-POSTHOOK: Input: default@import3_mm@p=457
-#### A masked pattern was here ####
-0	456
-10	456
-97	455
-98	455
-100	457
-103	457
-PREHOOK: query: drop table import3_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import3_mm
-PREHOOK: Output: default@import3_mm
-POSTHOOK: query: drop table import3_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import3_mm
-POSTHOOK: Output: default@import3_mm
-PREHOOK: query: drop table import4_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import4_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table import4_mm(key int, p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@import4_mm
-POSTHOOK: query: create table import4_mm(key int, p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import4_mm
-PREHOOK: query: import table import4_mm from 'ql/test/data/exports/intermmediate_nonpart'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: default@import4_mm
-POSTHOOK: query: import table import4_mm from 'ql/test/data/exports/intermmediate_nonpart'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: default@import4_mm
-PREHOOK: query: select * from import4_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import4_mm
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import4_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import4_mm
-#### A masked pattern was here ####
-0	456
-10	456
-97	455
-98	455
-100	457
-103	457
-PREHOOK: query: drop table import4_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import4_mm
-PREHOOK: Output: default@import4_mm
-POSTHOOK: query: drop table import4_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import4_mm
-POSTHOOK: Output: default@import4_mm
-PREHOOK: query: drop table import5_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import5_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table import5_mm(key int) partitioned by (p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@import5_mm
-POSTHOOK: query: create table import5_mm(key int) partitioned by (p int) tblproperties("transactional"="true", "transactional_properties"="insert_only")
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import5_mm
-PREHOOK: query: import table import5_mm partition(p=455) from 'ql/test/data/exports/intermmediate_part'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: default@import5_mm
-POSTHOOK: query: import table import5_mm partition(p=455) from 'ql/test/data/exports/intermmediate_part'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: default@import5_mm
-POSTHOOK: Output: default@import5_mm@p=455
-PREHOOK: query: select * from import5_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import5_mm
-PREHOOK: Input: default@import5_mm@p=455
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import5_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import5_mm
-POSTHOOK: Input: default@import5_mm@p=455
-#### A masked pattern was here ####
-97	455
-98	455
-PREHOOK: query: drop table import5_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import5_mm
-PREHOOK: Output: default@import5_mm
-POSTHOOK: query: drop table import5_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import5_mm
-POSTHOOK: Output: default@import5_mm
-PREHOOK: query: drop table import6_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import6_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table import6_mm(key int, p int)
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@import6_mm
-POSTHOOK: query: create table import6_mm(key int, p int)
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import6_mm
-PREHOOK: query: import table import6_mm from 'ql/test/data/exports/intermmediate_nonpart'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: default@import6_mm
-POSTHOOK: query: import table import6_mm from 'ql/test/data/exports/intermmediate_nonpart'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: default@import6_mm
-PREHOOK: query: select * from import6_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import6_mm
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import6_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import6_mm
-#### A masked pattern was here ####
-0	456
-10	456
-97	455
-98	455
-100	457
-103	457
-PREHOOK: query: drop table import6_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import6_mm
-PREHOOK: Output: default@import6_mm
-POSTHOOK: query: drop table import6_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import6_mm
-POSTHOOK: Output: default@import6_mm
-PREHOOK: query: drop table import7_mm
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table import7_mm
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table import7_mm(key int) partitioned by (p int)
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@import7_mm
-POSTHOOK: query: create table import7_mm(key int) partitioned by (p int)
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@import7_mm
-PREHOOK: query: import table import7_mm from 'ql/test/data/exports/intermmediate_part'
-PREHOOK: type: IMPORT
-#### A masked pattern was here ####
-PREHOOK: Output: default@import7_mm
-POSTHOOK: query: import table import7_mm from 'ql/test/data/exports/intermmediate_part'
-POSTHOOK: type: IMPORT
-#### A masked pattern was here ####
-POSTHOOK: Output: default@import7_mm
-POSTHOOK: Output: default@import7_mm@p=455
-POSTHOOK: Output: default@import7_mm@p=456
-POSTHOOK: Output: default@import7_mm@p=457
-PREHOOK: query: select * from import7_mm order by key, p
-PREHOOK: type: QUERY
-PREHOOK: Input: default@import7_mm
-PREHOOK: Input: default@import7_mm@p=455
-PREHOOK: Input: default@import7_mm@p=456
-PREHOOK: Input: default@import7_mm@p=457
-#### A masked pattern was here ####
-POSTHOOK: query: select * from import7_mm order by key, p
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@import7_mm
-POSTHOOK: Input: default@import7_mm@p=455
-POSTHOOK: Input: default@import7_mm@p=456
-POSTHOOK: Input: default@import7_mm@p=457
-#### A masked pattern was here ####
-0	456
-10	456
-97	455
-98	455
-100	457
-103	457
-PREHOOK: query: drop table import7_mm
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@import7_mm
-PREHOOK: Output: default@import7_mm
-POSTHOOK: query: drop table import7_mm
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@import7_mm
-POSTHOOK: Output: default@import7_mm

http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/spark/stats_partscan_1_23.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/stats_partscan_1_23.q.out b/ql/src/test/results/clientpositive/spark/stats_partscan_1_23.q.out
deleted file mode 100644
index 403bc28..0000000
--- a/ql/src/test/results/clientpositive/spark/stats_partscan_1_23.q.out
+++ /dev/null
@@ -1,188 +0,0 @@
-PREHOOK: query: CREATE table analyze_srcpart_partial_scan (key STRING, value STRING)
-partitioned by (ds string, hr string)
-stored as rcfile
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: query: CREATE table analyze_srcpart_partial_scan (key STRING, value STRING)
-partitioned by (ds string, hr string)
-stored as rcfile
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@analyze_srcpart_partial_scan
-PREHOOK: query: insert overwrite table analyze_srcpart_partial_scan partition (ds, hr) select * from srcpart where ds is not null
-PREHOOK: type: QUERY
-PREHOOK: Input: default@srcpart
-PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
-PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
-PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
-PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: query: insert overwrite table analyze_srcpart_partial_scan partition (ds, hr) select * from srcpart where ds is not null
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@srcpart
-POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
-POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
-POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
-POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=12
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-09/hr=11
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-09/hr=12
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=11).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=11).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=12).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=12).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=11).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=11).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=12).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=12).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-PREHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-# col_name            	data_type           	comment             
-	 	 
-key                 	string              	                    
-value               	string              	                    
-	 	 
-# Partition Information	 	 
-# col_name            	data_type           	comment             
-	 	 
-ds                  	string              	                    
-hr                  	string              	                    
-	 	 
-# Detailed Partition Information	 	 
-Partition Value:    	[2008-04-08, 11]    	 
-Database:           	default             	 
-Table:              	analyze_srcpart_partial_scan	 
-#### A masked pattern was here ####
-Partition Parameters:	 	 
-	numFiles            	1                   
-	totalSize           	5293                
-#### A masked pattern was here ####
-	 	 
-# Storage Information	 	 
-SerDe Library:      	org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe	 
-InputFormat:        	org.apache.hadoop.hive.ql.io.RCFileInputFormat	 
-OutputFormat:       	org.apache.hadoop.hive.ql.io.RCFileOutputFormat	 
-Compressed:         	No                  	 
-Num Buckets:        	-1                  	 
-Bucket Columns:     	[]                  	 
-Sort Columns:       	[]                  	 
-Storage Desc Params:	 	 
-	serialization.format	1                   
-PREHOOK: query: explain
-analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-PREHOOK: type: QUERY
-POSTHOOK: query: explain
-analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-POSTHOOK: type: QUERY
-STAGE DEPENDENCIES:
-  Stage-2 is a root stage
-  Stage-1 depends on stages: Stage-0, Stage-2
-
-STAGE PLANS:
-  Stage: Stage-2
-    Partial Scan Statistics
-
-  Stage: Stage-1
-    Stats Work
-      Basic Stats Work:
-
-PREHOOK: query: analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-PREHOOK: type: QUERY
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-PREHOOK: Input: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-PREHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-POSTHOOK: query: analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: Input: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-POSTHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-PREHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-# col_name            	data_type           	comment             
-	 	 
-key                 	string              	                    
-value               	string              	                    
-	 	 
-# Partition Information	 	 
-# col_name            	data_type           	comment             
-	 	 
-ds                  	string              	                    
-hr                  	string              	                    
-	 	 
-# Detailed Partition Information	 	 
-Partition Value:    	[2008-04-08, 11]    	 
-Database:           	default             	 
-Table:              	analyze_srcpart_partial_scan	 
-#### A masked pattern was here ####
-Partition Parameters:	 	 
-	numFiles            	1                   
-	totalSize           	5293                
-#### A masked pattern was here ####
-	 	 
-# Storage Information	 	 
-SerDe Library:      	org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe	 
-InputFormat:        	org.apache.hadoop.hive.ql.io.RCFileInputFormat	 
-OutputFormat:       	org.apache.hadoop.hive.ql.io.RCFileOutputFormat	 
-Compressed:         	No                  	 
-Num Buckets:        	-1                  	 
-Bucket Columns:     	[]                  	 
-Sort Columns:       	[]                  	 
-Storage Desc Params:	 	 
-	serialization.format	1                   
-PREHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-09',hr=11)
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-09',hr=11)
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-# col_name            	data_type           	comment             
-	 	 
-key                 	string              	                    
-value               	string              	                    
-	 	 
-# Partition Information	 	 
-# col_name            	data_type           	comment             
-	 	 
-ds                  	string              	                    
-hr                  	string              	                    
-	 	 
-# Detailed Partition Information	 	 
-Partition Value:    	[2008-04-09, 11]    	 
-Database:           	default             	 
-Table:              	analyze_srcpart_partial_scan	 
-#### A masked pattern was here ####
-Partition Parameters:	 	 
-	numFiles            	1                   
-	totalSize           	5293                
-#### A masked pattern was here ####
-	 	 
-# Storage Information	 	 
-SerDe Library:      	org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe	 
-InputFormat:        	org.apache.hadoop.hive.ql.io.RCFileInputFormat	 
-OutputFormat:       	org.apache.hadoop.hive.ql.io.RCFileOutputFormat	 
-Compressed:         	No                  	 
-Num Buckets:        	-1                  	 
-Bucket Columns:     	[]                  	 
-Sort Columns:       	[]                  	 
-Storage Desc Params:	 	 
-	serialization.format	1                   
-PREHOOK: query: drop table analyze_srcpart_partial_scan
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: query: drop table analyze_srcpart_partial_scan
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: Output: default@analyze_srcpart_partial_scan

http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/stats_partscan_1_23.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/stats_partscan_1_23.q.out b/ql/src/test/results/clientpositive/stats_partscan_1_23.q.out
deleted file mode 100644
index 34f7023..0000000
--- a/ql/src/test/results/clientpositive/stats_partscan_1_23.q.out
+++ /dev/null
@@ -1,191 +0,0 @@
-PREHOOK: query: CREATE table analyze_srcpart_partial_scan (key STRING, value STRING)
-partitioned by (ds string, hr string)
-stored as rcfile
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: query: CREATE table analyze_srcpart_partial_scan (key STRING, value STRING)
-partitioned by (ds string, hr string)
-stored as rcfile
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@analyze_srcpart_partial_scan
-PREHOOK: query: insert overwrite table analyze_srcpart_partial_scan partition (ds, hr) select * from srcpart where ds is not null
-PREHOOK: type: QUERY
-PREHOOK: Input: default@srcpart
-PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
-PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
-PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
-PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: query: insert overwrite table analyze_srcpart_partial_scan partition (ds, hr) select * from srcpart where ds is not null
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@srcpart
-POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
-POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
-POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
-POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=12
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-09/hr=11
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-09/hr=12
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=11).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=11).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=12).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-08,hr=12).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=11).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=11).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=12).key SIMPLE [(srcpart)srcpart.FieldSchema(name:key, type:string, comment:default), ]
-POSTHOOK: Lineage: analyze_srcpart_partial_scan PARTITION(ds=2008-04-09,hr=12).value SIMPLE [(srcpart)srcpart.FieldSchema(name:value, type:string, comment:default), ]
-PREHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-# col_name            	data_type           	comment             
-	 	 
-key                 	string              	                    
-value               	string              	                    
-	 	 
-# Partition Information	 	 
-# col_name            	data_type           	comment             
-	 	 
-ds                  	string              	                    
-hr                  	string              	                    
-	 	 
-# Detailed Partition Information	 	 
-Partition Value:    	[2008-04-08, 11]    	 
-Database:           	default             	 
-Table:              	analyze_srcpart_partial_scan	 
-#### A masked pattern was here ####
-Partition Parameters:	 	 
-	numFiles            	1                   
-	totalSize           	5293                
-#### A masked pattern was here ####
-	 	 
-# Storage Information	 	 
-SerDe Library:      	org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe	 
-InputFormat:        	org.apache.hadoop.hive.ql.io.RCFileInputFormat	 
-OutputFormat:       	org.apache.hadoop.hive.ql.io.RCFileOutputFormat	 
-Compressed:         	No                  	 
-Num Buckets:        	-1                  	 
-Bucket Columns:     	[]                  	 
-Sort Columns:       	[]                  	 
-Storage Desc Params:	 	 
-	serialization.format	1                   
-PREHOOK: query: explain
-analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-PREHOOK: type: QUERY
-POSTHOOK: query: explain
-analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-POSTHOOK: type: QUERY
-STAGE DEPENDENCIES:
-  Stage-2 is a root stage
-  Stage-1 depends on stages: Stage-2
-
-STAGE PLANS:
-  Stage: Stage-2
-    Partial Scan Statistics
-
-  Stage: Stage-1
-    Stats Work
-      Basic Stats Work:
-
-PREHOOK: query: analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-PREHOOK: type: QUERY
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-PREHOOK: Input: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-PREHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-POSTHOOK: query: analyze table analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11) compute statistics partialscan
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: Input: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-POSTHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: Output: default@analyze_srcpart_partial_scan@ds=2008-04-08/hr=11
-PREHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-08',hr=11)
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-# col_name            	data_type           	comment             
-	 	 
-key                 	string              	                    
-value               	string              	                    
-	 	 
-# Partition Information	 	 
-# col_name            	data_type           	comment             
-	 	 
-ds                  	string              	                    
-hr                  	string              	                    
-	 	 
-# Detailed Partition Information	 	 
-Partition Value:    	[2008-04-08, 11]    	 
-Database:           	default             	 
-Table:              	analyze_srcpart_partial_scan	 
-#### A masked pattern was here ####
-Partition Parameters:	 	 
-	COLUMN_STATS_ACCURATE	{\"BASIC_STATS\":\"true\"}
-	numFiles            	1                   
-	numRows             	500                 
-	rawDataSize         	4812                
-	totalSize           	5293                
-#### A masked pattern was here ####
-	 	 
-# Storage Information	 	 
-SerDe Library:      	org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe	 
-InputFormat:        	org.apache.hadoop.hive.ql.io.RCFileInputFormat	 
-OutputFormat:       	org.apache.hadoop.hive.ql.io.RCFileOutputFormat	 
-Compressed:         	No                  	 
-Num Buckets:        	-1                  	 
-Bucket Columns:     	[]                  	 
-Sort Columns:       	[]                  	 
-Storage Desc Params:	 	 
-	serialization.format	1                   
-PREHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-09',hr=11)
-PREHOOK: type: DESCTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: query: describe formatted analyze_srcpart_partial_scan PARTITION(ds='2008-04-09',hr=11)
-POSTHOOK: type: DESCTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-# col_name            	data_type           	comment             
-	 	 
-key                 	string              	                    
-value               	string              	                    
-	 	 
-# Partition Information	 	 
-# col_name            	data_type           	comment             
-	 	 
-ds                  	string              	                    
-hr                  	string              	                    
-	 	 
-# Detailed Partition Information	 	 
-Partition Value:    	[2008-04-09, 11]    	 
-Database:           	default             	 
-Table:              	analyze_srcpart_partial_scan	 
-#### A masked pattern was here ####
-Partition Parameters:	 	 
-	numFiles            	1                   
-	totalSize           	5293                
-#### A masked pattern was here ####
-	 	 
-# Storage Information	 	 
-SerDe Library:      	org.apache.hadoop.hive.serde2.columnar.ColumnarSerDe	 
-InputFormat:        	org.apache.hadoop.hive.ql.io.RCFileInputFormat	 
-OutputFormat:       	org.apache.hadoop.hive.ql.io.RCFileOutputFormat	 
-Compressed:         	No                  	 
-Num Buckets:        	-1                  	 
-Bucket Columns:     	[]                  	 
-Sort Columns:       	[]                  	 
-Storage Desc Params:	 	 
-	serialization.format	1                   
-PREHOOK: query: drop table analyze_srcpart_partial_scan
-PREHOOK: type: DROPTABLE
-PREHOOK: Input: default@analyze_srcpart_partial_scan
-PREHOOK: Output: default@analyze_srcpart_partial_scan
-POSTHOOK: query: drop table analyze_srcpart_partial_scan
-POSTHOOK: type: DROPTABLE
-POSTHOOK: Input: default@analyze_srcpart_partial_scan
-POSTHOOK: Output: default@analyze_srcpart_partial_scan


[09/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_expressions.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_expressions.q.out b/ql/src/test/results/clientpositive/vector_windowing_expressions.q.out
deleted file mode 100644
index 7a26191..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_expressions.q.out
+++ /dev/null
@@ -1,2077 +0,0 @@
-PREHOOK: query: drop table over10k
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table over10k
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@over10k
-POSTHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) = round(sum(lag(p_retailprice,1,0.0)) over w1 + last_value(p_retailprice) over w1 , 2), 
-max(p_retailprice) over w1 - min(p_retailprice) over w1 = last_value(p_retailprice) over w1 - first_value(p_retailprice) over w1
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) = round(sum(lag(p_retailprice,1,0.0)) over w1 + last_value(p_retailprice) over w1 , 2), 
-max(p_retailprice) over w1 - min(p_retailprice) over w1 = last_value(p_retailprice) over w1 - first_value(p_retailprice) over w1
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_retailprice (type: double)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: string), VALUE._col4 (type: int), KEY.reducesinkkey1 (type: double)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: sum_window_1
-                        arguments: lag(...)
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: last_value_window_2
-                        arguments: _col7
-                        name: last_value
-                        window function: GenericUDAFLastValueEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: max_window_3
-                        arguments: _col7
-                        name: max
-                        window function: GenericUDAFMaxEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: min_window_4
-                        arguments: _col7
-                        name: min
-                        window function: GenericUDAFMinEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: first_value_window_5
-                        arguments: _col7
-                        name: first_value
-                        window function: GenericUDAFFirstValueEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Lead/Lag information: lag(...) (type: double)
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col7 (type: double), _col5 (type: int), (round(sum_window_0, 2) = round((sum_window_1 + last_value_window_2), 2)) (type: boolean), ((max_window_3 - min_window_4) = (last_value_window_2 - first_value_window_5)) (type: boolean)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) = round(sum(lag(p_retailprice,1,0.0)) over w1 + last_value(p_retailprice) over w1 , 2), 
-max(p_retailprice) over w1 - min(p_retailprice) over w1 = last_value(p_retailprice) over w1 - first_value(p_retailprice) over w1
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) = round(sum(lag(p_retailprice,1,0.0)) over w1 + last_value(p_retailprice) over w1 , 2), 
-max(p_retailprice) over w1 - min(p_retailprice) over w1 = last_value(p_retailprice) over w1 - first_value(p_retailprice) over w1
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_retailprice	p_size	_c3	_c4
-Manufacturer#1	1173.15	2	true	true
-Manufacturer#1	1173.15	2	true	true
-Manufacturer#1	1414.42	28	true	true
-Manufacturer#1	1602.59	6	true	true
-Manufacturer#1	1632.66	42	true	true
-Manufacturer#1	1753.76	34	true	true
-Manufacturer#2	1690.68	14	true	true
-Manufacturer#2	1698.66	25	true	true
-Manufacturer#2	1701.6	18	true	true
-Manufacturer#2	1800.7	40	true	true
-Manufacturer#2	2031.98	2	true	true
-Manufacturer#3	1190.27	14	true	true
-Manufacturer#3	1337.29	45	true	true
-Manufacturer#3	1410.39	19	true	true
-Manufacturer#3	1671.68	17	true	true
-Manufacturer#3	1922.98	1	true	true
-Manufacturer#4	1206.26	27	true	true
-Manufacturer#4	1290.35	12	true	true
-Manufacturer#4	1375.42	39	true	true
-Manufacturer#4	1620.67	10	true	true
-Manufacturer#4	1844.92	7	true	true
-Manufacturer#5	1018.1	46	true	true
-Manufacturer#5	1464.48	23	true	true
-Manufacturer#5	1611.66	6	true	true
-Manufacturer#5	1788.73	2	true	true
-Manufacturer#5	1789.69	31	true	true
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_retailprice, p_size,
-rank() over (distribute by p_mfgr sort by p_retailprice) as r,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) as s2,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) -5 as s1
-from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_retailprice, p_size,
-rank() over (distribute by p_mfgr sort by p_retailprice) as r,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) as s2,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) -5 as s1
-from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_retailprice (type: double)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: string), VALUE._col4 (type: int), KEY.reducesinkkey1 (type: double)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col7
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: sum_window_1
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col7 (type: double), _col5 (type: int), rank_window_0 (type: int), sum_window_1 (type: double), (sum_window_1 - 5.0) (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_retailprice, p_size,
-rank() over (distribute by p_mfgr sort by p_retailprice) as r,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) as s2,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) -5 as s1
-from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_retailprice, p_size,
-rank() over (distribute by p_mfgr sort by p_retailprice) as r,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) as s2,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) -5 as s1
-from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_retailprice	p_size	r	s2	s1
-Manufacturer#1	1173.15	2	1	1173.15	1168.15
-Manufacturer#1	1173.15	2	1	2346.3	2341.3
-Manufacturer#1	1414.42	28	3	3760.7200000000003	3755.7200000000003
-Manufacturer#1	1602.59	6	4	5363.31	5358.31
-Manufacturer#1	1632.66	42	5	6995.97	6990.97
-Manufacturer#1	1753.76	34	6	8749.73	8744.73
-Manufacturer#2	1690.68	14	1	1690.68	1685.68
-Manufacturer#2	1698.66	25	2	3389.34	3384.34
-Manufacturer#2	1701.6	18	3	5090.9400000000005	5085.9400000000005
-Manufacturer#2	1800.7	40	4	6891.64	6886.64
-Manufacturer#2	2031.98	2	5	8923.62	8918.62
-Manufacturer#3	1190.27	14	1	1190.27	1185.27
-Manufacturer#3	1337.29	45	2	2527.56	2522.56
-Manufacturer#3	1410.39	19	3	3937.95	3932.95
-Manufacturer#3	1671.68	17	4	5609.63	5604.63
-Manufacturer#3	1922.98	1	5	7532.610000000001	7527.610000000001
-Manufacturer#4	1206.26	27	1	1206.26	1201.26
-Manufacturer#4	1290.35	12	2	2496.6099999999997	2491.6099999999997
-Manufacturer#4	1375.42	39	3	3872.0299999999997	3867.0299999999997
-Manufacturer#4	1620.67	10	4	5492.7	5487.7
-Manufacturer#4	1844.92	7	5	7337.62	7332.62
-Manufacturer#5	1018.1	46	1	1018.1	1013.1
-Manufacturer#5	1464.48	23	2	2482.58	2477.58
-Manufacturer#5	1611.66	6	3	4094.24	4089.24
-Manufacturer#5	1788.73	2	4	5882.969999999999	5877.969999999999
-Manufacturer#5	1789.69	31	5	7672.66	7667.66
-PREHOOK: query: explain vectorization detail
-select s, si, f, si - lead(f, 3) over (partition by t order by bo,s,si,f desc) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, si, f, si - lead(f, 3) over (partition by t order by bo,s,si,f desc) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: t (type: tinyint), bo (type: boolean), s (type: string), si (type: smallint), f (type: float)
-              sort order: ++++-
-              Map-reduce partition columns: t (type: tinyint)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [0, 1, 4, 6, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: tinyint), KEY.reducesinkkey3 (type: smallint), KEY.reducesinkkey4 (type: float), KEY.reducesinkkey1 (type: boolean), KEY.reducesinkkey2 (type: string)
-          outputColumnNames: _col0, _col1, _col4, _col6, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col1: smallint, _col4: float, _col6: boolean, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col6 ASC NULLS FIRST, _col7 ASC NULLS FIRST, _col1 ASC NULLS FIRST, _col4 DESC NULLS LAST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: lead_window_0
-                        arguments: _col4, 3
-                        name: lead
-                        window function: GenericUDAFLeadEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col1 (type: smallint), _col4 (type: float), (UDFToFloat(_col1) - lead_window_0) (type: float)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, si, f, si - lead(f, 3) over (partition by t order by bo,s,si,f desc) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, si, f, si - lead(f, 3) over (partition by t order by bo,s,si,f desc) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	si	f	_c3
-alice allen	400	76.31	337.23
-alice davidson	384	71.97	357.79
-alice king	455	2.48	395.93
-alice king	458	62.77	384.16998
-alice xylophone	485	26.21	464.05
-bob falkner	260	59.07	242.4
-bob ichabod	454	73.83	381.7
-bob polk	264	20.95	257.17
-bob underhill	454	17.6	424.94
-bob underhill	465	72.3	453.17
-bob van buren	433	6.83	398.4
-calvin ichabod	431	29.06	334.22
-david garcia	485	11.83	421.51
-ethan steinbeck	298	34.6	288.14
-fred ellison	376	96.78	330.76
-holly steinbeck	384	63.49	293.7
-holly underhill	318	9.86	269.91
-irene ellison	458	45.24	365.29
-irene underhill	307	90.3	244.19
-jessica johnson	494	48.09	490.18
-jessica king	459	92.71	452.2
-jessica white	284	62.81	209.08
-luke garcia	311	3.82	267.27
-luke young	451	6.8	429.0
-mike king	275	74.92	211.81
-oscar garcia	362	43.73	340.66
-priscilla laertes	316	22.0	296.06
-priscilla quirinius	423	63.19	362.72
-priscilla zipper	485	21.34	400.61
-quinn ellison	266	19.94	209.95
-quinn polk	507	60.28	447.66
-sarah robinson	320	84.39	309.74
-tom polk	346	56.05	320.33
-ulysses ellison	381	59.34	358.66
-ulysses quirinius	303	10.26	259.6
-ulysses robinson	313	25.67	269.31
-ulysses steinbeck	333	22.34	270.61
-victor allen	337	43.4	311.5
-victor hernandez	447	43.69	375.22
-victor xylophone	438	62.39	424.33
-wendy quirinius	279	25.5	250.25
-wendy robinson	275	71.78	262.88
-wendy xylophone	314	13.67	295.73
-xavier garcia	493	28.75	474.56
-zach thompson	386	12.12	377.63
-zach young	286	18.27	263.65
-alice falkner	280	18.44	227.7
-bob ellison	339	8.37	300.95
-bob johnson	374	22.35	326.49
-calvin white	280	52.3	198.32
-david carson	270	38.05	255.77
-david falkner	469	47.51	388.35
-david hernandez	408	81.68	339.27
-ethan underhill	339	14.23	256.26
-gabriella brown	498	80.65	413.25
-holly nixon	505	68.73	440.71
-holly polk	268	82.74	182.04001
-holly thompson	387	84.75	298.22
-irene young	458	64.29	401.8
-jessica miller	299	85.96	243.41
-katie ichabod	469	88.78	385.61
-luke ichabod	289	56.2	286.74
-luke king	337	55.59	274.88
-mike allen	465	83.39	383.03
-mike polk	500	2.26	427.74
-mike white	454	62.12	430.78
-mike xylophone	448	81.97	447.17
-nick nixon	335	72.26	240.78
-nick robinson	350	23.22	294.59
-oscar davidson	432	0.83	420.93
-oscar johnson	315	94.22	233.05
-oscar johnson	469	55.41	468.44
-oscar miller	324	11.07	265.19
-rachel davidson	507	81.95	468.78
-rachel thompson	344	0.56	246.12
-sarah miller	386	58.81	304.36
-sarah xylophone	275	38.22	177.48999
-sarah zipper	376	97.88	294.61
-tom hernandez	467	81.64	459.9
-tom hernandez	477	97.51	415.19
-tom steinbeck	414	81.39	361.87
-ulysses carson	343	7.1	314.22
-victor robinson	415	61.81	349.5
-victor thompson	344	52.13	NULL
-xavier ovid	280	28.78	NULL
-yuri xylophone	430	65.5	NULL
-alice underhill	389	26.68	368.06
-alice underhill	446	6.49	444.21
-bob ovid	331	67.12	236.43
-bob van buren	406	20.94	383.32
-david falkner	406	1.79	374.34
-david miller	450	94.57	380.13
-ethan allen	380	22.68	375.6
-ethan king	395	31.66	361.51
-ethan nixon	475	69.87	431.39
-ethan polk	283	4.4	243.82
-fred allen	331	33.49	281.68
-fred king	511	43.61	457.22
-fred polk	261	39.18	248.73
-fred young	303	49.32	221.51001
-PREHOOK: query: explain vectorization detail
-select s, i, i - lead(i, 3, 0) over (partition by si order by i,s) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, i, i - lead(i, 3, 0) over (partition by si order by i,s) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: si (type: smallint), i (type: int), s (type: string)
-              sort order: +++
-              Map-reduce partition columns: si (type: smallint)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [1, 2, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: smallint), KEY.reducesinkkey1 (type: int), KEY.reducesinkkey2 (type: string)
-          outputColumnNames: _col1, _col2, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: smallint, _col2: int, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST, _col7 ASC NULLS FIRST
-                  partition by: _col1
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: lead_window_0
-                        arguments: _col2, 3, 0
-                        name: lead
-                        window function: GenericUDAFLeadEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col2 (type: int), (_col2 - lead_window_0) (type: int)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, i, i - lead(i, 3, 0) over (partition by si order by i,s) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, i, i - lead(i, 3, 0) over (partition by si order by i,s) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	i	_c2
-wendy garcia	65540	-18
-ethan thompson	65543	-20
-zach nixon	65549	-31
-alice robinson	65558	-28
-wendy nixon	65563	-33
-victor robinson	65580	-19
-ethan falkner	65586	-18
-victor davidson	65596	-17
-xavier quirinius	65599	-14
-fred quirinius	65604	-11
-nick zipper	65613	-3
-xavier van buren	65613	-7
-victor johnson	65615	-12
-alice ovid	65616	-24
-xavier ovid	65620	-23
-ulysses white	65627	-24
-sarah white	65640	-13
-calvin young	65643	-25
-victor thompson	65651	-42
-calvin johnson	65653	-53
-irene polk	65668	-45
-zach underhill	65693	-38
-quinn hernandez	65706	-27
-rachel ovid	65713	-24
-gabriella falkner	65731	-7
-zach white	65733	-8
-fred hernandez	65737	-7
-rachel ellison	65738	-6
-oscar steinbeck	65741	-6
-alice ellison	65744	-8
-tom allen	65744	-19
-quinn quirinius	65747	-31
-victor hernandez	65752	-26
-holly xylophone	65763	-26
-david davidson	65778	65778
-ulysses young	65778	65778
-sarah brown	65789	65789
-xavier brown	65541	-16
-zach hernandez	65542	-18
-katie ichabod	65547	-19
-oscar young	65557	-15
-holly white	65560	-14
-priscilla laertes	65566	-9
-ethan king	65572	-6
-zach hernandez	65574	-10
-oscar thompson	65575	-13
-victor xylophone	65578	-16
-gabriella ellison	65584	-26
-nick quirinius	65588	-22
-holly robinson	65594	-18
-alice xylophone	65610	-16
-yuri brown	65610	-21
-sarah hernandez	65612	-26
-katie garcia	65626	-28
-jessica laertes	65631	-23
-ethan underhill	65638	-17
-irene young	65654	-37
-priscilla thompson	65654	-40
-luke quirinius	65655	-44
-david brown	65691	-20
-luke falkner	65694	-18
-priscilla miller	65699	-20
-rachel robinson	65711	-9
-ethan polk	65712	-10
-wendy brown	65719	-13
-mike underhill	65720	-18
-zach underhill	65722	-26
-nick zipper	65732	-20
-fred brown	65738	-18
-ulysses young	65748	-23
-nick davidson	65752	-19
-fred zipper	65756	-15
-yuri nixon	65771	-10
-zach hernandez	65771	-19
-zach zipper	65771	65771
-alice underhill	65781	65781
-oscar laertes	65790	65790
-sarah zipper	65546	-19
-bob falkner	65551	-17
-luke ovid	65551	-17
-katie allen	65565	-4
-nick falkner	65568	-5
-zach steinbeck	65568	-11
-oscar van buren	65569	-13
-gabriella young	65573	-11
-jessica ichabod	65579	-24
-david garcia	65582	-24
-nick xylophone	65584	-27
-calvin johnson	65603	-14
-xavier zipper	65606	-50
-alice nixon	65611	-58
-jessica laertes	65617	-62
-fred king	65656	-61
-priscilla underhill	65669	-48
-priscilla zipper	65679	-45
-nick king	65717	-11
-sarah polk	65717	-17
-irene quirinius	65724	-28
-tom laertes	65728	-25
-yuri johnson	65734	-27
-PREHOOK: query: explain vectorization detail
-select s, si, d, si - lag(d, 3) over (partition by b order by si,s,d) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, si, d, si - lag(d, 3) over (partition by b order by si,s,d) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: b (type: bigint), si (type: smallint), s (type: string), d (type: double)
-              sort order: ++++
-              Map-reduce partition columns: b (type: bigint)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [1, 3, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: smallint), KEY.reducesinkkey0 (type: bigint), KEY.reducesinkkey3 (type: double), KEY.reducesinkkey2 (type: string)
-          outputColumnNames: _col1, _col3, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: smallint, _col3: bigint, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST, _col7 ASC NULLS FIRST, _col5 ASC NULLS FIRST
-                  partition by: _col3
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: lag_window_0
-                        arguments: _col5, 3
-                        name: lag
-                        window function: GenericUDAFLagEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col1 (type: smallint), _col5 (type: double), (UDFToDouble(_col1) - lag_window_0) (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, si, d, si - lag(d, 3) over (partition by b order by si,s,d) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, si, d, si - lag(d, 3) over (partition by b order by si,s,d) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	si	d	_c3
-jessica ellison	262	30.41	NULL
-david young	266	45.12	NULL
-jessica steinbeck	274	2.15	NULL
-david zipper	275	43.45	244.59
-zach nixon	283	15.95	237.88
-holly allen	285	24.37	282.85
-irene garcia	292	33.54	248.55
-ulysses xylophone	292	44.66	276.05
-irene van buren	309	35.81	284.63
-sarah miller	312	6.65	278.46
-victor garcia	312	39.14	267.34000000000003
-ethan ichabod	319	29.4	283.19
-wendy falkner	322	10.02	315.35
-oscar miller	324	25.95	284.86
-david ovid	332	28.34	302.6
-alice zipper	333	3.38	322.98
-yuri nixon	333	8.28	307.05
-ulysses nixon	335	18.48	306.66
-david ovid	336	9.36	332.62
-calvin falkner	337	17.63	328.72
-katie quirinius	349	11.3	330.52
-quinn miller	351	22.46	341.64
-victor xylophone	357	38.58	339.37
-ethan garcia	368	9.2	356.7
-nick steinbeck	395	37.54	372.54
-ulysses ichabod	415	47.61	376.42
-rachel thompson	416	37.99	406.8
-calvin young	418	47.22	380.46
-katie xylophone	425	32.59	377.39
-nick quirinius	429	19.63	391.01
-ethan ellison	453	47.92	405.78
-irene nixon	454	48.03	421.40999999999997
-bob steinbeck	462	47.04	442.37
-luke robinson	462	47.48	414.08
-gabriella steinbeck	467	9.35	418.97
-tom hernandez	467	29.36	419.96
-irene polk	485	14.26	437.52
-mike xylophone	494	36.92	484.65
-calvin allen	499	39.99	469.64
-quinn steinbeck	503	16.62	488.74
-calvin thompson	263	30.87	NULL
-rachel quirinius	263	29.46	NULL
-ulysses garcia	263	31.85	NULL
-mike steinbeck	266	48.57	235.13
-rachel young	275	14.75	245.54
-tom king	278	31.11	246.15
-oscar robinson	283	30.35	234.43
-zach allen	284	1.88	269.25
-bob king	308	27.61	276.89
-ulysses allen	310	22.77	279.65
-fred nixon	317	0.48	315.12
-gabriella robinson	321	0.33	293.39
-bob johnson	325	9.61	302.23
-rachel davidson	335	2.34	334.52
-fred brown	337	5.8	336.67
-wendy ellison	350	20.25	340.39
-zach falkner	391	13.67	388.66
-katie xylophone	410	39.09	404.2
-holly king	413	3.56	392.75
-sarah van buren	417	7.81	403.33
-calvin van buren	430	36.01	390.90999999999997
-katie white	434	33.56	430.44
-oscar quirinius	454	7.03	446.19
-zach young	505	18.19	468.99
-gabriella robinson	506	12.8	472.44
-sarah xylophone	507	16.09	499.97
-rachel thompson	267	46.87	NULL
-gabriella van buren	271	41.04	NULL
-mike steinbeck	284	11.44	NULL
-ethan ovid	293	2.08	246.13
-luke falkner	293	40.67	251.96
-irene nixon	321	24.35	309.56
-mike van buren	327	2.58	324.92
-ulysses robinson	329	26.64	288.33
-quinn laertes	332	10.71	307.65
-tom polk	346	34.03	343.42
-jessica johnson	352	45.71	325.36
-xavier davidson	354	33.9	343.29
-wendy nixon	364	29.42	329.97
-jessica quirinius	375	47.33	329.29
-xavier brown	376	26.17	342.1
-gabriella davidson	383	18.87	353.58
-jessica brown	388	34.09	340.67
-gabriella garcia	391	32.44	364.83
-ethan miller	396	49.07	377.13
-bob garcia	416	7.82	381.90999999999997
-priscilla hernandez	416	29.94	383.56
-holly nixon	419	17.81	369.93
-nick underhill	429	39.54	421.18
-xavier falkner	434	0.88	404.06
-luke robinson	461	44.02	443.19
-bob underhill	465	22.58	425.46
-ulysses king	483	37.98	482.12
-jessica miller	486	26.14	441.98
-bob ovid	493	9.7	470.42
-alice falkner	500	37.85	462.02
-quinn xylophone	267	49.8	NULL
-gabriella thompson	268	17.15	NULL
-calvin xylophone	275	49.32	NULL
-gabriella zipper	279	30.41	229.2
-PREHOOK: query: explain vectorization detail
-select s, lag(s, 3, 'fred') over (partition by f order by b) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, lag(s, 3, 'fred') over (partition by f order by b) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: f (type: float), b (type: bigint)
-              sort order: ++
-              Map-reduce partition columns: f (type: float)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: s (type: string)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [3, 4, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: bigint), KEY.reducesinkkey0 (type: float), VALUE._col5 (type: string)
-          outputColumnNames: _col3, _col4, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col3: bigint, _col4: float, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col3 ASC NULLS FIRST
-                  partition by: _col4
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: lag_window_0
-                        arguments: _col7, 3, 'fred'
-                        name: lag
-                        window function: GenericUDAFLagEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), lag_window_0 (type: string)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, lag(s, 3, 'fred') over (partition by f order by b) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, lag(s, 3, 'fred') over (partition by f order by b) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	lag_window_0
-yuri thompson	fred
-bob ichabod	fred
-luke king	fred
-luke steinbeck	fred
-fred zipper	fred
-quinn miller	fred
-calvin van buren	fred
-holly steinbeck	fred
-david davidson	fred
-calvin thompson	fred
-calvin quirinius	fred
-david ovid	fred
-holly thompson	fred
-nick zipper	fred
-victor steinbeck	fred
-victor robinson	fred
-zach ovid	fred
-ulysses zipper	fred
-luke falkner	fred
-irene thompson	fred
-yuri johnson	fred
-ulysses falkner	fred
-gabriella robinson	fred
-alice robinson	fred
-priscilla xylophone	fred
-david laertes	fred
-mike underhill	fred
-victor van buren	fred
-holly falkner	fred
-priscilla falkner	fred
-ethan ovid	fred
-luke zipper	fred
-mike steinbeck	fred
-calvin white	fred
-alice quirinius	fred
-irene miller	fred
-wendy polk	fred
-nick young	fred
-yuri davidson	fred
-ethan ellison	fred
-zach hernandez	fred
-wendy miller	fred
-katie underhill	fred
-irene zipper	fred
-holly allen	fred
-quinn brown	fred
-calvin ovid	fred
-zach robinson	fred
-nick miller	fred
-mike allen	fred
-yuri van buren	fred
-priscilla young	fred
-zach miller	fred
-victor xylophone	fred
-sarah falkner	fred
-rachel ichabod	fred
-alice robinson	fred
-calvin ovid	fred
-calvin ovid	fred
-luke laertes	fred
-david hernandez	fred
-alice ovid	fred
-luke quirinius	fred
-oscar white	fred
-zach falkner	fred
-rachel thompson	fred
-priscilla king	fred
-xavier polk	fred
-wendy ichabod	fred
-rachel ovid	fred
-wendy allen	fred
-luke brown	fred
-mike brown	fred
-oscar ichabod	fred
-xavier garcia	fred
-yuri brown	fred
-bob xylophone	fred
-luke davidson	fred
-ethan quirinius	fred
-zach davidson	fred
-irene miller	fred
-wendy king	fred
-bob zipper	fred
-sarah thompson	fred
-bob carson	fred
-bob laertes	fred
-xavier allen	fred
-sarah robinson	fred
-david king	fred
-oscar davidson	fred
-victor hernandez	fred
-wendy polk	fred
-david ellison	fred
-ulysses johnson	fred
-jessica ovid	fred
-bob king	fred
-ulysses garcia	fred
-irene falkner	fred
-holly robinson	fred
-yuri white	fred
-PREHOOK: query: explain vectorization detail
-select p_mfgr, avg(p_retailprice) over(partition by p_mfgr, p_type order by p_mfgr) from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, avg(p_retailprice) over(partition by p_mfgr, p_type order by p_mfgr) from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_type (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string), p_type (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_retailprice (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [2, 4, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: string), KEY.reducesinkkey1 (type: string), VALUE._col5 (type: double)
-          outputColumnNames: _col2, _col4, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: string, _col4: string, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST
-                  partition by: _col2, _col4
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col7
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), avg_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr, p_type order by p_mfgr) from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr, p_type order by p_mfgr) from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	avg_window_0
-Manufacturer#1	1753.76
-Manufacturer#1	1632.66
-Manufacturer#1	1602.59
-Manufacturer#1	1173.15
-Manufacturer#1	1173.15
-Manufacturer#1	1414.42
-Manufacturer#2	1800.7
-Manufacturer#2	1690.68
-Manufacturer#2	2031.98
-Manufacturer#2	1698.66
-Manufacturer#2	1701.6
-Manufacturer#3	1922.98
-Manufacturer#3	1410.39
-Manufacturer#3	1671.68
-Manufacturer#3	1190.27
-Manufacturer#3	1337.29
-Manufacturer#4	1844.92
-Manufacturer#4	1375.42
-Manufacturer#4	1620.67
-Manufacturer#4	1206.26
-Manufacturer#4	1290.35
-Manufacturer#5	1018.1
-Manufacturer#5	1464.48
-Manufacturer#5	1789.69
-Manufacturer#5	1788.73
-Manufacturer#5	1611.66
-PREHOOK: query: explain vectorization detail
-select p_mfgr, avg(p_retailprice) over(partition by p_mfgr order by p_type,p_mfgr rows between unbounded preceding and current row) from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, avg(p_retailprice) over(partition by p_mfgr order by p_type,p_mfgr rows between unbounded preceding and current row) from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_type (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_retailprice (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [2, 4, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: string), KEY.reducesinkkey1 (type: string), VALUE._col5 (type: double)
-          outputColumnNames: _col2, _col4, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: string, _col4: string, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST, _col2 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col7
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), avg_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr order by p_type,p_mfgr rows between unbounded preceding and current row) from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr order by p_type,p_mfgr rows between unbounded preceding and current row) from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	avg_window_0
-Manufacturer#1	1753.76
-Manufacturer#1	1693.21
-Manufacturer#1	1663.0033333333333
-Manufacturer#1	1540.54
-Manufacturer#1	1467.062
-Manufacturer#1	1458.2883333333332
-Manufacturer#2	1800.7
-Manufacturer#2	1745.69
-Manufacturer#2	1841.1200000000001
-Manufacturer#2	1805.505
-Manufacturer#2	1784.7240000000002
-Manufacturer#3	1922.98
-Manufacturer#3	1666.685
-Manufacturer#3	1668.3500000000001
-Manufacturer#3	1548.83
-Manufacturer#3	1506.522
-Manufacturer#4	1844.92
-Manufacturer#4	1610.17
-Manufacturer#4	1613.67
-Manufacturer#4	1511.8175
-Manufacturer#4	1467.5240000000001
-Manufacturer#5	1018.1
-Manufacturer#5	1241.29
-Manufacturer#5	1424.0900000000001
-Manufacturer#5	1515.25
-Manufacturer#5	1534.532
-PREHOOK: query: create table t1 (a1 int, b1 string)
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@t1
-POSTHOOK: query: create table t1 (a1 int, b1 string)
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@t1
-PREHOOK: query: create table t2 (a1 int, b1 string)
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@t2
-POSTHOOK: query: create table t2 (a1 int, b1 string)
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@t2
-PREHOOK: query: explain vectorization detail
-from (select sum(i) over (partition by ts order by i), s from over10k) tt insert overwrite table t1 select * insert overwrite table t2 select *
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-from (select sum(i) over (partition by ts order by i), s from over10k) tt insert overwrite table t1 select * insert overwrite table t2 select *
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-2 is a root stage
-  Stage-0 depends on stages: Stage-2
-  Stage-3 depends on stages: Stage-0
-  Stage-1 depends on stages: Stage-2
-  Stage-4 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), i (type: int)
-              sort order: ++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: s (type: string)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 7, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), VALUE._col6 (type: string), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col2, _col7, _col8
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col7: string, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col2
-                        name: sum
-                        window function: GenericUDAFSumLong
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: sum_window_0 (type: bigint), _col7 (type: string)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: UDFToInteger(_col0) (type: int), _col1 (type: string)
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 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
-                      name: default.t1
-              Select Operator
-                expressions: UDFToInteger(_col0) (type: int), _col1 (type: string)
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 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
-                      name: default.t2
-
-  Stage: Stage-0
-    Move Operator
-      tables:
-          replace: true
-          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
-              name: default.t1
-
-  Stage: Stage-3
-    Stats Work
-      Basic Stats Work:
-
-  Stage: Stage-1
-    Move Operator
-      tables:
-          replace: true
-          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
-              name: default.t2
-
-  Stage: Stage-4
-    Stats Work
-      Basic Stats Work:
-
-PREHOOK: query: from (select sum(i) over (partition by ts order by i), s from over10k) tt insert overwrite table t1 select * insert overwrite table t2 select *
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-PREHOOK: Output: default@t1
-PREHOOK: Output: default@t2
-POSTHOOK: query: from (select sum(i) over (partition by ts order by i), s from over10k) tt insert overwrite table t1 select * insert overwrite table t2 select *
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-POSTHOOK: Output: default@t1
-POSTHOOK: Output: default@t2
-POSTHOOK: Lineage: t1.a1 SCRIPT [(over10k)over10k.FieldSchema(name:t, type:tinyint, comment:null), (over10k)over10k.FieldSchema(name:si, type:smallint, comment:null), (over10k)over10k.FieldSchema(name:i, type:int, comment:null), (over10k)over10k.FieldSchema(name:b, type:bigint, comment:null), (over10k)over10k.FieldSchema(name:f, type:float, comment:null), (over10k)over10k.FieldSchema(name:d, type:double, comment:null), (over10k)over10k.FieldSchema(name:bo, type:boolean, comment:null), (over10k)over10k.FieldSchema(name:s, type:string, comment:null), (over10k)over10k.FieldSchema(name:ts, type:timestamp, comment:null), (over10k)over10k.FieldSchema(name:dec, type:decimal(4,2), comment:null), (over10k)over10k.FieldSchema(name:bin, type:binary, comment:null), ]
-POSTHOOK: Lineage: t1.b1 SIMPLE [(over10k)over10k.FieldSchema(name:s, type:string, comment:null), ]
-POSTHOOK: Lineage: t2.a1 SCRIPT [(over10k)over10k.FieldSchema(name:t, type:tinyint, comment:null), (over10k)over10k.FieldSchema(name:si, type:smallint, comment:null), (over10k)over10k.FieldSchema(name:i, type:int, comment:null), (over10k)over10k.FieldSchema(name:b, type:bigint, comment:null), (over10k)over10k.FieldSchema(name:f, type:float, comment:null), (over10k)over10k.FieldSchema(name:d, type:double, comment:null), (over10k)over10k.FieldSchema(name:bo, type:boolean, comment:null), (over10k)over10k.FieldSchema(name:s, type:string, comment:null), (over10k)over10k.FieldSchema(name:ts, type:timestamp, comment:null), (over10k)over10k.FieldSchema(name:dec, type:decimal(4,2), comment:null), (over10k)over10k.FieldSchema(name:bin, type:binary, comment:null), ]
-POSTHOOK: Lineage: t2.b1 SIMPLE [(over10k)over10k.FieldSchema(name:s, type:string, comment:null), ]
-_col0	_col1
-PREHOOK: query: select * from t1 limit 3
-PREHOOK: type: QUERY
-PREHOOK: Input: default@t1
-#### A masked pattern was here ####
-POSTHOOK: query: select * from t1 limit 3
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@t1
-#### A masked pattern was here ####
-t1.a1	t1.b1
-65542	rachel thompson
-131088	oscar brown
-262258	wendy steinbeck
-PREHOOK: query: select * from t2 limit 3
-PREHOOK: type: QUERY
-PREHOOK: Input: default@t2
-#### A masked pattern was here ####
-POSTHOOK: query: select * from t2 limit 3
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@t2
-#### A masked pattern was here ####
-t2.a1	t2.b1
-65542	rachel thompson
-131088	oscar brown
-262258	wendy steinbeck
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) + 50.0 = round(sum(lag(p_retailprice,1,50.0)) over w1 + (last_value(p_retailprice) over w1),2)
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-limit 11
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) + 50.0 = round(sum(lag(p_retailprice,1,50.0)) over w1 + (last_value(p_retailprice) over w1),2)
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-limit 11
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_retailprice (type: double)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: string), VALUE._col4 (type: int), KEY.reducesinkkey1 (type: double)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: sum_window_1
-                        arguments: lag(...)
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: last_value_window_2
-                        arguments: _col7
-                        name: last_value
-                        window function: GenericUDAFLastValueEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Lead/Lag information: lag(...) (type: double)
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col7 (type: double), _col5 (type: int), ((round(sum_window_0, 2) + 50.0) = round((sum_window_1 + last_value_window_2), 2)) (type: boolean)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 11
-                Statistics: Num rows: 11 Data size: 1331 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 11 Data size: 1331 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 11
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) + 50.0 = round(sum(lag(p_retailprice,1,50.0)) over w1 + (last_value(p_retailprice) over w1),2)
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-limit 11
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) + 50.0 = round(sum(lag(p_retailprice,1,50.0)) over w1 + (last_value(p_retailprice) over w1),2)
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-limit 11
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_retailprice	p_size	_c3
-Manufacturer#1	1173.15	2	true
-Manufacturer#1	1173.15	2	true
-Manufacturer#1	1414.42	28	true
-Manufacturer#1	1602.59	6	true
-Manufacturer#1	1632.66	42	true
-Manufacturer#1	1753.76	34	true
-Manufacturer#2	1690.68	14	true
-Manufacturer#2	1698.66	25	true
-Manufacturer#2	1701.6	18	true
-Manufacturer#2	1800.7	40	true
-Manufacturer#2	2031.98	2	true
-PREHOOK: query: select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) = round(sum(lag(p_retailprice,1,0.0)) over w1 + last_value(p_retailprice) over w1 , 2), 
-max(p_retailprice) over w1 - min(p_retailprice) over w1 = last_value(p_retailprice) over w1 - first_value(p_retailprice) over w1
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_retailprice, p_size,
-round(sum(p_retailprice) over w1 , 2) = round(sum(lag(p_retailprice,1,0.0)) over w1 + last_value(p_retailprice) over w1 , 2), 
-max(p_retailprice) over w1 - min(p_retailprice) over w1 = last_value(p_retailprice) over w1 - first_value(p_retailprice) over w1
-from part
-window w1 as (distribute by p_mfgr sort by p_retailprice)
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_retailprice	p_size	_c3	_c4
-Manufacturer#1	1173.15	2	true	true
-Manufacturer#1	1173.15	2	true	true
-Manufacturer#1	1414.42	28	true	true
-Manufacturer#1	1602.59	6	true	true
-Manufacturer#1	1632.66	42	true	true
-Manufacturer#1	1753.76	34	true	true
-Manufacturer#2	1690.68	14	true	true
-Manufacturer#2	1698.66	25	true	true
-Manufacturer#2	1701.6	18	true	true
-Manufacturer#2	1800.7	40	true	true
-Manufacturer#2	2031.98	2	true	true
-Manufacturer#3	1190.27	14	true	true
-Manufacturer#3	1337.29	45	true	true
-Manufacturer#3	1410.39	19	true	true
-Manufacturer#3	1671.68	17	true	true
-Manufacturer#3	1922.98	1	true	true
-Manufacturer#4	1206.26	27	true	true
-Manufacturer#4	1290.35	12	true	true
-Manufacturer#4	1375.42	39	true	true
-Manufacturer#4	1620.67	10	true	true
-Manufacturer#4	1844.92	7	true	true
-Manufacturer#5	1018.1	46	true	true
-Manufacturer#5	1464.48	23	true	true
-Manufacturer#5	1611.66	6	true	true
-Manufacturer#5	1788.73	2	true	true
-Manufacturer#5	1789.69	31	true	true
-PREHOOK: query: select p_mfgr, p_retailprice, p_size,
-rank() over (distribute by p_mfgr sort by p_retailprice) as r,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) as s2,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) -5 as s1
-from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_retailprice, p_size,
-rank() over (distribute by p_mfgr sort by p_retailprice) as r,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) as s2,
-sum(p_retailprice) over (distribute by p_mfgr sort by p_retailprice rows between unbounded preceding and current row) -5 as s1
-from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_retailprice	p_size	r	s2	s1
-Manufacturer#1	1173.15	2	1	1173.15	1168.15
-Manufacturer#1	1173.15	2	1	2346.3	2341.3
-Manufacturer#1	1414.42	28	3	3760.7200000000003	3755.7200000000003
-Manufacturer#1	1602.59	6	4	5363.31	5358.31
-Manufacturer#1	1632.66	42	5	6995.97	6990.97
-Manufacturer#1	1753.76	34	6	8749.73	8744.73
-Manufacturer#2	1690.68	14	1	1690.68	1685.68
-Manufacturer#2	1698.66	25	2	3389.34	3384.34
-Manufacturer#2	1701.6	18	3	5090.9400000000005	5085.9400000000005
-Manufacturer#2	1800.7	40	4	6891.64	6886.64
-Manufacturer#2	2031.98	2	5	8923.62	8918.62
-Manufacturer#3	1190.27	14	1	1190.27	1185.27
-Manufacturer#3	1337.29	45	2	2527.56	2522.56
-Manufacturer#3	1410.39	19	3	3937.95	3932.95
-Manufacturer#3	1671.68	17	4	5609.63	5604.63
-Manufacturer#3	1922.98	1	5	7532.610000000001	7527.610000000001
-Manufacturer#4	1206.26	27	1	1206.26	1201.26
-Manufacturer#4	1290.35	12	2	2496.6099999999997	2491.6099999999997
-Manufacturer#4	1375.42	39	3	3872.0299999999997	3867.0299999999997
-Manufacturer#4	1620.67	10	4	5492.7	5487.7
-Manufacturer#4	1844.92	7	5	7337.62	7332.62
-Manufacturer#5	1018.1	46	1	1018.1	1013.1
-Manufacturer#5	1464.48	23	2	2482.58	2477.58
-Manufacturer#5	1611.66	6	3	4094.24	4089.24
-Manufacturer#5	1788.73	2	4	5882.969999999999	5877.969999999999
-Manufacturer#5	1789.69	31	5	7672.66	7667.66
-PREHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr, p_type order by p_mfgr) from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr, p_type order by p_mfgr) from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	avg_window_0
-Manufacturer#1	1753.76
-Manufacturer#1	1632.66
-Manufacturer#1	1602.59
-Manufacturer#1	1173.15
-Manufacturer#1	1173.15
-Manufacturer#1	1414.42
-Manufacturer#2	1800.7
-Manufacturer#2	1690.68
-Manufacturer#2	2031.98
-Manufacturer#2	1698.66
-Manufacturer#2	1701.6
-Manufacturer#3	1922.98
-Manufacturer#3	1410.39
-Manufacturer#3	1671.68
-Manufacturer#3	1190.27
-Manufacturer#3	1337.29
-Manufacturer#4	1844.92
-Manufacturer#4	1375.42
-Manufacturer#4	1620.67
-Manufacturer#4	1206.26
-Manufacturer#4	1290.35
-Manufacturer#5	1018.1
-Manufacturer#5	1464.48
-Manufacturer#5	1789.69
-Manufacturer#5	1788.73
-Manufacturer#5	1611.66
-PREHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr order by p_type,p_mfgr rows between unbounded preceding and current row) from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, avg(p_retailprice) over(partition by p_mfgr order by p_type,p_mfgr rows between unbounded preceding and current row) from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	avg_window_0
-Manufacturer#1	1753.76
-Manufacturer#1	1693.21
-Manufacturer#1	1663.0033333333333
-Manufacturer#1	1540.54
-Manufacturer#1	1467.062
-Manufacturer#1	1458.2883333333332
-Manufacturer#2	1800.7
-Manufacturer#2	1745.69
-Manufacturer#2	1841.1200000000001
-Manufacturer#2	1805.505
-Manufacturer#2	1784.7240000000002
-Manufacturer#3	1922.98
-Manufacturer#3	1666.685
-Manufacturer#3	1668.3500000000001
-Manufacturer#3	1548.83
-Manufacturer#3	1506.522
-Manufacturer#4	18

<TRUNCATED>

[08/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_gby.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_gby.q.out b/ql/src/test/results/clientpositive/vector_windowing_gby.q.out
deleted file mode 100644
index 7585f26..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_gby.q.out
+++ /dev/null
@@ -1,245 +0,0 @@
-PREHOOK: query: explain vectorization detail
-       select rank() over (order by return_ratio) as return_rank from
-       (select sum(wr.cint)/sum(ws.c_int)  as return_ratio
-                 from cbo_t3  ws join alltypesorc wr on ws.value = wr.cstring1
-                  group by ws.c_boolean ) in_web
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-       select rank() over (order by return_ratio) as return_rank from
-       (select sum(wr.cint)/sum(ws.c_int)  as return_ratio
-                 from cbo_t3  ws join alltypesorc wr on ws.value = wr.cstring1
-                  group by ws.c_boolean ) in_web
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-3 depends on stages: Stage-2
-  Stage-0 depends on stages: Stage-3
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: ws
-            Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: value is not null (type: boolean)
-              Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: value (type: string), c_int (type: int), c_boolean (type: boolean)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 20 Data size: 262 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: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: int), _col2 (type: boolean)
-          TableScan
-            alias: wr
-            Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: cstring1 is not null (type: boolean)
-              Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: cint (type: int), cstring1 (type: string)
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col1 (type: string)
-                  sort order: +
-                  Map-reduce partition columns: _col1 (type: string)
-                  Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col0 (type: int)
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: Vectorized map work only works with 1 TableScanOperator IS false
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Join Operator
-          condition map:
-               Inner Join 0 to 1
-          keys:
-            0 _col0 (type: string)
-            1 _col1 (type: string)
-          outputColumnNames: _col1, _col2, _col3
-          Statistics: Num rows: 13516 Data size: 2906160 Basic stats: COMPLETE Column stats: NONE
-          Group By Operator
-            aggregations: sum(_col3), sum(_col1)
-            keys: _col2 (type: boolean)
-            mode: hash
-            outputColumnNames: _col0, _col1, _col2
-            Statistics: Num rows: 13516 Data size: 2906160 Basic stats: COMPLETE Column stats: NONE
-            File Output Operator
-              compressed: false
-              table:
-                  input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                  output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                  serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2]
-                projectedColumns: [_col0:boolean, _col1:bigint, _col2:bigint]
-            Reduce Output Operator
-              key expressions: _col0 (type: boolean)
-              sort order: +
-              Map-reduce partition columns: _col0 (type: boolean)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 13516 Data size: 2906160 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: bigint), _col2 (type: bigint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 3
-              includeColumns: [0, 1, 2]
-              dataColumns: _col0:boolean, _col1:bigint, _col2:bigint
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: sum(VALUE._col0), sum(VALUE._col1)
-          keys: KEY._col0 (type: boolean)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2
-          Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-          Select Operator
-            expressions: _col1 (type: bigint), _col2 (type: bigint)
-            outputColumnNames: _col1, _col2
-            Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-            File Output Operator
-              compressed: false
-              table:
-                  input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                  output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                  serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-3
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1]
-                projectedColumns: [_col1:bigint, _col2:bigint]
-            Reduce Output Operator
-              key expressions: 0 (type: int), (UDFToDouble(_col1) / UDFToDouble(_col2)) (type: double)
-              sort order: ++
-              Map-reduce partition columns: 0 (type: int)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: bigint), _col2 (type: bigint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 2
-              includeColumns: [0, 1]
-              dataColumns: _col1:bigint, _col2:bigint
-              partitionColumnCount: 0
-              scratchColumnTypeNames: [bigint, double, double, double, bigint]
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col1 (type: bigint), VALUE._col2 (type: bigint)
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: bigint, _col2: bigint
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: (UDFToDouble(_col1) / UDFToDouble(_col2)) ASC NULLS FIRST
-                  partition by: 0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: (UDFToDouble(_col1) / UDFToDouble(_col2))
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: rank_window_0 (type: int)
-              outputColumnNames: _col0
-              Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select rank() over (order by return_ratio) as return_rank from
-       (select sum(wr.cint)/sum(ws.c_int)  as return_ratio
-                 from cbo_t3  ws join alltypesorc wr on ws.value = wr.cstring1
-                  group by ws.c_boolean ) in_web
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypesorc
-PREHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-POSTHOOK: query: select rank() over (order by return_ratio) as return_rank from
-       (select sum(wr.cint)/sum(ws.c_int)  as return_ratio
-                 from cbo_t3  ws join alltypesorc wr on ws.value = wr.cstring1
-                  group by ws.c_boolean ) in_web
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypesorc
-POSTHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-return_rank

http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_gby2.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_gby2.q.out b/ql/src/test/results/clientpositive/vector_windowing_gby2.q.out
deleted file mode 100644
index ba3f374..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_gby2.q.out
+++ /dev/null
@@ -1,1007 +0,0 @@
-PREHOOK: query: explain vectorization detail
-select rank() over (order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by ws.key
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select rank() over (order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by ws.key
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-0 depends on stages: Stage-2
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: ws
-            Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4]
-                projectedColumns: [key:string, value:string, c_int:int, c_float:float, c_boolean:boolean]
-            Select Operator
-              expressions: key (type: string), c_int (type: int)
-              outputColumnNames: key, c_int
-              Select Vectorization:
-                  className: VectorSelectOperator
-                  native: true
-                  projectedOutputColumnNums: [0, 2]
-              Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: sum(c_int)
-                Group By Vectorization:
-                    aggregators: VectorUDAFSumLong(col 2:int) -> bigint
-                    className: VectorGroupByOperator
-                    groupByMode: HASH
-                    keyExpressions: col 0:string
-                    native: false
-                    vectorProcessingMode: HASH
-                    projectedOutputColumnNums: [0]
-                keys: key (type: string)
-                mode: hash
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: string)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: string)
-                  Reduce Sink Vectorization:
-                      className: VectorReduceSinkOperator
-                      native: false
-                      nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                      nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-                  Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: bigint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 5
-              includeColumns: [0, 2]
-              dataColumns: key:string, value:string, c_int:int, c_float:float, c_boolean:boolean
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: sum(VALUE._col0)
-          keys: KEY._col0 (type: string)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          Select Operator
-            expressions: _col1 (type: bigint)
-            outputColumnNames: _col1
-            Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-            File Output Operator
-              compressed: false
-              table:
-                  input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                  output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                  serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0]
-                projectedColumns: [_col1:bigint]
-            Reduce Output Operator
-              key expressions: 0 (type: int), _col1 (type: bigint)
-              sort order: ++
-              Map-reduce partition columns: 0 (type: int)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 1
-              includeColumns: [0]
-              dataColumns: _col1:bigint
-              partitionColumnCount: 0
-              scratchColumnTypeNames: [bigint, bigint]
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: bigint)
-          outputColumnNames: _col1
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: bigint
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: 0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: rank_window_0 (type: int)
-              outputColumnNames: _col0
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select rank() over (order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by ws.key
-PREHOOK: type: QUERY
-PREHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-POSTHOOK: query: select rank() over (order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by ws.key
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-return_rank
-1
-2
-2
-2
-5
-5
-7
-PREHOOK: query: explain vectorization detail
-select avg(cast(ws.key as int)) over (partition by min(ws.value) order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by cast(ws.key as int)
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select avg(cast(ws.key as int)) over (partition by min(ws.value) order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by cast(ws.key as int)
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-0 depends on stages: Stage-2
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: ws
-            Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4]
-                projectedColumns: [key:string, value:string, c_int:int, c_float:float, c_boolean:boolean]
-            Select Operator
-              expressions: UDFToInteger(key) (type: int), value (type: string), c_int (type: int)
-              outputColumnNames: _col0, _col1, _col2
-              Select Vectorization:
-                  className: VectorSelectOperator
-                  native: true
-                  projectedOutputColumnNums: [5, 1, 2]
-                  selectExpressions: CastStringToLong(col 0:string) -> 5:int
-              Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: min(_col1), sum(_col2)
-                Group By Vectorization:
-                    aggregators: VectorUDAFMinString(col 1:string) -> string, VectorUDAFSumLong(col 2:int) -> bigint
-                    className: VectorGroupByOperator
-                    groupByMode: HASH
-                    keyExpressions: col 5:int
-                    native: false
-                    vectorProcessingMode: HASH
-                    projectedOutputColumnNums: [0, 1]
-                keys: _col0 (type: int)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: int)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: int)
-                  Reduce Sink Vectorization:
-                      className: VectorReduceSinkOperator
-                      native: false
-                      nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                      nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-                  Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: string), _col2 (type: bigint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 5
-              includeColumns: [0, 1, 2]
-              dataColumns: key:string, value:string, c_int:int, c_float:float, c_boolean:boolean
-              partitionColumnCount: 0
-              scratchColumnTypeNames: [bigint]
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: min(VALUE._col0), sum(VALUE._col1)
-          keys: KEY._col0 (type: int)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2]
-                projectedColumns: [_col0:int, _col1:string, _col2:bigint]
-            Reduce Output Operator
-              key expressions: _col1 (type: string), _col2 (type: bigint)
-              sort order: ++
-              Map-reduce partition columns: _col1 (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col0 (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 3
-              includeColumns: [0, 1, 2]
-              dataColumns: _col0:int, _col1:string, _col2:bigint
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col0 (type: int), KEY.reducesinkkey0 (type: string), KEY.reducesinkkey1 (type: bigint)
-          outputColumnNames: _col0, _col1, _col2
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: int, _col1: string, _col2: bigint
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST
-                  partition by: _col1
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col0
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: avg_window_0 (type: double)
-              outputColumnNames: _col0
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select avg(cast(ws.key as int)) over (partition by min(ws.value) order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by cast(ws.key as int)
-PREHOOK: type: QUERY
-PREHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-POSTHOOK: query: select avg(cast(ws.key as int)) over (partition by min(ws.value) order by sum(ws.c_int)) as return_rank
-from cbo_t3 ws
-group by cast(ws.key as int)
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-return_rank
-NULL
-1.0
-2.0
-3.0
-PREHOOK: query: explain vectorization detail
-select rank () over(partition by key order by sum(c_int - c_float) desc) ,
-dense_rank () over(partition by lower(value) order by sum(c_float/c_int) asc),
-percent_rank () over(partition by max(c_int) order by sum((c_float/c_int) - c_int) asc)
-from cbo_t3
-group by key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select rank () over(partition by key order by sum(c_int - c_float) desc) ,
-dense_rank () over(partition by lower(value) order by sum(c_float/c_int) asc),
-percent_rank () over(partition by max(c_int) order by sum((c_float/c_int) - c_int) asc)
-from cbo_t3
-group by key, value
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-3 depends on stages: Stage-2
-  Stage-4 depends on stages: Stage-3
-  Stage-0 depends on stages: Stage-4
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: cbo_t3
-            Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4]
-                projectedColumns: [key:string, value:string, c_int:int, c_float:float, c_boolean:boolean]
-            Select Operator
-              expressions: key (type: string), value (type: string), (UDFToFloat(c_int) - c_float) (type: float), (UDFToDouble(c_float) / UDFToDouble(c_int)) (type: double), c_int (type: int), ((UDFToDouble(c_float) / UDFToDouble(c_int)) - UDFToDouble(c_int)) (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-              Select Vectorization:
-                  className: VectorSelectOperator
-                  native: true
-                  projectedOutputColumnNums: [0, 1, 6, 7, 2, 9]
-                  selectExpressions: DoubleColSubtractDoubleColumn(col 5:float, col 3:float)(children: CastLongToFloatViaLongToDouble(col 2:int) -> 5:float) -> 6:float, DoubleColDivideDoubleColumn(col 3:double, col 5:double)(children: col 3:float, CastLongToDouble(col 2:int) -> 5:double) -> 7:double, DoubleColSubtractDoubleColumn(col 8:double, col 5:double)(children: DoubleColDivideDoubleColumn(col 3:double, col 5:double)(children: col 3:float, CastLongToDouble(col 2:int) -> 5:double) -> 8:double, CastLongToDouble(col 2:int) -> 5:double) -> 9:double
-              Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: sum(_col2), sum(_col3), max(_col4), sum(_col5)
-                Group By Vectorization:
-                    aggregators: VectorUDAFSumDouble(col 6:float) -> double, VectorUDAFSumDouble(col 7:double) -> double, VectorUDAFMaxLong(col 2:int) -> int, VectorUDAFSumDouble(col 9:double) -> double
-                    className: VectorGroupByOperator
-                    groupByMode: HASH
-                    keyExpressions: col 0:string, col 1:string
-                    native: false
-                    vectorProcessingMode: HASH
-                    projectedOutputColumnNums: [0, 1, 2, 3]
-                keys: _col0 (type: string), _col1 (type: string)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-                Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string)
-                  sort order: ++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string)
-                  Reduce Sink Vectorization:
-                      className: VectorReduceSinkOperator
-                      native: false
-                      nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                      nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-                  Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col2 (type: double), _col3 (type: double), _col4 (type: int), _col5 (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 5
-              includeColumns: [0, 1, 2, 3]
-              dataColumns: key:string, value:string, c_int:int, c_float:float, c_boolean:boolean
-              partitionColumnCount: 0
-              scratchColumnTypeNames: [double, double, double, double, double]
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: sum(VALUE._col0), sum(VALUE._col1), max(VALUE._col2), sum(VALUE._col3)
-          keys: KEY._col0 (type: string), KEY._col1 (type: string)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5]
-                projectedColumns: [_col0:string, _col1:string, _col2:double, _col3:double, _col4:int, _col5:double]
-            Reduce Output Operator
-              key expressions: _col0 (type: string), _col2 (type: double)
-              sort order: +-
-              Map-reduce partition columns: _col0 (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: string), _col3 (type: double), _col4 (type: int), _col5 (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 6
-              includeColumns: [0, 1, 2, 3, 4, 5]
-              dataColumns: _col0:string, _col1:string, _col2:double, _col3:double, _col4:int, _col5:double
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: string), VALUE._col0 (type: string), KEY.reducesinkkey1 (type: double), VALUE._col1 (type: double), VALUE._col2 (type: int), VALUE._col3 (type: double)
-          outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: string, _col1: string, _col2: double, _col3: double, _col4: int, _col5: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 DESC NULLS LAST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col2
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: rank_window_0 (type: int), _col1 (type: string), _col3 (type: double), _col4 (type: int), _col5 (type: double)
-              outputColumnNames: rank_window_0, _col1, _col3, _col4, _col5
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-3
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4]
-                projectedColumns: [rank_window_0:int, _col1:string, _col3:double, _col4:int, _col5:double]
-            Reduce Output Operator
-              key expressions: lower(_col1) (type: string), _col3 (type: double)
-              sort order: ++
-              Map-reduce partition columns: lower(_col1) (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              value expressions: rank_window_0 (type: int), _col1 (type: string), _col4 (type: int), _col5 (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 5
-              includeColumns: [0, 1, 2, 3, 4]
-              dataColumns: rank_window_0:int, _col1:string, _col3:double, _col4:int, _col5:double
-              partitionColumnCount: 0
-              scratchColumnTypeNames: [string, string]
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col0 (type: int), VALUE._col2 (type: string), KEY.reducesinkkey1 (type: double), VALUE._col4 (type: int), VALUE._col5 (type: double)
-          outputColumnNames: _col0, _col2, _col4, _col5, _col6
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: int, _col2: string, _col4: double, _col5: int, _col6: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST
-                  partition by: lower(_col2)
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col4
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: dense_rank_window_1 (type: int), _col0 (type: int), _col5 (type: int), _col6 (type: double)
-              outputColumnNames: dense_rank_window_1, _col0, _col5, _col6
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-4
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3]
-                projectedColumns: [dense_rank_window_1:int, _col0:int, _col5:int, _col6:double]
-            Reduce Output Operator
-              key expressions: _col5 (type: int), _col6 (type: double)
-              sort order: ++
-              Map-reduce partition columns: _col5 (type: int)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              value expressions: dense_rank_window_1 (type: int), _col0 (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 4
-              includeColumns: [0, 1, 2, 3]
-              dataColumns: dense_rank_window_1:int, _col0:int, _col5:int, _col6:double
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col0 (type: int), VALUE._col1 (type: int), KEY.reducesinkkey0 (type: int), KEY.reducesinkkey1 (type: double)
-          outputColumnNames: _col0, _col1, _col6, _col7
-          Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: int, _col1: int, _col6: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST
-                  partition by: _col6
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: percent_rank_window_2
-                        arguments: _col7
-                        name: percent_rank
-                        window function: GenericUDAFPercentRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col1 (type: int), _col0 (type: int), percent_rank_window_2 (type: double)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 10 Data size: 131 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select rank () over(partition by key order by sum(c_int - c_float) desc) ,
-dense_rank () over(partition by lower(value) order by sum(c_float/c_int) asc),
-percent_rank () over(partition by max(c_int) order by sum((c_float/c_int) - c_int) asc)
-from cbo_t3
-group by key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-POSTHOOK: query: select rank () over(partition by key order by sum(c_int - c_float) desc) ,
-dense_rank () over(partition by lower(value) order by sum(c_float/c_int) asc),
-percent_rank () over(partition by max(c_int) order by sum((c_float/c_int) - c_int) asc)
-from cbo_t3
-group by key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-_c0	_c1	_c2
-1	1	0.0
-1	1	0.0
-1	1	0.0
-1	1	0.0
-1	1	0.0
-1	1	0.0
-1	1	0.0
-PREHOOK: query: explain vectorization detail
-select rank() over (order by sum(wr.cint)/sum(ws.c_int)) as return_rank
-from cbo_t3 ws join alltypesorc wr on ws.value = wr.cstring1
-group by ws.c_boolean
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select rank() over (order by sum(wr.cint)/sum(ws.c_int)) as return_rank
-from cbo_t3 ws join alltypesorc wr on ws.value = wr.cstring1
-group by ws.c_boolean
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-3 depends on stages: Stage-2
-  Stage-0 depends on stages: Stage-3
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: ws
-            Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: value is not null (type: boolean)
-              Statistics: Num rows: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: value (type: string), c_int (type: int), c_boolean (type: boolean)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 20 Data size: 262 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: 20 Data size: 262 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: int), _col2 (type: boolean)
-          TableScan
-            alias: wr
-            Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: cstring1 is not null (type: boolean)
-              Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: cint (type: int), cstring1 (type: string)
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col1 (type: string)
-                  sort order: +
-                  Map-reduce partition columns: _col1 (type: string)
-                  Statistics: Num rows: 12288 Data size: 2641964 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col0 (type: int)
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: Vectorized map work only works with 1 TableScanOperator IS false
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Join Operator
-          condition map:
-               Inner Join 0 to 1
-          keys:
-            0 _col0 (type: string)
-            1 _col1 (type: string)
-          outputColumnNames: _col1, _col2, _col3
-          Statistics: Num rows: 13516 Data size: 2906160 Basic stats: COMPLETE Column stats: NONE
-          Group By Operator
-            aggregations: sum(_col3), sum(_col1)
-            keys: _col2 (type: boolean)
-            mode: hash
-            outputColumnNames: _col0, _col1, _col2
-            Statistics: Num rows: 13516 Data size: 2906160 Basic stats: COMPLETE Column stats: NONE
-            File Output Operator
-              compressed: false
-              table:
-                  input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                  output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                  serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2]
-                projectedColumns: [_col0:boolean, _col1:bigint, _col2:bigint]
-            Reduce Output Operator
-              key expressions: _col0 (type: boolean)
-              sort order: +
-              Map-reduce partition columns: _col0 (type: boolean)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 13516 Data size: 2906160 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: bigint), _col2 (type: bigint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 3
-              includeColumns: [0, 1, 2]
-              dataColumns: _col0:boolean, _col1:bigint, _col2:bigint
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: sum(VALUE._col0), sum(VALUE._col1)
-          keys: KEY._col0 (type: boolean)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2
-          Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-          Select Operator
-            expressions: _col1 (type: bigint), _col2 (type: bigint)
-            outputColumnNames: _col1, _col2
-            Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-            File Output Operator
-              compressed: false
-              table:
-                  input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                  output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                  serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-3
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1]
-                projectedColumns: [_col1:bigint, _col2:bigint]
-            Reduce Output Operator
-              key expressions: 0 (type: int), (UDFToDouble(_col1) / UDFToDouble(_col2)) (type: double)
-              sort order: ++
-              Map-reduce partition columns: 0 (type: int)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: bigint), _col2 (type: bigint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 2
-              includeColumns: [0, 1]
-              dataColumns: _col1:bigint, _col2:bigint
-              partitionColumnCount: 0
-              scratchColumnTypeNames: [bigint, double, double, double, bigint]
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col1 (type: bigint), VALUE._col2 (type: bigint)
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: bigint, _col2: bigint
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: (UDFToDouble(_col1) / UDFToDouble(_col2)) ASC NULLS FIRST
-                  partition by: 0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: (UDFToDouble(_col1) / UDFToDouble(_col2))
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: rank_window_0 (type: int)
-              outputColumnNames: _col0
-              Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 6758 Data size: 1453080 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select rank() over (order by sum(wr.cint)/sum(ws.c_int)) as return_rank
-from cbo_t3 ws join alltypesorc wr on ws.value = wr.cstring1
-group by ws.c_boolean
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypesorc
-PREHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-POSTHOOK: query: select rank() over (order by sum(wr.cint)/sum(ws.c_int)) as return_rank
-from cbo_t3 ws join alltypesorc wr on ws.value = wr.cstring1
-group by ws.c_boolean
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypesorc
-POSTHOOK: Input: default@cbo_t3
-#### A masked pattern was here ####
-return_rank


[12/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
HIVE-18067 : Remove extraneous golden files


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

Branch: refs/heads/master
Commit: afa9ffee8ae308c39ece2fa76897a304acd1c1ca
Parents: de78ddb
Author: Ashutosh Chauhan <ha...@apache.org>
Authored: Tue Nov 14 21:51:38 2017 -0800
Committer: Ashutosh Chauhan <ha...@apache.org>
Committed: Tue Nov 14 21:51:38 2017 -0800

----------------------------------------------------------------------
 .../clientpositive/insert_column_mixcase.q.out  |    18 -
 .../clientpositive/llap/vector_decimal_6b.q.out |  1099 --
 .../llap/vectorized_distinct_gby.q.out          |   344 -
 .../test/results/clientpositive/mm_exim.q.out   |   557 -
 .../spark/stats_partscan_1_23.q.out             |   188 -
 .../clientpositive/stats_partscan_1_23.q.out    |   191 -
 .../clientpositive/vector_windowing.q.out       |  9276 -------------
 .../vector_windowing_expressions.q.out          |  2077 ---
 .../clientpositive/vector_windowing_gby.q.out   |   245 -
 .../clientpositive/vector_windowing_gby2.q.out  |  1007 --
 .../vector_windowing_multipartitioning.q.out    | 11320 ---------------
 .../vector_windowing_order_null.q.out           |  1013 --
 .../vector_windowing_range_multiorder.q.out     | 12270 -----------------
 .../clientpositive/vector_windowing_rank.q.out  |  1564 ---
 .../vector_windowing_streaming.q.out            |   849 --
 .../vector_windowing_windowspec.q.out           |  2093 ---
 .../vector_windowing_windowspec4.q.out          |   214 -
 .../vectorization_input_format_excludes.q.out   |  1340 --
 18 files changed, 45665 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/insert_column_mixcase.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/insert_column_mixcase.q.out b/ql/src/test/results/clientpositive/insert_column_mixcase.q.out
deleted file mode 100644
index 9395e89..0000000
--- a/ql/src/test/results/clientpositive/insert_column_mixcase.q.out
+++ /dev/null
@@ -1,18 +0,0 @@
-PREHOOK: query: DROP TABLE IF EXISTS insert_camel_case
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: DROP TABLE IF EXISTS insert_camel_case
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: CREATE TABLE insert_camel_case (key int, value string)
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@insert_camel_case
-POSTHOOK: query: CREATE TABLE insert_camel_case (key int, value string)
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@insert_camel_case
-PREHOOK: query: INSERT INTO insert_camel_case(KeY, VALuE) SELECT * FROM src LIMIT 100
-PREHOOK: type: QUERY
-PREHOOK: Output: default@insert_camel_case
-POSTHOOK: query: INSERT INTO insert_camel_case(KeY, VALuE) SELECT * FROM src LIMIT 100
-POSTHOOK: type: QUERY
-POSTHOOK: Output: default@insert_camel_case

http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/llap/vector_decimal_6b.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vector_decimal_6b.q.out b/ql/src/test/results/clientpositive/llap/vector_decimal_6b.q.out
deleted file mode 100644
index 0327689..0000000
--- a/ql/src/test/results/clientpositive/llap/vector_decimal_6b.q.out
+++ /dev/null
@@ -1,1099 +0,0 @@
-PREHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_1_txt
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_1_txt
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_1
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_1
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_2_txt
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_2_txt
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_2
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_2
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_3_txt
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_3_txt
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_3
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: DROP TABLE IF EXISTS DECIMAL_6_3
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: CREATE TABLE DECIMAL_6_1_txt(key decimal(10,5), value int)
-ROW FORMAT DELIMITED
-   FIELDS TERMINATED BY ' '
-STORED AS TEXTFILE
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@DECIMAL_6_1_txt
-POSTHOOK: query: CREATE TABLE DECIMAL_6_1_txt(key decimal(10,5), value int)
-ROW FORMAT DELIMITED
-   FIELDS TERMINATED BY ' '
-STORED AS TEXTFILE
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@DECIMAL_6_1_txt
-PREHOOK: query: CREATE TABLE DECIMAL_6_2_txt(key decimal(17,5), value int)
-ROW FORMAT DELIMITED
-   FIELDS TERMINATED BY ' '
-STORED AS TEXTFILE
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@DECIMAL_6_2_txt
-POSTHOOK: query: CREATE TABLE DECIMAL_6_2_txt(key decimal(17,5), value int)
-ROW FORMAT DELIMITED
-   FIELDS TERMINATED BY ' '
-STORED AS TEXTFILE
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@DECIMAL_6_2_txt
-PREHOOK: query: CREATE TABLE DECIMAL_6_3_txt(key decimal(10,5), value int, key_big decimal(20,5))
-ROW FORMAT DELIMITED
-   FIELDS TERMINATED BY ' '
-STORED AS TEXTFILE
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@DECIMAL_6_3_txt
-POSTHOOK: query: CREATE TABLE DECIMAL_6_3_txt(key decimal(10,5), value int, key_big decimal(20,5))
-ROW FORMAT DELIMITED
-   FIELDS TERMINATED BY ' '
-STORED AS TEXTFILE
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@DECIMAL_6_3_txt
-PREHOOK: query: LOAD DATA LOCAL INPATH '../../data/files/kv9.txt' INTO TABLE DECIMAL_6_1_txt
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@decimal_6_1_txt
-POSTHOOK: query: LOAD DATA LOCAL INPATH '../../data/files/kv9.txt' INTO TABLE DECIMAL_6_1_txt
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@decimal_6_1_txt
-PREHOOK: query: LOAD DATA LOCAL INPATH '../../data/files/kv9.txt' INTO TABLE DECIMAL_6_2_txt
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@decimal_6_2_txt
-POSTHOOK: query: LOAD DATA LOCAL INPATH '../../data/files/kv9.txt' INTO TABLE DECIMAL_6_2_txt
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@decimal_6_2_txt
-PREHOOK: query: INSERT INTO DECIMAL_6_3_txt SELECT key, value, key FROM DECIMAL_6_1_txt
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_1_txt
-PREHOOK: Output: default@decimal_6_3_txt
-POSTHOOK: query: INSERT INTO DECIMAL_6_3_txt SELECT key, value, key FROM DECIMAL_6_1_txt
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_1_txt
-POSTHOOK: Output: default@decimal_6_3_txt
-POSTHOOK: Lineage: decimal_6_3_txt.key SIMPLE [(decimal_6_1_txt)decimal_6_1_txt.FieldSchema(name:key, type:decimal(10,5), comment:null), ]
-POSTHOOK: Lineage: decimal_6_3_txt.key_big EXPRESSION [(decimal_6_1_txt)decimal_6_1_txt.FieldSchema(name:key, type:decimal(10,5), comment:null), ]
-POSTHOOK: Lineage: decimal_6_3_txt.value SIMPLE [(decimal_6_1_txt)decimal_6_1_txt.FieldSchema(name:value, type:int, comment:null), ]
-PREHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT * FROM DECIMAL_6_1_txt where key < 200BD ORDER BY key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT * FROM DECIMAL_6_1_txt where key < 200BD ORDER BY key, value
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: decimal_6_1_txt
-                  Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      projectedColumnNums: [0, 1]
-                      projectedColumns: [key:decimal(10,5), value:int]
-                  Filter Operator
-                    Filter Vectorization:
-                        className: VectorFilterOperator
-                        native: true
-                        predicateExpression: FilterDecimalColLessDecimalScalar(col 0:decimal(10,5), val 200)
-                    predicate: (key < 200) (type: boolean)
-                    Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                    Select Operator
-                      expressions: key (type: decimal(10,5)), value (type: int)
-                      outputColumnNames: _col0, _col1
-                      Select Vectorization:
-                          className: VectorSelectOperator
-                          native: true
-                          projectedOutputColumnNums: [0, 1]
-                      Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                      Reduce Output Operator
-                        key expressions: _col0 (type: decimal(10,5)), _col1 (type: int)
-                        sort order: ++
-                        Reduce Sink Vectorization:
-                            className: VectorReduceSinkObjectHashOperator
-                            keyColumnNums: [0, 1]
-                            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: []
-                        Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-            Execution mode: vectorized, llap
-            LLAP IO: no inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-                vectorizationSupportRemovedReasons: [DECIMAL_64 removed because LLAP is enabled]
-                vectorizationSupport: []
-                inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-                allNative: true
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 2
-                    includeColumns: [0, 1]
-                    dataColumns: key:decimal(10,5), value:int
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: aa
-                reduceColumnSortOrder: ++
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 2
-                    dataColumns: KEY.reducesinkkey0:decimal(10,5), KEY.reducesinkkey1:int
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Select Operator
-                expressions: KEY.reducesinkkey0 (type: decimal(10,5)), KEY.reducesinkkey1 (type: int)
-                outputColumnNames: _col0, _col1
-                Select Vectorization:
-                    className: VectorSelectOperator
-                    native: true
-                    projectedOutputColumnNums: [0, 1]
-                Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: SELECT * FROM DECIMAL_6_1_txt where key < 200BD ORDER BY key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_1_txt
-#### A masked pattern was here ####
-POSTHOOK: query: SELECT * FROM DECIMAL_6_1_txt where key < 200BD ORDER BY key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_1_txt
-#### A masked pattern was here ####
--4400.00000	4400
--1255.49000	-1255
--1.12200	-11
--1.12000	-1
--0.33300	0
--0.30000	0
-0.00000	0
-0.00000	0
-0.33300	0
-1.00000	1
-1.00000	1
-1.12000	1
-1.12200	1
-2.00000	2
-3.14000	3
-3.14000	3
-3.14000	4
-10.00000	10
-10.73433	5
-124.00000	124
-125.20000	125
-PREHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT * FROM DECIMAL_6_1_txt where key - 100BD < 200BD ORDER BY key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT * FROM DECIMAL_6_1_txt where key - 100BD < 200BD ORDER BY key, value
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: decimal_6_1_txt
-                  Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      projectedColumnNums: [0, 1]
-                      projectedColumns: [key:decimal(10,5), value:int]
-                  Filter Operator
-                    Filter Vectorization:
-                        className: VectorFilterOperator
-                        native: true
-                        predicateExpression: FilterDecimalColLessDecimalScalar(col 2:decimal(11,5), val 200)(children: DecimalColSubtractDecimalScalar(col 0:decimal(10,5), val 100) -> 2:decimal(11,5))
-                    predicate: ((key - 100) < 200) (type: boolean)
-                    Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                    Select Operator
-                      expressions: key (type: decimal(10,5)), value (type: int)
-                      outputColumnNames: _col0, _col1
-                      Select Vectorization:
-                          className: VectorSelectOperator
-                          native: true
-                          projectedOutputColumnNums: [0, 1]
-                      Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                      Reduce Output Operator
-                        key expressions: _col0 (type: decimal(10,5)), _col1 (type: int)
-                        sort order: ++
-                        Reduce Sink Vectorization:
-                            className: VectorReduceSinkObjectHashOperator
-                            keyColumnNums: [0, 1]
-                            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: []
-                        Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-            Execution mode: vectorized, llap
-            LLAP IO: no inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-                vectorizationSupportRemovedReasons: [DECIMAL_64 removed because LLAP is enabled]
-                vectorizationSupport: []
-                inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-                allNative: true
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 2
-                    includeColumns: [0, 1]
-                    dataColumns: key:decimal(10,5), value:int
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: [decimal(11,5)]
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: aa
-                reduceColumnSortOrder: ++
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 2
-                    dataColumns: KEY.reducesinkkey0:decimal(10,5), KEY.reducesinkkey1:int
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Select Operator
-                expressions: KEY.reducesinkkey0 (type: decimal(10,5)), KEY.reducesinkkey1 (type: int)
-                outputColumnNames: _col0, _col1
-                Select Vectorization:
-                    className: VectorSelectOperator
-                    native: true
-                    projectedOutputColumnNums: [0, 1]
-                Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: SELECT * FROM DECIMAL_6_1_txt where key - 100BD < 200BD ORDER BY key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_1_txt
-#### A masked pattern was here ####
-POSTHOOK: query: SELECT * FROM DECIMAL_6_1_txt where key - 100BD < 200BD ORDER BY key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_1_txt
-#### A masked pattern was here ####
--4400.00000	4400
--1255.49000	-1255
--1.12200	-11
--1.12000	-1
--0.33300	0
--0.30000	0
-0.00000	0
-0.00000	0
-0.33300	0
-1.00000	1
-1.00000	1
-1.12000	1
-1.12200	1
-2.00000	2
-3.14000	3
-3.14000	3
-3.14000	4
-10.00000	10
-10.73433	5
-124.00000	124
-125.20000	125
-PREHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key - 100BD FROM DECIMAL_6_1_txt ORDER BY key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key - 100BD FROM DECIMAL_6_1_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: decimal_6_1_txt
-                  Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      projectedColumnNums: [0, 1]
-                      projectedColumns: [key:decimal(10,5), value:int]
-                  Select Operator
-                    expressions: key (type: decimal(10,5)), value (type: int), (key - 100) (type: decimal(11,5))
-                    outputColumnNames: _col0, _col1, _col2
-                    Select Vectorization:
-                        className: VectorSelectOperator
-                        native: true
-                        projectedOutputColumnNums: [0, 1, 2]
-                        selectExpressions: DecimalColSubtractDecimalScalar(col 0:decimal(10,5), val 100) -> 2:decimal(11,5)
-                    Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                    Reduce Output Operator
-                      key expressions: _col0 (type: decimal(10,5)), _col1 (type: int)
-                      sort order: ++
-                      Reduce Sink Vectorization:
-                          className: VectorReduceSinkObjectHashOperator
-                          keyColumnNums: [0, 1]
-                          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: [2]
-                      Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                      value expressions: _col2 (type: decimal(11,5))
-            Execution mode: vectorized, llap
-            LLAP IO: no inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-                vectorizationSupportRemovedReasons: [DECIMAL_64 removed because LLAP is enabled]
-                vectorizationSupport: []
-                inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-                allNative: true
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 2
-                    includeColumns: [0, 1]
-                    dataColumns: key:decimal(10,5), value:int
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: [decimal(11,5)]
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: aa
-                reduceColumnSortOrder: ++
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 3
-                    dataColumns: KEY.reducesinkkey0:decimal(10,5), KEY.reducesinkkey1:int, VALUE._col0:decimal(11,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Select Operator
-                expressions: KEY.reducesinkkey0 (type: decimal(10,5)), KEY.reducesinkkey1 (type: int), VALUE._col0 (type: decimal(11,5))
-                outputColumnNames: _col0, _col1, _col2
-                Select Vectorization:
-                    className: VectorSelectOperator
-                    native: true
-                    projectedOutputColumnNums: [0, 1, 2]
-                Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 1 Data size: 116 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: SELECT key, value, key - 100BD FROM DECIMAL_6_1_txt ORDER BY key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_1_txt
-#### A masked pattern was here ####
-POSTHOOK: query: SELECT key, value, key - 100BD FROM DECIMAL_6_1_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_1_txt
-#### A masked pattern was here ####
-NULL	-1234567890	NULL
-NULL	0	NULL
-NULL	3	NULL
-NULL	4	NULL
-NULL	1234567890	NULL
--4400.00000	4400	-4500.00000
--1255.49000	-1255	-1355.49000
--1.12200	-11	-101.12200
--1.12000	-1	-101.12000
--0.33300	0	-100.33300
--0.30000	0	-100.30000
-0.00000	0	-100.00000
-0.00000	0	-100.00000
-0.33300	0	-99.66700
-1.00000	1	-99.00000
-1.00000	1	-99.00000
-1.12000	1	-98.88000
-1.12200	1	-98.87800
-2.00000	2	-98.00000
-3.14000	3	-96.86000
-3.14000	3	-96.86000
-3.14000	4	-96.86000
-10.00000	10	-90.00000
-10.73433	5	-89.26567
-124.00000	124	24.00000
-125.20000	125	25.20000
-23232.23435	2	23132.23435
-PREHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key - 100BD, key_big FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key - 100BD, key_big FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: decimal_6_3_txt
-                  Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      projectedColumnNums: [0, 1, 2]
-                      projectedColumns: [key:decimal(10,5), value:int, key_big:decimal(20,5)]
-                  Select Operator
-                    expressions: key (type: decimal(10,5)), value (type: int), (key - 100) (type: decimal(11,5)), key_big (type: decimal(20,5))
-                    outputColumnNames: _col0, _col1, _col2, _col3
-                    Select Vectorization:
-                        className: VectorSelectOperator
-                        native: true
-                        projectedOutputColumnNums: [0, 1, 3, 2]
-                        selectExpressions: DecimalColSubtractDecimalScalar(col 0:decimal(10,5), val 100) -> 3:decimal(11,5)
-                    Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                    Reduce Output Operator
-                      key expressions: _col0 (type: decimal(10,5)), _col1 (type: int)
-                      sort order: ++
-                      Reduce Sink Vectorization:
-                          className: VectorReduceSinkObjectHashOperator
-                          keyColumnNums: [0, 1]
-                          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, 2]
-                      Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                      value expressions: _col2 (type: decimal(11,5)), _col3 (type: decimal(20,5))
-            Execution mode: vectorized, llap
-            LLAP IO: no inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-                vectorizationSupportRemovedReasons: [DECIMAL_64 removed because LLAP is enabled]
-                vectorizationSupport: []
-                inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-                allNative: true
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 3
-                    includeColumns: [0, 1, 2]
-                    dataColumns: key:decimal(10,5), value:int, key_big:decimal(20,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: [decimal(11,5)]
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: aa
-                reduceColumnSortOrder: ++
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 4
-                    dataColumns: KEY.reducesinkkey0:decimal(10,5), KEY.reducesinkkey1:int, VALUE._col0:decimal(11,5), VALUE._col1:decimal(20,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Select Operator
-                expressions: KEY.reducesinkkey0 (type: decimal(10,5)), KEY.reducesinkkey1 (type: int), VALUE._col0 (type: decimal(11,5)), VALUE._col1 (type: decimal(20,5))
-                outputColumnNames: _col0, _col1, _col2, _col3
-                Select Vectorization:
-                    className: VectorSelectOperator
-                    native: true
-                    projectedOutputColumnNums: [0, 1, 2, 3]
-                Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: SELECT key, value, key - 100BD, key_big FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-POSTHOOK: query: SELECT key, value, key - 100BD, key_big FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-NULL	-1234567890	NULL	NULL
-NULL	0	NULL	NULL
-NULL	3	NULL	NULL
-NULL	4	NULL	NULL
-NULL	1234567890	NULL	NULL
--4400.00000	4400	-4500.00000	-4400.00000
--1255.49000	-1255	-1355.49000	-1255.49000
--1.12200	-11	-101.12200	-1.12200
--1.12000	-1	-101.12000	-1.12000
--0.33300	0	-100.33300	-0.33300
--0.30000	0	-100.30000	-0.30000
-0.00000	0	-100.00000	0.00000
-0.00000	0	-100.00000	0.00000
-0.33300	0	-99.66700	0.33300
-1.00000	1	-99.00000	1.00000
-1.00000	1	-99.00000	1.00000
-1.12000	1	-98.88000	1.12000
-1.12200	1	-98.87800	1.12200
-2.00000	2	-98.00000	2.00000
-3.14000	3	-96.86000	3.14000
-3.14000	3	-96.86000	3.14000
-3.14000	4	-96.86000	3.14000
-10.00000	10	-90.00000	10.00000
-10.73433	5	-89.26567	10.73433
-124.00000	124	24.00000	124.00000
-125.20000	125	25.20000	125.20000
-23232.23435	2	23132.23435	23232.23435
-PREHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key - 100BD, key_big, key_big - key FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key - 100BD, key_big, key_big - key FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: decimal_6_3_txt
-                  Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      projectedColumnNums: [0, 1, 2]
-                      projectedColumns: [key:decimal(10,5), value:int, key_big:decimal(20,5)]
-                  Select Operator
-                    expressions: key (type: decimal(10,5)), value (type: int), (key - 100) (type: decimal(11,5)), key_big (type: decimal(20,5)), (key_big - key) (type: decimal(21,5))
-                    outputColumnNames: _col0, _col1, _col2, _col3, _col4
-                    Select Vectorization:
-                        className: VectorSelectOperator
-                        native: true
-                        projectedOutputColumnNums: [0, 1, 3, 2, 4]
-                        selectExpressions: DecimalColSubtractDecimalScalar(col 0:decimal(10,5), val 100) -> 3:decimal(11,5), DecimalColSubtractDecimalColumn(col 2:decimal(20,5), col 0:decimal(10,5)) -> 4:decimal(21,5)
-                    Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                    Reduce Output Operator
-                      key expressions: _col0 (type: decimal(10,5)), _col1 (type: int)
-                      sort order: ++
-                      Reduce Sink Vectorization:
-                          className: VectorReduceSinkObjectHashOperator
-                          keyColumnNums: [0, 1]
-                          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, 2, 4]
-                      Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                      value expressions: _col2 (type: decimal(11,5)), _col3 (type: decimal(20,5)), _col4 (type: decimal(21,5))
-            Execution mode: vectorized, llap
-            LLAP IO: no inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-                vectorizationSupportRemovedReasons: [DECIMAL_64 removed because LLAP is enabled]
-                vectorizationSupport: []
-                inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-                allNative: true
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 3
-                    includeColumns: [0, 1, 2]
-                    dataColumns: key:decimal(10,5), value:int, key_big:decimal(20,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: [decimal(11,5), decimal(21,5)]
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: aa
-                reduceColumnSortOrder: ++
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 5
-                    dataColumns: KEY.reducesinkkey0:decimal(10,5), KEY.reducesinkkey1:int, VALUE._col0:decimal(11,5), VALUE._col1:decimal(20,5), VALUE._col2:decimal(21,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Select Operator
-                expressions: KEY.reducesinkkey0 (type: decimal(10,5)), KEY.reducesinkkey1 (type: int), VALUE._col0 (type: decimal(11,5)), VALUE._col1 (type: decimal(20,5)), VALUE._col2 (type: decimal(21,5))
-                outputColumnNames: _col0, _col1, _col2, _col3, _col4
-                Select Vectorization:
-                    className: VectorSelectOperator
-                    native: true
-                    projectedOutputColumnNums: [0, 1, 2, 3, 4]
-                Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 27 Data size: 6156 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: SELECT key, value, key - 100BD, key_big, key_big - key FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-POSTHOOK: query: SELECT key, value, key - 100BD, key_big, key_big - key FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-NULL	-1234567890	NULL	NULL	NULL
-NULL	0	NULL	NULL	NULL
-NULL	3	NULL	NULL	NULL
-NULL	4	NULL	NULL	NULL
-NULL	1234567890	NULL	NULL	NULL
--4400.00000	4400	-4500.00000	-4400.00000	0.00000
--1255.49000	-1255	-1355.49000	-1255.49000	0.00000
--1.12200	-11	-101.12200	-1.12200	0.00000
--1.12000	-1	-101.12000	-1.12000	0.00000
--0.33300	0	-100.33300	-0.33300	0.00000
--0.30000	0	-100.30000	-0.30000	0.00000
-0.00000	0	-100.00000	0.00000	0.00000
-0.00000	0	-100.00000	0.00000	0.00000
-0.33300	0	-99.66700	0.33300	0.00000
-1.00000	1	-99.00000	1.00000	0.00000
-1.00000	1	-99.00000	1.00000	0.00000
-1.12000	1	-98.88000	1.12000	0.00000
-1.12200	1	-98.87800	1.12200	0.00000
-2.00000	2	-98.00000	2.00000	0.00000
-3.14000	3	-96.86000	3.14000	0.00000
-3.14000	3	-96.86000	3.14000	0.00000
-3.14000	4	-96.86000	3.14000	0.00000
-10.00000	10	-90.00000	10.00000	0.00000
-10.73433	5	-89.26567	10.73433	0.00000
-124.00000	124	24.00000	124.00000	0.00000
-125.20000	125	25.20000	125.20000	0.00000
-23232.23435	2	23132.23435	23232.23435	0.00000
-PREHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, cast(key as decimal(20,4)) FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, cast(key as decimal(20,4)) FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: decimal_6_3_txt
-                  Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      projectedColumnNums: [0, 1, 2]
-                      projectedColumns: [key:decimal(10,5), value:int, key_big:decimal(20,5)]
-                  Select Operator
-                    expressions: key (type: decimal(10,5)), value (type: int), CAST( key AS decimal(20,4)) (type: decimal(20,4))
-                    outputColumnNames: _col0, _col1, _col2
-                    Select Vectorization:
-                        className: VectorSelectOperator
-                        native: true
-                        projectedOutputColumnNums: [0, 1, 3]
-                        selectExpressions: CastDecimalToDecimal(col 0:decimal(10,5)) -> 3:decimal(20,4)
-                    Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                    Reduce Output Operator
-                      key expressions: _col0 (type: decimal(10,5)), _col1 (type: int)
-                      sort order: ++
-                      Reduce Sink Vectorization:
-                          className: VectorReduceSinkObjectHashOperator
-                          keyColumnNums: [0, 1]
-                          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: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                      value expressions: _col2 (type: decimal(20,4))
-            Execution mode: vectorized, llap
-            LLAP IO: no inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-                vectorizationSupportRemovedReasons: [DECIMAL_64 removed because LLAP is enabled]
-                vectorizationSupport: []
-                inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-                allNative: true
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 3
-                    includeColumns: [0, 1]
-                    dataColumns: key:decimal(10,5), value:int, key_big:decimal(20,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: [decimal(20,4)]
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: aa
-                reduceColumnSortOrder: ++
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 3
-                    dataColumns: KEY.reducesinkkey0:decimal(10,5), KEY.reducesinkkey1:int, VALUE._col0:decimal(20,4)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Select Operator
-                expressions: KEY.reducesinkkey0 (type: decimal(10,5)), KEY.reducesinkkey1 (type: int), VALUE._col0 (type: decimal(20,4))
-                outputColumnNames: _col0, _col1, _col2
-                Select Vectorization:
-                    className: VectorSelectOperator
-                    native: true
-                    projectedOutputColumnNums: [0, 1, 2]
-                Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: SELECT key, value, cast(key as decimal(20,4)) FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-POSTHOOK: query: SELECT key, value, cast(key as decimal(20,4)) FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-NULL	-1234567890	NULL
-NULL	0	NULL
-NULL	3	NULL
-NULL	4	NULL
-NULL	1234567890	NULL
--4400.00000	4400	-4400.0000
--1255.49000	-1255	-1255.4900
--1.12200	-11	-1.1220
--1.12000	-1	-1.1200
--0.33300	0	-0.3330
--0.30000	0	-0.3000
-0.00000	0	0.0000
-0.00000	0	0.0000
-0.33300	0	0.3330
-1.00000	1	1.0000
-1.00000	1	1.0000
-1.12000	1	1.1200
-1.12200	1	1.1220
-2.00000	2	2.0000
-3.14000	3	3.1400
-3.14000	3	3.1400
-3.14000	4	3.1400
-10.00000	10	10.0000
-10.73433	5	10.7343
-124.00000	124	124.0000
-125.20000	125	125.2000
-23232.23435	2	23232.2344
-PREHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key * value FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-POSTHOOK: query: EXPLAIN VECTORIZATION DETAIL
-SELECT key, value, key * value FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: decimal_6_3_txt
-                  Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      projectedColumnNums: [0, 1, 2]
-                      projectedColumns: [key:decimal(10,5), value:int, key_big:decimal(20,5)]
-                  Select Operator
-                    expressions: key (type: decimal(10,5)), value (type: int), (key * CAST( value AS decimal(10,0))) (type: decimal(21,5))
-                    outputColumnNames: _col0, _col1, _col2
-                    Select Vectorization:
-                        className: VectorSelectOperator
-                        native: true
-                        projectedOutputColumnNums: [0, 1, 4]
-                        selectExpressions: DecimalColMultiplyDecimalColumn(col 0:decimal(10,5), col 3:decimal(10,0))(children: CastLongToDecimal(col 1:int) -> 3:decimal(10,0)) -> 4:decimal(21,5)
-                    Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                    Reduce Output Operator
-                      key expressions: _col0 (type: decimal(10,5)), _col1 (type: int)
-                      sort order: ++
-                      Reduce Sink Vectorization:
-                          className: VectorReduceSinkObjectHashOperator
-                          keyColumnNums: [0, 1]
-                          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: [4]
-                      Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                      value expressions: _col2 (type: decimal(21,5))
-            Execution mode: vectorized, llap
-            LLAP IO: no inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-                vectorizationSupportRemovedReasons: [DECIMAL_64 removed because LLAP is enabled]
-                vectorizationSupport: []
-                inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-                allNative: true
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 3
-                    includeColumns: [0, 1]
-                    dataColumns: key:decimal(10,5), value:int, key_big:decimal(20,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: [decimal(10,0), decimal(21,5)]
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: aa
-                reduceColumnSortOrder: ++
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 3
-                    dataColumns: KEY.reducesinkkey0:decimal(10,5), KEY.reducesinkkey1:int, VALUE._col0:decimal(21,5)
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Select Operator
-                expressions: KEY.reducesinkkey0 (type: decimal(10,5)), KEY.reducesinkkey1 (type: int), VALUE._col0 (type: decimal(21,5))
-                outputColumnNames: _col0, _col1, _col2
-                Select Vectorization:
-                    className: VectorSelectOperator
-                    native: true
-                    projectedOutputColumnNums: [0, 1, 2]
-                Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 27 Data size: 3132 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: SELECT key, value, key * value FROM DECIMAL_6_3_txt ORDER BY key, value
-PREHOOK: type: QUERY
-PREHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-POSTHOOK: query: SELECT key, value, key * value FROM DECIMAL_6_3_txt ORDER BY key, value
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@decimal_6_3_txt
-#### A masked pattern was here ####
-NULL	-1234567890	NULL
-NULL	0	NULL
-NULL	3	NULL
-NULL	4	NULL
-NULL	1234567890	NULL
--4400.00000	4400	-19360000.00000
--1255.49000	-1255	1575639.95000
--1.12200	-11	12.34200
--1.12000	-1	1.12000
--0.33300	0	0.00000
--0.30000	0	0.00000
-0.00000	0	0.00000
-0.00000	0	0.00000
-0.33300	0	0.00000
-1.00000	1	1.00000
-1.00000	1	1.00000
-1.12000	1	1.12000
-1.12200	1	1.12200
-2.00000	2	4.00000
-3.14000	3	9.42000
-3.14000	3	9.42000
-3.14000	4	12.56000
-10.00000	10	100.00000
-10.73433	5	53.67165
-124.00000	124	15376.00000
-125.20000	125	15650.00000
-23232.23435	2	46464.46870

http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/llap/vectorized_distinct_gby.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vectorized_distinct_gby.q.out b/ql/src/test/results/clientpositive/llap/vectorized_distinct_gby.q.out
deleted file mode 100644
index 8c0bf86..0000000
--- a/ql/src/test/results/clientpositive/llap/vectorized_distinct_gby.q.out
+++ /dev/null
@@ -1,344 +0,0 @@
-PREHOOK: query: create table dtest(a int, b int) clustered by (a) sorted by (a) into 1 buckets stored as orc
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@dtest
-POSTHOOK: query: create table dtest(a int, b int) clustered by (a) sorted by (a) into 1 buckets stored as orc
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@dtest
-PREHOOK: query: insert into table dtest select c,b from (select array(300,300,300,300,300) as a, 1 as b from src order by a limit 1) y lateral view  explode(a) t1 as c
-PREHOOK: type: QUERY
-PREHOOK: Input: default@src
-PREHOOK: Output: default@dtest
-POSTHOOK: query: insert into table dtest select c,b from (select array(300,300,300,300,300) as a, 1 as b from src order by a limit 1) y lateral view  explode(a) t1 as c
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@src
-POSTHOOK: Output: default@dtest
-POSTHOOK: Lineage: dtest.a SCRIPT []
-POSTHOOK: Lineage: dtest.b SIMPLE []
-PREHOOK: query: explain vectorization detail
-select sum(distinct a), count(distinct a) from dtest
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select sum(distinct a), count(distinct a) from dtest
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (CUSTOM_SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: dtest
-                  Statistics: Num rows: 5 Data size: 20 Basic stats: COMPLETE Column stats: NONE
-                  TableScan Vectorization:
-                      native: true
-                      vectorizationSchemaColumns: [0:a:int, 1:b:int, 2:ROW__ID:struct<transactionid:bigint,bucketid:int,rowid:bigint>]
-                  Select Operator
-                    expressions: a (type: int)
-                    outputColumnNames: a
-                    Select Vectorization:
-                        className: VectorSelectOperator
-                        native: true
-                        projectedOutputColumnNums: [0]
-                    Statistics: Num rows: 5 Data size: 20 Basic stats: COMPLETE Column stats: NONE
-                    Group By Operator
-                      Group By Vectorization:
-                          className: VectorGroupByOperator
-                          groupByMode: FINAL
-                          keyExpressions: col 0:int
-                          native: false
-                          vectorProcessingMode: STREAMING
-                          projectedOutputColumnNums: []
-                      keys: a (type: int)
-                      mode: final
-                      outputColumnNames: _col0
-                      Statistics: Num rows: 2 Data size: 8 Basic stats: COMPLETE Column stats: NONE
-                      Group By Operator
-                        aggregations: sum(_col0), count(_col0)
-                        Group By Vectorization:
-                            aggregators: VectorUDAFSumLong(col 0:int) -> bigint, VectorUDAFCount(col 0:int) -> bigint
-                            className: VectorGroupByOperator
-                            groupByMode: HASH
-                            native: false
-                            vectorProcessingMode: HASH
-                            projectedOutputColumnNums: [0, 1]
-                        mode: hash
-                        outputColumnNames: _col0, _col1
-                        Statistics: Num rows: 1 Data size: 20 Basic stats: COMPLETE Column stats: NONE
-                        Reduce Output Operator
-                          sort order: 
-                          Reduce Sink Vectorization:
-                              className: VectorReduceSinkEmptyKeyOperator
-                              keyColumnNums: []
-                              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: [0, 1]
-                          Statistics: Num rows: 1 Data size: 20 Basic stats: COMPLETE Column stats: NONE
-                          value expressions: _col0 (type: bigint), _col1 (type: bigint)
-            Execution mode: vectorized, llap
-            LLAP IO: all inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vectorized.input.format IS true
-                inputFormatFeatureSupport: []
-                featureSupportInUse: []
-                inputFileFormats: org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 2
-                    includeColumns: [0]
-                    dataColumns: a:int, b:int
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: 
-                reduceColumnSortOrder: 
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 2
-                    dataColumns: VALUE._col0:bigint, VALUE._col1:bigint
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Group By Operator
-                aggregations: sum(VALUE._col0), count(VALUE._col1)
-                Group By Vectorization:
-                    aggregators: VectorUDAFSumLong(col 0:bigint) -> bigint, VectorUDAFCountMerge(col 1:bigint) -> bigint
-                    className: VectorGroupByOperator
-                    groupByMode: MERGEPARTIAL
-                    native: false
-                    vectorProcessingMode: GLOBAL
-                    projectedOutputColumnNums: [0, 1]
-                mode: mergepartial
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 1 Data size: 20 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 1 Data size: 20 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select sum(distinct a), count(distinct a) from dtest
-PREHOOK: type: QUERY
-PREHOOK: Input: default@dtest
-#### A masked pattern was here ####
-POSTHOOK: query: select sum(distinct a), count(distinct a) from dtest
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@dtest
-#### A masked pattern was here ####
-300	1
-PREHOOK: query: explain vectorization detail
-select sum(distinct cint), count(distinct cint), avg(distinct cint), std(distinct cint) from alltypesorc
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select sum(distinct cint), count(distinct cint), avg(distinct cint), std(distinct cint) from alltypesorc
-POSTHOOK: type: QUERY
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-0 depends on stages: Stage-1
-
-STAGE PLANS:
-  Stage: Stage-1
-    Tez
-#### A masked pattern was here ####
-      Edges:
-        Reducer 2 <- Map 1 (SIMPLE_EDGE)
-        Reducer 3 <- Reducer 2 (CUSTOM_SIMPLE_EDGE)
-#### A masked pattern was here ####
-      Vertices:
-        Map 1 
-            Map Operator Tree:
-                TableScan
-                  alias: alltypesorc
-                  Statistics: Num rows: 12288 Data size: 36696 Basic stats: COMPLETE Column stats: COMPLETE
-                  TableScan Vectorization:
-                      native: true
-                      vectorizationSchemaColumns: [0:ctinyint:tinyint, 1:csmallint:smallint, 2:cint:int, 3:cbigint:bigint, 4:cfloat:float, 5:cdouble:double, 6:cstring1:string, 7:cstring2:string, 8:ctimestamp1:timestamp, 9:ctimestamp2:timestamp, 10:cboolean1:boolean, 11:cboolean2:boolean, 12:ROW__ID:struct<transactionid:bigint,bucketid:int,rowid:bigint>]
-                  Select Operator
-                    expressions: cint (type: int)
-                    outputColumnNames: cint
-                    Select Vectorization:
-                        className: VectorSelectOperator
-                        native: true
-                        projectedOutputColumnNums: [2]
-                    Statistics: Num rows: 12288 Data size: 36696 Basic stats: COMPLETE Column stats: COMPLETE
-                    Group By Operator
-                      Group By Vectorization:
-                          className: VectorGroupByOperator
-                          groupByMode: HASH
-                          keyExpressions: col 2:int
-                          native: false
-                          vectorProcessingMode: HASH
-                          projectedOutputColumnNums: []
-                      keys: cint (type: int)
-                      mode: hash
-                      outputColumnNames: _col0
-                      Statistics: Num rows: 6030 Data size: 18008 Basic stats: COMPLETE Column stats: COMPLETE
-                      Reduce Output Operator
-                        key expressions: _col0 (type: int)
-                        sort order: +
-                        Map-reduce partition columns: _col0 (type: int)
-                        Reduce Sink Vectorization:
-                            className: VectorReduceSinkLongOperator
-                            keyColumnNums: [0]
-                            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: []
-                        Statistics: Num rows: 6030 Data size: 18008 Basic stats: COMPLETE Column stats: COMPLETE
-            Execution mode: vectorized, llap
-            LLAP IO: all inputs
-            Map Vectorization:
-                enabled: true
-                enabledConditionsMet: hive.vectorized.use.vectorized.input.format IS true
-                inputFormatFeatureSupport: []
-                featureSupportInUse: []
-                inputFileFormats: org.apache.hadoop.hive.ql.io.orc.OrcInputFormat
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 12
-                    includeColumns: [2]
-                    dataColumns: ctinyint:tinyint, csmallint:smallint, cint:int, cbigint:bigint, cfloat:float, cdouble:double, cstring1:string, cstring2:string, ctimestamp1:timestamp, ctimestamp2:timestamp, cboolean1:boolean, cboolean2:boolean
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-        Reducer 2 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: a
-                reduceColumnSortOrder: +
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 1
-                    dataColumns: KEY._col0:int
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Group By Operator
-                Group By Vectorization:
-                    className: VectorGroupByOperator
-                    groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:int
-                    native: false
-                    vectorProcessingMode: MERGE_PARTIAL
-                    projectedOutputColumnNums: []
-                keys: KEY._col0 (type: int)
-                mode: mergepartial
-                outputColumnNames: _col0
-                Statistics: Num rows: 6030 Data size: 18008 Basic stats: COMPLETE Column stats: COMPLETE
-                Group By Operator
-                  aggregations: sum(_col0), count(_col0), avg(_col0), std(_col0)
-                  Group By Vectorization:
-                      aggregators: VectorUDAFSumLong(col 0:int) -> bigint, VectorUDAFCount(col 0:int) -> bigint, VectorUDAFAvgLong(col 0:int) -> struct<count:bigint,sum:double,input:int>, VectorUDAFVarLong(col 0:int) -> struct<count:bigint,sum:double,variance:double> aggregation: std
-                      className: VectorGroupByOperator
-                      groupByMode: HASH
-                      native: false
-                      vectorProcessingMode: HASH
-                      projectedOutputColumnNums: [0, 1, 2, 3]
-                  mode: hash
-                  outputColumnNames: _col0, _col1, _col2, _col3
-                  Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: COMPLETE
-                  Reduce Output Operator
-                    sort order: 
-                    Reduce Sink Vectorization:
-                        className: VectorReduceSinkEmptyKeyOperator
-                        keyColumnNums: []
-                        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: [0, 1, 2, 3]
-                    Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: COMPLETE
-                    value expressions: _col0 (type: bigint), _col1 (type: bigint), _col2 (type: struct<count:bigint,sum:double,input:int>), _col3 (type: struct<count:bigint,sum:double,variance:double>)
-        Reducer 3 
-            Execution mode: vectorized, llap
-            Reduce Vectorization:
-                enabled: true
-                enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true
-                reduceColumnNullOrder: 
-                reduceColumnSortOrder: 
-                allNative: false
-                usesVectorUDFAdaptor: false
-                vectorized: true
-                rowBatchContext:
-                    dataColumnCount: 4
-                    dataColumns: VALUE._col0:bigint, VALUE._col1:bigint, VALUE._col2:struct<count:bigint,sum:double,input:int>, VALUE._col3:struct<count:bigint,sum:double,variance:double>
-                    partitionColumnCount: 0
-                    scratchColumnTypeNames: []
-            Reduce Operator Tree:
-              Group By Operator
-                aggregations: sum(VALUE._col0), count(VALUE._col1), avg(VALUE._col2), std(VALUE._col3)
-                Group By Vectorization:
-                    aggregators: VectorUDAFSumLong(col 0:bigint) -> bigint, VectorUDAFCountMerge(col 1:bigint) -> bigint, VectorUDAFAvgFinal(col 2:struct<count:bigint,sum:double,input:int>) -> double, VectorUDAFVarFinal(col 3:struct<count:bigint,sum:double,variance:double>) -> double aggregation: std
-                    className: VectorGroupByOperator
-                    groupByMode: MERGEPARTIAL
-                    native: false
-                    vectorProcessingMode: GLOBAL
-                    projectedOutputColumnNums: [0, 1, 2, 3]
-                mode: mergepartial
-                outputColumnNames: _col0, _col1, _col2, _col3
-                Statistics: Num rows: 1 Data size: 32 Basic stats: COMPLETE Column stats: COMPLETE
-                File Output Operator
-                  compressed: false
-                  File Sink Vectorization:
-                      className: VectorFileSinkOperator
-                      native: false
-                  Statistics: Num rows: 1 Data size: 32 Basic stats: COMPLETE Column stats: COMPLETE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select sum(distinct cint), count(distinct cint), avg(distinct cint), std(distinct cint) from alltypesorc
-PREHOOK: type: QUERY
-PREHOOK: Input: default@alltypesorc
-#### A masked pattern was here ####
-POSTHOOK: query: select sum(distinct cint), count(distinct cint), avg(distinct cint), std(distinct cint) from alltypesorc
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@alltypesorc
-#### A masked pattern was here ####
--3482841611	6082	-572647.4204209142	1.1894598769807303E9


[04/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_rank.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_rank.q.out b/ql/src/test/results/clientpositive/vector_windowing_rank.q.out
deleted file mode 100644
index 5d4ddcd..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_rank.q.out
+++ /dev/null
@@ -1,1564 +0,0 @@
-PREHOOK: query: drop table over10k
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table over10k
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@over10k
-POSTHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: explain vectorization detail
-select s, rank() over (partition by f order by t) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, rank() over (partition by f order by t) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: f (type: float), t (type: tinyint)
-              sort order: ++
-              Map-reduce partition columns: f (type: float)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: s (type: string)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [0, 4, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: tinyint), KEY.reducesinkkey0 (type: float), VALUE._col5 (type: string)
-          outputColumnNames: _col0, _col4, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col4: float, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col0 ASC NULLS FIRST
-                  partition by: _col4
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col0
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), rank_window_0 (type: int)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, rank() over (partition by f order by t) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, rank() over (partition by f order by t) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	rank_window_0
-bob ichabod	1
-yuri thompson	2
-luke steinbeck	1
-fred zipper	2
-luke king	3
-calvin van buren	1
-quinn miller	2
-holly steinbeck	1
-david davidson	1
-calvin quirinius	1
-calvin thompson	2
-david ovid	1
-nick zipper	2
-holly thompson	3
-victor steinbeck	1
-victor robinson	2
-zach ovid	1
-ulysses zipper	1
-irene thompson	1
-luke falkner	2
-yuri johnson	1
-ulysses falkner	1
-gabriella robinson	2
-alice robinson	1
-priscilla xylophone	2
-david laertes	1
-mike underhill	2
-victor van buren	1
-holly falkner	1
-priscilla falkner	1
-luke zipper	1
-ethan ovid	2
-alice quirinius	1
-calvin white	2
-mike steinbeck	3
-nick young	1
-wendy polk	2
-irene miller	3
-ethan ellison	1
-yuri davidson	2
-zach hernandez	1
-wendy miller	1
-katie underhill	1
-irene zipper	1
-holly allen	1
-quinn brown	2
-calvin ovid	1
-zach robinson	1
-nick miller	2
-mike allen	1
-priscilla young	1
-yuri van buren	2
-zach miller	3
-sarah falkner	1
-victor xylophone	2
-rachel ichabod	1
-calvin ovid	1
-alice robinson	2
-calvin ovid	1
-alice ovid	1
-david hernandez	2
-luke laertes	3
-luke quirinius	1
-oscar white	1
-zach falkner	1
-rachel thompson	1
-priscilla king	1
-xavier polk	1
-wendy ichabod	1
-rachel ovid	1
-wendy allen	1
-luke brown	1
-oscar ichabod	2
-mike brown	3
-xavier garcia	1
-bob xylophone	1
-yuri brown	2
-ethan quirinius	1
-luke davidson	2
-zach davidson	1
-irene miller	1
-wendy king	1
-bob zipper	1
-sarah thompson	1
-bob laertes	1
-xavier allen	2
-bob carson	3
-sarah robinson	1
-david king	1
-oscar davidson	1
-wendy polk	1
-victor hernandez	2
-david ellison	1
-ulysses johnson	1
-jessica ovid	1
-bob king	1
-ulysses garcia	1
-irene falkner	1
-holly robinson	1
-yuri white	1
-PREHOOK: query: explain vectorization detail
-select s, dense_rank() over (partition by ts order by i,s desc) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, dense_rank() over (partition by ts order by i,s desc) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), i (type: int), s (type: string)
-              sort order: ++-
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 7, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), KEY.reducesinkkey2 (type: string), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col2, _col7, _col8
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col7: string, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST, _col7 DESC NULLS LAST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: dense_rank_window_0
-                        arguments: _col2, _col7
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), dense_rank_window_0 (type: int)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, dense_rank() over (partition by ts order by i,s desc) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, dense_rank() over (partition by ts order by i,s desc) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	dense_rank_window_0
-rachel thompson	1
-oscar brown	2
-wendy steinbeck	3
-victor van buren	4
-fred zipper	5
-priscilla zipper	6
-katie white	7
-fred nixon	8
-gabriella van buren	9
-luke zipper	10
-victor ellison	11
-david falkner	12
-nick carson	13
-calvin laertes	14
-yuri allen	15
-calvin brown	16
-tom johnson	17
-jessica laertes	18
-sarah falkner	19
-gabriella xylophone	20
-mike laertes	21
-bob ovid	22
-rachel garcia	23
-katie king	24
-calvin steinbeck	25
-jessica polk	26
-xavier davidson	1
-ethan ovid	2
-calvin white	3
-katie zipper	4
-quinn allen	5
-victor underhill	6
-ulysses xylophone	7
-priscilla zipper	8
-quinn ovid	9
-katie xylophone	10
-rachel ovid	11
-yuri brown	12
-oscar van buren	13
-alice miller	14
-luke thompson	15
-gabriella steinbeck	16
-priscilla brown	17
-gabriella underhill	18
-jessica robinson	19
-luke steinbeck	20
-nick ellison	21
-oscar davidson	22
-wendy johnson	23
-ulysses johnson	24
-jessica nixon	25
-fred king	26
-jessica brown	27
-ethan young	28
-xavier johnson	29
-gabriella johnson	30
-calvin nixon	31
-bob king	32
-calvin carson	33
-zach young	34
-yuri hernandez	35
-sarah van buren	36
-holly falkner	37
-jessica brown	38
-rachel ovid	39
-katie davidson	40
-bob falkner	41
-rachel young	42
-irene brown	43
-fred polk	44
-priscilla hernandez	45
-wendy thompson	46
-rachel robinson	47
-luke xylophone	48
-luke king	49
-holly thompson	50
-yuri garcia	1
-nick king	2
-calvin white	3
-rachel polk	4
-rachel davidson	5
-victor hernandez	6
-wendy miller	7
-wendy brown	8
-priscilla thompson	9
-holly nixon	10
-victor hernandez	11
-priscilla polk	12
-ethan nixon	13
-alice underhill	14
-jessica thompson	15
-tom hernandez	16
-sarah falkner	17
-wendy underhill	18
-rachel ichabod	19
-jessica johnson	20
-rachel ellison	21
-wendy falkner	22
-holly allen	23
-ulysses carson	24
-PREHOOK: query: explain vectorization detail
-select s, cume_dist() over (partition by bo order by b,s) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, cume_dist() over (partition by bo order by b,s) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: bo (type: boolean), b (type: bigint), s (type: string)
-              sort order: +++
-              Map-reduce partition columns: bo (type: boolean)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [3, 6, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: bigint), KEY.reducesinkkey0 (type: boolean), KEY.reducesinkkey2 (type: string)
-          outputColumnNames: _col3, _col6, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col3: bigint, _col6: boolean, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col3 ASC NULLS FIRST, _col7 ASC NULLS FIRST
-                  partition by: _col6
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: cume_dist_window_0
-                        arguments: _col3, _col7
-                        name: cume_dist
-                        window function: GenericUDAFCumeDistEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), cume_dist_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, cume_dist() over (partition by bo order by b,s) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, cume_dist() over (partition by bo order by b,s) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	cume_dist_window_0
-calvin allen	2.0112630732099757E-4
-david ovid	4.0225261464199515E-4
-david zipper	6.033789219629927E-4
-ethan ellison	8.045052292839903E-4
-holly allen	0.001005631536604988
-irene garcia	0.0012067578439259854
-irene van buren	0.0014078841512469831
-jessica steinbeck	0.0016090104585679806
-katie xylophone	0.0018101367658889783
-mike xylophone	0.002011263073209976
-nick quirinius	0.0022123893805309734
-nick steinbeck	0.002413515687851971
-quinn steinbeck	0.002614641995172969
-rachel thompson	0.0028157683024939663
-sarah miller	0.0030168946098149637
-tom hernandez	0.003218020917135961
-ulysses ichabod	0.003419147224456959
-ulysses nixon	0.0036202735317779565
-ulysses xylophone	0.003821399839098954
-victor garcia	0.004022526146419952
-victor xylophone	0.004223652453740949
-wendy falkner	0.004424778761061947
-yuri nixon	0.004625905068382945
-bob johnson	0.004827031375703942
-bob king	0.00502815768302494
-calvin van buren	0.005229283990345938
-gabriella robinson	0.005430410297666935
-katie xylophone	0.0056315366049879325
-mike steinbeck	0.00583266291230893
-oscar quirinius	0.006033789219629927
-rachel davidson	0.006234915526950925
-sarah van buren	0.006436041834271922
-tom king	0.00663716814159292
-ulysses allen	0.006838294448913918
-wendy ellison	0.007039420756234915
-zach allen	0.007240547063555913
-zach young	0.007441673370876911
-alice falkner	0.007642799678197908
-bob ovid	0.007843925985518906
-bob underhill	0.008045052292839904
-ethan ovid	0.008246178600160902
-gabriella davidson	0.008447304907481898
-gabriella garcia	0.008648431214802896
-irene nixon	0.008849557522123894
-jessica brown	0.009050683829444892
-jessica miller	0.00925181013676589
-jessica quirinius	0.009452936444086887
-luke falkner	0.009654062751407884
-luke robinson	0.009855189058728881
-mike steinbeck	0.01005631536604988
-mike van buren	0.010257441673370877
-priscilla hernandez	0.010458567980691875
-tom polk	0.010659694288012871
-ulysses king	0.01086082059533387
-ulysses robinson	0.011061946902654867
-xavier davidson	0.011263073209975865
-alice hernandez	0.011464199517296863
-bob underhill	0.01166532582461786
-calvin nixon	0.011866452131938857
-david davidson	0.012067578439259855
-holly falkner	0.012268704746580853
-irene laertes	0.01246983105390185
-jessica robinson	0.012670957361222849
-mike falkner	0.012872083668543845
-nick falkner	0.013073209975864843
-oscar laertes	0.01327433628318584
-oscar miller	0.013475462590506838
-oscar thompson	0.013676588897827836
-priscilla nixon	0.013877715205148834
-priscilla xylophone	0.01407884151246983
-quinn miller	0.014279967819790828
-victor robinson	0.014481094127111826
-wendy allen	0.014682220434432824
-wendy nixon	0.014883346741753822
-yuri ellison	0.015084473049074818
-calvin nixon	0.015285599356395816
-fred carson	0.015486725663716814
-holly davidson	0.015687851971037812
-irene king	0.01588897827835881
-jessica davidson	0.016090104585679808
-katie polk	0.016492357200321803
-katie polk	0.016492357200321803
-luke johnson	0.0166934835076428
-nick allen	0.016894609814963796
-nick ellison	0.017095736122284794
-oscar king	0.01729686242960579
-priscilla laertes	0.01749798873692679
-priscilla underhill	0.017699115044247787
-priscilla young	0.017900241351568785
-victor steinbeck	0.018101367658889783
-wendy miller	0.01830249396621078
-calvin carson	0.01850362027353178
-ethan hernandez	0.018704746580852777
-ethan laertes	0.01910699919549477
-ethan laertes	0.01910699919549477
-ethan white	0.019308125502815767
-fred ellison	0.019509251810136765
-gabriella hernandez	0.019710378117457763
-gabriella ovid	0.01991150442477876
-gabriella steinbeck	0.02011263073209976
-PREHOOK: query: explain vectorization detail
-select s, percent_rank() over (partition by `dec` order by f) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, percent_rank() over (partition by `dec` order by f) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: dec (type: decimal(4,2)), f (type: float)
-              sort order: ++
-              Map-reduce partition columns: dec (type: decimal(4,2))
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: s (type: string)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 7, 9]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: float), VALUE._col6 (type: string), KEY.reducesinkkey0 (type: decimal(4,2))
-          outputColumnNames: _col4, _col7, _col9
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col7: string, _col9: decimal(4,2)
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST
-                  partition by: _col9
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: percent_rank_window_0
-                        arguments: _col4
-                        name: percent_rank
-                        window function: GenericUDAFPercentRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), percent_rank_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, percent_rank() over (partition by `dec` order by f) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, percent_rank() over (partition by `dec` order by f) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	percent_rank_window_0
-wendy king	0.0
-calvin robinson	1.0
-mike steinbeck	0.0
-calvin hernandez	0.0
-sarah king	1.0
-yuri ellison	0.0
-victor king	0.0
-alice ovid	0.0
-ethan steinbeck	0.5
-mike steinbeck	1.0
-gabriella young	0.0
-jessica johnson	0.0
-holly king	0.5
-tom young	1.0
-victor falkner	0.0
-ethan polk	0.0
-oscar miller	0.0
-ethan quirinius	0.0
-fred hernandez	0.0
-david steinbeck	1.0
-wendy xylophone	0.0
-luke laertes	0.0
-alice quirinius	1.0
-calvin ovid	0.0
-holly allen	0.0
-tom brown	1.0
-wendy ovid	0.0
-mike brown	0.0
-alice polk	0.0
-alice zipper	0.0
-sarah quirinius	1.0
-luke underhill	0.0
-victor white	0.5
-holly xylophone	1.0
-oscar quirinius	0.0
-ethan davidson	0.0
-ethan allen	0.0
-wendy underhill	0.5
-irene xylophone	1.0
-ulysses steinbeck	0.0
-mike hernandez	1.0
-irene brown	0.0
-priscilla brown	0.0
-calvin johnson	1.0
-sarah xylophone	0.0
-yuri underhill	0.5
-ethan nixon	1.0
-calvin hernandez	0.0
-yuri underhill	0.0
-holly allen	1.0
-victor laertes	0.0
-ethan underhill	0.0
-irene steinbeck	1.0
-mike van buren	0.0
-xavier allen	0.5
-sarah xylophone	1.0
-luke van buren	0.0
-gabriella xylophone	0.0
-gabriella ellison	0.0
-luke falkner	0.0
-priscilla garcia	0.0
-ethan quirinius	0.3333333333333333
-alice xylophone	0.6666666666666666
-ethan underhill	1.0
-tom white	0.0
-alice johnson	0.0
-priscilla zipper	0.0
-tom laertes	0.5
-zach laertes	1.0
-xavier miller	0.0
-yuri ovid	0.0
-david steinbeck	0.0
-wendy underhill	0.0
-priscilla xylophone	0.0
-nick hernandez	0.0
-luke steinbeck	0.0
-oscar davidson	0.0
-sarah allen	0.0
-katie steinbeck	0.0
-oscar ovid	1.0
-yuri ellison	0.0
-rachel quirinius	0.0
-irene van buren	0.0
-victor ichabod	0.0
-quinn miller	0.0
-luke allen	0.0
-xavier laertes	0.0
-wendy miller	0.0
-victor brown	0.0
-tom thompson	0.0
-david brown	1.0
-zach quirinius	0.0
-oscar king	1.0
-david nixon	0.0
-ethan white	0.0
-ethan polk	0.0
-ulysses steinbeck	0.0
-victor van buren	0.3333333333333333
-sarah carson	0.6666666666666666
-priscilla nixon	1.0
-PREHOOK: query: explain vectorization detail
-select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where rnk =  1 limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where rnk =  1 limit 10
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-0 depends on stages: Stage-2
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: other
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: b is not null (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: b (type: bigint), ts (type: timestamp), dec (type: decimal(4,2))
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: bigint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: bigint)
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: timestamp), _col2 (type: decimal(4,2))
-          TableScan
-            alias: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: b is not null (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: b (type: bigint)
-                outputColumnNames: _col0
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: bigint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: bigint)
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: Vectorized map work only works with 1 TableScanOperator IS false
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Join Operator
-          condition map:
-               Inner Join 0 to 1
-          keys:
-            0 _col0 (type: bigint)
-            1 _col0 (type: bigint)
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1]
-                projectedColumns: [_col1:timestamp, _col2:decimal(4,2)]
-            Reduce Output Operator
-              key expressions: _col1 (type: timestamp), _col2 (type: decimal(4,2))
-              sort order: ++
-              Map-reduce partition columns: _col1 (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 2
-              includeColumns: [0, 1]
-              dataColumns: _col1:timestamp, _col2:decimal(4,2)
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: timestamp), KEY.reducesinkkey1 (type: decimal(4,2))
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: timestamp, _col2: decimal(4,2)
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST
-                  partition by: _col1
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col2
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (rank_window_0 = 1) (type: boolean)
-              Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col1 (type: timestamp), _col2 (type: decimal(4,2)), 1 (type: int)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                Limit
-                  Number of rows: 10
-                  Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                  File Output Operator
-                    compressed: false
-                    Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                    table:
-                        input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                        output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where rnk =  1 limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where rnk =  1 limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-ts	dec	rnk
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-2013-03-01 09:11:58.70307	0.50	1
-PREHOOK: query: explain vectorization detail
-select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where `dec` = 89.5 limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where `dec` = 89.5 limit 10
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-0 depends on stages: Stage-2
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: other
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: b is not null (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: b (type: bigint), ts (type: timestamp), dec (type: decimal(4,2))
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: bigint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: bigint)
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col1 (type: timestamp), _col2 (type: decimal(4,2))
-          TableScan
-            alias: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: b is not null (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: b (type: bigint)
-                outputColumnNames: _col0
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: bigint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: bigint)
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: Vectorized map work only works with 1 TableScanOperator IS false
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Join Operator
-          condition map:
-               Inner Join 0 to 1
-          keys:
-            0 _col0 (type: bigint)
-            1 _col0 (type: bigint)
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1]
-                projectedColumns: [_col1:timestamp, _col2:decimal(4,2)]
-            Reduce Output Operator
-              key expressions: _col1 (type: timestamp)
-              sort order: +
-              Map-reduce partition columns: _col1 (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col2 (type: decimal(4,2))
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 2
-              includeColumns: [0, 1]
-              dataColumns: _col1:timestamp, _col2:decimal(4,2)
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: timestamp), VALUE._col1 (type: decimal(4,2))
-          outputColumnNames: _col1, _col2
-          Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: timestamp, _col2: decimal(4,2)
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col1
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (_col2 = 89.5) (type: boolean)
-              Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col1 (type: timestamp), 89.5 (type: decimal(4,2)), rank_window_0 (type: int)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                Limit
-                  Number of rows: 10
-                  Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                  File Output Operator
-                    compressed: false
-                    Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                    table:
-                        input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                        output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where `dec` = 89.5 limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-            ) joined
-  ) ranked
-where `dec` = 89.5 limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-ts	dec	rnk
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-2013-03-01 09:11:58.703124	89.50	1
-PREHOOK: query: explain vectorization detail
-select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-             where other.t < 10
-            ) joined
-  ) ranked
-where rnk = 1 limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-             where other.t < 10
-            ) joined
-  ) ranked
-where rnk = 1 limit 10
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-0 depends on stages: Stage-2
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: other
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: ((t < 10) and b is not null) (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: b (type: bigint), ts (type: timestamp), dec (type: decimal(4,2))
-                outputColumnNames: _col1, _col2, _col3
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col1 (type: bigint)
-                  sort order: +
-                  Map-reduce partition columns: _col1 (type: bigint)
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col2 (type: timestamp), _col3 (type: decimal(4,2))
-          TableScan
-            alias: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: b is not null (type: boolean)
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: b (type: bigint)
-                outputColumnNames: _col0
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: bigint)
-                  sort order: +
-                  Map-reduce partition columns: _col0 (type: bigint)
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: Vectorized map work only works with 1 TableScanOperator IS false
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Join Operator
-          condition map:
-               Inner Join 0 to 1
-          keys:
-            0 _col1 (type: bigint)
-            1 _col0 (type: bigint)
-          outputColumnNames: _col2, _col3
-          Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1]
-                projectedColumns: [_col2:timestamp, _col3:decimal(4,2)]
-            Reduce Output Operator
-              key expressions: _col2 (type: timestamp), _col3 (type: decimal(4,2))
-              sort order: ++
-              Map-reduce partition columns: _col2 (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 2
-              includeColumns: [0, 1]
-              dataColumns: _col2:timestamp, _col3:decimal(4,2)
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: timestamp), KEY.reducesinkkey1 (type: decimal(4,2))
-          outputColumnNames: _col2, _col3
-          Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: timestamp, _col3: decimal(4,2)
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col3 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col3
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: (rank_window_0 = 1) (type: boolean)
-              Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col2 (type: timestamp), _col3 (type: decimal(4,2)), 1 (type: int)
-                outputColumnNames: _col0, _col1, _col2
-                Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                Limit
-                  Number of rows: 10
-                  Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                  File Output Operator
-                    compressed: false
-                    Statistics: Num rows: 1 Data size: 1119298 Basic stats: COMPLETE Column stats: NONE
-                    table:
-                        input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                        output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-             where other.t < 10
-            ) joined
-  ) ranked
-where rnk = 1 limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select ts, `dec`, rnk
-from
-  (select ts, `dec`,
-          rank() over (partition by ts order by `dec`)  as rnk
-          from
-            (select other.ts, other.`dec`
-             from over10k other
-             join over10k on (other.b = over10k.b)
-             where other.t < 10
-            ) joined
-  ) ranked
-where rnk = 1 limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-ts	dec	rnk
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1
-2013-03-01 09:11:58.70307	37.30	1


[05/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_range_multiorder.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_range_multiorder.q.out b/ql/src/test/results/clientpositive/vector_windowing_range_multiorder.q.out
deleted file mode 100644
index 9b31e52..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_range_multiorder.q.out
+++ /dev/null
@@ -1,12270 +0,0 @@
-PREHOOK: query: drop table over10k
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table over10k
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-           ts timestamp,
-           `dec` decimal(4,2),
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@over10k
-POSTHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-           ts timestamp,
-           `dec` decimal(4,2),
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: explain vectorization detail
-select first_value(t) over ( partition by si order by i, b ) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select first_value(t) over ( partition by si order by i, b ) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: si (type: smallint), i (type: int), b (type: bigint)
-              sort order: +++
-              Map-reduce partition columns: si (type: smallint)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: t (type: tinyint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [0, 1, 2, 3]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col0 (type: tinyint), KEY.reducesinkkey0 (type: smallint), KEY.reducesinkkey1 (type: int), KEY.reducesinkkey2 (type: bigint)
-          outputColumnNames: _col0, _col1, _col2, _col3
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col1: smallint, _col2: int, _col3: bigint
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST, _col3 ASC NULLS FIRST
-                  partition by: _col1
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: first_value_window_0
-                        arguments: _col0
-                        name: first_value
-                        window function: GenericUDAFFirstValueEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: first_value_window_0 (type: tinyint)
-              outputColumnNames: _col0
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select first_value(t) over ( partition by si order by i, b ) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select first_value(t) over ( partition by si order by i, b ) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-first_value_window_0
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-51
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-48
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-47
-PREHOOK: query: explain vectorization detail
-select last_value(i) over (partition by si, bo order by i, f desc range current row) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select last_value(i) over (partition by si, bo order by i, f desc range current row) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: si (type: smallint), bo (type: boolean), i (type: int), f (type: float)
-              sort order: +++-
-              Map-reduce partition columns: si (type: smallint), bo (type: boolean)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [1, 2, 4, 6]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: smallint), KEY.reducesinkkey2 (type: int), KEY.reducesinkkey3 (type: float), KEY.reducesinkkey1 (type: boolean)
-          outputColumnNames: _col1, _col2, _col4, _col6
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: smallint, _col2: int, _col4: float, _col6: boolean
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST, _col4 DESC NULLS LAST
-                  partition by: _col1, _col6
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: last_value_window_0
-                        arguments: _col2
-                        name: last_value
-                        window function: GenericUDAFLastValueEvaluator
-                        window frame: RANGE CURRENT~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: last_value_window_0 (type: int)
-              outputColumnNames: _col0
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select last_value(i) over (partition by si, bo order by i, f desc range current row) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select last_value(i) over (partition by si, bo order by i, f desc range current row) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-last_value_window_0
-65543
-65549
-65558
-65580
-65586
-65596
-65616
-65620
-65627
-65640
-65643
-65706
-65713
-65737
-65744
-65752
-65778
-65540
-65563
-65599
-65604
-65613
-65613
-65615
-65651
-65653
-65668
-65693
-65731
-65733
-65738
-65741
-65744
-65747
-65763
-65778
-65789
-65541
-65547
-65560
-65572
-65574
-65575
-65578
-65588
-65594
-65610
-65691
-65694
-65711
-65719
-65722
-65738
-65756
-65790
-65542
-65557
-65566
-65584
-65610
-65612
-65626
-65631
-65638
-65654
-65654
-65655
-65699
-65712
-65720
-65732
-65748
-65752
-65771
-65771
-65771
-65781
-65565
-65569
-65573
-65582
-65584
-65606
-65656
-65669
-65717
-65724
-65728
-65761
-65762
-65770
-65771
-65781
-65546
-65551
-65551
-65568
-65568
-65579
-65603
-PREHOOK: query: explain vectorization detail
-select row_number() over (partition by si, bo order by i, f desc range between unbounded preceding and unbounded following) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select row_number() over (partition by si, bo order by i, f desc range between unbounded preceding and unbounded following) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: si (type: smallint), bo (type: boolean), i (type: int), f (type: float)
-              sort order: +++-
-              Map-reduce partition columns: si (type: smallint), bo (type: boolean)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [1, 2, 4, 6]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: smallint), KEY.reducesinkkey2 (type: int), KEY.reducesinkkey3 (type: float), KEY.reducesinkkey1 (type: boolean)
-          outputColumnNames: _col1, _col2, _col4, _col6
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: smallint, _col2: int, _col4: float, _col6: boolean
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST, _col4 DESC NULLS LAST
-                  partition by: _col1, _col6
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: row_number_window_0
-                        name: row_number
-                        window function: GenericUDAFRowNumberEvaluator
-                        window frame: RANGE PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: row_number_window_0 (type: int)
-              outputColumnNames: _col0
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select row_number() over (partition by si, bo order by i, f desc range between unbounded preceding and unbounded following) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select row_number() over (partition by si, bo order by i, f desc range between unbounded preceding and unbounded following) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-row_number_window_0
-1
-2
-3
-4
-5
-6
-7
-8
-9
-10
-11
-12
-13
-14
-15
-16
-17
-1
-2
-3
-4
-5
-6
-7
-8
-9
-10
-11
-12
-13
-14
-15
-16
-17
-18
-19
-20
-1
-2
-3
-4
-5
-6
-7
-8
-9
-10
-11
-12
-13
-14
-15
-16
-17
-18
-1
-2
-3
-4
-5
-6
-7
-8
-9
-10
-11
-12
-13
-14
-15
-16
-17
-18
-19
-20
-21
-22
-1
-2
-3
-4
-5
-6
-7
-8
-9
-10
-11
-12
-13
-14
-15
-16
-1
-2
-3
-4
-5
-6
-7
-PREHOOK: query: explain vectorization detail
-select s, si, i, avg(i) over (partition by s range between unbounded preceding and current row) from over10k
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, si, i, avg(i) over (partition by s range between unbounded preceding and current row) from over10k
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string)
-              sort order: +
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: si (type: smallint), i (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [1, 2, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col1 (type: smallint), VALUE._col2 (type: int), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col1, _col2, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: smallint, _col2: int, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col2
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col1 (type: smallint), _col2 (type: int), avg_window_0 (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, si, i, avg(i) over (partition by s range between unbounded preceding and current row) from over10k
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, si, i, avg(i) over (partition by s range between unbounded preceding and current row) from over10k
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	si	i	avg_window_0
-alice allen	451	65662	65640.125
-alice allen	462	65545	65640.125
-alice allen	501	65720	65640.125
-alice allen	501	65670	65640.125
-alice allen	484	65600	65640.125
-alice allen	472	65609	65640.125
-alice allen	509	65758	65640.125
-alice allen	400	65557	65640.125
-alice brown	425	65570	65696.71428571429
-alice brown	376	65708	65696.71428571429
-alice brown	324	65569	65696.71428571429
-alice brown	302	65711	65696.71428571429
-alice brown	381	65704	65696.71428571429
-alice brown	452	65666	65696.71428571429
-alice brown	346	65696	65696.71428571429
-alice brown	471	65733	65696.71428571429
-alice brown	409	65667	65696.71428571429
-alice brown	399	65779	65696.71428571429
-alice brown	332	65781	65696.71428571429
-alice brown	337	65707	65696.71428571429
-alice brown	499	65790	65696.71428571429
-alice brown	492	65673	65696.71428571429
-alice carson	404	65710	65645.4
-alice carson	376	65576	65645.4
-alice carson	508	65545	65645.4
-alice carson	427	65559	65645.4
-alice carson	473	65565	65645.4
-alice carson	390	65747	65645.4
-alice carson	318	65695	65645.4
-alice carson	316	65559	65645.4
-alice carson	268	65713	65645.4
-alice carson	380	65785	65645.4
-alice davidson	298	65554	65648.5
-alice davidson	479	65631	65648.5
-alice davidson	445	65590	65648.5
-alice davidson	384	65676	65648.5
-alice davidson	408	65791	65648.5
-alice davidson	321	65677	65648.5
-alice davidson	448	65641	65648.5
-alice davidson	423	65740	65648.5
-alice davidson	270	65563	65648.5
-alice davidson	431	65677	65648.5
-alice davidson	487	65596	65648.5
-alice davidson	402	65544	65648.5
-alice davidson	272	65742	65648.5
-alice davidson	287	65747	65648.5
-alice davidson	328	65547	65648.5
-alice davidson	437	65690	65648.5
-alice davidson	308	65560	65648.5
-alice davidson	408	65707	65648.5
-alice ellison	405	65713	65669.13333333333
-alice ellison	490	65572	65669.13333333333
-alice ellison	354	65698	65669.13333333333
-alice ellison	331	65557	65669.13333333333
-alice ellison	313	65612	65669.13333333333
-alice ellison	296	65741	65669.13333333333
-alice ellison	403	65544	65669.13333333333
-alice ellison	482	65681	65669.13333333333
-alice ellison	320	65745	65669.13333333333
-alice ellison	274	65537	65669.13333333333
-alice ellison	256	65744	65669.13333333333
-alice ellison	355	65699	65669.13333333333
-alice ellison	343	65787	65669.13333333333
-alice ellison	335	65730	65669.13333333333
-alice ellison	374	65677	65669.13333333333
-alice falkner	342	65752	65695.76470588235
-alice falkner	280	65597	65695.76470588235
-alice falkner	393	65611	65695.76470588235
-alice falkner	389	65699	65695.76470588235
-alice falkner	345	65773	65695.76470588235
-alice falkner	500	65775	65695.76470588235
-alice falkner	323	65669	65695.76470588235
-alice falkner	393	65685	65695.76470588235
-alice falkner	339	65785	65695.76470588235
-alice falkner	382	65690	65695.76470588235
-alice falkner	371	65710	65695.76470588235
-alice falkner	481	65709	65695.76470588235
-alice falkner	311	65715	65695.76470588235
-alice falkner	477	65722	65695.76470588235
-alice falkner	382	65622	65695.76470588235
-alice falkner	455	65718	65695.76470588235
-alice falkner	452	65596	65695.76470588235
-alice garcia	388	65675	65688.76923076923
-alice garcia	366	65744	65688.76923076923
-alice garcia	331	65734	65688.76923076923
-alice garcia	299	65623	65688.76923076923
-alice garcia	379	65746	65688.76923076923
-alice garcia	486	65725	65688.76923076923
-alice garcia	427	65674	65688.76923076923
-alice garcia	263	65630	65688.76923076923
-alice garcia	459	65712	65688.76923076923
-alice garcia	446	65759	65688.76923076923
-alice garcia	325	65573	65688.76923076923
-alice garcia	309	65746	65688.76923076923
-alice garcia	446	65613	65688.76923076923
-alice hernandez	396	65545	65678.38888888889
-alice hernandez	336	65786	65678.38888888889
-alice hernandez	324	65720	65678.38888888889
-alice hernandez	270	65717	65678.38888888889
-alice hernandez	323	65727	65678.38888888889
-alice hernandez	441	65684	65678.38888888889
-alice hernandez	320	65700	65678.38888888889
-alice hernandez	347	65785	65678.38888888889
-alice hernandez	379	65737	65678.38888888889
-alice hernandez	408	65603	65678.38888888889
-alice hernandez	290	65685	65678.38888888889
-alice hernandez	435	65543	65678.38888888889
-alice hernandez	396	65649	65678.38888888889
-alice hernandez	296	65569	65678.38888888889
-alice hernandez	448	65784	65678.38888888889
-alice hernandez	341	65653	65678.38888888889
-alice hernandez	402	65633	65678.38888888889
-alice hernandez	497	65691	65678.38888888889
-alice ichabod	300	65704	65654.95454545454
-alice ichabod	347	65547	65654.95454545454
-alice ichabod	458	65550	65654.95454545454
-alice ichabod	398	65785	65654.95454545454
-alice ichabod	366	65590	65654.95454545454
-alice ichabod	338	65538	65654.95454545454
-alice ichabod	453	65780	65654.95454545454
-alice ichabod	292	65788	65654.95454545454
-alice ichabod	344	65545	65654.95454545454
-alice ichabod	416	65536	65654.95454545454
-alice ichabod	315	65772	65654.95454545454
-alice ichabod	338	65545	65654.95454545454
-alice ichabod	412	65718	65654.95454545454
-alice ichabod	398	65680	65654.95454545454
-alice ichabod	303	65692	65654.95454545454
-alice ichabod	305	65617	65654.95454545454
-alice ichabod	436	65738	65654.95454545454
-alice ichabod	301	65693	65654.95454545454
-alice ichabod	320	65622	65654.95454545454
-alice ichabod	440	65725	65654.95454545454
-alice ichabod	292	65585	65654.95454545454
-alice ichabod	398	65659	65654.95454545454
-alice johnson	475	65706	65705.33333333333
-alice johnson	401	65689	65705.33333333333
-alice johnson	328	65749	65705.33333333333
-alice johnson	409	65728	65705.33333333333
-alice johnson	501	65759	65705.33333333333
-alice johnson	360	65622	65705.33333333333
-alice johnson	323	65739	65705.33333333333
-alice johnson	438	65606	65705.33333333333
-alice johnson	454	65775	65705.33333333333
-alice johnson	464	65752	65705.33333333333
-alice johnson	365	65591	65705.33333333333
-alice johnson	259	65748	65705.33333333333
-alice king	297	65765	65675.25
-alice king	361	65660	65675.25
-alice king	373	65718	65675.25
-alice king	345	65677	65675.25
-alice king	365	65583	65675.25
-alice king	361	65771	65675.25
-alice king	278	65745	65675.25
-alice king	455	65570	65675.25
-alice king	507	65538	65675.25
-alice king	346	65674	65675.25
-alice king	497	65738	65675.25
-alice king	430	65682	65675.25
-alice king	319	65734	65675.25
-alice king	366	65627	65675.25
-alice king	458	65563	65675.25
-alice king	386	65759	65675.25
-alice laertes	399	65741	65699.75
-alice laertes	336	65588	65699.75
-alice laertes	450	65708	65699.75
-alice laertes	409	65669	65699.75
-alice laertes	316	65685	65699.75
-alice laertes	365	65769	65699.75
-alice laertes	387	65718	65699.75
-alice laertes	509	65685	65699.75
-alice laertes	372	65683	65699.75
-alice laertes	426	65619	65699.75
-alice laertes	285	65781	65699.75
-alice laertes	269	65760	65699.75
-alice laertes	400	65751	65699.75
-alice laertes	263	65671	65699.75
-alice laertes	303	65771	65699.75
-alice laertes	336	65597	65699.75
-alice miller	304	65756	65673.4375
-alice miller	492	65562	65673.4375
-alice miller	376	65707	65673.4375
-alice miller	329	65732	65673.4375
-alice miller	459	65734	65673.4375
-alice miller	266	65755	65673.4375
-alice miller	332	65628	65673.4375
-alice miller	263	65635	65673.4375
-alice miller	328	65612	65673.4375
-alice miller	323	65616	65673.4375
-alice miller	359	65604	65673.4375
-alice miller	394	65740	65673.4375
-alice miller	360	65590	65673.4375
-alice miller	310	65732	65673.4375
-alice miller	491	65791	65673.4375
-alice miller	451	65581	65673.4375
-alice nixon	459	65595	65666.16666666667
-alice nixon	406	65752	65666.16666666667
-alice nixon	392	65586	65666.16666666667
-alice nixon	373	65548	65666.16666666667
-alice nixon	258	65770	65666.16666666667
-alice nixon	377	65774	65666.16666666667
-alice nixon	299	65624	65666.16666666667
-alice nixon	398	65609	65666.16666666667
-alice nixon	444	65681	65666.16666666667
-alice nixon	358	65609	65666.16666666667
-alice nixon	485	65682	65666.16666666667
-alice nixon	463	65766	65666.16666666667
-alice nixon	258	65611	65666.16666666667
-alice nixon	367	65652	65666.16666666667
-alice nixon	376	65681	65666.16666666667
-alice nixon	347	65604	65666.16666666667
-alice nixon	420	65682	65666.16666666667
-alice nixon	470	65765	65666.16666666667
-alice ovid	354	65779	65682.82352941176
-alice ovid	355	65541	65682.82352941176
-alice ovid	296	65656	65682.82352941176
-alice ovid	369	65540	65682.82352941176
-alice ovid	380	65627	65682.82352941176
-alice ovid	262	65761	65682.82352941176
-alice ovid	322	65763	65682.82352941176
-alice ovid	275	65625	65682.82352941176
-alice ovid	256	65616	65682.82352941176
-alice ovid	476	65666	65682.82352941176
-alice ovid	387	65578	65682.82352941176
-alice ovid	264	65737	65682.82352941176
-alice ovid	274	65778	65682.82352941176
-alice ovid	305	65772	65682.82352941176
-alice ovid	386	65772	65682.82352941176
-alice ovid	407	65656	65682.82352941176
-alice ovid	480	65741	65682.82352941176
-alice polk	444	65564	65661.57142857143
-alice polk	407	65617	65661.57142857143
-alice polk	273	65548	65661.57142857143
-alice polk	443	65734	65661.57142857143
-alice polk	487	65746	65661.57142857143
-alice polk	285	65761	65661.57142857143
-alice polk	395	65751	65661.57142857143
-alice polk	321	65744	65661.57142857143
-alice polk	507	65744	65661.57142857143
-alice polk	366	65595	65661.57142857143
-alice polk	378	65598	65661.57142857143
-alice polk	357	65550	65661.57142857143
-alice polk	324	65749	65661.57142857143
-alice polk	466	65561	65661.57142857143
-alice quirinius	476	65728	65652.0
-alice quirinius	386	65577	65652.0
-alice quirinius	466	65669	65652.0
-alice quirinius	336	65654	65652.0
-alice quirinius	474	65789	65652.0
-alice quirinius	423	65587	65652.0
-alice quirinius	335	65636	65652.0
-alice quirinius	372	65606	65652.0
-alice quirinius	395	65760	65652.0
-alice quirinius	493	65627	65652.0
-alice quirinius	403	65539	65652.0
-alice quirinius	384	65637	65652.0
-alice quirinius	463	65558	65652.0
-alice quirinius	487	65763	65652.0
-alice quirinius	372	65650	65652.0
-alice robinson	485	65538	65655.29411764706
-alice robinson	329	65789	65655.29411764706
-alice robinson	287	65649	65655.29411764706
-alice robinson	286	65791	65655.29411764706
-alice robinson	455	65567	65655.29411764706
-alice robinson	501	65606	65655.29411764706
-alice robinson	398	65663	65655.29411764706
-alice robinson	382	65572	65655.29411764706
-alice robinson	381	65682	65655.29411764706
-alice robinson	492	65773	65655.29411764706
-alice robinson	423	65573	65655.29411764706
-alice robinson	256	65558	65655.29411764706
-alice robinson	447	65752	65655.29411764706
-alice robinson	416	65771	65655.29411764706
-alice robinson	354	65766	65655.29411764706
-alice robinson	307	65554	65655.29411764706
-alice robinson	416	65536	65655.29411764706
-alice steinbeck	277	65691	65680.4375
-alice steinbeck	263	65651	65680.4375
-alice steinbeck	346	65673	65680.4375
-alice steinbeck	326	65654	65680.4375
-alice steinbeck	342	65671	65680.4375
-alice steinbeck	480	65598	65680.4375
-alice steinbeck	377	65786	65680.4375
-alice steinbeck	303	65599	65680.4375
-alice steinbeck	279	65705	65680.4375
-alice steinbeck	443	65655	65680.4375
-alice steinbeck	374	65773	65680.4375
-alice steinbeck	503	65670	65680.4375
-alice steinbeck	351	65649	65680.4375
-alice steinbeck	329	65751	65680.4375
-alice steinbeck	451	65783	65680.4375
-alice steinbeck	435	65578	65680.4375
-alice thompson	487	65637	65649.33333333333
-alice thompson	273	65541	65649.33333333333
-alice thompson	330	65699	65649.33333333333
-alice thompson	491	65599	65649.33333333333
-alice thompson	473	65565	65649.33333333333
-alice thompson	285	65783	65649.33333333333
-alice thompson	435	65739	65649.33333333333
-alice thompson	450	65738	65649.33333333333
-alice thompson	435	65543	65649.33333333333
-alice underhill	336	65645	65708.0
-alice underhill	377	65656	65708.0
-alice underhill	377	65705	65708.0
-alice underhill	380	65765	65708.0
-alice underhill	257	65781	65708.0
-alice underhill	379	65750	65708.0
-alice underhill	491	65712	65708.0
-alice underhill	389	65706	65708.0
-alice underhill	337	65663	65708.0
-alice underhill	351	65677	65708.0
-alice underhill	446	65790	65708.0
-alice underhill	392	65758	65708.0
-alice underhill	489	65582	65708.0
-alice underhill	289	65722	65708.0
-alice van buren	383	65694	65654.33333333333
-alice van buren	455	65723	65654.33333333333
-alice van buren	493	65562	65654.33333333333
-alice van buren	373	65595	65654.33333333333
-alice van buren	319	65695	65654.33333333333
-alice van buren	386	65772	65654.33333333333
-alice van buren	442	65724	65654.33333333333
-alice van buren	477	65566	65654.33333333333
-alice van buren	369	65558	65654.33333333333
-alice white	452	65722	65653.1
-alice white	313	65643	65653.1
-alice white	311	65647	65653.1
-alice white	429	65618	65653.1
-alice white	344	65770	65653.1
-alice white	394	65702	65653.1
-alice white	479	65587	65653.1
-alice white	307	65610	65653.1
-alice white	486	65548	65653.1
-alice white	458	65684	65653.1
-alice xylophone	508	65589	65660.45454545454
-alice xylophone	383	65578	65660.45454545454
-alice xylophone	466	65731	65660.45454545454
-alice xylophone	324	65690	65660.45454545454
-alice xylophone	275	65732	65660.45454545454
-alice xylophone	309	65780	65660.45454545454
-alice xylophone	288	65600	65660.45454545454
-alice xylophone	312	65599	65660.45454545454
-alice xylophone	393	65715	65660.45454545454
-alice xylophone	306	65624	65660.45454545454
-alice xylophone	295	65554	65660.45454545454
-alice xylophone	257	65610	65660.45454545454
-alice xylophone	365	65558	65660.45454545454
-alice xylophone	363	65761	65660.45454545454
-alice xylophone	398	65702	65660.45454545454
-alice xylophone	346	65650	65660.45454545454
-alice xylophone	299	65605	65660.45454545454
-alice xylophone	345	65691	65660.45454545454
-alice xylophone	485	65661	65660.45454545454
-alice xylophone	483	65734	65660.45454545454
-alice xylophone	501	65585	65660.45454545454
-alice xylophone	299	65781	65660.45454545454
-alice young	447	65789	65706.63636363637
-alice young	308	65776	65706.63636363637
-alice young	383	65558	65706.63636363637
-alice young	286	65705	65706.63636363637
-alice young	468	65649	65706.63636363637
-alice young	282	65671	65706.63636363637
-alice young	419	65735	65706.63636363637
-alice young	425	65677	65706.63636363637
-alice young	314	65791	65706.63636363637
-alice young	351	65776	65706.63636363637
-alice young	489	65646	65706.63636363637
-alice zipper	333	65620	65632.83333333333
-alice zipper	261	65547	65632.83333333333
-alice zipper	396	65600	65632.83333333333
-alice zipper	426	65651	65632.83333333333
-alice zipper	442	65553	65632.83333333333
-alice zipper	363	65659	65632.83333333333
-alice zipper	461	65602	65632.83333333333
-alice zipper	295	65682	65632.83333333333
-alice zipper	431	65605	65632.83333333333
-alice zipper	504	65766	65632.83333333333
-alice zipper	361	65647	65632.83333333333
-alice zipper	444	65662	65632.83333333333
-bob allen	288	65654	65658.5
-bob allen	317	65598	65658.5
-bob allen	344	65674	65658.5
-bob allen	349	65570	65658.5
-bob allen	396	65702	65658.5
-bob allen	395	65725	65658.5
-bob allen	412	65650	65658.5
-bob allen	269	65698	65658.5
-bob allen	288	65660	65658.5
-bob allen	448	65654	65658.5
-bob brown	459	65595	65688.30769230769
-bob brown	261	65662	65688.30769230769
-bob brown	379	65664	65688.30769230769
-bob brown	391	65631	65688.30769230769
-bob brown	276	65584	65688.30769230769
-bob brown	409	65777	65688.30769230769
-bob brown	419	65783	65688.30769230769
-bob brown	372	65744	65688.30769230769
-bob brown	428	65623	65688.30769230769
-bob brown	392	65761	65688.30769230769
-bob brown	371	65602	65688.30769230769
-bob brown	508	65765	65688.30769230769
-bob brown	420	65757	65688.30769230769
-bob carson	485	65721	65663.04347826086
-bob carson	456	65691	65663.04347826086
-bob carson	502	65638	65663.04347826086
-bob carson	453	65780	65663.04347826086
-bob carson	266	65617	65663.04347826086
-bob carson	302	65696	65663.04347826086
-bob carson	422	65617	65663.04347826086
-bob carson	469	65688	65663.04347826086
-bob carson	412	65606	65663.04347826086
-bob carson	417	65775	65663.04347826086
-bob carson	298	65756	65663.04347826086
-bob carson	444	65622	65663.04347826086
-bob carson	370	65571	65663.04347826086
-bob carson	475	65640	65663.04347826086
-bob carson	478	65701	65663.04347826086
-bob carson	265	65547	65663.04347826086
-bob carson	356	65721	65663.04347826086
-bob carson	314	65671	65663.04347826086
-bob carson	417	65642	65663.04347826086
-bob carson	465	65656	65663.04347826086
-bob carson	261	65644	65663.04347826086
-bob carson	465	65713	65663.04347826086
-bob carson	462	65537	65663.04347826086
-bob davidson	504	65768	65671.23076923077
-bob davidson	477	65682	65671.23076923077
-bob davidson	424	65681	65671.23076923077
-bob davidson	364	65791	65671.23076923077
-bob davidson	309	65631	65671.23076923077
-bob davidson	286	65698	65671.23076923077
-bob davidson	432	65565	65671.23076923077
-bob davidson	391	65609	65671.23076923077
-bob davidson	382	65733	65671.23076923077
-bob davidson	336	65664	65671.23076923077
-bob davidson	390	65693	65671.23076923077
-bob davidson	471	65581	65671.23076923077
-bob davidson	395	65630	65671.23076923077
-bob ellison	286	65579	65649.92857142857
-bob ellison	320	65624	65649.92857142857
-bob ellison	417	65557	65649.92857142857
-bob ellison	508	65637	65649.92857142857
-bob ellison	392	65760	65649.92857142857
-bob ellison	299	65605	65649.92857142857
-bob ellison	410	65721	65649.92857142857
-bob ellison	430	65591	65649.92857142857
-bob ellison	499	65617	65649.92857142857
-bob ellison	345	65644	65649.92857142857
-bob ellison	339	65671	65649.92857142857
-bob ellison	261	65657	65649.92857142857
-bob ellison	349	65745	65649.92857142857
-bob ellison	275	65691	65649.92857142857
-bob falkner	329	65720	65674.17647058824
-bob falkner	330	65727	65674.17647058824
-bob falkner	394	65648	65674.17647058824
-bob falkner	291	65789	65674.17647058824
-bob falkner	414	65587	65674.17647058824
-bob falkner	302	65711	65674.17647058824
-bob falkner	357	65566	65674.17647058824
-bob falkner	474	65734	65674.17647058824
-bob falkner	390	65556	65674.17647058824
-bob falkner	410	65749	65674.17647058824
-bob falkner	258	65551	65674.17647058824
-bob falkner	317	65624	65674.17647058824
-bob falkner	260	65595	65674.17647058824
-bob falkner	459	65746	65674.17647058824
-bob falkner	264	65693	65674.17647058824
-bob falkner	389	65738	65674.17647058824
-bob falkner	406	65727	65674.17647058824
-bob garcia	344	65738	65675.86666666667
-bob garcia	332	65642	65675.86666666667
-bob garcia	418	65598	65675.86666666667
-bob garcia	315	65782	65675.86666666667
-bob garcia	422	65655	65675.86666666667
-bob garcia	444	65789	65675.86666666667
-bob garcia	361	65737	65675.86666666667
-bob garcia	421	65652	65675.86666666667
-bob garcia	416	65582	65675.86666666667
-bob garcia	398	65697	65675.86666666667
-bob garcia	279	65754	65675.86666666667
-bob garcia	466	65673	65675.86666666667
-bob garcia	480	65567	65675.86666666667
-bob garcia	354	65687	65675.86666666667
-bob garcia	320	65585	65675.86666666667
-bob hernandez	481	65615	65672.61538461539
-bob hernandez	295	65743	65672.61538461539
-bob hernandez	452	65582	65672.61538461539
-bob hernandez	363	65593	65672.61538461539
-bob hernandez	412	65719	65672.61538461539
-bob hernandez	259	65771	65672.61538461539
-bob hernandez	261	65566	65672.61538461539
-bob hernandez	504	65557	65672.61538461539
-bob hernandez	502	65778	65672.61538461539
-bob hernandez	504	65673	65672.61538461539
-bob hernandez	306	65751	65672.61538461539
-bob hernandez	275	65757	65672.61538461539
-bob hernandez	405	65639	65672.61538461539
-bob ichabod	454	65733	65667.76470588235
-bob ichabod	432	65774	65667.76470588235
-bob ichabod	361	65712	65667.76470588235
-bob ichabod	478	65700	65667.76470588235
-bob ichabod	489	65549	65667.76470588235
-bob ichabod	489	65567	65667.76470588235
-bob ichabod	468	65574	65667.76470588235
-bob ichabod	342	65703	65667.76470588235
-bob ichabod	389	65669	65667.76470588235
-bob ichabod	365	65734	65667.76470588235
-bob ichabod	294	65779	65667.76470588235
-bob ichabod	400	65639	65667.76470588235
-bob ichabod	289	65785	65667.76470588235
-bob ichabod	263	65648	65667.76470588235
-bob ichabod	354	65640	65667.76470588235
-bob ichabod	370	65558	65667.76470588235
-bob ichabod	436	65588	65667.76470588235
-bob johnson	269	65774	65665.0
-bob johnson	459	65564	65665.0
-bob johnson	357	65620	65665.0
-bob johnson	325	65582	65665.0
-bob johnson	374	65731	65665.0
-bob johnson	422	65696	65665.0
-bob johnson	317	65575	65665.0
-bob johnson	296	65664	65665.0
-bob johnson	336	65779	65665.0
-bob king	308	65715	65672.05555555556
-bob king	447	65757	65672.05555555556
-bob king	383	65672	65672.05555555556
-bob king	477	65597	65672.05555555556
-bob king	407	65764	65672.05555555556
-bob king	501	65657	65672.05555555556
-bob king	460	65630	65672.05555555556
-bob king	411	65646	65672.05555555556
-bob king	402	65558	65672.05555555556
-bob king	286	65696	65672.05555555556
-bob king	465	65697	65672.05555555556
-bob king	359	65563	65672.05555555556
-bob king	377	65560	65672.05555555556
-bob king	304	65786	65672.05555555556
-bob king	305	65783	65672.05555555556
-bob king	360	65780	65672.05555555556
-bob king	378	65553	65672.05555555556
-bob king	377	65683	65672.05555555556
-bob laertes	285	65567	65671.23529411765
-bob laertes	406	65773	65671.23529411765
-bob laertes	446	65602	65671.23529411765
-bob laertes	423	65663	65671.23529411765
-bob laertes	405	65752	65671.23529411765
-bob laertes	303	65646	65671.23529411765
-bob laertes	341	65554	65671.23529411765
-bob laertes	267	65646	65671.23529411765
-bob laertes	429	65591	65671.23529411765
-bob laertes	362	65667	65671.23529411765
-bob laertes	487	65720	65671.23529411765
-bob laertes	482	65772	65671.23529411765
-bob laertes	376	65602	65671.23529411765
-bob laertes	440	65751	65671.23529411765
-bob laertes	456	65650	65671.23529411765
-bob laertes	437	65729	65671.23529411765
-bob laertes	406	65726	65671.23529411765
-bob miller	460	65737	65647.41666666667
-bob miller	484	65545	65647.41666666667
-bob miller	451	65580	65647.41666666667
-bob miller	395	65644	65647.41666666667
-bob miller	305	65577	65647.41666666667
-bob miller	395	65731	65647.41666666667
-bob miller	389	65711	65647.41666666667
-bob miller	461	65608	65647.41666666667
-bob miller	457	65603	65647.41666666667
-bob miller	301	65541	65647.41666666667
-bob miller	301	65717	65647.41666666667
-bob miller	389	65775	65647.41666666667
-bob nixon	307	65695	65701.07692307692
-bob nixon	398	65641	65701.07692307692
-bob nixon	273	65668	65701.07692307692
-bob nixon	490	65641	65701.07692307692
-bob nixon	379	65788	65701.07692307692
-bob nixon	348	65707	65701.07692307692
-bob nixon	351	65781	65701.07692307692
-bob nixon	423	65629	65701.07692307692
-bob nixon	270	65660	65701.07692307692
-bob nixon	384	65623	65701.07692307692
-bob nixon	397	65791	65701.07692307692
-bob nixon	362	65722	65701.07692307692
-bob nixon	476	65768	65701.07692307692
-bob ovid	331	65707	65647.64285714286
-bob ovid	440	65719	65647.64285714286
-bob ovid	343	65610	65647.64285714286
-bob ovid	493	65616	65647.64285714286
-bob ovid	319	65570	65647.64285714286
-bob ovid	472	65750	65647.64285714286
-bob ovid	366	65565	65647.64285714286
-bob ovid	261	65619	65647.64285714286
-bob ovid	486	65768	65647.64285714286
-bob ovid	462	65673	65647.64285714286
-bob ovid	265	65563	65647.64285714286
-bob ovid	393	65555	65647.64285714286
-bob ovid	283	65564	65647.64285714286
-bob ovid	476	65592	65647.64285714286
-bob ovid	317	65647	65647.64285714286
-bob ovid	427	65671	65647.64285714286
-bob ovid	449	65726	65647.64285714286
-bob ovid	482	65581	65647.64285714286
-bob ovid	349	65686	65647.64285714286
-bob ovid	509	65742	65647.64285714286
-bob ovid	364	65652	65647.64285714286
-bob ovid	478	65742	65647.64285714286
-bob ovid	450	65578	65647.64285714286
-bob ovid	373	65592	65647.64285714286
-bob ovid	331	65564	65647.64285714286
-bob ovid	470	65729	65647.64285714286
-bob ovid	269	65748	65647.64285714286
-bob ovid	446	65605	65647.64285714286
-bob polk	316	65778	65660.4
-bob polk	434	65731	65660.4
-bob polk	436	65569	65660.4
-bob polk	511	65582	65660.4
-bob polk	433	65767	65660.4
-bob polk	310	65599	65660.4
-bob polk	423	65609	65660.4
-bob polk	420	65599	65660.4
-bob polk	264	65776	65660.4
-bob polk	325	65594	65660.4
-bob quirinius	398	65669	65675.0
-bob quirinius	269	65577	65675.0
-bob quirinius	366	65718	65675.0
-bob quirinius	303	65728	65675.0
-bob quirinius	278	65582	65675.0
-bob quirinius	463	65645	65675.0
-bob quirinius	442	65652	65675.0
-bob quirinius	492	65673	65675.0
-bob quirinius	353	65686	65675.0
-bob quirinius	348	65747	65675.0
-bob quirinius	508	65723	65675.0
-bob quirinius	362	65758	65675.0
-bob quirinius	265	65575	65675.0
-bob quirinius	393	65699	65675.0
-bob quirinius	295	65572	65675.0
-bob quirinius	345	65771	65675.0
-bob quirinius	465	65700	65675.0
-bob robinson	261	65536	65670.75
-bob robinson	332	65696	65670.75
-bob robinson	496	65649	65670.75
-bob robinson	334	65785	65670.75
-bob robinson	274	65688	65670.75
-bob robinson	360	65770	65670.75
-bob robinson	415	65560	65670.75
-bob robinson	329	65737	65670.75
-bob robinson	272	65632	65670.75
-bob robinson	379	65762	65670.75
-bob robinson	439	65638	65670.75
-bob robinson	427	65648	65670.75
-bob robinson	304	65785	65670.75
-bob robinson	451	65744	65670.75
-bob robinson	332	65554	65670.75
-bob robinson	391	65548	65670.75
-bob steinbeck	462	65624	65643.90909090909
-bob steinbeck	312	65597	65643.90909090909
-bob steinbeck	295	65621	65643.90909090909
-bob steinbeck	346	65665	65643.90909090909
-bob steinbeck	360	65611	65643.90909090909
-bob steinbeck	506	65728	65643.90909090909
-bob steinbeck	482	65637	65643.90909090909
-bob steinbeck	477	65764	65643.90909090909
-bob steinbeck	327	65650	65643.90909090909
-bob steinbeck	396	65569	65643.90909090909
-bob steinbeck	308	65617	65643.90909090909
-bob thompson	422	65590	65651.33333333333
-bob thompson	457	65663	65651.33333333333
-bob thompson	356	65564	65651.33333333333
-bob thompson	361	65703	65651.33333333333
-bob thompson	344	65643	65651.33333333333
-bob thompson	440	65570	65651.33333333333
-bob thompson	294	65737	65651.33333333333
-bob thompson	395	65609	65651.33333333333
-bob thompson	399	65686	65651.33333333333
-bob thompson	359	65768	65651.33333333333
-bob thompson	372	65731	65651.33333333333
-bob thompson	480	65552	65651.33333333333
-bob underhill	443	65678	65634.78571428571
-bob underhill	463	65683	65634.78571428571
-bob underhill	358	65592	65634.78571428571
-bob underhill	348	65626	65634.78571428571
-bob underhill	312	65598	65634.78571428571
-bob underhill	339	65544	65634.78571428571
-bob underhill	355	65621	65634.78571428571
-bob underhill	454	65627	65634.78571428571
-bob underhill	404	65595	65634.78571428571
-bob underhill	393	65666	65634.78571428571
-bob underhill	356	65561	65634.78571428571
-bob underhill	349	65627	65634.78571428571
-bob underhill	465	65735	65634.78571428571
-bob underhill	290	65734	65634.78571428571
-bob van buren	412	65609	65665.28571428571
-bob van buren	440	65730	65665.28571428571
-bob van buren	452	65706	65665.28571428571
-bob van buren	492	65619	65665.28571428571
-bob van buren	445	65778	65665.28571428571
-bob van buren	378	65672	65665.28571428571
-bob van buren	406	65582	65665.28571428571
-bob van buren	303	65647	65665.28571428571
-bob van buren	262	65771	65665.28571428571
-bob van buren	301	65661	65665.28571428571
-bob van buren	446	65565	65665.28571428571
-bob van buren	433	65654	65665.28571428571
-bob van buren	290	65573	65665.28571428571
-bob van buren	327	65747	65665.28571428571
-bob white	351	65777	65676.21052631579
-bob white	353	65739	65676.21052631579
-bob white	373	65764	65676.21052631579
-bob white	313	65543	65676.21052631579
-bob white	308	65782	65676.21052631579
-bob white	469	65728	65676.21052631579
-bob white	391	65649	65676.21052631579
-bob white	472	65670	65676.21052631579
-bob white	340	65767	65676.21052631579
-bob white	348	65646	65676.21052631579
-bob white	481	65723	65676.21052631579
-bob white	281	65605	65676.21052631579
-bob white	484	65587	65676.21052631579
-bob white	420	65643	65676.21052631579
-bob white	389	65623	65676.21052631579
-bob white	440	65661	65676.21052631579
-bob white	289	65786	65676.21052631579
-bob white	344	65555	65676.21052631579
-bob white	340	65600	65676.21052631579
-bob xylophone	452	65730	65658.57142857143
-bob xylophone	471	65543	65658.57142857143
-bob xylophone	495	65648	65658.57142857143
-bob xylophone	405	65595	65658.57142857143
-bob xylophone	455	65746	65658.57142857143
-bob xylophone	454	65545	65658.57142857143
-bob xylophone	437	65560	65658.57142857143
-bob xylophone	385	65570	65658.57142857143
-bob xylophone	348	65770	65658.57142857143
-bob xylophone	427	65666	65658.57142857143
-bob xylophone	335	65574	65658.57142857143
-bob xylophone	335	65732	65658.57142857143
-bob xylophone	323	65751	65658.57142857143
-bob xylophone	440	65718	65658.57142857143
-bob xylophone	405	65734	65658.57142857143
-bob xylophone	388	65574	65658.57142857143
-bob xylophone	279	65771	65658.57142857143
-bob xylophone	265	65546	65658.57142857143
-bob xylophone	442	65756	65658.57142857143
-bob xylophone	507	65549	65658.57142857143
-bob xylophone	408	65752	65658.57142857143
-bob young	321	65727	65684.17647058824
-bob young	448	65726	65684.17647058824
-bob young	348	65556	65684.17647058824
-bob young	504	65694	65684.17647058824
-bob young	317	65758	65684.17647058824
-bob young	415	65635	65684.17647058824
-bob young	453	65735	65684.17647058824
-bob young	288	65599	65684.17647058824
-bob young	468	65654	65684.17647058824
-bob young	494	65629	65684.17647058824
-bob young	263	65778	65684.17647058824
-bob young	349	65777	65684.17647058824
-bob young	299	65621	65684.17647058824
-bob young	449	65589	65684.17647058824
-bob young	459	65727	65684.17647058824
-bob young	410	65758	65684.17647058824
-bob young	488	65668	65684.17647058824
-bob zipper	352	65559	65655.36363636363
-bob zipper	279	65715	65655.36363636363
-bob zipper	419	65633	65655.36363636363
-bob zipper	344	65714	65655.36363636363
-bob zipper	309	65546	65655.36363636363
-bob zipper	338	65713	65655.36363636363
-bob zipper	442	65745	65655.36363636363
-bob zipper	273	65739	65655.36363636363
-bob zipper	307	65612	65655.36363636363
-bob zipper	464	65659	65655.36363636363
-bob zipper	321	65574	65655.36363636363
-calvin allen	437	65726	65671.81818181818
-calvin allen	479	65751	65671.81818181818
-calvin allen	326	65676	65671.81818181818
-calvin allen	466	65747	65671.81818181818
-calvin allen	443	65681	65671.81818181818
-calvin allen	351	65701	65671.81818181818
-calvin allen	360	65575	65671.81818181818
-calvin allen	309	65538	65671.81818181818
-calvin allen	276	65661	65671.81818181818
-calvin allen	432	65669	65671.81818181818
-calvin allen	499	65665	65671.81818181818
-calvin brown	262	65726	65657.15384615384
-calvin brown	371	65620	65657.15384615384
-calvin brown	469	65580	65657.15384615384
-calvin brown	344	65677	65657.15384615384
-calvin brown	320	65756	65657.15384615384
-calvin brown	392	65738	65657.15384615384
-calvin brown	365	65601	65657.15384615384
-calvin brown	437	65637	65657.15384615384
-calvin brown	389	65749	65657.15384615384
-calvin brown	346	65552	65657.15384615384
-calvin brown	355	65537	65657.15384615384
-calvin brown	477	65692	65657.15384615384
-calvin brown	364	65678	65657.15384615384
-calvin carson	264	65614	65651.94117647059
-calvin carson	440	65778	65651.94117647059
-calvin carson	310	65686	65651.94117647059
-calvin carson	450	65688	65651.94117647059
-calvin carson	389	65682	65651.94117647059
-calvin carson	397	65668	65651.94117647059
-calvin carson	464	65543	65651.94117647059
-calvin carson	333	65607	65651.94117647059
-calvin carson	295	65663	65651.94117647059
-calvin carson	401	65613	65651.94117647059
-calvin carson	373	65728	65651.94117647059
-calvin carson	341	65697	65651.94117647059
-calvin carson	447	65546	65651.94117647059
-calvin carson	507	65595	65651.94117647059
-calvin carson	344	65557	65651.94117647059
-calvin carson	440	65781	65651.94117647059
-calvin carson	435	65637	65651.94117647059
-calvin davidson	301	65716	65671.71428571429
-calvin davidson	309	65689	65671.71428571429
-calvin davidson	427	65704	65671.71428571429
-calvin davidson	258	65780	65671.71428571429
-calvin davidson	360	65771	65671.71428571429
-calvin davidson	347	65578	65671.71428571429
-calvin davidson	466	65541	65671.71428571429
-calvin davidson	337	65547	65671.71428571429
-calvin davidson	389	65752	65671.71428571429
-calvin davidson	411	65772	65671.71428571429
-calvin davidson	478	65775	65671.71428571429
-calvin davidson	264	65564	65671.71428571429
-calvin davidson	506	65632	65671.71428571429
-calvin davidson	468	65583	65671.71428571429
-calvin ellison	436	65677	65643.21428571429
-calvin ellison	439	65667	65643.21428571429
-calvin ellison	345	65718	65643.21428571429
-calvin ellison	488	65649	65643.21428571429
-calvin ellison	351	65757	65643.21428571429
-calvin ellison	370	65542	65643.21428571429
-calvin ellison	368	65567	65643.21428571429
-calvin ellison	382	65547	65643.21428571429
-calvin ellison	389	65604	65643.21428571429
-calvin ellison	266	65734	65643.21428571429
-calvin ellison	283	65624	65643.21428571429
-calvin ellison	412	65612	65643.21428571429
-calvin ellison	306	65601	65643.21428571429
-calvin ellison	273	65706	65643.21428571429
-calvin falkner	315	65747	65673.64705882352
-calvin falkner	411	65722	65673.64705882352
-calvin falkner	337	65625	65673.64705882352
-calvin falkner	369	65674	65673.64705882352
-calvin falkner	266	65762	65673.64705882352
-calvin falkner	357	65632	65673.64705882352
-calvin falkner	282	65738	65673.64705882352
-calvin falkner	422	65784	65673.64705882352
-calvin falkner	372	65573	65673.64705882352
-calvin falkner	337	65616	65673.64705882352
-calvin falkner	428	65565	65673.64705882352
-calvin falkner	464	65673	65673.64705882352
-calvin falkner	451	65680	65673.64705882352
-calvin falkner	266	65710	65673.64705882352
-calvin falkner	268	65778	65673.64705882352
-calvin falkner	307	65596	65673.64705882352
-calvin falkner	287	65577	65673.64705882352
-calvin garcia	319	65589	65688.875
-calvin garcia	292	65714	65688.875
-calvin garcia	432	65570	65688.875
-calvin garcia	412	65663	65688.875
-calvin garcia	375	65757	65688.875
-calvin garcia	389	65570	65688.875
-calvin garcia	365	65754	65688.875
-calvin garcia	399	65664	65688.875
-calvin garcia	511	65755	65688.875
-calvin garcia	413	65730	65688.875
-calvin garcia	368	65692	65688.875
-calvin garcia	280	65743	65688.875
-calvin garcia	300	65770	65688.875
-calvin garcia	446	65716	65688.875
-calvin garcia	335	65556	65688.875
-calvin garcia	281	65779	65688.875
-calvin hernandez	376	65665	65690.94117647059
-calvin hernandez	283	65788	65690.94117647059
-calvin hernandez	369	65546	65690.94117647059
-calvin hernandez	313	65687	65690.94117647059
-calvin hernandez	422	65589	65690.94117647059
-calvin hernandez	443	65706	65690.94117647059
-calvin hernandez	288	65578	65690.94117647059
-calvin hernandez	507	65779	65690.94117647059
-calvin hernandez	345	65765	65690.94117647059
-calvin hernandez	464	65716	65690.94117647059
-calvin hernandez	506	65745	65690.94117647059
-calvin hernandez	460	65688	65690.94117647059
-calvin hernandez	313	65672	65690.94117647059
-calvin hernandez	372	65728	65690.94117647059
-calvin hernandez	434	65721	65690.94117647059
-calvin hernandez	415	65785	65690.94117647059
-calvin hernandez	446	65588	65690.94117647059
-calvin ichabod	271	65619	65691.76923076923
-calvin ichabod	453	65744	65691.76923076923
-calvin ichabod	385	65713	65691.76923076923
-calvin ichabod	497	65778	65691.76923076923
-calvin ichabod	324	65721	65691.76923076923
-calvin ichabod	431	65635	65691.76923076923
-calvin ichabod	317	65671	65691.76923076923
-calvin ichabod	432	65759	65691.76923076923
-calvin ichabod	268	65720	65691.76923076923
-calvin ichabod	273	65760	65691.76923076923
-calvin ichabod	322	65543	65691.76923076923
-calvin ichabod	505	65643	65691.76923076923
-calvin ichabod	467	65687	65691.76923076923
-calvin johnson	401	65714	65673.80952380953
-calvin johnson	356	65735	65673.80952380953
-calvin johnson	380	65746	65673.80952380953
-calvin johnson	256	65653	65673.80952380953
-calvin johnson	456	65766	65673.80952380953
-calvin johnson	461	65583	65673.80952380953
-calvin johnson	415	65731	65673.80952380953
-calvin johnson	421	65541	65673.80952380953
-calvin johnson	299	65692	65673.80952380953
-calvin johnson	258	65603	65673.80952380953
-calvin johnson	412	65572	65673.80952380953
-calvin johnson	398	65731	65673.80952380953
-calvin johnson	409	65721	65673.80952380953
-calvin johnson	350	65639	65673.80952380953
-calvin johnson	310	65652	65673.80952380953
-calvin johnson	327	65730	65673.80952380953
-calvin johnson	472	65614	65673.80952380953
-calvin johnson	465	65698	65673.80952380953
-calvin johnson	483	65704	65673.80952380953
-calvin johnson	383	65640	65673.80952380953
-calvin johnson	354	65685	65673.80952380953
-calvin king	400	65624	65684.35294117648
-calvin king	467	65773	65684.35294117648
-calvin king	424	65756	65684.35294117648
-calvin king	280	65596	65684.35294117648
-calvin king	443	65624	65684.35294117648
-calvin king	467	65708	65684.35294117648
-calvin king	423	65751	65684.35294117648
-calvin king	372	65556	65684.35294117648
-calvin king	348	65645	65684.35294117648
-calvin king	344	65605	65684.35294117648
-calvin king	311	65777	65684.35294117648
-calvin king	290	65670	65684.35294117648
-calvin king	263	65725	65684.35294117648
-calvin king	275	65692	65684.35294117648
-calvin king	443	65724	65684.35294117648
-calvin king	328	65684	65684.35294117648
-calvin king	503	65724	65684.35294117648
-calvin laertes	316	65687	65639.76923076923
-calvin laertes	329	65643	65639.76923076923
-calvin laertes	317	65684	65639.76923076923
-calvin laertes	500	65544	65639.76923076923
-calvin laertes	355	65668	65639.76923076923
-calvin laertes	419	65683	65639.76923076923
-calvin laertes	430	65570	65639.76923076923
-calvin laertes	447	65652	65639.76923076923
-calvin laertes	390	65564	65639.76923076923
-calvin laertes	326	65652	65639.76923076923
-calvin laertes	271	65541	65639.76923076923
-calvin laertes	385	65772	65639.76923076923
-calvin laertes	511	65657	65639.76923076923
-calvin miller	359	65664	65668.0
-calvin miller	429	65634	65668.0
-calvin miller	340	65740	65668.0
-calvin miller	414	65789	65668.0
-calvin miller	510	65662	65668.0
-calvin miller	350	65611	65668.0
-calvin miller	457	65616	65668.0
-calvin miller	267	65709	65668.0
-calvin miller	424	65599	65668.0
-calvin miller	422	65710	65668.0
-calvin miller	392	65573	65668.0
-calvin miller	342	65700	65668.0
-calvin miller	284	65780	65668.0
-calvin miller	467	65586	65668.0
-calvin miller	376	65550	65668.0
-calvin miller	425	65619	65668.0
-calvin miller	439	65713	65668.0
-calvin miller	345	65769	65668.0
-calvin nixon	302	65575	65662.35294117648
-calvin nixon	278	65680	65662.35294117648
-calvin nixon	389	65724	65662.35294117648
-calvin nixon	396	65592	65662.35294117648
-calvin nixon	468	65693	65662.35294117648
-calvin nixon	422	65570	65662.35294117648
-calvin nixon	316	65654	65662.35294117648
-calvin nixon	468	65611	65662.35294117648
-calvin nixon	325	65785	65662.35294117648
-calvin nixon	307	65695	65662.35294117648
-calvin nixon	380	65741	65662.35294117648
-calvin nixon	261	65681	65662.35294117648
-calvin nixon	511	65724	65662.35294117648
-calvin nixon	412	65567	65662.35294117648
-calvin nixon	369	65544	65662.35294117648
-calvin nixon	391	65749	65662.35294117648
-calvin nixon	377	65675	65662.35294117648
-calvin ovid	475	65554	65644.5
-calvin ovid	421	65616	65644.5
-calvin ovid	405	65715	65644.5
-calvin ovid	304	65580	65644.5
-calvin ovid	401	65693	65644.5
-calvin ovid	457	65548	65644.5
-calvin ovid	412	65704	65644.5
-calvin ovid	437	65670	65644.5
-calvin ovid	488	65718	65644.5
-calvin ovid	297	65639	65644.5
-calvin ovid	333	65669	65644.5
-calvin ovid	458	65554	65644.5
-calvin ovid	499	65787	65644.5
-calvin ovid	300	65663	65644.5
-calvin ovid	457	65559	65644.5
-calvin ovid	496	65643	65644.5
-calvin polk	391	65660	65657.53333333334
-calvin polk	306	65671	65657.53333333334
-calvin polk	403	65753	65657.53333333334
-calvin polk	337	65552	65657.53333333334
-calvin polk	298	65729	65657.53333333334
-calvin polk	424	65684	65657.53333333334
-calvin polk	417	65600	65657.53333333334
-calvin polk	471	65561	65657.53333333334
-calvin polk	289	65635	65657.53333333334
-calvin polk	424	65731	65657.53333333334
-calvin polk	466	65612	65657.53333333334
-calvin polk	429	65588	65657.53333333334
-calvin polk	325	65636	65657.53333333334
-calvin polk	494	65782	65657.53333333334
-calvin polk	457	65669	65657.53333333334
-calvin quirinius	360	65710	65664.125
-calvin quirinius	378	65606	65664.125
-calvin quirinius	296	65602	65664.125
-calvin quirinius	263	65769	65664.125
-calvin quirinius	353	65601	65664.125
-calvin quirinius	299	65662	65664.125
-calvin quirinius	376	65708	65664.125
-calvin quirinius	509	65576	65664.125
-calvin quirinius	316	65766	65664.125
-calvin quirinius	270	65762	65664.125
-calvin quirinius	449	65704	65664.125
-calvin quirinius	421	65579	65664.125
-calvin quirinius	395	65741	65664.125
-calvin quirinius	399	65572	65664.125
-calvin quirinius	369	65721	65664.125
-calvin quirinius	470	65547	65664.125
-calvin robinson	359	65748	65650.07692307692
-calvin robinson	425	65708	65650.07692307692
-calvin robinson	419	65597	65650.07692307692
-calvin robinson	316	65691	65650.07692307692
-calvin robinson	435	65683	65650.07692307692
-calvin robinson	458	65548	65650.07692307692
-calvin robinson	492	65604	65650.07692307692
-calvin robinson	374	65601	65650.07692307692
-calvin robinson	362	65628	65650.07692307692
-calvin robinson	322	65697	65650.07692307692
-calvin robinson	354	65607	65650.07692307692
-calvin robinson	356	65581	65650.07692307692
-calvin robinson	462	65758	65650.07692307692
-calvin steinbeck	467	65658	65666.93333333333
-calvin steinbeck	381	65687	65666.93333333333
-calvin steinbeck	323	65612	65666.93333333333
-calvin steinbeck	432	65692	65666.93333333333
-calvin steinbeck	325	65575	65666.93333333333
-calvin steinbeck	282	65615	65666.93333333333
-calvin steinbeck	355	65548	65666.93333333333
-calvin steinbeck	258	65762	65666.93333333333
-calvin steinbeck	477	65680	65666.93333333333
-calvin steinbeck	429	65777	65666.93333333333
-calvin steinbeck	400	65740	65666.93333333333
-calvin steinbeck	479	65649	65666.93333333333
-calvin steinbeck	476	65563	65666.93333333333
-calvin steinbeck	273	65779	65666.93333333333
-calvin steinbeck	306	65667	65666.93333333333
-calvin thompson	496	65640	65633.3125
-calvin thompson	298	65576	65633.3125
-calvin thompson	494	65740	65633.3125
-calvin thompson	436	65609	65633.3125
-calvin thompson	415	65629	65633.3125
-calvin thompson	420	65680	65633.3125
-calvin thompson	411	65560	65633.3125
-calvin thompson	453	65661	65633.3125
-calvin thompson	263	65614	65633.3125
-calvin thompson	412	65640	65633.3125
-calvin thompson	389	65544	65633.3125
-calvin thompson	425	65774	65633.3125
-calvin thompson	354	65597	65633.3125
-calvin thompson	497	65684	65633.3125
-calvin thompson	374	65649	65633.3125
-calvin thompson	439	65536	65633.3125
-calvin underhill	454	65659	65681.66666666667
-calvin underhill	462	65732	65681.66666666667
-calvin underhill	285	65759	65681.66666666667
-calvin underhill	449	65644	65681.66666666667
-calvin underhill	502	65540	65681.66666666667
-calvin underhill	278	65554	65681.66666666667
-calvin underhill	268	65748	65681.66666666667
-calvin underhill	264	65785	65681.66666666667
-calvin underhill	347	65714	65681.66666666667
-calvin van buren	474	65757	65685.86666666667
-calvin van buren	352	65752	65685.86666666667
-calvin van buren	313	65678	65685.86666666667
-calvin van buren	417	65717	65685.86666666667
-calvin van buren	426	65664	65685.86666666667
-calvin van buren	363	65745	65685.86666666667
-calvin van buren	329	65684	65685.86666666667
-calvin van buren	447	65557	65685.86666666667
-calvin van buren	501	65782	65685.86666666667
-calvin van buren	417	65552	65685.86666666667
-calvin van buren	296	65738	65685.86666666667
-calvin van buren	411	65574	65685.86666666667
-calvin van buren	486	65588	65685.86666666667
-calvin van buren	420	65771	65685.86666666667
-calvin van buren	430	65729	65685.86666666667
-calvin white	280	65548	65632.55555555556
-calvin white	500	65720	65632.55555555556
-calvin white	381	65588	65632.55555555556
-calvin white	457	65583	65632.55555555556
-calvin white	342	65608	65632.55555555556
-calvin white	494	65551	65632.55555555556
-calvin white	478	65765	65632.55555555556
-calvin white	396	65618	65632.55555555556
-calvin white	413	65746	65632.55555555556
-calvin white	303	65649	65632.55555555556
-calvin white	295	65668	65632.55555555556
-calvin white	393	65561	65632.55555555556
-calvin white	350	65683	65632.55555555556
-calvin white	466	65560	65632.55555555556
-calvin white	303	65644	65632.55555555556
-calvin white	414	65788	65632.55555555556
-calvin white	509	65553	65632.55555555556
-calvin white	433	65553	65632.55555555556
-calvin xylophone	313	65726	65674.27777777778
-calvin xylophone	491	65727	65674.27777777778
-calvin xylophone	483	65713	65674.27777777778
-calvin xylophone	260	65621	65674.27777777778
-calvin xylophone	407	65740	65674.27777777778
-calvin xylophone	322	65645	65674.27777777778
-calvin xylophone	457	65722	65674.27777777778
-calvin xylophone	262	65580	65674.27777777778
-calvin xylophone	507	65699	65674.27777777778
-calvin xylophone	438	65575	65674.27777777778
-calvin xylophone	370	65631	65674.27777777778
-calvin xylophone	318	65742	65674.27777777778
-calvin xylophone	305	65767	65674.27777777778
-calvin xylophone	366	65667	65674.27777777778
-calvin xylophone	398	65663	65674.27777777778
-calvin xylophone	462	65699	65674.27777777778
-calvin xylophone	275	65596	65674.27777777778
-calvin xylophone	433	65624	65674.27777777778
-calvin young	379	65574	65641.875
-calvin young	360	65684	65641.875
-calvin young	288	65737	65641.875
-calvin young	503	65647	65641.875
-calvin young	302	65773	65641.875
-calvin young	436	65746	65641.875
-calvin young	318	65639	65641.875
-calvin young	272	65565	65641.875
-calvin young	287	65564	65641.875
-calvin young	330	65788	65641.875
-calvin young	292	65548	65641.875
-calvin young	434	65567	65641.875
-calvin young	427	65540	65641.875
-calvin young	481	65585	65641.875
-calvin young	418	65670	65641.875
-calvin young	256	65643	65641.875
-calvin zipper	300	65595	65652.16666666667
-calvin zipper	485	65739	65652.16666666667
-calvin zipper	300	65685	65652.16666666667
-calvin zipper	305	65600	65652.16666666667
-calvin zipper	279	65776	65652.16666666667
-calvin zipper	305	65673	65652.16666666667
-calvin zipper	433	65721	65652.16666666667
-calvin zipper	403	65562	65652.16666666667
-calvin zipper	459	65737	65652.16666666667
-calvin zipper	354	65619	65652.16666666667
-calvin zipper	380	65611	65652.16666666667
-calvin zipper	463	65653	65652.16666666667
-calvin zipper	283	65546	65652.16666666667
-calvin zipper	380	65647	65652.16666666667
-calvin zipper	439	65787	65652.16666666667
-calvin zipper	260	65574	65652.16666666667
-calvin zipper	432	65545	65652.16666666667
-calvin zipper	351	65669	65652.16666666667
-david allen	377	65604	65666.19047619047
-david allen	333	65607	65666.19047619047
-david allen	300	65768	65666.19047619047
-david allen	407	65588	65666.19047619047
-david allen	408	65736	65666.19047619047
-david allen	335	65617	65666.19047619047
-david allen	329	65676	65666.19047619047
-david allen	393	65747	65666.19047619047
-david allen	371	65765	65666.19047619047
-david allen	346	65609	65666.19047619047
-david allen	510	65691	65666.19047619047
-david allen	331	65565	65666.19047619047
-david allen	497	65729	65666.19047619047
-david allen	297	65666	65666.19047619047
-david allen	475	65561	65666.19047619047
-david allen	339	65728	65666.19047619047
-david allen	357	65730	65666.19047619047
-david allen	293	65726	65666.19047619047
-david allen	368	65606	65666.19047619047
-david allen	328	65588	65666.19047619047
-david allen	467	65683	65666.19047619047
-david brown	277	65749	65671.73333333334
-david brown	444	65678	65671.73333333334
-david brown	417	65555	65671.73333333334
-david brown	360	65702	65671.73333333334
-david brown	267	65637	65671.73333333334
-david brown	357	65601	65671.73333333334
-david brown	257	65691	65671.73333333334
-david brown	405	65785	65671.73333333334
-david brown	461	65760	65671.73333333334
-david brown	497	65669	65671.73333333334
-david brown	356	65596	65671.73333333334
-david brown	415	65738	65671.73333333334
-david brown	302	65590	65671.73333333334
-david brown	380	65681	65671.73333333334
-david brown	417	65644	65671.73333333334
-david carson	356	65628	65666.90909090909
-david carson	259	65703	65666.90909090909
-david carson	385	65663	65666.90909090909
-david carson	347	65677	65666.90909090909
-david carson	392	65789	65666.90909090909
-david carson	270	65702	65666.90909090909
-david carson	273	65592	65666.90909090909
-david carson	374	65589	65666.90909090909
-david carson	434	65627	65666.90909090909
-david carson	426	65776	65666.90909090909
-david carson	278	65590	65666.90909090909
-david davidson	423	65754	65669.61538461539
-david davidson	311	65762	65669.61538461539
-david davidson	423	65649	65669.61538461539
-david davidson	382	65779	65669.61538461539
-david davidson	271	65627	65669.61538461539
-david davidson	443	65664	65669.61538461539
-david davidson	363	65569	65669.61538461539
-david davidson	341	65756	65669.61538461539
-david davidson	308	65559	65669.61538461539
-david davidson	276	65604	65669.61538461539
-david davidson	256	65778	65669.61538461539
-david davidson	271	65620	65669.61538461539
-david davidson	502	65584	65669.61538461539
-david ellison	390	65583	65659.8125
-david ellison	386	65647	65659.8125
-david ellison	321	65724	65659.8125
-david ellison	295	65540	65659.8125
-david ellison	338	65634	65659.8125
-david ellison	273	65724	65659.8125
-david ellison	339	65692	65659.8125
-david ellison	352	65759	65659.8125
-david ellison	307	65754	65659.8125
-david ellison	339	65710	65659.8125
-david ellison	413	65712	65659.8125
-david ellison	310	65539	65659.8125
-david ellison	371	65702	65659.8125
-david ellison	389	65560	65659.8125
-david ellison	481	65639	65659.8125
-david ellison	483	65638	65659.8125
-david falkner	458	65747	65654.61538461539
-david falkner	421	65638	65654.61538461539
-david falkner	469	65698	65654.61538461539
-david falkner	315	65757	65654.61538461539
-david falkner	387	65604	65654.61538461539
-david falkner	381	65632	65654.61538461539
-david falkner	407	65571	65654.61538461539
-david falkner	296	65718	65654.61538461539
-david falkner	415	65555	65654.61538461539
-david falkner	414	65639	65654.61538461539
-david falkner	321	65596	65654.61538461539
-david falkner	406	65762	65654.61538461539
-david falkner	280	65593	65654.61538461539
-david garcia	258	65582	65691.26666666666
-david garcia	411	65576	65691.26666666666
-david garcia	259	65789	65691.26666666666
-david garcia	485	65684	65691.26666666666
-david garcia	290	65692	65691.26666666666
-david garcia	496	65716	65691.26666666666
-david garcia	425	65752	65691.26666666666
-david garcia	324	65649	65691.26666666666
-david garcia	486	65771	65691.26666666666
-david garcia	332	65750	65691.26666666666
-david garcia	347	65600	65691.26666666666
-david garcia	479	65603	65691.26666666666
-david garcia	396	65770	65691.26666666666
-david garcia	424	65728	65691.26666666666
-david garcia	275	65707	65691.26666666666
-david hernandez	498	65759	65704.75
-david hernandez	410	65787	65704.75
-david hernandez	343	65547	65704.75
-david hernandez	430	65763	65704.75
-david hernandez	415	65780	65704.75
-david hernandez	408	65667	65704.75
-david hernandez	457	65680	65704.75
-david hernandez	279	65655	65704.75
-david ichabod	317	65675	65692.14285714286
-david ichabod	457	65657	65692.14285714286
-david ichabod	472	65699	65692.14285714286
-david ichabod	407	65703	65692.14285714286
-david ichabod	391	65697	65692.14285714286
-david ichabod	335	65699	65692.14285714286
-david ichabod	322	65715	65692.14285714286
-david johnson	277	65565	65637.07142857143
-david johnson	333	65624	65637.07142857143
-david johnson	409	65577	65637.07142857143
-david johnson	497	65671	65637.07142857143
-david johnson	433	65582	65637.07142857143
-david johnson	491	65598	65637.07142857143
-david johnson	314	65685	65637.07142857143
-david johnson	482	65634	65637.07142857143
-david johnson	341	65724	65637.07142857143
-david johnson	480	65593	65637.07142857143
-david johnson	286	65536	65637.07142857143
-david johnson	260	65708	65637.07142857143
-david johnson	301	65719	65637.07142857143
-david johnson	455	65703	65637.07142857143
-david king	262	65555	65649.2
-david king	270	65725	65649.2
-david king	436	65764	65649.2
-david king	439	65545	65649.2
-david king	382	65633	65649.2
-david king	447	65673	65649.2
-david king	368	65657	65649.2
-david king	379	65603	65649.2
-david king	291	65644	65649.2
-david king	425	65732	65649.2
-david king	442	65576	65649.2
-david king	274	65780	65649.2
-david king	305	65689	65649.2
-david king	427	65598	65649.2
-david king	412	65564	65649.2
-david laertes	289	65726	65659.65
-david laertes	301	65585	65659.65
-david laertes	371	65651	65659.65
-david laertes	427	65748	65659.65
-david laertes	282	65722	65659.65
-david laertes	300	65690	65659.65
-david laertes	382	65568	65659.65
-david laertes	408	65551	65659.65
-david laertes	415	65703	65659.65
-david laertes	407	65612	65659.65
-david laertes	342	65734	65659.65
-david laertes	352	65720	65659.65
-david laertes	273	65733	65659.65
-david laertes	451	65541	65659.65
-david laertes	454	65536	65659.65
-david laertes	405	65551	65659.65
-david laertes	437	65762	65659.65
-david laertes	317	65665	65659.65
-david laertes	364	65675	65659.65
-david laertes	330	65720	65659.65
-david miller	298	65669	65713.75
-david miller	427	65757	65713.75
-david miller	492	65690	65713.75
-david miller	450	65727	65713.75
-david miller	464	65717	65713.75
-david miller	499	65594	65713.75
-david miller	311	65777	65713.75
-david miller	315	65779	65713.75
-david nixon	305	65575	65660.42857142857
-david nixon	289	65758	65660.42857142857
-david nixon	474	65578	65660.42857142857
-david nixon	450	65669	65660.42857142857
-david nixon	369	65740	65660.42857142857
-david nixon	440	65547	65660.42857142857
-david nixon	310	65749	65660.42857142857
-david nixon	397	65678	65660.42857142857
-david nixon	396	65772	65660.42857142857
-david nixon	497	65536	65660.42857142857
-david nixon	275	65536	65660.42857142857
-david nixon	334	65719	65660.42857142857
-david nixon	285	65674	65660.42857142857
-david nixon	344	65715	65660.42857142857
-david ovid	329	65628	65683.625
-david ovid	299	65741	65683.625
-david ovid	411	65743	65683.625
-david ovid	438	65664	65683.625
-david ovid	396	65762	65683.625
-david ovid	382	65623	65683.625
-david ovid	410	65571	65683.625
-david ovid	475	65777	65683.625
-david ovid	315	65619	65683.625
-david ovid	270	65755	65683.625
-david ovid	359	65695	65683.625
-david ovid	356	65765	65683.625
-david ovid	264	65587	65683.625
-david ovid	336	65578	65683.625
-david ovid	392	65709	65683.625
-david ovid	332	65721	65683.625
-david polk	277	65539	65653.72727272728
-david polk	266	65693	65653.72727272728
-david polk	460	65709	65653.72727272728
-david polk	415	65715	65653.72727272728
-david polk	486	65693	65653.72727272728
-david polk	441	65659	65653.72727272728
-david polk	361	65551	65653.72727272728
-david polk	318	65560	65653.72727272728
-david polk	470	65735	65653.72727272728
-david polk	496	65605	65653.72727272728
-david polk	402	65732	65653.72727272728
-david quirinius	401	65779	65699.78571428571
-david quirinius	400	65777	65699.78571428571
-david quirinius	344	65649	65699.78571428571
-david quirinius	374	65786	65699.78571428571
-david quirinius	464	65569	65699.78571428571
-david quirinius	494	65685	65699.78571428571
-david quirinius	470	65606	65699.78571428571
-david quirinius	468	65780	65699.78571428571
-david quirinius	275	65617	65699.78571428571
-david quirinius	466	65764	65699.78571428571
-david quirinius	374	65676	65699.78571428571
-david quirinius	439	65759	65699.78571428571
-david quirinius	360	65653	65699.78571428571
-david quirinius	473	65697	65699.78571428571
-david robinson	327	65728	65687.8
-david robinson	321	65572	65687.8
-david robinson	375	65775	65687.8
-david robinson	382	65762	65687.8
-david robinson	291	65727	65687.8
-david robinson	289	65735	65687.8
-david robinson	325	65547	65687.8
-david robinson	357	65595	65687.8
-david robinson	378	65737	65687.8
-david robinson	280	65733	65687.8
-david robinson	458	65785	65687.8
-david robinson	345	65778	65687.8
-david robinson	433	65545	65687.8
-david robinson	313	65618	65687.8
-david robinson	311	65680	65687.8
-david steinbeck	339	65715	65682.15384615384
-david steinbeck	427	65699	65682.15384615384
-david steinbeck	375	65758	65682.15384615384
-david steinbeck	413	65612	65682.15384615384
-david steinbeck	267	65546	65682.15384615384
-david steinbeck	276	65788	65682.15384615384
-david steinbeck	347	65699	65682.15384615384
-david steinbeck	469	65780	65682.15384615384
-david steinbeck	376	65547	65682.15384615384
-david steinbeck	403	65546	65682.15384615384
-david steinbeck	439	65700	65682.15384615384
-david steinbeck	496	65724	65682.15384615384
-david steinbeck	262	65754	65682.15384615384
-david thompson	320	65780	65664.66666666667
-david thompson	495	65575	65664.66666666667
-david thompson	273	65766	65664.66666666667
-david thompson	281	65774	65664.66666666667
-david thompson	319	65660	65664.66666666667
-david thompson	313	65550	65664.66666666667
-david thompson	325	65578	65664.66666666667
-david thompson	405	65569	65664.66666666667
-david thompson	420	65612	65664.66666666667
-david thompson	328	65723	65664.66666666667
-david thompson	358	65651	65664.66666666667
-david thompson	363	65738	65664.66666666667
-david underhill	311	65581	65660.27777777778
-david underhill	376	65751	65660.27777777778
-david underhill	370	65631	65660.27777777778
-david underhill	494	65601	65660.27777777778
-david underhill	466	65602	65660.27777777778
-david underhill	361	65662	65660.27777777778
-david underhill	405	65787	65660.27777777778
-david underhill	322	65629	65660.27777777778
-david underhill	394	65594	65660.27777777778
-david underhill	307	65713	65660.27777777778
-david underhill	436	65726	65660.27777777778
-david underhill	395	65666	65660.27777777778
-david underhill	501	65603	65660.27777777778
-david underhill	402	65568	65660.27777777778
-david underhill	498	65767	65660.27777777778
-david underhill	269	65700	65660.27777777778
-david underhill	409	65560	65660.27777777778
-david underhill	394	65744	65660.27777777778
-david van buren	310	65688	65677.13333333333
-david van buren	485	65625	65677.13333333333
-david van buren	459	65710	65677.13333333333
-david van buren	484	65656	65677.13333333333
-david van buren	431	65784	65677.13333333333
-david van buren	318	65692	65677.13333333333
-david van buren	373	65578	65677.13333333333
-david van buren	395	65698	65677.13333333333
-david van buren	366	65551	65677.13333333333
-david van buren	279	65558	65677.13333333333
-david van buren	291	65634	65677.13333333333
-david van buren	364	65733	65677.13333333333
-david van buren	419	65780	65677.13333333333
-david van buren	280	65740	65677.13333333333
-david van buren	447	65730	65677.13333333333
-david white	279	65756	65683.18181818182
-david white	510	65745	65683.18181818182
-david white	326	65678	65683.18181818182
-david white	312	65739	65683.18181818182
-david white	335	65769	65683.18181818182
-david white	401	65720	65683.18181818182
-david white	356	65587	65683.18181818182
-david white	379	65583	65683.18181818182
-david white	466	65539	65683.18181818182
-david white	432	65626	65683.18181818182
-david white	373	65773	65683.18181818182
-david xylophone	264	65537	65657.28571428571
-david xylophone	505	65564	65657.28571428571
-david xylophone	336	65747	65657.28571428571
-david xylophone	355	65639	65657.28571428571
-david xylophone	265	65705	65657.28571428571
-david xylophone	451	65581	65657.28571428571
-david xylophone	303	65764	65657.28571428571
-david xylophone	300	65635	65657.28571428571
-david xylophone	448	65744	65657.28571428571
-david xylophone	269	65631	65657.28571428571
-david xylophone	501	65607	65657.28571428571
-david xylophone	264	65670	65657.28571428571
-david xylophone	486	65787	65657.28571428571
-david xylophone	389	65591	65657.28571428571
-david young	340	65653	65667.36842105263
-david young	455	65738	65667.36842105263
-david young	390	65625	65667.36842105263
-david young	466	65642	65667.36842105263
-david young	320	65630	65667.36842105263
-david young	275	65727	65667.36842105263
-david young	486	65694	65667.36842105263
-david young	308	65704	65667.36842105263
-david young	408	65574	65667.36842105263
-david young	266	65551	65667.36842105263
-david young	460	65653	65667.36842105263
-david young	377	65653	65667.36842105263
-david young	445	65698	65667.36842105263
-david young	472	65765	65667.36842105263
-david young	481	65580	65667.36842105263
-david young	501	65608	65667.36842105263
-david young	332	65707	65667.36842105263
-david young	472	65769	65667.36842105263
-david young	268	65709	65667.36842105263
-david zipper	429	65775	65648.11764705883
-david zipper	381	65606	65648.11764705883
-david zipper	354	65579	65648.11764705883
-david zipper	427	65760	65648.11764705883
-david zipper	416	65749	65648.11764705883
-david zipper	457	65630	65648.11764705883
-david zipper	395	65659	65648.11764705883
-david zipper	376	65566	65648.11764705883
-david zipper	275	65654	65648.11764705883
-david zipper	304	65649	65648.11764705883
-david zipper	407	65686	65648.11764705883
-david zipper	494	65578	65648.11764705883
-david zipper	350	65746	65648.11764705883
-david zipper	416	65580	65648.11764705883
-david zipper	266	65576	65648.11764705883
-david zipper	336	65649	65648.11764705883
-david zipper	452	65576	65648.11764705883
-ethan allen	380	65707	65664.26666666666
-ethan allen	449	65586	65664.26666666666
-ethan allen	277	65712	65664.26666666666
-ethan allen	434	65607	65664.26666666666
-ethan allen	486	65695	65664.26666666666
-ethan allen	498	65650	65664.26666666666
-ethan allen	358	65710	65664.26666666666
-ethan allen	454	65686	65664.26666666666
-ethan allen	271	65624	65664.26666666666
-ethan allen	440	65651	65664.26666666666
-ethan allen	339	65686	65664.26666666666
-ethan allen	368	65585	65664.26666666666
-ethan allen	266	65747	65664.26666666666
-ethan allen	267	65560	65664.26666666666
-ethan allen	465	65758	65664.26666666666
-ethan brown	371	65685	65680.23529411765
-ethan brown	427	65562	65680.23529411765
-ethan brown	446	65733	65680.23529411765
-ethan brown	379	65791	65680.23529411765
-ethan brown	265	65585	65680.23529411765
-ethan brown	381	65598	65680.23529411765
-ethan brown	396	65637	65680.23529411765
-ethan brown	346	65756	65680.23529411765
-ethan brown	454	65760	65680.23529411765
-ethan brown	475	65658	65680.23529411765
-ethan brown	331	65539	65680.23529411765
-ethan brown	485	65780	65680.23529411765
-ethan brown	464	65617	65680.23529411765
-ethan brown	323	65685	65680.23529411765
-ethan brown	427	65722	65680.23529411765
-ethan brown	332	65736	65680.23529411765
-ethan brown	308	65720	65680.23529411765
-ethan carson	443	65678	65689.22727272728
-ethan carson	397	65635	65689.22727272728
-ethan carson	461	65605	65689.22727272728
-ethan carson	508	65769	65689.22727272728
-ethan carson	280	65703	65689.22727272728
-ethan carson	367	65766	65689.22727272728
-ethan carson	359	65720	65689.22727272728
-ethan carson	444	65613	65689.22727272728
-ethan carson	456	65567	65689.227272

<TRUNCATED>

[10/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing.q.out b/ql/src/test/results/clientpositive/vector_windowing.q.out
deleted file mode 100644
index d12b1c1..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing.q.out
+++ /dev/null
@@ -1,9276 +0,0 @@
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size,
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1
-from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size,
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1
-from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int), p_retailprice (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), VALUE._col3 (type: int), VALUE._col5 (type: double)
-          outputColumnNames: _col1, _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col1
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: sum_window_2
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col1 (type: string), _col5 (type: int), rank_window_0 (type: int), dense_rank_window_1 (type: int), round(sum_window_2, 2) (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_name, p_size,
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1
-from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_name, p_size,
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1
-from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_name	p_size	r	dr	s1
-Manufacturer#1	almond antique burnished rose metallic	2	1	1	1173.15
-Manufacturer#1	almond antique burnished rose metallic	2	1	1	2346.3
-Manufacturer#1	almond antique chartreuse lavender yellow	34	3	2	4100.06
-Manufacturer#1	almond antique salmon chartreuse burlywood	6	4	3	5702.65
-Manufacturer#1	almond aquamarine burnished black steel	28	5	4	7117.07
-Manufacturer#1	almond aquamarine pink moccasin thistle	42	6	5	8749.73
-Manufacturer#2	almond antique violet chocolate turquoise	14	1	1	1690.68
-Manufacturer#2	almond antique violet turquoise frosted	40	2	2	3491.38
-Manufacturer#2	almond aquamarine midnight light salmon	2	3	3	5523.36
-Manufacturer#2	almond aquamarine rose maroon antique	25	4	4	7222.02
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	18	5	5	8923.62
-Manufacturer#3	almond antique chartreuse khaki white	17	1	1	1671.68
-Manufacturer#3	almond antique forest lavender goldenrod	14	2	2	2861.95
-Manufacturer#3	almond antique metallic orange dim	19	3	3	4272.34
-Manufacturer#3	almond antique misty red olive	1	4	4	6195.32
-Manufacturer#3	almond antique olive coral navajo	45	5	5	7532.61
-Manufacturer#4	almond antique gainsboro frosted violet	10	1	1	1620.67
-Manufacturer#4	almond antique violet mint lemon	39	2	2	2996.09
-Manufacturer#4	almond aquamarine floral ivory bisque	27	3	3	4202.35
-Manufacturer#4	almond aquamarine yellow dodger mint	7	4	4	6047.27
-Manufacturer#4	almond azure aquamarine papaya violet	12	5	5	7337.62
-Manufacturer#5	almond antique blue firebrick mint	31	1	1	1789.69
-Manufacturer#5	almond antique medium spring khaki	6	2	2	3401.35
-Manufacturer#5	almond antique sky peru orange	2	3	3	5190.08
-Manufacturer#5	almond aquamarine dodger light gainsboro	46	4	4	6208.18
-Manufacturer#5	almond azure blanched chiffon midnight	23	5	5	7672.66
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, 
-min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name)as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, 
-min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name)as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Select Operator
-              expressions: p_name (type: string), p_mfgr (type: string), p_size (type: int), p_retailprice (type: double)
-              outputColumnNames: p_name, p_mfgr, p_size, p_retailprice
-              Select Vectorization:
-                  className: VectorSelectOperator
-                  native: true
-                  projectedOutputColumnNums: [1, 2, 5, 7]
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: min(p_retailprice)
-                Group By Vectorization:
-                    aggregators: VectorUDAFMinDouble(col 7:double) -> double
-                    className: VectorGroupByOperator
-                    groupByMode: HASH
-                    keyExpressions: col 2:string, col 1:string, col 5:int
-                    native: false
-                    vectorProcessingMode: HASH
-                    projectedOutputColumnNums: [0]
-                keys: p_mfgr (type: string), p_name (type: string), p_size (type: int)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2, _col3
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
-                  sort order: +++
-                  Map-reduce partition columns: _col0 (type: string)
-                  Reduce Sink Vectorization:
-                      className: VectorReduceSinkOperator
-                      native: false
-                      nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                      nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-                  Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col3 (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: min(VALUE._col0)
-          keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2, _col3
-          Statistics: Num rows: 13 Data size: 1573 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: string, _col1: string, _col2: int, _col3: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col1
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: lag_window_2
-                        arguments: _col2, 1, _col2
-                        name: lag
-                        window function: GenericUDAFLagEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 13 Data size: 1573 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int), _col3 (type: double), rank_window_0 (type: int), dense_rank_window_1 (type: int), _col2 (type: int), (_col2 - lag_window_2) (type: int)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7
-              Statistics: Num rows: 13 Data size: 1573 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 13 Data size: 1573 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_name, p_size, 
-min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name)as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_name, p_size, 
-min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name)as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_name	p_size	_c3	r	dr	p_size	deltasz
-Manufacturer#1	almond antique burnished rose metallic	2	1173.15	1	1	2	0
-Manufacturer#1	almond antique chartreuse lavender yellow	34	1753.76	2	2	34	32
-Manufacturer#1	almond antique salmon chartreuse burlywood	6	1602.59	3	3	6	-28
-Manufacturer#1	almond aquamarine burnished black steel	28	1414.42	4	4	28	22
-Manufacturer#1	almond aquamarine pink moccasin thistle	42	1632.66	5	5	42	14
-Manufacturer#2	almond antique violet chocolate turquoise	14	1690.68	1	1	14	0
-Manufacturer#2	almond antique violet turquoise frosted	40	1800.7	2	2	40	26
-Manufacturer#2	almond aquamarine midnight light salmon	2	2031.98	3	3	2	-38
-Manufacturer#2	almond aquamarine rose maroon antique	25	1698.66	4	4	25	23
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	18	1701.6	5	5	18	-7
-Manufacturer#3	almond antique chartreuse khaki white	17	1671.68	1	1	17	0
-Manufacturer#3	almond antique forest lavender goldenrod	14	1190.27	2	2	14	-3
-Manufacturer#3	almond antique metallic orange dim	19	1410.39	3	3	19	5
-Manufacturer#3	almond antique misty red olive	1	1922.98	4	4	1	-18
-Manufacturer#3	almond antique olive coral navajo	45	1337.29	5	5	45	44
-Manufacturer#4	almond antique gainsboro frosted violet	10	1620.67	1	1	10	0
-Manufacturer#4	almond antique violet mint lemon	39	1375.42	2	2	39	29
-Manufacturer#4	almond aquamarine floral ivory bisque	27	1206.26	3	3	27	-12
-Manufacturer#4	almond aquamarine yellow dodger mint	7	1844.92	4	4	7	-20
-Manufacturer#4	almond azure aquamarine papaya violet	12	1290.35	5	5	12	5
-Manufacturer#5	almond antique blue firebrick mint	31	1789.69	1	1	31	0
-Manufacturer#5	almond antique medium spring khaki	6	1611.66	2	2	6	-25
-Manufacturer#5	almond antique sky peru orange	2	1788.73	3	3	2	-4
-Manufacturer#5	almond aquamarine dodger light gainsboro	46	1018.1	4	4	46	44
-Manufacturer#5	almond azure blanched chiffon midnight	23	1464.48	5	5	23	-23
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-having p_size > 0
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-having p_size > 0
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Filter Operator
-              Filter Vectorization:
-                  className: VectorFilterOperator
-                  native: true
-                  predicateExpression: FilterLongColGreaterLongScalar(col 5:int, val 0)
-              predicate: (p_size > 0) (type: boolean)
-              Statistics: Num rows: 8 Data size: 968 Basic stats: COMPLETE Column stats: NONE
-              Group By Operator
-                aggregations: min(p_retailprice)
-                Group By Vectorization:
-                    aggregators: VectorUDAFMinDouble(col 7:double) -> double
-                    className: VectorGroupByOperator
-                    groupByMode: HASH
-                    keyExpressions: col 2:string, col 1:string, col 5:int
-                    native: false
-                    vectorProcessingMode: HASH
-                    projectedOutputColumnNums: [0]
-                keys: p_mfgr (type: string), p_name (type: string), p_size (type: int)
-                mode: hash
-                outputColumnNames: _col0, _col1, _col2, _col3
-                Statistics: Num rows: 8 Data size: 968 Basic stats: COMPLETE Column stats: NONE
-                Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
-                  sort order: +++
-                  Map-reduce partition columns: _col0 (type: string)
-                  Reduce Sink Vectorization:
-                      className: VectorReduceSinkOperator
-                      native: false
-                      nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                      nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-                  Statistics: Num rows: 8 Data size: 968 Basic stats: COMPLETE Column stats: NONE
-                  value expressions: _col3 (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Group By Operator
-          aggregations: min(VALUE._col0)
-          keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
-          mode: mergepartial
-          outputColumnNames: _col0, _col1, _col2, _col3
-          Statistics: Num rows: 4 Data size: 484 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: string, _col1: string, _col2: int, _col3: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col1
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: lag_window_2
-                        arguments: _col2, 1, _col2
-                        name: lag
-                        window function: GenericUDAFLagEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 4 Data size: 484 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int), _col3 (type: double), rank_window_0 (type: int), dense_rank_window_1 (type: int), _col2 (type: int), (_col2 - lag_window_2) (type: int)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7
-              Statistics: Num rows: 4 Data size: 484 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 4 Data size: 484 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_name, p_size, min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-having p_size > 0
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_name, p_size, min(p_retailprice),
-rank() over(distribute by p_mfgr sort by p_name) as r,
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz
-from part
-group by p_mfgr, p_name, p_size
-having p_size > 0
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_name	p_size	_c3	r	dr	p_size	deltasz
-Manufacturer#1	almond antique burnished rose metallic	2	1173.15	1	1	2	0
-Manufacturer#1	almond antique chartreuse lavender yellow	34	1753.76	2	2	34	32
-Manufacturer#1	almond antique salmon chartreuse burlywood	6	1602.59	3	3	6	-28
-Manufacturer#1	almond aquamarine burnished black steel	28	1414.42	4	4	28	22
-Manufacturer#1	almond aquamarine pink moccasin thistle	42	1632.66	5	5	42	14
-Manufacturer#2	almond antique violet chocolate turquoise	14	1690.68	1	1	14	0
-Manufacturer#2	almond antique violet turquoise frosted	40	1800.7	2	2	40	26
-Manufacturer#2	almond aquamarine midnight light salmon	2	2031.98	3	3	2	-38
-Manufacturer#2	almond aquamarine rose maroon antique	25	1698.66	4	4	25	23
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	18	1701.6	5	5	18	-7
-Manufacturer#3	almond antique chartreuse khaki white	17	1671.68	1	1	17	0
-Manufacturer#3	almond antique forest lavender goldenrod	14	1190.27	2	2	14	-3
-Manufacturer#3	almond antique metallic orange dim	19	1410.39	3	3	19	5
-Manufacturer#3	almond antique misty red olive	1	1922.98	4	4	1	-18
-Manufacturer#3	almond antique olive coral navajo	45	1337.29	5	5	45	44
-Manufacturer#4	almond antique gainsboro frosted violet	10	1620.67	1	1	10	0
-Manufacturer#4	almond antique violet mint lemon	39	1375.42	2	2	39	29
-Manufacturer#4	almond aquamarine floral ivory bisque	27	1206.26	3	3	27	-12
-Manufacturer#4	almond aquamarine yellow dodger mint	7	1844.92	4	4	7	-20
-Manufacturer#4	almond azure aquamarine papaya violet	12	1290.35	5	5	12	5
-Manufacturer#5	almond antique blue firebrick mint	31	1789.69	1	1	31	0
-Manufacturer#5	almond antique medium spring khaki	6	1611.66	2	2	6	-25
-Manufacturer#5	almond antique sky peru orange	2	1788.73	3	3	2	-4
-Manufacturer#5	almond aquamarine dodger light gainsboro	46	1018.1	4	4	46	44
-Manufacturer#5	almond azure blanched chiffon midnight	23	1464.48	5	5	23	-23
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_name, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd 
-from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_name, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd 
-from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), VALUE._col3 (type: int)
-          outputColumnNames: _col1, _col2, _col5
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string, _col5: int
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: count_window_0
-                        arguments: _col5
-                        name: count
-                        window function: GenericUDAFCountEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col1 (type: string), count_window_0 (type: bigint)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_name, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd 
-from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_name, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd 
-from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_name	cd
-Manufacturer#1	almond antique burnished rose metallic	2
-Manufacturer#1	almond antique burnished rose metallic	2
-Manufacturer#1	almond antique chartreuse lavender yellow	3
-Manufacturer#1	almond antique salmon chartreuse burlywood	4
-Manufacturer#1	almond aquamarine burnished black steel	5
-Manufacturer#1	almond aquamarine pink moccasin thistle	6
-Manufacturer#2	almond antique violet chocolate turquoise	1
-Manufacturer#2	almond antique violet turquoise frosted	2
-Manufacturer#2	almond aquamarine midnight light salmon	3
-Manufacturer#2	almond aquamarine rose maroon antique	4
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	5
-Manufacturer#3	almond antique chartreuse khaki white	1
-Manufacturer#3	almond antique forest lavender goldenrod	2
-Manufacturer#3	almond antique metallic orange dim	3
-Manufacturer#3	almond antique misty red olive	4
-Manufacturer#3	almond antique olive coral navajo	5
-Manufacturer#4	almond antique gainsboro frosted violet	1
-Manufacturer#4	almond antique violet mint lemon	2
-Manufacturer#4	almond aquamarine floral ivory bisque	3
-Manufacturer#4	almond aquamarine yellow dodger mint	4
-Manufacturer#4	almond azure aquamarine papaya violet	5
-Manufacturer#5	almond antique blue firebrick mint	1
-Manufacturer#5	almond antique medium spring khaki	2
-Manufacturer#5	almond antique sky peru orange	3
-Manufacturer#5	almond aquamarine dodger light gainsboro	4
-Manufacturer#5	almond azure blanched chiffon midnight	5
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int), p_retailprice (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), VALUE._col3 (type: int), VALUE._col5 (type: double)
-          outputColumnNames: _col1, _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col1
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: count_window_2
-                        arguments: _col5
-                        name: count
-                        window function: GenericUDAFCountEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: sum_window_3
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: lag_window_4
-                        arguments: _col5, 1, _col5
-                        name: lag
-                        window function: GenericUDAFLagEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col1 (type: string), rank_window_0 (type: int), dense_rank_window_1 (type: int), count_window_2 (type: bigint), _col7 (type: double), round(sum_window_3, 2) (type: double), _col5 (type: int), (_col5 - lag_window_4) (type: int)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_name	r	dr	cd	p_retailprice	s1	p_size	deltasz
-Manufacturer#1	almond antique burnished rose metallic	1	1	2	1173.15	1173.15	2	0
-Manufacturer#1	almond antique burnished rose metallic	1	1	2	1173.15	2346.3	2	0
-Manufacturer#1	almond antique chartreuse lavender yellow	3	2	3	1753.76	4100.06	34	32
-Manufacturer#1	almond antique salmon chartreuse burlywood	4	3	4	1602.59	5702.65	6	-28
-Manufacturer#1	almond aquamarine burnished black steel	5	4	5	1414.42	7117.07	28	22
-Manufacturer#1	almond aquamarine pink moccasin thistle	6	5	6	1632.66	8749.73	42	14
-Manufacturer#2	almond antique violet chocolate turquoise	1	1	1	1690.68	1690.68	14	0
-Manufacturer#2	almond antique violet turquoise frosted	2	2	2	1800.7	3491.38	40	26
-Manufacturer#2	almond aquamarine midnight light salmon	3	3	3	2031.98	5523.36	2	-38
-Manufacturer#2	almond aquamarine rose maroon antique	4	4	4	1698.66	7222.02	25	23
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	5	5	5	1701.6	8923.62	18	-7
-Manufacturer#3	almond antique chartreuse khaki white	1	1	1	1671.68	1671.68	17	0
-Manufacturer#3	almond antique forest lavender goldenrod	2	2	2	1190.27	2861.95	14	-3
-Manufacturer#3	almond antique metallic orange dim	3	3	3	1410.39	4272.34	19	5
-Manufacturer#3	almond antique misty red olive	4	4	4	1922.98	6195.32	1	-18
-Manufacturer#3	almond antique olive coral navajo	5	5	5	1337.29	7532.61	45	44
-Manufacturer#4	almond antique gainsboro frosted violet	1	1	1	1620.67	1620.67	10	0
-Manufacturer#4	almond antique violet mint lemon	2	2	2	1375.42	2996.09	39	29
-Manufacturer#4	almond aquamarine floral ivory bisque	3	3	3	1206.26	4202.35	27	-12
-Manufacturer#4	almond aquamarine yellow dodger mint	4	4	4	1844.92	6047.27	7	-20
-Manufacturer#4	almond azure aquamarine papaya violet	5	5	5	1290.35	7337.62	12	5
-Manufacturer#5	almond antique blue firebrick mint	1	1	1	1789.69	1789.69	31	0
-Manufacturer#5	almond antique medium spring khaki	2	2	2	1611.66	3401.35	6	-25
-Manufacturer#5	almond antique sky peru orange	3	3	3	1788.73	5190.08	2	-4
-Manufacturer#5	almond aquamarine dodger light gainsboro	4	4	4	1018.1	6208.18	46	44
-Manufacturer#5	almond azure blanched chiffon midnight	5	5	5	1464.48	7672.66	23	-23
-PREHOOK: query: explain vectorization detail
-select sub1.r, sub1.dr, sub1.cd, sub1.s1, sub1.deltaSz 
-from (select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part 
-) sub1
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select sub1.r, sub1.dr, sub1.cd, sub1.s1, sub1.deltaSz 
-from (select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part 
-) sub1
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int), p_retailprice (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), VALUE._col3 (type: int), VALUE._col5 (type: double)
-          outputColumnNames: _col1, _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col1
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: count_window_2
-                        arguments: _col5
-                        name: count
-                        window function: GenericUDAFCountEvaluator
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: sum_window_3
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: lag_window_4
-                        arguments: _col5, 1, _col5
-                        name: lag
-                        window function: GenericUDAFLagEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: rank_window_0 (type: int), dense_rank_window_1 (type: int), count_window_2 (type: bigint), round(sum_window_3, 2) (type: double), (_col5 - lag_window_4) (type: int)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select sub1.r, sub1.dr, sub1.cd, sub1.s1, sub1.deltaSz 
-from (select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part 
-) sub1
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select sub1.r, sub1.dr, sub1.cd, sub1.s1, sub1.deltaSz 
-from (select p_mfgr, p_name, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-count(p_size) over(distribute by p_mfgr sort by p_name) as cd, 
-p_retailprice, round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2) as s1,
-p_size, p_size - lag(p_size,1,p_size) over(distribute by p_mfgr sort by p_name) as deltaSz 
-from part 
-) sub1
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-sub1.r	sub1.dr	sub1.cd	sub1.s1	sub1.deltasz
-1	1	1	1620.67	0
-1	1	1	1671.68	0
-1	1	1	1690.68	0
-1	1	1	1789.69	0
-1	1	2	1173.15	0
-1	1	2	2346.3	0
-2	2	2	2861.95	-3
-2	2	2	2996.09	29
-2	2	2	3401.35	-25
-2	2	2	3491.38	26
-3	2	3	4100.06	32
-3	3	3	4202.35	-12
-3	3	3	4272.34	5
-3	3	3	5190.08	-4
-3	3	3	5523.36	-38
-4	3	4	5702.65	-28
-4	4	4	6047.27	-20
-4	4	4	6195.32	-18
-4	4	4	6208.18	44
-4	4	4	7222.02	23
-5	4	5	7117.07	22
-5	5	5	7337.62	5
-5	5	5	7532.61	44
-5	5	5	7672.66	-23
-5	5	5	8923.62	-7
-6	5	6	8749.73	14
-PREHOOK: query: explain vectorization detail
-select abc.p_mfgr, abc.p_name, 
-rank() over(distribute by abc.p_mfgr sort by abc.p_name) as r, 
-dense_rank() over(distribute by abc.p_mfgr sort by abc.p_name) as dr, 
-abc.p_retailprice, round(sum(abc.p_retailprice) over (distribute by abc.p_mfgr sort by abc.p_name rows between unbounded preceding and current row),2) as s1,
-abc.p_size, abc.p_size - lag(abc.p_size,1,abc.p_size) over(distribute by abc.p_mfgr sort by abc.p_name) as deltaSz 
-from noop(on part 
-partition by p_mfgr 
-order by p_name 
-) abc join part p1 on abc.p_partkey = p1.p_partkey
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select abc.p_mfgr, abc.p_name, 
-rank() over(distribute by abc.p_mfgr sort by abc.p_name) as r, 
-dense_rank() over(distribute by abc.p_mfgr sort by abc.p_name) as dr, 
-abc.p_retailprice, round(sum(abc.p_retailprice) over (distribute by abc.p_mfgr sort by abc.p_name rows between unbounded preceding and current row),2) as s1,
-abc.p_size, abc.p_size - lag(abc.p_size,1,abc.p_size) over(distribute by abc.p_mfgr sort by abc.p_name) as deltaSz 
-from noop(on part 
-partition by p_mfgr 
-order by p_name 
-) abc join part p1 on abc.p_partkey = p1.p_partkey
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
-  Stage-3 depends on stages: Stage-2
-  Stage-0 depends on stages: Stage-3
-
-STAGE PLANS:
-  Stage: Stage-1
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            alias: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_partkey (type: int), p_size (type: int), p_retailprice (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [0, 1, 2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col0 (type: int), KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), VALUE._col3 (type: int), VALUE._col5 (type: double)
-          outputColumnNames: _col0, _col1, _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: part
-                  output shape: _col0: int, _col1: string, _col2: string, _col5: int, _col7: double
-                  type: TABLE
-                Partition table definition
-                  input alias: abc
-                  name: noop
-                  order by: _col1 ASC NULLS FIRST
-                  output shape: _col0: int, _col1: string, _col2: string, _col5: int, _col7: double
-                  partition by: _col2
-                  raw input shape:
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: _col0 is not null (type: boolean)
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-2
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            Reduce Output Operator
-              key expressions: _col0 (type: int)
-              sort order: +
-              Map-reduce partition columns: _col0 (type: int)
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: string), _col2 (type: string), _col5 (type: int), _col7 (type: double)
-          TableScan
-            alias: p1
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Filter Operator
-              predicate: p_partkey is not null (type: boolean)
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              Reduce Output Operator
-                key expressions: p_partkey (type: int)
-                sort order: +
-                Map-reduce partition columns: p_partkey (type: int)
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-      Map Vectorization:
-          enabled: false
-          enabledConditionsNotMet: Vectorized map work only works with 1 TableScanOperator IS false
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Join Operator
-          condition map:
-               Inner Join 0 to 1
-          keys:
-            0 _col0 (type: int)
-            1 p_partkey (type: int)
-          outputColumnNames: _col1, _col2, _col5, _col7
-          Statistics: Num rows: 28 Data size: 3461 Basic stats: COMPLETE Column stats: NONE
-          File Output Operator
-            compressed: false
-            table:
-                input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                serde: org.apache.hadoop.hive.serde2.lazybinary.LazyBinarySerDe
-
-  Stage: Stage-3
-    Map Reduce
-      Map Operator Tree:
-          TableScan
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3]
-                projectedColumns: [_col1:string, _col2:string, _col5:int, _col7:double]
-            Reduce Output Operator
-              key expressions: _col2 (type: string), _col1 (type: string)
-              sort order: ++
-              Map-reduce partition columns: _col2 (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 28 Data size: 3461 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col5 (type: int), _col7 (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: []
-          featureSupportInUse: []
-          inputFileFormats: org.apache.hadoop.mapred.SequenceFileInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 4
-              includeColumns: [0, 1, 2, 3]
-              dataColumns: _col1:string, _col2:string, _col5:int, _col7:double
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), VALUE._col3 (type: int), VALUE._col5 (type: double)
-          outputColumnNames: _col1, _col2, _col5, _col7
-          Statistics: Num rows: 28 Data size: 3461 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col1
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: sum_window_2
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-                      window function definition
-                        alias: lag_window_3
-                        arguments: _col5, 1, _col5
-                        name: lag
-                        window function: GenericUDAFLagEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 28 Data size: 3461 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col1 (type: string), rank_window_0 (type: int), dense_rank_window_1 (type: int), _col7 (type: double), round(sum_window_2, 2) (type: double), _col5 (type: int), (_col5 - lag_window_3) (type: int)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7
-              Statistics: Num rows: 28 Data size: 3461 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 28 Data size: 3461 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select abc.p_mfgr, abc.p_name, 
-rank() over(distribute by abc.p_mfgr sort by abc.p_name) as r, 
-dense_rank() over(distribute by abc.p_mfgr sort by abc.p_name) as dr, 
-abc.p_retailprice, round(sum(abc.p_retailprice) over (distribute by abc.p_mfgr sort by abc.p_name rows between unbounded preceding and current row),2) as s1,
-abc.p_size, abc.p_size - lag(abc.p_size,1,abc.p_size) over(distribute by abc.p_mfgr sort by abc.p_name) as deltaSz 
-from noop(on part 
-partition by p_mfgr 
-order by p_name 
-) abc join part p1 on abc.p_partkey = p1.p_partkey
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select abc.p_mfgr, abc.p_name, 
-rank() over(distribute by abc.p_mfgr sort by abc.p_name) as r, 
-dense_rank() over(distribute by abc.p_mfgr sort by abc.p_name) as dr, 
-abc.p_retailprice, round(sum(abc.p_retailprice) over (distribute by abc.p_mfgr sort by abc.p_name rows between unbounded preceding and current row),2) as s1,
-abc.p_size, abc.p_size - lag(abc.p_size,1,abc.p_size) over(distribute by abc.p_mfgr sort by abc.p_name) as deltaSz 
-from noop(on part 
-partition by p_mfgr 
-order by p_name 
-) abc join part p1 on abc.p_partkey = p1.p_partkey
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-abc.p_mfgr	abc.p_name	r	dr	abc.p_retailprice	s1	abc.p_size	deltasz
-Manufacturer#1	almond antique burnished rose metallic	1	1	1173.15	1173.15	2	0
-Manufacturer#1	almond antique burnished rose metallic	1	1	1173.15	2346.3	2	0
-Manufacturer#1	almond antique burnished rose metallic	1	1	1173.15	3519.45	2	0
-Manufacturer#1	almond antique burnished rose metallic	1	1	1173.15	4692.6	2	0
-Manufacturer#1	almond antique chartreuse lavender yellow	5	2	1753.76	6446.36	34	32
-Manufacturer#1	almond antique salmon chartreuse burlywood	6	3	1602.59	8048.95	6	-28
-Manufacturer#1	almond aquamarine burnished black steel	7	4	1414.42	9463.37	28	22
-Manufacturer#1	almond aquamarine pink moccasin thistle	8	5	1632.66	11096.03	42	14
-Manufacturer#2	almond antique violet chocolate turquoise	1	1	1690.68	1690.68	14	0
-Manufacturer#2	almond antique violet turquoise frosted	2	2	1800.7	3491.38	40	26
-Manufacturer#2	almond aquamarine midnight light salmon	3	3	2031.98	5523.36	2	-38
-Manufacturer#2	almond aquamarine rose maroon antique	4	4	1698.66	7222.02	25	23
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	5	5	1701.6	8923.62	18	-7
-Manufacturer#3	almond antique chartreuse khaki white	1	1	1671.68	1671.68	17	0
-Manufacturer#3	almond antique forest lavender goldenrod	2	2	1190.27	2861.95	14	-3
-Manufacturer#3	almond antique metallic orange dim	3	3	1410.39	4272.34	19	5
-Manufacturer#3	almond antique misty red olive	4	4	1922.98	6195.32	1	-18
-Manufacturer#3	almond antique olive coral navajo	5	5	1337.29	7532.61	45	44
-Manufacturer#4	almond antique gainsboro frosted violet	1	1	1620.67	1620.67	10	0
-Manufacturer#4	almond antique violet mint lemon	2	2	1375.42	2996.09	39	29
-Manufacturer#4	almond aquamarine floral ivory bisque	3	3	1206.26	4202.35	27	-12
-Manufacturer#4	almond aquamarine yellow dodger mint	4	4	1844.92	6047.27	7	-20
-Manufacturer#4	almond azure aquamarine papaya violet	5	5	1290.35	7337.62	12	5
-Manufacturer#5	almond antique blue firebrick mint	1	1	1789.69	1789.69	31	0
-Manufacturer#5	almond antique medium spring khaki	2	2	1611.66	3401.35	6	-25
-Manufacturer#5	almond antique sky peru orange	3	3	1788.73	5190.08	2	-4
-Manufacturer#5	almond aquamarine dodger light gainsboro	4	4	1018.1	6208.18	46	44
-Manufacturer#5	almond azure blanched chiffon midnight	5	5	1464.48	7672.66	23	-23
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name, p_size desc) as R
-from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name, p_size desc) as R
-from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string), p_size (type: int)
-              sort order: ++-
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), KEY.reducesinkkey2 (type: int)
-          outputColumnNames: _col1, _col2, _col5
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string, _col5: int
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST, _col5 DESC NULLS LAST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1, _col5
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col1 (type: string), _col5 (type: int), rank_window_0 (type: int)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name, p_size desc) as R
-from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name, p_size desc) as R
-from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_name	p_size	r
-Manufacturer#1	almond antique burnished rose metallic	2	1
-Manufacturer#1	almond antique burnished rose metallic	2	1
-Manufacturer#1	almond antique chartreuse lavender yellow	34	3
-Manufacturer#1	almond antique salmon chartreuse burlywood	6	4
-Manufacturer#1	almond aquamarine burnished black steel	28	5
-Manufacturer#1	almond aquamarine pink moccasin thistle	42	6
-Manufacturer#2	almond antique violet chocolate turquoise	14	1
-Manufacturer#2	almond antique violet turquoise frosted	40	2
-Manufacturer#2	almond aquamarine midnight light salmon	2	3
-Manufacturer#2	almond aquamarine rose maroon antique	25	4
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	18	5
-Manufacturer#3	almond antique chartreuse khaki white	17	1
-Manufacturer#3	almond antique forest lavender goldenrod	14	2
-Manufacturer#3	almond antique metallic orange dim	19	3
-Manufacturer#3	almond antique misty red olive	1	4
-Manufacturer#3	almond antique olive coral navajo	45	5
-Manufacturer#4	almond antique gainsboro frosted violet	10	1
-Manufacturer#4	almond antique violet mint lemon	39	2
-Manufacturer#4	almond aquamarine floral ivory bisque	27	3
-Manufacturer#4	almond aquamarine yellow dodger mint	7	4
-Manufacturer#4	almond azure aquamarine papaya violet	12	5
-Manufacturer#5	almond antique blue firebrick mint	31	1
-Manufacturer#5	almond antique medium spring khaki	6	2
-Manufacturer#5	almond antique sky peru orange	2	3
-Manufacturer#5	almond aquamarine dodger light gainsboro	46	4
-Manufacturer#5	almond azure blanched chiffon midnight	23	5
-PREHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2)  as s1
-from part
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2)  as s1
-from part
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: part
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8]
-                projectedColumns: [p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string]
-            Reduce Output Operator
-              key expressions: p_mfgr (type: string), p_name (type: string)
-              sort order: ++
-              Map-reduce partition columns: p_mfgr (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              value expressions: p_size (type: int), p_retailprice (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 9
-              includeColumns: [1, 2, 5, 7]
-              dataColumns: p_partkey:int, p_name:string, p_mfgr:string, p_brand:string, p_type:string, p_size:int, p_container:string, p_retailprice:double, p_comment:string
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: string), VALUE._col3 (type: int), VALUE._col5 (type: double)
-          outputColumnNames: _col1, _col2, _col5, _col7
-          Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: string, _col2: string, _col5: int, _col7: double
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: dense_rank_window_1
-                        arguments: _col1
-                        name: dense_rank
-                        window function: GenericUDAFDenseRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: sum_window_2
-                        arguments: _col7
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: string), _col1 (type: string), _col5 (type: int), rank_window_0 (type: int), dense_rank_window_1 (type: int), round(sum_window_2, 2) (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
-              Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 26 Data size: 3147 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2)  as s1
-from part
-PREHOOK: type: QUERY
-PREHOOK: Input: default@part
-#### A masked pattern was here ####
-POSTHOOK: query: select p_mfgr, p_name, p_size, 
-rank() over(distribute by p_mfgr sort by p_name) as r, 
-dense_rank() over(distribute by p_mfgr sort by p_name) as dr, 
-round(sum(p_retailprice) over (distribute by p_mfgr sort by p_name rows between unbounded preceding and current row),2)  as s1
-from part
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@part
-#### A masked pattern was here ####
-p_mfgr	p_name	p_size	r	dr	s1
-Manufacturer#1	almond antique burnished rose metallic	2	1	1	1173.15
-Manufacturer#1	almond antique burnished rose metallic	2	1	1	2346.3
-Manufacturer#1	almond antique chartreuse lavender yellow	34	3	2	4100.06
-Manufacturer#1	almond antique salmon chartreuse burlywood	6	4	3	5702.65
-Manufacturer#1	almond aquamarine burnished black steel	28	5	4	7117.07
-Manufacturer#1	almond aquamarine pink moccasin thistle	42	6	5	8749.73
-Manufacturer#2	almond antique violet chocolate turquoise	14	1	1	1690.68
-Manufacturer#2	almond antique violet turquoise frosted	40	2	2	3491.38
-Manufacturer#2	almond aquamarine midnight light salmon	2	3	3	5523.36
-Manufacturer#2	almond aquamarine rose maroon antique	25	4	4	7222.02
-Manufacturer#2	almond aquamarine sandy cyan gainsboro	18	5	5	8923.62
-Manufacturer#3	almond antique chartreuse khaki white	17	1	1	1671.68
-Manufacturer#3	almond antique forest lavender goldenrod	14	2	2	2861.95
-Manufacturer#3	almond antique metallic orange dim	19	3	3	4272.34
-Manufacturer#3	almond antique misty red olive	1	4	4	6195.32
-Manufacturer#3	almond antique olive coral navajo	45	5	5	7532.61
-Manufacturer#4	almond antique gainsboro frosted violet	10	1	1	1620.67
-Manufacturer#4	almond antique violet mint lemon	39	2	2	2996.09
-Manufacturer#4	almond aquamarine floral ivory bisque	27	3	3	4202.35
-Manufacturer#4	almond aquamarine yellow dodger mint	7	4	4	6047.27
-Manufacturer#4	almond azure aquamarine papaya violet	12	5	5	7337

<TRUNCATED>

[07/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_multipartitioning.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_multipartitioning.q.out b/ql/src/test/results/clientpositive/vector_windowing_multipartitioning.q.out
deleted file mode 100644
index 9f1813d..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_multipartitioning.q.out
+++ /dev/null
@@ -1,11320 +0,0 @@
-PREHOOK: query: drop table over10k
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table over10k
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@over10k
-POSTHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal(4,2),  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: explain vectorization detail
-select s, rank() over (partition by s order by si), sum(b) over (partition by s order by si) from over10k
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, rank() over (partition by s order by si), sum(b) over (partition by s order by si) from over10k
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string), si (type: smallint)
-              sort order: ++
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: b (type: bigint)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [1, 3, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(4,2)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: smallint), VALUE._col2 (type: bigint), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col1, _col3, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col1: smallint, _col3: bigint, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col1 ASC NULLS FIRST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: rank_window_0
-                        arguments: _col1
-                        name: rank
-                        window function: GenericUDAFRankEvaluator
-                        window frame: ROWS PRECEDING(MAX)~FOLLOWING(MAX)
-                        isPivotResult: true
-                      window function definition
-                        alias: sum_window_1
-                        arguments: _col3
-                        name: sum
-                        window function: GenericUDAFSumLong
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), rank_window_0 (type: int), sum_window_1 (type: bigint)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              File Output Operator
-                compressed: false
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                table:
-                    input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                    output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                    serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: -1
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, rank() over (partition by s order by si), sum(b) over (partition by s order by si) from over10k
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, rank() over (partition by s order by si), sum(b) over (partition by s order by si) from over10k
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	rank_window_0	sum_window_1
-alice allen	1	4294967503
-alice allen	2	8589934990
-alice allen	3	12884902428
-alice allen	4	17179869743
-alice allen	5	21474837237
-alice allen	6	30064772191
-alice allen	6	30064772191
-alice allen	8	34359739722
-alice brown	1	4294967391
-alice brown	2	8589934706
-alice brown	3	12884902122
-alice brown	4	17179869504
-alice brown	5	21474836859
-alice brown	6	25769804175
-alice brown	7	30064771680
-alice brown	8	34359739221
-alice brown	9	38654706641
-alice brown	10	42949674011
-alice brown	11	47244641313
-alice brown	12	51539608718
-alice brown	13	55834576122
-alice brown	14	60129543595
-alice carson	1	4294967446
-alice carson	2	8589934775
-alice carson	3	12884902150
-alice carson	4	17179869461
-alice carson	5	21474836824
-alice carson	6	25769804187
-alice carson	7	30064771550
-alice carson	8	34359738920
-alice carson	9	38654706240
-alice carson	10	42949673743
-alice davidson	1	4294967453
-alice davidson	2	8589934978
-alice davidson	3	12884902338
-alice davidson	4	17179869653
-alice davidson	5	21474836975
-alice davidson	6	25769804493
-alice davidson	7	30064772010
-alice davidson	8	34359739463
-alice davidson	9	38654706943
-alice davidson	10	47244641824
-alice davidson	10	47244641824
-alice davidson	12	51539609264
-alice davidson	13	55834576590
-alice davidson	14	60129544020
-alice davidson	15	64424511548
-alice davidson	16	68719479029
-alice davidson	17	73014446462
-alice davidson	18	77309413954
-alice ellison	1	4294967496
-alice ellison	2	8589934942
-alice ellison	3	12884902454
-alice ellison	4	17179869870
-alice ellison	5	21474837181
-alice ellison	6	25769804587
-alice ellison	7	30064772066
-alice ellison	8	34359739616
-alice ellison	9	38654706933
-alice ellison	10	42949674421
-alice ellison	11	47244641904
-alice ellison	12	51539609208
-alice ellison	13	55834576596
-alice ellison	14	60129544054
-alice ellison	15	64424511508
-alice falkner	1	4294967377
-alice falkner	2	8589934805
-alice falkner	3	12884902121
-alice falkner	4	17179869431
-alice falkner	5	21474836879
-alice falkner	6	25769804283
-alice falkner	7	30064771719
-alice falkner	8	38654706491
-alice falkner	8	38654706491
-alice falkner	10	42949673903
-alice falkner	11	51539608896
-alice falkner	11	51539608896
-alice falkner	13	55834576336
-alice falkner	14	60129543752
-alice falkner	15	64424511125
-alice falkner	16	68719478658
-alice falkner	17	73014445956
-alice garcia	1	4294967303
-alice garcia	2	8589934839
-alice garcia	3	12884902276
-alice garcia	4	17179869705
-alice garcia	5	21474837050
-alice garcia	6	25769804353
-alice garcia	7	30064771681
-alice garcia	8	34359739213
-alice garcia	9	38654706564
-alice garcia	10	47244641402
-alice garcia	10	47244641402
-alice garcia	12	51539608899
-alice garcia	13	55834576425
-alice hernandez	1	4294967345
-alice hernandez	2	8589934782
-alice hernandez	3	12884902197
-alice hernandez	4	17179869695
-alice hernandez	5	21474837123
-alice hernandez	6	25769804540
-alice hernandez	7	30064771939
-alice hernandez	8	34359739291
-alice hernandez	9	38654706633
-alice hernandez	10	42949673947
-alice hernandez	11	51539608696
-alice hernandez	11	51539608696
-alice hernandez	13	55834576212
-alice hernandez	14	60129543753
-alice hernandez	15	64424511159
-alice hernandez	16	68719478495
-alice hernandez	17	73014445794
-alice hernandez	18	77309413194
-alice ichabod	1	8589934867
-alice ichabod	1	8589934867
-alice ichabod	3	12884902292
-alice ichabod	4	17179869746
-alice ichabod	5	21474837191
-alice ichabod	6	25769804551
-alice ichabod	7	30064772057
-alice ichabod	8	34359739392
-alice ichabod	9	42949674325
-alice ichabod	9	42949674325
-alice ichabod	11	47244641874
-alice ichabod	12	51539609351
-alice ichabod	13	55834576801
-alice ichabod	14	68719478884
-alice ichabod	14	68719478884
-alice ichabod	14	68719478884
-alice ichabod	17	73014446221
-alice ichabod	18	77309413662
-alice ichabod	19	81604381174
-alice ichabod	20	85899348577
-alice ichabod	21	90194316061
-alice ichabod	22	94489283569
-alice johnson	1	4294967394
-alice johnson	2	8589934818
-alice johnson	3	12884902316
-alice johnson	4	17179869792
-alice johnson	5	21474837331
-alice johnson	6	25769804652
-alice johnson	7	30064772030
-alice johnson	8	34359739501
-alice johnson	9	38654706853
-alice johnson	10	42949674273
-alice johnson	11	47244641696
-alice johnson	12	51539609075
-alice king	1	4294967325
-alice king	2	8589934854
-alice king	3	12884902241
-alice king	4	17179869580
-alice king	5	21474837055
-alice king	6	30064771927
-alice king	6	30064771927
-alice king	8	34359739357
-alice king	9	38654706713
-alice king	10	42949674182
-alice king	11	47244641530
-alice king	12	51539608840
-alice king	13	55834576144
-alice king	14	60129543459
-alice king	15	64424511005
-alice king	16	68719478512
-alice laertes	1	4294967519
-alice laertes	2	8589934924
-alice laertes	3	12884902353
-alice laertes	4	17179869728
-alice laertes	5	21474837277
-alice laertes	6	30064772158
-alice laertes	6	30064772158
-alice laertes	8	34359739472
-alice laertes	9	38654706992
-alice laertes	10	42949674449
-alice laertes	11	47244641960
-alice laertes	12	51539609313
-alice laertes	13	55834576832
-alice laertes	14	60129544373
-alice laertes	15	64424511875
-alice laertes	16	68719479245
-alice miller	1	4294967430
-alice miller	2	8589934911
-alice miller	3	12884902274
-alice miller	4	17179869735
-alice miller	5	21474837202
-alice miller	6	25769804640
-alice miller	7	30064771958
-alice miller	8	34359739296
-alice miller	9	38654706804
-alice miller	10	42949674128
-alice miller	11	47244641483
-alice miller	12	51539608987
-alice miller	13	55834576480
-alice miller	14	60129543902
-alice miller	15	64424511270
-alice miller	16	68719478767
-alice nixon	1	8589934937
-alice nixon	1	8589934937
-alice nixon	3	12884902438
-alice nixon	4	17179869922
-alice nixon	5	21474837327
-alice nixon	6	25769804680
-alice nixon	7	30064772103
-alice nixon	8	34359739593
-alice nixon	9	38654707017
-alice nixon	10	42949674427
-alice nixon	11	47244641749
-alice nixon	12	51539609058
-alice nixon	13	55834576388
-alice nixon	14	60129543787
-alice nixon	15	64424511200
-alice nixon	16	68719478635
-alice nixon	17	73014446030
-alice nixon	18	77309413333
-alice ovid	1	4294967514
-alice ovid	2	8589934909
-alice ovid	3	12884902321
-alice ovid	4	17179869745
-alice ovid	5	21474837247
-alice ovid	6	25769804653
-alice ovid	7	30064772055
-alice ovid	8	34359739569
-alice ovid	9	38654706875
-alice ovid	10	42949674255
-alice ovid	11	47244641754
-alice ovid	12	51539609087
-alice ovid	13	55834576412
-alice ovid	14	60129543745
-alice ovid	15	64424511093
-alice ovid	16	68719478465
-alice ovid	17	73014445961
-alice polk	1	4294967366
-alice polk	2	8589934847
-alice polk	3	12884902165
-alice polk	4	17179869597
-alice polk	5	21474836969
-alice polk	6	25769804375
-alice polk	7	30064771903
-alice polk	8	34359739238
-alice polk	9	38654706576
-alice polk	10	42949673986
-alice polk	11	47244641399
-alice polk	12	51539608883
-alice polk	13	55834576322
-alice polk	14	60129543637
-alice quirinius	1	4294967505
-alice quirinius	2	8589934981
-alice quirinius	3	17179869756
-alice quirinius	3	17179869756
-alice quirinius	5	21474837139
-alice quirinius	6	25769804663
-alice quirinius	7	30064772127
-alice quirinius	8	34359739599
-alice quirinius	9	38654707029
-alice quirinius	10	42949674405
-alice quirinius	11	47244641754
-alice quirinius	12	51539609175
-alice quirinius	13	55834576724
-alice quirinius	14	60129544222
-alice quirinius	15	64424511581
-alice robinson	1	4294967506
-alice robinson	2	8589934857
-alice robinson	3	12884902353
-alice robinson	4	17179869784
-alice robinson	5	21474837286
-alice robinson	6	25769804650
-alice robinson	7	30064772000
-alice robinson	8	34359739458
-alice robinson	9	38654706895
-alice robinson	10	47244641897
-alice robinson	10	47244641897
-alice robinson	12	51539609275
-alice robinson	13	55834576715
-alice robinson	14	60129544030
-alice robinson	15	64424511350
-alice robinson	16	68719478843
-alice robinson	17	73014446288
-alice steinbeck	1	4294967520
-alice steinbeck	2	8589934886
-alice steinbeck	3	12884902219
-alice steinbeck	4	17179869609
-alice steinbeck	5	21474837083
-alice steinbeck	6	25769804388
-alice steinbeck	7	30064771738
-alice steinbeck	8	34359739287
-alice steinbeck	9	38654706712
-alice steinbeck	10	42949674176
-alice steinbeck	11	47244641540
-alice steinbeck	12	51539609014
-alice steinbeck	13	55834576397
-alice steinbeck	14	60129543804
-alice steinbeck	15	64424511260
-alice steinbeck	16	68719478658
-alice thompson	1	4294967337
-alice thompson	2	8589934761
-alice thompson	3	12884902209
-alice thompson	4	21474836990
-alice thompson	4	21474836990
-alice thompson	6	25769804512
-alice thompson	7	30064771899
-alice thompson	8	34359739290
-alice thompson	9	38654706595
-alice underhill	1	4294967331
-alice underhill	2	8589934735
-alice underhill	3	12884902038
-alice underhill	4	17179869439
-alice underhill	5	21474836853
-alice underhill	6	30064771635
-alice underhill	6	30064771635
-alice underhill	8	34359739076
-alice underhill	9	38654706443
-alice underhill	10	42949673931
-alice underhill	11	47244641278
-alice underhill	12	51539608580
-alice underhill	13	55834575899
-alice underhill	14	60129543395
-alice van buren	1	4294967549
-alice van buren	2	8589935055
-alice van buren	3	12884902541
-alice van buren	4	17179869906
-alice van buren	5	21474837222
-alice van buren	6	25769804759
-alice van buren	7	30064772240
-alice van buren	8	34359739558
-alice van buren	9	38654706986
-alice white	1	4294967394
-alice white	2	8589934853
-alice white	3	12884902355
-alice white	4	17179869869
-alice white	5	21474837376
-alice white	6	25769804920
-alice white	7	30064772412
-alice white	8	34359739821
-alice white	9	38654707328
-alice white	10	42949674661
-alice xylophone	1	4294967355
-alice xylophone	2	8589934846
-alice xylophone	3	12884902273
-alice xylophone	4	17179869678
-alice xylophone	5	25769804549
-alice xylophone	5	25769804549
-alice xylophone	7	30064771867
-alice xylophone	8	34359739297
-alice xylophone	9	38654706816
-alice xylophone	10	42949674234
-alice xylophone	11	47244641546
-alice xylophone	12	51539608852
-alice xylophone	13	55834576381
-alice xylophone	14	60129543742
-alice xylophone	15	64424511100
-alice xylophone	16	68719478405
-alice xylophone	17	73014445785
-alice xylophone	18	77309413226
-alice xylophone	19	81604380641
-alice xylophone	20	85899348082
-alice xylophone	21	90194315445
-alice xylophone	22	94489282957
-alice young	1	4294967533
-alice young	2	8589935035
-alice young	3	12884902356
-alice young	4	17179869692
-alice young	5	21474837185
-alice young	6	25769804648
-alice young	7	30064771953
-alice young	8	34359739323
-alice young	9	38654706683
-alice young	10	42949674060
-alice young	11	47244641550
-alice zipper	1	4294967497
-alice zipper	2	8589934960
-alice zipper	3	12884902256
-alice zipper	4	17179869616
-alice zipper	5	21474837060
-alice zipper	6	25769804513
-alice zipper	7	30064771925
-alice zipper	8	34359739296
-alice zipper	9	38654706676
-alice zipper	10	42949674215
-alice zipper	11	47244641583
-alice zipper	12	51539609103
-bob allen	1	4294967326
-bob allen	2	12884902039
-bob allen	2	12884902039
-bob allen	4	17179869398
-bob allen	5	21474836737
-bob allen	6	25769804219
-bob allen	7	30064771676
-bob allen	8	34359739107
-bob allen	9	38654706515
-bob allen	10	42949673985
-bob brown	1	4294967343
-bob brown	2	8589934774
-bob brown	3	12884902215
-bob brown	4	17179869555
-bob brown	5	21474837100
-bob brown	6	25769804575
-bob brown	7	30064772120
-bob brown	8	34359739542
-bob brown	9	38654706969
-bob brown	10	42949674456
-bob brown	11	47244641870
-bob brown	12	51539609395
-bob brown	13	55834576911
-bob carson	1	4294967395
-bob carson	2	8589934785
-bob carson	3	12884902259
-bob carson	4	17179869569
-bob carson	5	21474836885
-bob carson	6	25769804344
-bob carson	7	30064771794
-bob carson	8	34359739135
-bob carson	9	38654706518
-bob carson	10	47244641504
-bob carson	10	47244641504
-bob carson	12	51539608984
-bob carson	13	55834576440
-bob carson	14	60129543922
-bob carson	15	64424511329
-bob carson	16	68719478775
-bob carson	17	77309413523
-bob carson	17	77309413523
-bob carson	19	81604380859
-bob carson	20	85899348229
-bob carson	21	90194315718
-bob carson	22	94489283231
-bob carson	23	98784250610
-bob davidson	1	4294967351
-bob davidson	2	8589934812
-bob davidson	3	12884902247
-bob davidson	4	17179869679
-bob davidson	5	21474837047
-bob davidson	6	25769804551
-bob davidson	7	30064772020
-bob davidson	8	34359739552
-bob davidson	9	38654706916
-bob davidson	10	42949674386
-bob davidson	11	47244641706
-bob davidson	12	51539609064
-bob davidson	13	55834576418
-bob ellison	1	4294967495
-bob ellison	2	8589934995
-bob ellison	3	12884902325
-bob ellison	4	17179869716
-bob ellison	5	21474837246
-bob ellison	6	25769804557
-bob ellison	7	30064771870
-bob ellison	8	34359739329
-bob ellison	9	38654706765
-bob ellison	10	42949674127
-bob ellison	11	47244641452
-bob ellison	12	51539608796
-bob ellison	13	55834576160
-bob ellison	14	60129543608
-bob falkner	1	4294967366
-bob falkner	2	8589934911
-bob falkner	3	12884902304
-bob falkner	4	17179869768
-bob falkner	5	21474837124
-bob falkner	6	25769804647
-bob falkner	7	30064772030
-bob falkner	8	34359739333
-bob falkner	9	38654706770
-bob falkner	10	42949674290
-bob falkner	11	47244641747
-bob falkner	12	51539609143
-bob falkner	13	55834576693
-bob falkner	14	60129544176
-bob falkner	15	64424511613
-bob falkner	16	68719478988
-bob falkner	17	73014446478
-bob garcia	1	4294967435
-bob garcia	2	8589934804
-bob garcia	3	12884902148
-bob garcia	4	17179869698
-bob garcia	5	21474837013
-bob garcia	6	25769804498
-bob garcia	7	30064771976
-bob garcia	8	34359739363
-bob garcia	9	38654706661
-bob garcia	10	42949674100
-bob garcia	11	47244641637
-bob garcia	12	51539609188
-bob garcia	13	55834576659
-bob garcia	14	60129543977
-bob garcia	15	64424511475
-bob hernandez	1	4294967360
-bob hernandez	2	8589934883
-bob hernandez	3	12884902190
-bob hernandez	4	17179869549
-bob hernandez	5	21474837020
-bob hernandez	6	25769804487
-bob hernandez	7	30064771966
-bob hernandez	8	34359739347
-bob hernandez	9	38654706801
-bob hernandez	10	42949674229
-bob hernandez	11	47244641533
-bob hernandez	12	55834576424
-bob hernandez	12	55834576424
-bob ichabod	1	4294967527
-bob ichabod	2	8589934853
-bob ichabod	3	12884902265
-bob ichabod	4	17179869572
-bob ichabod	5	21474836974
-bob ichabod	6	25769804286
-bob ichabod	7	30064771819
-bob ichabod	8	34359739214
-bob ichabod	9	38654706745
-bob ichabod	10	42949674226
-bob ichabod	11	47244641670
-bob ichabod	12	51539609135
-bob ichabod	13	55834576679
-bob ichabod	14	60129544223
-bob ichabod	15	64424511666
-bob ichabod	16	73014446639
-bob ichabod	16	73014446639
-bob johnson	1	4294967324
-bob johnson	2	8589934759
-bob johnson	3	12884902263
-bob johnson	4	17179869560
-bob johnson	5	21474837065
-bob johnson	6	25769804539
-bob johnson	7	30064771927
-bob johnson	8	34359739290
-bob johnson	9	38654706744
-bob king	1	4294967494
-bob king	2	8589934876
-bob king	3	12884902319
-bob king	4	17179869616
-bob king	5	21474836931
-bob king	6	25769804263
-bob king	7	34359739073
-bob king	7	34359739073
-bob king	9	38654706534
-bob king	10	42949673972
-bob king	11	47244641413
-bob king	12	51539608898
-bob king	13	55834576396
-bob king	14	60129543935
-bob king	15	64424511356
-bob king	16	68719478875
-bob king	17	73014446218
-bob king	18	77309413669
-bob laertes	1	4294967525
-bob laertes	2	8589935053
-bob laertes	3	12884902520
-bob laertes	4	17179870064
-bob laertes	5	21474837363
-bob laertes	6	25769804835
-bob laertes	7	30064772282
-bob laertes	8	38654707248
-bob laertes	8	38654707248
-bob laertes	10	42949674628
-bob laertes	11	47244641990
-bob laertes	12	51539609482
-bob laertes	13	55834576872
-bob laertes	14	60129544197
-bob laertes	15	64424511590
-bob laertes	16	68719479034
-bob laertes	17	73014446478
-bob miller	1	8589934966
-bob miller	1	8589934966
-bob miller	3	12884902331
-bob miller	4	21474837103
-bob miller	4	21474837103
-bob miller	6	30064771945
-bob miller	6	30064771945
-bob miller	8	34359739267
-bob miller	9	38654706777
-bob miller	10	42949674124
-bob miller	11	47244641473
-bob miller	12	51539608883
-bob nixon	1	4294967525
-bob nixon	2	8589934911
-bob nixon	3	12884902277
-bob nixon	4	17179869629
-bob nixon	5	21474837102
-bob nixon	6	25769804578
-bob nixon	7	30064772019
-bob nixon	8	34359739524
-bob nixon	9	38654707053
-bob nixon	10	42949674539
-bob nixon	11	47244641915
-bob nixon	12	51539609251
-bob nixon	13	55834576683
-bob ovid	1	4294967401
-bob ovid	2	8589934840
-bob ovid	3	12884902383
-bob ovid	4	17179869783
-bob ovid	5	21474837328
-bob ovid	6	25769804864
-bob ovid	7	34359739649
-bob ovid	7	34359739649
-bob ovid	9	38654707140
-bob ovid	10	42949674652
-bob ovid	11	47244642196
-bob ovid	12	51539609663
-bob ovid	13	55834577105
-bob ovid	14	60129544602
-bob ovid	15	64424511961
-bob ovid	16	68719479467
-bob ovid	17	73014446809
-bob ovid	18	77309414204
-bob ovid	19	81604381606
-bob ovid	20	85899349139
-bob ovid	21	90194316687
-bob ovid	22	94489284218
-bob ovid	23	98784251760
-bob ovid	24	103079219163
-bob ovid	25	107374186545
-bob ovid	26	111669154002
-bob ovid	27	115964121300
-bob ovid	28	120259088805
-bob polk	1	4294967398
-bob polk	2	8589934754
-bob polk	3	12884902166
-bob polk	4	17179869503
-bob polk	5	21474836809
-bob polk	6	25769804318
-bob polk	7	30064771713
-bob polk	8	34359739240
-bob polk	9	38654706593
-bob polk	10	42949673992
-bob quirinius	1	4294967516
-bob quirinius	2	8589934833
-bob quirinius	3	12884902147
-bob quirinius	4	17179869565
-bob quirinius	5	21474836987
-bob quirinius	6	25769804383
-bob quirinius	7	30064771753
-bob quirinius	8	34359739168
-bob quirinius	9	38654706501
-bob quirinius	10	42949673873
-bob quirinius	11	47244641189
-bob quirinius	12	51539608517
-bob quirinius	13	55834576007
-bob quirinius	14	60129543368
-bob quirinius	15	64424510714
-bob quirinius	16	68719478259
-bob quirinius	17	73014445792
-bob robinson	1	4294967349
-bob robinson	2	8589934896
-bob robinson	3	12884902365
-bob robinson	4	17179869695
-bob robinson	5	21474837077
-bob robinson	6	30064771848
-bob robinson	6	30064771848
-bob robinson	8	34359739181
-bob robinson	9	38654706606
-bob robinson	10	42949673960
-bob robinson	11	47244641326
-bob robinson	12	51539608734
-bob robinson	13	55834576043
-bob robinson	14	60129543490
-bob robinson	15	64424510832
-bob robinson	16	68719478353
-bob steinbeck	1	4294967344
-bob steinbeck	2	8589934849
-bob steinbeck	3	12884902375
-bob steinbeck	4	17179869847
-bob steinbeck	5	21474837396
-bob steinbeck	6	25769804817
-bob steinbeck	7	30064772317
-bob steinbeck	8	34359739613
-bob steinbeck	9	38654707155
-bob steinbeck	10	42949674497
-bob steinbeck	11	47244642041
-bob thompson	1	4294967346
-bob thompson	2	8589934790
-bob thompson	3	12884902262
-bob thompson	4	17179869798
-bob thompson	5	21474837155
-bob thompson	6	25769804476
-bob thompson	7	30064771937
-bob thompson	8	34359739384
-bob thompson	9	38654706810
-bob thompson	10	42949674248
-bob thompson	11	47244641780
-bob thompson	12	51539609262
-bob underhill	1	4294967366
-bob underhill	2	8589934866
-bob underhill	3	12884902373
-bob underhill	4	17179869746
-bob underhill	5	21474837136
-bob underhill	6	25769804555
-bob underhill	7	30064772040
-bob underhill	8	34359739373
-bob underhill	9	38654706922
-bob underhill	10	42949674396
-bob underhill	11	47244641695
-bob underhill	12	51539609176
-bob underhill	13	55834576504
-bob underhill	14	60129543802
-bob van buren	1	4294967518
-bob van buren	2	8589934992
-bob van buren	3	12884902354
-bob van buren	4	17179869807
-bob van buren	5	21474837329
-bob van buren	6	25769804639
-bob van buren	7	30064771950
-bob van buren	8	34359739451
-bob van buren	9	38654706906
-bob van buren	10	42949674378
-bob van buren	11	47244641800
-bob van buren	12	51539609113
-bob van buren	13	55834576625
-bob van buren	14	60129543984
-bob white	1	4294967493
-bob white	2	8589934993
-bob white	3	12884902433
-bob white	4	17179869795
-bob white	5	25769804734
-bob white	5	25769804734
-bob white	7	30064772097
-bob white	8	34359739550
-bob white	9	38654706932
-bob white	10	42949674277
-bob white	11	47244641707
-bob white	12	51539609172
-bob white	13	55834576587
-bob white	14	60129543905
-bob white	15	64424511453
-bob white	16	68719478766
-bob white	17	73014446305
-bob white	18	77309413707
-bob white	19	81604381117
-bob xylophone	1	4294967465
-bob xylophone	2	8589934793
-bob xylophone	3	12884902241
-bob xylophone	4	21474837236
-bob xylophone	4	21474837236
-bob xylophone	6	25769804643
-bob xylophone	7	30064772018
-bob xylophone	8	34359739425
-bob xylophone	9	42949674315
-bob xylophone	9	42949674315
-bob xylophone	11	47244641798
-bob xylophone	12	51539609263
-bob xylophone	13	55834576811
-bob xylophone	14	60129544179
-bob xylophone	15	64424511578
-bob xylophone	16	68719478904
-bob xylophone	17	73014446344
-bob xylophone	18	77309413694
-bob xylophone	19	81604381204
-bob xylophone	20	85899348572
-bob xylophone	21	90194315965
-bob young	1	4294967521
-bob young	2	8589934943
-bob young	3	12884902397
-bob young	4	17179869802
-bob young	5	21474837122
-bob young	6	25769804535
-bob young	7	30064771941
-bob young	8	34359739478
-bob young	9	38654706895
-bob young	10	42949674342
-bob young	11	47244641868
-bob young	12	51539609366
-bob young	13	55834576741
-bob young	14	60129544102
-bob young	15	64424511611
-bob young	16	68719479094
-bob young	17	73014446526
-bob zipper	1	4294967416
-bob zipper	2	8589934717
-bob zipper	3	12884902192
-bob zipper	4	17179869718
-bob zipper	5	21474837080
-bob zipper	6	25769804395
-bob zipper	7	30064771805
-bob zipper	8	34359739158
-bob zipper	9	38654706457
-bob zipper	10	42949673839
-bob zipper	11	47244641288
-calvin allen	1	4294967539
-calvin allen	2	8589934873
-calvin allen	3	12884902219
-calvin allen	4	17179869680
-calvin allen	5	21474837084
-calvin allen	6	25769804457
-calvin allen	7	30064771823
-calvin allen	8	34359739131
-calvin allen	9	38654706456
-calvin allen	10	42949673834
-calvin allen	11	47244641130
-calvin brown	1	4294967337
-calvin brown	2	8589934684
-calvin brown	3	12884902214
-calvin brown	4	17179869626
-calvin brown	5	21474837063
-calvin brown	6	25769804556
-calvin brown	7	30064771936
-calvin brown	8	34359739241
-calvin brown	9	38654706740
-calvin brown	10	42949674287
-calvin brown	11	47244641781
-calvin brown	12	51539609192
-calvin brown	13	55834576622
-calvin carson	1	4294967415
-calvin carson	2	8589934778
-calvin carson	3	12884902180
-calvin carson	4	17179869496
-calvin carson	5	21474836919
-calvin carson	6	25769804335
-calvin carson	7	30064771736
-calvin carson	8	34359739211
-calvin carson	9	38654706697
-calvin carson	10	42949673998
-calvin carson	11	47244641532
-calvin carson	12	55834576366
-calvin carson	12	55834576366
-calvin carson	14	60129543828
-calvin carson	15	64424511159
-calvin carson	16	68719478610
-calvin carson	17	73014446023
-calvin davidson	1	4294967448
-calvin davidson	2	8589934885
-calvin davidson	3	12884902270
-calvin davidson	4	17179869787
-calvin davidson	5	21474837131
-calvin davidson	6	25769804610
-calvin davidson	7	30064772098
-calvin davidson	8	34359739539
-calvin davidson	9	38654706904
-calvin davidson	10	42949674271
-calvin davidson	11	47244641739
-calvin davidson	12	51539609161
-calvin davidson	13	55834576480
-calvin davidson	14	60129543888
-calvin ellison	1	4294967319
-calvin ellison	2	8589934840
-calvin ellison	3	12884902165
-calvin ellison	4	17179869594
-calvin ellison	5	21474837043
-calvin ellison	6	25769804497
-calvin ellison	7	30064771830
-calvin ellison	8	34359739147
-calvin ellison	9	38654706537
-calvin ellison	10	42949673961
-calvin ellison	11	47244641260
-calvin ellison	12	51539608649
-calvin ellison	13	55834576129
-calvin ellison	14	60129543523
-calvin falkner	1	8589934689
-calvin falkner	1	8589934689
-calvin falkner	3	12884902107
-calvin falkner	4	17179869539
-calvin falkner	5	21474837004
-calvin falkner	6	25769804304
-calvin falkner	7	30064771655
-calvin falkner	8	38654706332
-calvin falkner	8	38654706332
-calvin falkner	10	42949673786
-calvin falkner	11	47244641292
-calvin falkner	12	51539608637
-calvin falkner	13	55834576088
-calvin falkner	14	60129543538
-calvin falkner	15	64424511033
-calvin falkner	16	68719478463
-calvin falkner	17	73014445841
-calvin garcia	1	4294967451
-calvin garcia	2	8589934959
-calvin garcia	3	12884902389
-calvin garcia	4	17179869881
-calvin garcia	5	21474837218
-calvin garcia	6	25769804654
-calvin garcia	7	30064772043
-calvin garcia	8	34359739438
-calvin garcia	9	38654706792
-calvin garcia	10	42949674192
-calvin garcia	11	47244641684
-calvin garcia	12	51539609180
-calvin garcia	13	55834576505
-calvin garcia	14	60129543996
-calvin garcia	15	64424511534
-calvin garcia	16	68719479069
-calvin hernandez	1	4294967313
-calvin hernandez	2	8589934654
-calvin hernandez	3	17179869394
-calvin hernandez	3	17179869394
-calvin hernandez	5	21474836864
-calvin hernandez	6	25769804346
-calvin hernandez	7	30064771831
-calvin hernandez	8	34359739372
-calvin hernandez	9	38654706870
-calvin hernandez	10	42949674358
-calvin hernandez	11	47244641858
-calvin hernandez	12	51539609372
-calvin hernandez	13	55834576903
-calvin hernandez	14	60129544343
-calvin hernandez	15	64424511656
-calvin hernandez	16	68719479114
-calvin hernandez	17	73014446505
-calvin ichabod	1	4294967463
-calvin ichabod	2	8589934776
-calvin ichabod	3	12884902117
-calvin ichabod	4	17179869636
-calvin ichabod	5	21474836944
-calvin ichabod	6	25769804251
-calvin ichabod	7	30064771575
-calvin ichabod	8	34359739075
-calvin ichabod	9	38654706461
-calvin ichabod	10	42949673908
-calvin ichabod	11	47244641446
-calvin ichabod	12	51539608931
-calvin ichabod	13	55834576417
-calvin johnson	1	4294967536
-calvin johnson	2	8589934956
-calvin johnson	3	12884902329
-calvin johnson	4	17179869639
-calvin johnson	5	21474837078
-calvin johnson	6	25769804583
-calvin johnson	7	30064772006
-calvin johnson	8	34359739351
-calvin johnson	9	38654706745
-calvin johnson	10	42949674235
-calvin johnson	11	47244641781
-calvin johnson	12	51539609313
-calvin johnson	13	55834576652
-calvin johnson	14	60129543991
-calvin johnson	15	64424511499
-calvin johnson	16	68719478909
-calvin johnson	17	73014446264
-calvin johnson	18	77309413672
-calvin johnson	19	81604381155
-calvin johnson	20	85899348488
-calvin johnson	21	90194315858
-calvin king	1	4294967341
-calvin king	2	8589934761
-calvin king	3	12884902215
-calvin king	4	17179869750
-calvin king	5	21474837180
-calvin king	6	25769804589
-calvin king	7	30064771977
-calvin king	8	34359739437
-calvin king	9	38654706904
-calvin king	10	42949674281
-calvin king	11	47244641799
-calvin king	12	51539609242
-calvin king	13	60129543972
-calvin king	13	60129543972
-calvin king	15	68719478824
-calvin king	15	68719478824
-calvin king	17	73014446265
-calvin laertes	1	4294967416
-calvin laertes	2	8589934814
-calvin laertes	3	12884902313
-calvin laertes	4	17179869615
-calvin laertes	5	21474836934
-calvin laertes	6	25769804371
-calvin laertes	7	30064771799
-calvin laertes	8	34359739104
-calvin laertes	9	38654706544
-calvin laertes	10	42949673975
-calvin laertes	11	47244641480
-calvin laertes	12	51539608817
-calvin laertes	13	55834576211
-calvin miller	1	4294967405
-calvin miller	2	8589934891
-calvin miller	3	12884902256
-calvin miller	4	17179869733
-calvin miller	5	21474837212
-calvin miller	6	25769804632
-calvin miller	7	30064772173
-calvin miller	8	34359739607
-calvin miller	9	38654707125
-calvin miller	10	42949674617
-calvin miller	11	47244642049
-calvin miller	12	51539609352
-calvin miller	13	55834576690
-calvin miller	14	60129544135
-calvin miller	15	64424511533
-calvin miller	16	68719478942
-calvin miller	17	73014446279
-calvin miller	18	77309413694
-calvin nixon	1	4294967540
-calvin nixon	2	8589934965
-calvin nixon	3	12884902336
-calvin nixon	4	17179869785
-calvin nixon	5	21474837273
-calvin nixon	6	25769804736
-calvin nixon	7	30064772161
-calvin nixon	8	34359739709
-calvin nixon	9	38654707036
-calvin nixon	10	42949674336
-calvin nixon	11	47244641748
-calvin nixon	12	51539609047
-calvin nixon	13	55834576510
-calvin nixon	14	60129543903
-calvin nixon	15	68719478865
-calvin nixon	15	68719478865
-calvin nixon	17	73014446178
-calvin ovid	1	4294967531
-calvin ovid	2	8589934874
-calvin ovid	3	12884902425
-calvin ovid	4	17179869738
-calvin ovid	5	21474837282
-calvin ovid	6	25769804820
-calvin ovid	7	30064772295
-calvin ovid	8	34359739764
-calvin ovid	9	38654707105
-calvin ovid	10	47244642059
-calvin ovid	10	47244642059
-calvin ovid	12	51539609388
-calvin ovid	13	55834576732
-calvin ovid	14	60129544055
-calvin ovid	15	64424511404
-calvin ovid	16	68719478769
-calvin polk	1	4294967475
-calvin polk	2	8589935014
-calvin polk	3	12884902346
-calvin polk	4	17179869693
-calvin polk	5	21474837094
-calvin polk	6	25769804427
-calvin polk	7	30064771813
-calvin polk	8	34359739309
-calvin polk	9	42949674121
-calvin polk	9	42949674121
-calvin polk	11	47244641453
-calvin polk	12	51539608987
-calvin polk	13	55834576443
-calvin polk	14	60129543921
-calvin polk	15	64424511434
-calvin quirinius	1	4294967532
-calvin quirinius	2	8589934978
-calvin quirinius	3	12884902413
-calvin quirinius	4	17179869964
-calvin quirinius	5	21474837326
-calvin quirinius	6	25769804634
-calvin quirinius	7	30064772025
-calvin quirinius	8	34359739515
-calvin quirinius	9	38654706817
-calvin quirinius	10	42949674273
-calvin quirinius	11	47244641794
-calvin quirinius	12	51539609225
-calvin quirinius	13	55834576539
-calvin quirinius	14	60129544071
-calvin quirinius	15	64424511564
-calvin quirinius	16	68719478927
-calvin robinson	1	4294967395
-calvin robinson	2	8589934828
-calvin robinson	3	12884902169
-calvin robinson	4	17179869495
-calvin robinson	5	21474837033
-calvin robinson	6	25769804459
-calvin robinson	7	30064771764
-calvin robinson	8	34359739066
-calvin robinson	9	38654706559
-calvin robinson	10	42949673947
-calvin robinson	11	47244641347
-calvin robinson	12	51539608808
-calvin robinson	13	55834576161
-calvin steinbeck	1	4294967417
-calvin steinbeck	2	8589934891
-calvin steinbeck	3	12884902433
-calvin steinbeck	4	17179869860
-calvin steinbeck	5	21474837404
-calvin steinbeck	6	25769804725
-calvin steinbeck	7	30064772271
-calvin steinbeck	8	34359739639
-calvin steinbeck	9	38654706966
-calvin steinbeck	10	42949674405
-calvin steinbeck	11	47244641918
-calvin steinbeck	12	51539609398
-calvin steinbeck	13	55834576850
-calvin steinbeck	14	60129544355
-calvin steinbeck	15	64424511805
-calvin thompson	1	4294967297
-calvin thompson	2	8589934701
-calvin thompson	3	12884902116
-calvin thompson	4	17179869612
-calvin thompson	5	21474837043
-calvin thompson	6	25769804389
-calvin thompson	7	30064771756
-calvin thompson	8	34359739241
-calvin thompson	9	38654706583
-calvin thompson	10	42949673966
-calvin thompson	11	47244641469
-calvin thompson	12	51539608805
-calvin thompson	13	55834576216
-calvin thompson	14	60129543747
-calvin thompson	15	64424511260
-calvin thompson	16	68719478756
-calvin underhill	1	4294967370
-calvin underhill	2	8589934877
-calvin underhill	3	12884902217
-calvin underhill	4	17179869664
-calvin underhill	5	21474837108
-calvin underhill	6	25769804488
-calvin underhill	7	30064771852
-calvin underhill	8	34359739330
-calvin underhill	9	38654706799
-calvin van buren	1	4294967481
-calvin van buren	2	8589934781
-calvin van buren	3	12884902322
-calvin van buren	4	17179869807
-calvin van buren	5	21474837120
-calvin van buren	6	25769804625
-calvin van buren	7	34359739389
-calvin van buren	7	34359739389
-calvin van buren	9	38654706897
-calvin van buren	10	42949674363
-calvin van buren	11	47244641660
-calvin van buren	12	51539609129
-calvin van buren	13	55834576644
-calvin van buren	14	60129543995
-calvin van buren	15	64424511399
-calvin white	1	4294967350
-calvin white	2	8589934706
-calvin white	3	17179869660
-calvin white	3	17179869660
-calvin white	5	21474837177
-calvin white	6	25769804628
-calvin white	7	30064772048
-calvin white	8	34359739352
-calvin white	9	38654706890
-calvin white	10	42949674436
-calvin white	11	47244641866
-calvin white	12	51539609370
-calvin white	13	55834576883
-calvin white	14	60129544234
-calvin white	15	64424511606
-calvin white	16	68719478946
-calvin white	17	73014446467
-calvin white	18	77309414011
-calvin xylophone	1	4294967456
-calvin xylophone	2	8589935007
-calvin xylophone	3	12884902306
-calvin xylophone	4	17179869835
-calvin xylophone	5	21474837333
-calvin xylophone	6	25769804787
-calvin xylophone	7	30064772087
-calvin xylophone	8	34359739450
-calvin xylophone	9	38654706910
-calvin xylophone	10	42949674400
-calvin xylophone	11	47244641734
-calvin xylophone	12	51539609086
-calvin xylophone	13	55834576462
-calvin xylophone	14	60129543951
-calvin xylophone	15	64424511342
-calvin xylophone	16	68719478800
-calvin xylophone	17	73014446105
-calvin xylophone	18	77309413617
-calvin young	1	4294967351
-calvin young	2	8589934894
-calvin young	3	12884902264
-calvin young	4	17179869674
-calvin young	5	21474837224
-calvin young	6	25769804590
-calvin young	7	30064771929
-calvin young	8	34359739315
-calvin young	9	38654706625
-calvin young	10	42949674035
-calvin young	11	47244641331
-calvin young	12	51539608833
-calvin young	13	55834576314
-calvin young	14	60129543656
-calvin young	15	64424511011
-calvin young	16	68719478532
-calvin zipper	1	4294967497
-calvin zipper	2	8589934880
-calvin zipper	3	12884902198
-calvin zipper	4	21474836905
-calvin zipper	4	21474836905
-calvin zipper	6	30064771774
-calvin zipper	6	30064771774
-calvin zipper	8	34359739215
-calvin zipper	9	38654706627
-calvin zipper	10	47244641491
-calvin zipper	10	47244641491
-calvin zipper	12	51539608930
-calvin zipper	13	55834576430
-calvin zipper	14	60129543967
-calvin zipper	15	64424511292
-calvin zipper	16	68719478747
-calvin zipper	17	73014446230
-calvin zipper	18	77309413749
-david allen	1	4294967311
-david allen	2	8589934628
-david allen	3	12884902001
-david allen	4	17179869501
-david allen	5	21474836820
-david allen	6	25769804278
-david allen	7	30064771668
-david allen	8	34359739049
-david allen	9	38654706460
-david allen	10	42949673892
-david allen	11	47244641427
-david allen	12	51539608850
-david allen	13	55834576387
-david allen	14	60129543785
-david allen	15	64424511151
-david allen	16	68719478522
-david allen	17	73014445987
-david allen	18	77309413386
-david allen	19	81604380897
-david allen	20	85899348333
-david allen	21	90194315794
-david brown	1	4294967305
-david brown	2	8589934849
-david brown	3	12884902240
-david brown	4	17179869587
-david brown	5	21474837027
-david brown	6	25769804364
-david brown	7	30064771675
-david brown	8	34359739166
-david brown	9	38654706680
-david brown	10	42949674102
-david brown	11	51539608926
-david brown	11	51539608926
-david brown	13	55834576281
-david brown	14	60129543607
-david brown	15	64424510972
-david carson	1	4294967352
-david carson	2	8589934864
-david carson	3	12884902255
-david carson	4	17179869577
-david carson	5	21474837087
-david carson	6	25769804562
-david carson	7	30064771880
-david carson	8	34359739301
-david carson	9	38654706700
-david carson	10	42949674229
-david carson	11	47244641604
-david davidson	1	4294967487
-david davidson	2	12884902370
-david davidson	2	12884902370
-david davidson	4	17179869808
-david davidson	5	21474837273
-david davidson	6	25769804818
-david davidson	7	30064772340
-david davidson	8	34359739808
-david davidson	9	38654707153
-david davidson	10	47244641800
-david davidson	10	47244641800
-david davidson	12	51539609307
-david davidson	13	55834576717
-david ellison	1	4294967477
-david ellison	2	8589934909
-david ellison	3	12884902394
-david ellison	4	17179869732
-david ellison	5	21474837218
-david ellison	6	25769804681
-david ellison	7	34359739515
-david ellison	7	34359739515
-david ellison	9	38654707024
-david ellison	10	42949674542
-david ellison	11	47244641978
-david ellison	12	51539609498
-david ellison	13	55834576974
-david ellison	14	60129544486
-david ellison	15	64424511812
-david ellison	16	68719479285
-david falkner	1	4294967529
-david falkner	2	8589934900
-david falkner	3	12884902217
-david falkner	4	17179869720
-david falkner	5	21474837158
-david falkner	6	25769804580
-david falkner	7	30064772023
-david falkner	8	34359739446
-david falkner	9	38654706944
-david falkner	10	42949674462
-david falkner	11	47244641990
-david falkner	12	51539609509
-david falkner	13	55834576866
-david garcia	1	4294967355
-david garcia	2	8589934779
-david garcia	3	12884902098
-david garcia	4	17179869447
-david garcia	5	21474836761
-david garcia	6	25769804192
-david garcia	7	30064771559
-david garcia	8	34359739035
-david garcia	9	38654706343
-david garcia	10	42949673656
-david garcia	11	47244640991
-david garcia	12	51539608311
-david garcia	13	55834575794
-david garcia	14	60129543180
-david garcia	15	64424510575
-david hernandez	1	4294967337
-david hernandez	2	8589934887
-david hernandez	3	12884902396
-david hernandez	4	17179869796
-david hernandez	5	21474837122
-david hernandez	6	25769804446
-david hernandez	7	30064771796
-david hernandez	8	34359739343
-david ichabod	1	4294967478
-david ichabod	2	8589934863
-david ichabod	3	12884902350
-david ichabod	4	17179869796
-david ichabod	5	21474837340
-david ichabod	6	25769804685
-david ichabod	7	30064772137
-david johnson	1	4294967415
-david johnson	2	8589934853
-david johnson	3	12884902343
-david johnson	4	17179869786
-david johnson	5	21474837135
-david johnson	6	25769804533
-david johnson	7	30064771933
-david johnson	8	34359739263
-david johnson	9	38654706797
-david johnson	10	42949674176
-david johnson	11	47244641579
-david johnson	12	51539609000
-david johnson	13	55834576540
-david johnson	14	60129543914
-david king	1	4294967319
-david king	2	8589934843
-david king	3	12884902315
-david king	4	17179869641
-david king	5	21474836966
-david king	6	25769804475
-david king	7	30064771790
-david king	8	34359739134
-david king	9	38654706595
-david king	10	42949673936
-david king	11	47244641382
-david king	12	51539608701
-david king	13	55834576252
-david king	14	60129543589
-david king	15	64424510922
-david laertes	1	4294967305
-david laertes	2	8589934846
-david laertes	3	12884902285
-david laertes	4	17179869705
-david laertes	5	21474837070
-david laertes	6	25769804414
-david laertes	7	30064771965
-david laertes	8	34359739469
-david laertes	9	38654707013
-david laertes	10	42949674473
-david laertes	11	47244641802
-david laertes	12	51539609295
-david laertes	13	55834576816
-david laertes	14	60129544134
-david laertes	15	64424511590
-david laertes	16	68719479128
-david laertes	17	73014446529
-david laertes	18	77309413914
-david laertes	19	81604381281
-david laertes	20	85899348712
-david miller	1	4294967328
-david miller	2	8589934710
-david miller	3	12884902240
-david miller	4	17179869782
-david miller	5	21474837269
-david miller	6	25769804659
-david miller	7	30064772047
-david miller	8	34359739406
-david nixon	1	4294967491
-david nixon	2	8589934911
-david nixon	3	12884902450
-david nixon	4	17179869942
-david nixon	5	21474837393
-david nixon	6	25769804858
-david nixon	7	30064772356
-david nixon	8	34359739885
-david nixon	9	38654707310
-david nixon	10	42949674747
-david nixon	11	47244642263
-david nixon	12	51539609574
-david nixon	13	55834576978
-david nixon	14	60129544359
-david ovid	1	4294967306
-david ovid	2	8589934852
-david ovid	3	12884902284
-david ovid	4	17179869638
-david ovid	5	21474837034
-david ovid	6	25769804330
-david ovid	7	30064771626
-david ovid	8	34359739107
-david ovid	9	38654706601
-david ovid	10	42949674044
-david ovid	11	47244641550
-david ovid	12	51539608891
-david ovid	13	55834576410
-david ovid	14	60129543726
-david ovid	15	64424511168
-david ovid	16	68719478701
-david polk	1	4294967470
-david polk	2	8589934870
-david polk	3	12884902224
-david polk	4	17179869692
-david polk	5	21474837208
-david polk	6	25769804687
-david polk	7	30064772066
-david polk	8	34359739609
-david polk	9	38654706923
-david polk	10	42949674312
-david polk	11	47244641676
-david quirinius	1	4294967478
-david quirinius	2	8589934814
-david quirinius	3	12884902302
-david quirinius	4	21474837146
-david quirinius	4	21474837146
-david quirinius	6	25769804500
-david quirinius	7	30064771875
-david quirinius	8	34359739405
-david quirinius	9	38654706931
-david quirinius	10	42949674437
-david quirinius	11	47244641861
-david quirinius	12	51539609210
-david quirinius	13	55834576667
-david quirinius	14	60129544085
-david robinson	1	4294967378
-david robinson	2	8589934885
-david robinson	3	12884902295
-david robinson	4	17179869708
-david robinson	5	21474837040
-david robinson	6	25769804393
-david robinson	7	30064771703
-david robinson	8	34359739107
-david robinson	9	38654706580
-david robinson	10	42949674037
-david robinson	11	47244641502
-david robinson	12	51539608901
-david robinson	13	55834576369
-david robinson	14	60129543890
-david robinson	15	64424511253
-david steinbeck	1	4294967385
-david steinbeck	2	8589934843
-david steinbeck	3	12884902296
-david steinbeck	4	17179869626
-david steinbeck	5	21474837103
-david steinbeck	6	25769804522
-david steinbeck	7	30064771935
-david steinbeck	8	34359739309
-david steinbeck	9	38654706629
-david steinbeck	10	42949674124
-david steinbeck	11	47244641525
-david steinbeck	12	51539608991
-david steinbeck	13	55834576520
-david thompson	1	4294967499
-david thompson	2	8589934883
-david thompson	3	12884902244
-david thompson	4	17179869595
-david thompson	5	21474837115
-david thompson	6	25769804421
-david thompson	7	30064771794
-david thompson	8	34359739205
-david thompson	9	38654706641
-david thompson	10	42949674129
-david thompson	11	47244641651
-david thompson	12	51539609008
-david underhill	1	4294967439
-david underhill	2	8589934761
-david underhill	3	12884902204
-david underhill	4	17179869735
-david underhill	5	21474837066
-david underhill	6	25769804372
-david underhill	7	30064771756
-david underhill	8	38654706663
-david underhill	8	38654706663
-david underhill	10	42949674156
-david underhill	11	47244641513
-david underhill	12	51539608873
-david underhill	13	55834576311
-david underhill	14	60129543795
-david underhill	15	64424511265
-david underhill	16	68719478668
-david underhill	17	73014446088
-david underhill	18	77309413607
-david van buren	1	4294967524
-david van buren	2	8589934849
-david van buren	3	12884902287
-david van buren	4	17179869761
-david van buren	5	21474837098
-david van buren	6	25769804617
-david van buren	7	30064771945
-david van buren	8	34359739318
-david van buren	9	38654706622
-david van buren	10	42949674080
-david van buren	11	47244641484
-david van buren	12	51539608940
-david van buren	13	55834576294
-david van buren	14	60129543772
-david van buren	15	64424511081
-david white	1	4294967439
-david white	2	8589934789
-david white	3	12884902217
-david white	4	17179869541
-david white	5	21474837050
-david white	6	25769804541
-david white	7	30064771953
-david white	8	34359739465
-david white	9	38654706900
-david white	10	42949674395
-david white	11	47244641853
-david xylophone	1	8589934898
-david xylophone	1	8589934898
-david xylophone	3	12884902444
-david xylophone	4	17179869984
-david xylophone	5	21474837303
-david xylophone	6	25769804783
-david xylophone	7	30064772288
-david xylophone	8	34359739719
-david xylophone	9	38654707180
-david xylophone	10	42949674659
-david xylophone	11	47244642093
-david xylophone	12	51539609519
-david xylophone	13	55834577040
-david xylophone	14	60129544485
-david young	1	4294967296
-david young	2	8589934721
-david young	3	12884902064
-david young	4	17179869588
-david young	5	21474836918
-david young	6	25769804281
-david young	7	30064771608
-david young	8	34359738954
-david young	9	38654706477
-david young	10	42949674023
-david young	11	47244641419
-david young	12	51539608927
-david young	13	55834576356
-david young	14	60129543689
-david young	15	68719478595
-david young	15	68719478595
-david young	17	73014445950
-david young	18	77309413255
-david young	19	81604380745
-david zipper	1	4294967306
-david zipper	2	8589934602
-david zipper	3	12884902056
-david zipper	4	17179869504
-david zipper	5	21474836943
-david zipper	6	25769804448
-david zipper	7	30064771817
-david zipper	8	34359739290
-david zipper	9	38654706693
-david zipper	10	42949673997
-david zipper	11	51539609017
-david zipper	11	51539609017
-david zipper	13	55834576473
-david zipper	14	60129543912
-david zipper	15	64424511286
-david zipper	16	68719478696
-david zipper	17	73014446179
-ethan allen	1	4294967351
-ethan allen	2	8589934789
-ethan allen	3	12884902242
-ethan allen	4	17179869702
-ethan allen	5	21474837246
-ethan allen	6	25769804650
-ethan allen	7	30064771987
-ethan allen	8	34359739513
-ethan allen	9	38654707044
-ethan allen	10	42949674497
-ethan allen	11	47244642037
-ethan allen	12	51539609425
-ethan allen	13	55834576910
-ethan allen	14	60129544247
-ethan allen	15	64424511559
-ethan brown	1	4294967545
-ethan brown	2	8589934993
-ethan brown	3	12884902470
-ethan brown	4	17179869890
-ethan brown	5	21474837224
-ethan brown	6	25769804692
-ethan brown	7	30064772012
-ethan brown	8	34359739402
-ethan brown	9	38654706750
-ethan brown	10	42949674173
-ethan brown	11	51539608858
-ethan brown	11	51539608858
-ethan brown	13	55834576261
-ethan brown	14	60129543738
-ethan brown	15	64424511162
-ethan brown	16	68719478476
-ethan brown	17	73014445851
-ethan carson	1	4294967382
-ethan carson	2	8589934930
-ethan carson	3	12884902273
-ethan carson	4	17179869750
-ethan carson	5	21474837157
-ethan carson	6	30064771978
-ethan carson	6	30064771978
-ethan carson	8	34359739474
-ethan carson	9	38654706979
-ethan carson	10	42949674455
-ethan carson	11	51539609176
-ethan carson	11	51539609176
-ethan carson	13	55834576584
-ethan carson	14	60129544093
-ethan carson	15	64424511398
-ethan carson	16	68719478908
-ethan carson	17	73014446274
-ethan carson	18	77309413591
-ethan carson	19	81604381050
-ethan carson	20	85899348558
-ethan carson	21	90194315910
-ethan carson	22	94489283352
-ethan davidson	1	4294967387
-ethan davidson	2	8589934701
-ethan davidson	3	12884902244
-ethan davidson	4	17179869785
-ethan davidson	5	21474837117
-ethan davidson	6	25769804543
-ethan davidson	7	30064771930
-ethan davidson	8	34359739384
-ethan davidson	9	38654706934
-ethan davidson	10	42949674388
-ethan davidson	11	47244641778
-ethan davidson	12	51539609181
-ethan davidson	13	55834576665
-ethan davidson	14	60129544125
-ethan ellison	1	4294967516
-ethan ellison	2	8589935003
-ethan ellison	3	12884902485
-ethan ellison	4	17179869966
-ethan ellison	5	21474837295
-ethan ellison	6	25769804839
-ethan ellison	7	30064772330
-ethan ellison	8	34359739788
-ethan ellison	9	38654707302
-ethan ellison	10	42949674686
-ethan ellison	11	47244642068
-ethan ellison	12	51539609490
-ethan ellison	13	55834576817
-ethan ellison	14	64424511527
-ethan ellison	14	64424511527
-ethan ellison	16	68719478875
-ethan ellison	17	73014446199
-ethan ellison	18	77309413631
-ethan ellison	19	81604381040
-ethan falkner	1	4294967460
-ethan falkner	2	8589934912
-ethan falkner	3	12884902447
-ethan falkner	4	17179869770
-ethan falkner	5	21474837088
-ethan falkner	6	25769804552
-ethan falkner	7	30064771893
-ethan falkner	8	34359739438
-ethan falkner	9	38654706813
-ethan falkner	10	42949674274
-ethan falkner	11	47244641581
-ethan falkner	12	51539608966
-ethan falkner	13	55834576390
-ethan falkner	14	60129543810
-ethan garcia	1	4294967542
-ethan garcia	2	8589935029
-ethan garcia	3	12884902493
-ethan garcia	4	17179869826
-ethan garcia	5	21474837355
-ethan garcia	6	25769804687
-ethan garcia	7	30064771983
-ethan garcia	8	34359739507
-ethan garcia	9	38654706978
-ethan garcia	10	42949674293
-ethan garcia	11	47244641707
-ethan garcia	12	51539609223
-ethan garcia	13	55834576565
-ethan garcia	14	60129543889
-ethan garcia	15	64424511350
-ethan garcia	16	68719478668
-ethan garcia	17	73014446187
-ethan garcia	18	77309413497
-ethan garcia	19	81604381016
-ethan hernandez	1	4294967309
-ethan hernandez	2	8589934810
-ethan hernandez	3	12884902211
-ethan hernandez	4	17179869532
-ethan hernandez	5	21474836961
-ethan hernandez	6	25769804491
-ethan hernandez	7	30064771867
-ethan hernandez	8	34359739168
-ethan hernandez	9	38654706574
-ethan hernandez	10	42949673923
-ethan hernandez	11	47244641429
-ethan hernandez	12	51539608939
-ethan hernandez	13	55834576343
-ethan ichabod	1	4294967518
-ethan ichabod	2	8589935064
-ethan ichabod	3	12884902592
-ethan ichabod	4	17179869888
-ethan ichabod	5	21474837232
-ethan ichabod	6	25769804737
-ethan ichabod	7	30064772254
-ethan ichabod	8	34359739759
-ethan ichabod	9	38654707145
-ethan ichabod	10	42949674516
-ethan ichabod	11	47244641906
-ethan ichabod	12	51539609439
-ethan ichabod	13	60129544315
-ethan ichabod	13	60129544315
-ethan johnson	1	4294967523
-ethan johnson	2	8589934916
-ethan johnson	3	12884902273
-ethan johnson	4	17179869749
-ethan johnson	5	21474837186
-ethan johnson	6	25769804643
-ethan johnson	7	30064772056
-ethan johnson	8	34359739424
-ethan johnson	9	38654706884
-ethan johnson	10	42949674430
-ethan johnson	11	47244641934
-ethan king	1	4294967411
-ethan king	2	8589934790
-ethan king	3	12884902274
-ethan king	4	17179869755
-ethan king	5	21474837182
-ethan king	6	25769804647
-ethan king	7	30064771991
-ethan king	8	34359739507
-ethan king	9	38654706816
-ethan king	10	42949674229
-ethan king	11	47244641729
-ethan king	12	51539609096
-ethan king	13	55834576491
-ethan king	14	60129543846
-ethan king	15	64424511243
-ethan king	16	68719478688
-ethan king	17	73014446089
-ethan king	18	77309413581
-ethan king	19	81604381010
-ethan king	20	85899348503
-ethan laertes	1	4294967453
-ethan laertes	2	8589934855
-ethan laertes	3	12884902312
-ethan laertes	4	17179869726
-ethan laertes	5	21474837149
-ethan laertes	6	25769804680
-ethan laertes	7	30064772171
-ethan laertes	8	34359739576
-ethan laertes	9	38654707066
-ethan laertes	10	42949674509
-ethan laertes	11	47244642048
-ethan laertes	12	51539609362
-ethan laertes	13	55834576784
-ethan laertes	14	60129544145
-ethan laertes	15	64424511446
-ethan laertes	16	68719478747
-ethan laertes	17	73014446099
-ethan laertes	18	77309413596
-ethan laertes	19	81604380967
-ethan laertes	20	85899348355
-ethan miller	1	4294967352
-ethan miller	2	8589934859
-ethan miller	3	12884902336
-ethan miller	4	17179869763
-ethan miller	5	21474837061
-ethan miller	6	25769804490
-ethan miller	7	30064771803
-ethan miller	8	34359739232
-ethan miller	9	38654706661
-ethan nixon	1	4294967418
-ethan nixon	2	8589934745
-ethan nixon	3	12884902123
-ethan nixon	4	17179869556
-ethan nixon	5	21474836983
-ethan nixon	6	25769804517
-ethan nixon	7	30064771970
-ethan nixon	8	34359739430
-ethan nixon	9	38654706829
-ethan nixon	10	42949674159
-ethan nixon	11	47244641485
-ethan nixon	12	51539608851
-ethan nixon	13	55834576374
-ethan nixon	14	60129543870
-ethan nixon	15	64424511173
-ethan nixon	16	68719478528
-ethan nixon	17	73014446027
-ethan nixon	18	77309413438
-ethan nixon	19	81604380978
-ethan nixon	20	85899348399
-ethan nixon	21	90194315707
-ethan nixon	22	94489283046
-ethan nixon	23	98784250531
-ethan ovid	1	4294967298
-ethan ovid	2	8589934701
-ethan ovid	3	12884902129
-ethan ovid	4	17179869658
-ethan ovid	5	21474836977
-ethan ovid	6	25769804304
-ethan ovid	7	30064771754
-ethan ovid	8	34359739209
-ethan ovid	9	38654706678
-ethan ovid	10	42949674106
-ethan ovid	11	47244641648
-ethan ovid	12	51539609088
-ethan ovid	13	55834576540
-ethan ovid	14	60129544042
-ethan ovid	15	64424511495
-ethan ovid	16	68719478879
-ethan polk	1	4294967533
-ethan polk	2	8589934862
-ethan polk	3	12884902298
-ethan polk	4	21474837088
-ethan polk	4	21474837088
-ethan polk	6	25769804584
-ethan polk	7	30064772024
-ethan polk	8	34359739516
-ethan polk	9	38654706963
-ethan polk	10	42949674505
-ethan polk	11	47244642046
-ethan polk	12	51539609563
-ethan polk	13	55834577062
-ethan polk	14	60129544541
-ethan polk	15	64424512040
-ethan polk	16	68719479440
-ethan quirinius	1	4294967375
-ethan quirinius	2	8589934710
-ethan quirinius	3	12884902211
-ethan quirinius	4	17179869572
-ethan quirinius	5	21474836992
-ethan quirinius	6	25769804473
-ethan quirinius	7	30064771901
-ethan quirinius	8	34359739386
-ethan quirinius	9	38654706904
-ethan quirinius	10	47244641674
-ethan quirinius	10	47244641674
-ethan quirinius	12	51539609022
-ethan quirinius	13	55834576357
-ethan quirinius	14	64424511276
-ethan quirinius	14	64424511276
-ethan quirinius	16	68719478658
-ethan robinson	1	8589934799
-ethan robinson	1	8589934799
-ethan robinson	3	12884902312
-ethan robinson	4	17179869723
-ethan robinson	5	21474837076
-ethan robinson	6	25769804504
-ethan robinson	7	30064772032
-ethan robinson	8	34359739453
-ethan robinson	9	38654706952
-ethan robinson	10	42949674450
-ethan robinson	11	47244641935
-ethan robinson	12	51539609471
-ethan robinson	13	55834576812
-ethan robinson	14	60129544291
-ethan robinson	15	64424511671
-ethan robinson	16	68719479173
-ethan robinson	17	73014446589
-ethan robinson	18	77309413933
-ethan steinbeck	1	4294967305
-ethan steinbeck	2	8589934675
-ethan steinbeck	3	12884902200
-ethan steinbeck	4	17179869708
-ethan steinbeck	5	21474837253
-ethan steinbeck	6	25769804674
-ethan steinbeck	7	30064772059
-ethan thompson	1	4294967313
-ethan thompson	2	8589934835
-ethan thompson	3	12884902349
-ethan thompson	4	17179869681
-ethan thompson	5	21474837069
-ethan thompson	6	25769804416
-ethan thompson	7	30064771963
-ethan thompson	8	34359739507
-ethan thompson	9	38654706847
-ethan thompson	10	42949674157
-ethan thompson	11	47244641572
-ethan thompson	12	51539609068
-ethan thompson	13	55834576528
-ethan thompson	14	60129543995
-ethan thompson	15	64424511401
-ethan thompson	16	68719478873
-ethan thompson	17	73014446235
-ethan thompson	18	77309413754
-ethan thompson	19	81604381055
-ethan thompson	20	85899348538
-ethan thompson	21	90194316055
-ethan thompson	22	94489283474
-ethan thompson	23	98784250826
-ethan thompson	24	103079218264
-ethan underhill	1	4294967365
-ethan underhill	2	8589934831
-ethan underhill	3	12884902341
-ethan underhill	4	17179869845
-ethan underhill	5	21474837350
-ethan underhill	6	25769804855
-ethan underhill	7	30064772308
-ethan underhill	8	34359739810
-ethan underhill	9	38654707345
-ethan underhill	10	42949674812
-ethan underhill	11	47244642123
-ethan underhill	12	51539609528
-ethan underhill	13	55834576969
-ethan underhill	14	60129544387
-ethan underhill	15	64424511794
-ethan underhill	16	68719479157
-ethan underhill	17	73014446497
-ethan van buren	1	4294967505
-ethan van buren	2	8589935016
-ethan van buren	3	17179869656
-ethan van buren	3	17179869656
-ethan van buren	5	21474836992
-ethan van buren	6	25769804410
-ethan van buren	7	30064771789
-ethan van buren	8	34359739264
-ethan van buren	9	38654706616
-ethan van buren	10	42949674122
-ethan van buren	11	47244641485
-ethan van buren	12	51539608796
-ethan van buren	13	55834576255
-ethan white	1	4294967304
-ethan white	2	12884902110
-ethan white	2	12884902110
-ethan white	4	17179869474
-ethan white	5	21474836775
-ethan white	6	25769804228
-ethan white	7	30064771673
-ethan white	8	34359739157
-ethan white	9	38654706561
-ethan white	10	42949674054
-ethan white	11	47244641481
-ethan white	12	51539608948
-ethan xylophone	1	4294967363
-ethan xylophone	2	8589934726
-ethan xylophone	3	12884902195
-ethan xylophone	4	17179869728
-ethan xylophone	5	21474837233
-ethan xylophone	6	25769804586
-ethan xylophone	7	30064772007
-ethan xylophone	8	34359739483
-ethan xylophone	9	38654706989
-ethan xylophone	10	42949674361
-ethan xylophone	11	47244641904
-ethan xylophone	12	51539609243
-ethan xylophone	13	55834576590
-ethan xylophone	14	60129543989
-ethan xylophone	15	64424511393
-ethan xylophone	16	73014446151
-ethan xylophone	16	73014446151
-ethan young	1	4294967506
-ethan young	2	8589934979
-ethan young	3	12884902282
-ethan young	4	17179869719
-ethan young	5	21474837267
-ethan young	6	25769804663
-ethan young	7	30064772213
-ethan young	8	34359739545
-ethan young	9	38654706986
-ethan young	10	42949674503
-ethan young	11	47244641993
-ethan young	12	51539609348
-ethan young	13	55834576719
-ethan young	14	60129544199
-ethan young	15	64424511602
-ethan zipper	1	4294967462
-ethan zipper	2	8589935013
-ethan zipper	3	12884902480
-ethan zipper	4	17179869942
-ethan zipper	5	21474837269
-ethan zipper	6	25769804794
-ethan zipper	7	30064772296
-ethan zipper	8	34359739726
-ethan zipper	9	38654707091
-ethan zipper	10	42949674501
-ethan zipper	11	47244641854
-ethan zipper	12	51539609352
-ethan zipper	13	55834576692
-ethan zipper	14	60129544040
-fred allen	1	4294967503
-fred allen	2	8589934954
-fred allen	3	12884902288
-fred allen	4	17179869595
-fred allen	5	21474837003
-fred allen	6	25769804506
-fred allen	7	30064771893
-fred allen	8	34359739288
-fred allen	9	38654706709
-fred allen	10	42949674187
-fred allen	11	47244641547
-fred allen	12	51539609040
-fred brown	1	4294967364
-fred brown	2	8589934707
-fred brown	3	12884902061
-fred brown	4	17179869517
-fred brown	5	21474836981
-fred brown	6	25769804278
-fred brown	7	30064771787
-fred brown	8	34359739229
-fred brown	9	38654706580
-fred brown	10	42949673884
-fred brown	11	47244641345
-fred brown	12	51539608894
-fred brown	13	55834576299
-fred brown	14	60129543764
-fred brown	15	64424511155
-fred carson	1	4294967401
-fred carson	2	8589934701
-fred carson	3	17179869641
-fred carson	3	17179869641
-fred carson	5	25769804538
-fred carson	5	25769804538
-fred carson	7	30064771968
-fred carson	8	34359739392
-fred carson	9	38654706747
-fred davidson	1	4294967512
-fred davidson	2	8589935052
-fred davidson	3	12884902373
-fred davidson	4	17179869797
-fred davidson	5	21474837322
-fred davidson	6	25769804789
-fred davidson	7	30064772125
-fred davidson	8	34359739457
-fred davidson	9	38654706814
-fred davidson	10	42949674289
-fred davidson	11	47244641600
-fred davidson	12	51539609148
-fred davidson	13	55834576636
-fred ellison	1	4294967395
-fred ellison	2	8589934696
-fred ellison	3	12884902121
-fred ellison	4	17179869654
-fred ellison	5	21474836958
-fred ellison	6	25769804361
-fred ellison	7	30064771681
-fred ellison	8	34359739151
-fred ellison	9	38654706619
-fred ellison	10	42949674050
-fred ellison	11	47244641485
-fred ellison	12	51539608878
-fred ellison	13	55834576404
-fred ellison	14	60129543760
-fred ellison	15	68719478614
-fred ellison	15	68719478614
-fred ellison	17	73014446043
-fred ellison	18	77309413525
-fred ellison	19	81604380920
-fred falkner	1	4294967340
-fred falkner	2	8589934702
-fred falkner	3	17179869649
-fred falkner	3	17179869649
-fred falkner	5	21474837200
-fred falkner	6	25769804513
-fred falkner	7	30064772008
-fred falkner	8	34359739422
-fred falkner	9	38654706847
-fred falkner	10	42949674147
-fred falkner	11	47244641663
-fred falkner	12	51539609097
-fred garcia	1	4294967419
-fred garcia	2	8589934888
-fred garcia	3	12884902403
-fred garcia	4	17179869924
-fred garcia	5	21474837427
-fred hernandez	1	4294967541
-fred hernandez	2	8589935050
-fred hernandez	3	12884902411
-fred hernandez	4	17179869892
-fred hernandez	5	21474837202
-fred hernandez	6	25769804679
-fred hernandez	7	30064772028
-fred hernandez	8	34359739433
-fred hernandez	9	42949674290
-fred hernandez	9	42949674290
-fred hernandez	11	47244641817
-fred hernandez	12	51539609309
-fred hernandez	13	55834576674
-fred hernandez	14	60129544213
-fred ichabod	1	4294967342
-fred ichabod	2	8589934831
-fred ichabod	3	12884902381
-fred ichabod	4	17179869722
-fred ichabod	5	21474837150
-fred ichabod	6	25769804542
-fred ichabod	7	34359739430
-fred ichabod	7	34359739430
-fred ichabod	9	38654706836
-fred ichabod	10	42949674253
-fred ichabod	11	47244641675
-fred ichabod	12	51539609015
-fred ichabod	13	55834576446
-fred johnson	1	4294967304
-fred johnson	2	8589934620
-fred johnson	3	12884902101
-fred johnson	4	17179869454
-fred johnson	5	21474836960
-fred johnson	6	25769804471
-fred johnson	7	30064771997
-fred johnson	8	34359739444
-fred johnson	9	38654706826
-fred johnson	10	42949674199
-fred johnson	11	47244641618
-fred johnson	12	51539609012
-fred johnson	13	55834576475
-fred johnson	14	60129544017
-fred johnson	15	64424511456
-fred king	1	4294967386
-fred king	2	8589934924
-fred king	3	12884902422
-fred king	4	17179869819
-fred king	5	21474837263
-fred king	6	25769804738
-fred king	7	30064772084
-fred king	8	34359739432
-fred king	9	38654706967
-fred king	10	42949674471
-fred king	11	47244641780
-fred king	12	51539609200
-fred king	13	55834576641
-fred king	14	60129543954
-fred laertes	1	4294967441
-fred laertes	2	8589934864
-fred laertes	3	12884902271
-fred laertes	4	17179869645
-fred laertes	5	21474837143
-fred laertes	6	25769804541
-fred laertes	7	30064771880
-fred laertes	8	34359739364
-fred laertes	9	38654706715
-fred laertes	10	42949674161
-fred laertes	11	47244641632
-fred laertes	12	51539609097
-fred miller	1	4294967537
-fred miller	2	8589934956
-fred miller	3	12884902313
-fred miller	4	17179869636
-fred miller	5	21474837087
-fred miller	6	25769804465
-fred miller	7	30064771866
-fred miller	8	34359739356
-fred miller	9	38654706859
-fred miller	10	42949674222
-fred miller	11	47244641591
-fred miller	12	51539609084
-fred miller	13	55834576629
-fred miller	14	60129544041
-fred miller	15	64424511553
-fred nixon	1	4294967413
-fred nixon	2	8589934927
-fred nixon	3	12884902460
-fred nixon	4	21474837151
-fred nixon	4	21474837151
-fred nixon	6	25769804671
-fred nixon	7	30064772050
-fred nixon	8	34359739532
-fred nixon	9	38654706872
-fred nixon	10	42949674397
-fred nixon	11	47244641735
-fred nixon	12	51539609232
-fred nixon	13	55834576742
-fred nixon	14	60129544184
-fred nixon	15	64424511647
-fred nixon	16	68719479042
-fred nixon	17	77309413954
-fred nixon	17	77309413954
-fred nixon	19	81604381329
-fred ovid	1	4294967458
-fred ovid	2	8589934781
-fred ovid	3	12884902225
-fred ovid	4	17179869747
-fred ovid	5	21474837143
-fred ovid	6	25769804637
-fred ovid	7	30064771978
-fred ovid	8	34359739468
-fred ovid	9	38654706785
-fred ovid	10	42949674255
-fred ovid	11	47244641804
-fred ovid	12	51539609297
-fred ovid	13	55834576644
-fred polk	1	4294967332
-fred polk	2	8589934814
-fred polk	3	12884902333
-fred polk	4	17179869752
-fred polk	5	21474837083
-fred polk	6	25769804548
-fred polk	7	30064771923
-fred polk	8	34359739252
-fred polk	9	38654706564
-fred polk	10	42949674087
-fred polk	11	47244641441
-fred polk	12	51539608976
-fred polk	13	55834576347
-fred polk	14	60129543790
-fred polk	15	64424511253
-fred polk	16	68719478583
-fred polk	17	73014446041
-fred polk	18	77309413548
-fred polk	19	81604380992
-fred polk	20	85899348404
-fred polk	21	90194315917
-fred quirinius	1	4294967443
-fred quirinius	2	8589934992
-fred quirinius	3	12884902522
-fred quirinius	4	17179869932
-fred quirinius	5	21474837432
-fred quirinius	6	25769804791
-fred quirinius	7	30064772217
-fred quirinius	8	34359739700
-fred quirinius	9	38654707118
-fred quirinius	10	42949674494
-fred quirinius	11	47244641829
-fred quirinius	12	51539609182
-fred quirinius	13	55834576674
-fred quirinius	14	60129544199
-fred quirinius	15	64424511630
-fred quirinius	16	68719479053
-fred quirinius	17	73014446406
-fred quirinius	18	77309413865
-fred robinson	1	4294967550
-fred robinson	2	8589935100
-fred robinson	3	12884902504
-fred robinson	4	17179869865
-fred robinson	5	21474837256
-fred robinson	6	25769804756
-fred robinson	7	30064772152
-fred robinson	8	34359739566
-fred robinson	9	38654707057
-fred robinson	10	42949674584
-fred robinson	11	47244642105
-fred robinson	12	51539609576
-fred robinson	13	55834577037
-fred robinson	14	60129544430
-fred robinson	15	64424511948
-fred robinson	16	68719479358
-fred robinson	17	73014446831
-fred steinbeck	1	4294967351
-fred steinbeck	2	8589934751
-fred steinbeck	3	12884902294
-fred steinbeck	4	17179869705
-fred steinbeck	5	21474837034
-fred steinbeck	6	25769804420
-fred steinbeck	7	30064771883
-fred steinbeck	8	34359739416
-fred steinbeck	9	38654706850
-fred steinbeck	10	42949674322
-fred steinbeck	11	47244641835
-fred thompson	1	4294967414
-fred thompson	2	8589934826
-fred thompson	3	12884902174
-fred thompson	4	17179869615
-fred thompson	5	21474837124
-fred thompson	6	25769804497
-fred thompson	7	30064771937
-fred thompson	8	34359739418
-fred thompson	9	38654706856
-fred thompson	10	42949674206
-fred thompson	11	47244641580
-fred underhill	1	4294967547
-fred underhill	2	8589935023
-fred underhill	3	12884902347
-fred underhill	4	17179869657
-fred underhill	5	21474837014
-fred underhill	6	25769804480
-fred underhill	7	30064771810
-fred underhill	8	34359739206
-fred underhill	9	42949673921
-fred underhill	9	42949673921
-fred underhill	11	47244641380
-fred underhill	12	51539608695
-fred underhill	13	55834576107
-fred van buren	1	4294967343
-fred van buren	2	8589934743
-fred van buren	3	12884902174
-fred van buren	4	17179869631
-fred van buren	5	21474836942
-fred van buren	6	25769804334
-fred van buren	7	30064771715
-fred van buren	8	34359739241
-fred van buren	9	38654706712
-fred van buren	10	42949674113
-fred van buren	11	47244641660
-fred van buren	12	51539608988
-fred van buren	13	55834576451
-fred van buren	14	60129543976
-fred van buren	15	64424511469
-fred van buren	16	68719478875
-fred van buren	17	73014446391
-fred white	1	8589934849
-fred white	1	8589934849
-fred white	3	12884902178
-fred white	4	17179869536
-fred white	5	21474837085
-fred white	6	25769804516
-fred white	7	30064771995
-fred white	8	34359739334
-fred white	9	38654706849
-fred white	10	42949674316
-fred white	11	47244641701
-fred white	12	51539609167
-fred white	13	55834576664
-fred white	14	60129544144
-fred white	15	64424511578
-fred xylophone	1	4294967493
-fred xylophone	2	8589934910
-fred xylophone	3	12884902407
-fred xylophone	4	17179869843
-fred xylophone	5	21474837369
-fred xylophone	6	25769804769
-fred xylophone	7	30064772082
-fred xylophone	8	34359739525
-fred xylophone	9	38654706903
-fred xylophone	10	42949674283
-fred xylophone	11	47244641594
-fred young	1	8589934778
-fred young	1	8589934778
-fred young	3	12884902209
-fred young	4	17179869704
-fred young	5	21474837189
-fred young	6	25769804514
-fred young	7	30064771860
-fred young	8	34359739251
-fred young	9	38654706695
-fred young	10	42949674176
-fred young	11	47244641579
-fred young	12	51539608884
-fred young	13	55834576252
-fred young	14	60129543746
-fred zipper	1	4294967414
-fred zipper	2	8589934894
-fred zipper	3	12884902225
-fred zipper	4	17179869598
-fred zipper	5	21474837045
-fred zipper	6	25769804536
-fred zipper	7	30064771862
-fred zipper	8	34359739166
-fred zipper	9	38654706647
-fred zipper	10	42949674173
-fred zipper	11	47244641687
-fred zipper	12	51539609052
-fred zipper	13	55834576583
-gabriella allen	1	4294967354
-gabriella allen	2	8589934759
-gabriella allen	3	12884902106
-gabriella allen	4	17179869641
-gabriella allen	5	21474837056
-gabriella allen	6	25769804525
-gabriella allen	7	30064772059
-gabriella brown	1	4294967509
-gabriella brown	2	8589935052
-gabriella brown	3	17179869958
-gabriella brown	3	17179869958
-gabriella brown	5	21474837479
-gabriella brown	6	25769804905
-gabriella brown	7	30064772286
-gabriella brown	8	34359739781
-gabriella brown	9	38654707281
-gabriella brown	10	42949674788
-gabriella brown	11	47244642228
-gabriella brown	12	51539609728
-gabriella brown	13	55834577126
-gabriella brown	14	60129544607
-gabriella brown	15	64424512143
-gabriella brown	16	68719479622
-gabriella brown	17	73014446983
-gabriella brown	18	81604381832
-gabriella brown	18	81604381832
-gabriella carson	1	4294967542
-gabriella carson	2	8589934881
-gabriella carson	3	12884902210
-gabriella carson	4	17179869572
-gabriella carson	5	21474836888
-gabriella carson	6	25769804428
-gabriella carson	7	30064771894
-gabriella carson	8	34359739345
-gabriella davidson	1	4294967459
-gabriella davidson	2	8589934906
-gabriella davidson	3	12884902274
-gabriella davidson	4	17179869703
-gabriella davidson	5	21474837001
-gabriella davidson	6	25769804435
-gabriella davidson	7	34359739145
-gabriella davidson	7	34359739145
-gabriella davidson	9	38654706551
-gabriella davidson	10	42949674075
-gabriella davidson	11	47244641582
-gabriella davidson	12	51539609107
-gabriella ellison	1	4294967355
-gabriella ellison	2	8589934681
-gabriella ellison	3	12884902074
-gabriella ellison	4	17179869528
-gabriella ellison	5	21474836968
-gabriella ellison	6	25769804273
-gabriella ellison	7	30064771672
-gabriella ellison	8	34359739113
-gabriella ellison	9	38654706453
-gabriella ellison	10	42949673899
-gabriella ellison	11	47244641379
-gabriella ellison	12	51539608685
-gabriella ellison	13	55834575997
-gabriella ellison	14	60129543497
-gabriella ellison	15	64424511011
-gabriella ellison	16	68719478507
-gabriella ellison	17	73014446007
-gabriella ellison	18	77309413433
-gabriella ellison	19	81604380883
-gabriella ellison	20	85899348421
-gabriella falkner	1	4294967375
-gabriella falkner	2	8589934753
-gabriella falkner	3	12884902268
-gabriella falkner	4	17179869757
-gabriella falkner	5	21474837085
-gabriella falkner	6	25769804608
-gabriella falkner	7	30064772058
-gabriella falkner	8	34359739593
-gabriella falkner	9	38654706951
-gabriella falkner	10	42949674320
-gabriella falkner	11	47244641792
-gabriella falkner	12	51539609205
-gabriella falkner	13	55834576755
-gabriella falkner	14	60129544189
-gabriella falkner	15	64424511494
-gabriella falkner	16	68719478904
-gabriella garcia	1	4294967487
-gabriella garcia	2	8589935006
-gabriella garcia	3	12884902463
-gabriella garcia	4	17179869801
-gabriella garcia	5	21474837232
-gabriella garcia	6	25769804540
-gabriella garcia	7	30064771959
-gabriella garcia	8	34359739329
-gabriella garcia	9	38654706627
-gabriella garcia	10	42949674168
-gabriella garcia	11	47244641492
-gabriella garcia	12	51539608971
-gabriella garcia	13	55834576447
-gabriella garcia	14	60129543981
-gabriella garcia	15	64424511347
-gabriella hernandez	1	4294967510
-gabriella hernandez	2	8589935042
-gabriella hernandez	3	12884902420
-gabriella hernandez	4	17179869758
-gabriella hernandez	5	21474837235
-gabriella hernandez	6	25769804554
-gabriella hernandez	7	30064772035
-gabriella hernandez	8	34359739430
-gabriella hernandez	9	38654706892
-gabriella hernandez	10	42949674307
-gabriella hernandez	11	47244641847
-gabriella hernandez	12	51539609148
-gabriella hernandez	13	55834576518
-gabriella hernandez	14	60129543819
-gabriella hernandez	15	64424511152
-gabriella hernandez	16	68719478585
-gabriella hernandez	17	73014445948
-gabriella hernandez	18	77309413459
-gabriella hernandez	19	81604380856
-gabriella ichabod	1	4294967424
-gabriella ichabod	2	8589934886
-gabriella ichabod	3	12884902359
-gabriella ichabod	4	17179869688
-gabriella ichabod	5	21474837228
-gabriella ichabod	6	25769804565
-gabriella ichabod	7	30064771971
-gabriella ichabod	8	34359739410
-gabriella ichabod	9	38654706891
-gabriella ichabod	10	42949674292
-gabriella ichabod	11	47244641680
-gabriella ichabod	12	51539609017
-gabriella ichabod	13	55834576422
-gabriella ichabod	14	60129543881
-gabriella ichabod	15	64424511201
-gabriella ichabod	16	68719478612
-gabriella ichabod	17	73014446045
-gabriella ichabod	18	77309413543
-gabriella ichabod	19	81604381063
-gabriella johnson	1	4294967496
-gabriella johnson	2	8589935002
-gabriella johnson	3	12884902414
-gabriella johnson	4	17179869893
-gabriella johnson	5	21474837423
-gabriella johnson	6	25769804756
-gabriella johnson	7	30064772076
-gabriella johnson	8	34359739464
-gabriella king	1	4294967434
-gabriella king	2	8589934733
-gabriella king	3	12884902126
-gabriella king	4	17179869489
-gabriella king	5	21474836886
-gabriella king	6	25769804408
-gabriella king	7	30064771803
-gabriella king	8	34359739134
-gabriella king	9	38654706557
-gabriella king	10	42949673941
-gabriella king	11	47244641421
-gabriella king	12	51539608783
-gabriella laertes	1	4294967370
-gabriella laertes	2	8589934835
-gabriella laertes	3	12884902266
-gabriella laertes	4	17179869709
-gabriella laertes	5	21474837119
-gabriella laertes	6	25769804468
-gabriella laertes	7	30064771899
-gabriella laertes	8	34359739246
-gabriella miller	1	4294967422
-gabriella miller	2	8589934742
-gabriella miller	3	12884902101
-gabriella miller	4	17179869436
-gabriella miller	5	21474836928
-gabriella miller	6	25769804291
-gabriella nixon	1	4294967538
-gabriella nixon	2	8589935089
-gabriella nixon	3	12884902486
-gabriella nixon	4	21474837278
-gabriella nixon	4	21474837278
-gabriella nixon	6	25769804683
-gabriella nixon	7	30064772109
-gabriella nixon	8	34359739549
-gabriella nixon	9	38654706882
-gabriella nixon	10	42949674240
-gabriella nixon	11	47244641727
-gabriella nixon	12	51539609033
-gabriella nixon	13	55834576361
-gabriella nixon	14	60129543773
-gabriella nixon	15	64424511295
-gabriella nixon	16	68719478653
-gabriella nixon	17	73014446064
-gabriella nixon	18	77309413508
-gabriella nixon	19	81604380938
-gabriella nixon	20	85899348365
-gabriella nixon	21	90194315749
-gabriella nixon	22	94489283223
-gabriella ovid	1	4294967484
-gabriella ovid	2	12884902469
-gabriella ovid	2	12884902469
-gabriella ovid	4	17179869806
-gabriella ovid	5	21474837107
-gabriella ovid	6	25769804629
-gabriella polk	1	8589934839
-gabriella polk	1	8589934839
-gabriella polk	3	12884902168
-gabriella polk	4	21474836920
-gabriella polk	4	21474836920
-gabriella polk	6	25769804309
-gabriella polk	7	30064771719
-gabriella polk	8	34359739243
-gabriella polk	9	38654706768
-gabriella polk	10	42949674171
-gabriella polk	11	47244641591
-gabriella polk	12	51539608992
-gabriella polk	13	55834576294
-gabriella quirinius	1	4294967473
-gabriella quirinius	2	8589934897
-gabriella quirinius	3	17179869788
-gabriella quirinius	3	17179869788
-gabriella quirinius	5	21474837193
-gabriella quirinius	6	25769804692
-gabriella quirinius	7	30064772030
-gabriella quirinius	8	34359739358
-gabriella quirinius	9	38654706745
-gabriella quirinius	10	42949674166
-gabriella quirinius	11	47244641498
-gabriella quirinius	12	51539609037
-gabriella quirinius	13	55834576503
-gabriella quirinius	14	60129543874
-gabriella quirinius	15	64424511337
-gabriella quirinius	16	68719478737
-gabriella quirinius	17	73014446109
-gabriella robinson	1	4294967428
-gabriella robinson	2	8589934725
-gabriella robinson	3	12884902207
-gabriella robinson	4	17179869632
-gabriella robinson	5	21474836961
-gabriella robinson	6	25769804369
-gabriella robinson	7	34359739239
-gabriella robinson	7	34359739239
-gabriella robinson	9	38654706572
-gabriella robinson	10	42949673954
-gabriella robinson	11	47244641326
-gabriella robinson	12	51539608792
-gabriella robinson	13	55834576337
-gabriella robinson	14	60129543819
-gabriella robinson	15	64424511209
-gabriella robinson	16	68719478506
-gabriella steinbeck	1	4294967500
-gabriella steinbeck	2	8589934801
-gabriella steinbeck	3	12884902279
-gabriella steinbeck	4	17179869727
-gabriella steinbeck	5	21474837162
-gabriella steinbeck	6	25769804675
-gabriella steinbeck	7	30064772166
-gabriella steinbeck	8	34359739518
-gabriella steinbeck	9	38654706914
-gabriella steinbeck	10	42949674271
-gabriella steinbeck	11	47244641687
-gabriella steinbeck	12	51539609155
-gabriella steinbeck	13	55834576451
-gabriella steinbeck	14	60129543944
-gabriella steinbeck	15	64424511245
-gabriella steinbeck	16	68719478658
-gabriella steinbeck	17	73014446084
-gabriella steinbeck	18	77309413457
-gabriella thompson	1	4294967299
-gabriella thompson	2	8589934762
-gabriella thompson	3	12884902174
-gabriella thompson	4	17179869523
-gabriella thompson	5	21474837008
-gabriella thompson	6	25769804451
-gabriella thompson	7	30064771819
-gabriella thompson	8	34359739292
-gabriella thompson	9	38654706611
-gabriella thompson	10	42949673923
-gabriella thompson	11	47244641249
-gabriella thompson	12	51539608699
-gabriella thompson	13	55834576184
-gabriella underhill	1	4294967430
-gabriella underhill	2	8589934970
-gabriella underhill	3	12884902311
-gabriella underhill	4	17179869851
-gabriella underhill	5	21474837194
-gabriella underhill	6	25769804526
-gabriella underhill	7	30064771863
-gabriella underhill	8	34359739411
-gabriella underhill	9	38654706874
-gabriella underhill	10	42949674284
-gabriella underhill	11	47244641785
-gabriella underhill	12	51539609302
-gabriella underhill	13	55834576637
-gabriella underhill	14	60129544100
-gabriella underhill	15	64424511586
-gabriella underhill	16	68719478994
-gabriella underhill	17	73014446301
-gabriella underhill	18	77309413608
-gabriella underhill	19	81604381115
-gabriella underhill	20	85899348433
-gabriella underhill	21	90194315888
-gabriella underhill	22	94489283294
-gabriella van buren	1	4294967302
-gabriella van buren	2	8589934600
-gabriella van buren	3	12884902057
-gabriella van buren	4	17179869496
-gabriella van buren	5	21474837003
-gabriella van buren	6	25769804547
-gabriella van buren	7	30064771946
-gabriella van buren	8	38654706926
-gabriella van buren	8	38654706926
-gabriella van buren	10	42949674255
-gabriella van buren	11	47244641735
-gabriella van buren	12	51539609229
-gabriella van buren	13	55834576580
-gabriella van buren	14	60129543947
-gabriella van buren	15	64424511322
-gabriella van buren	16	68719478802
-gabriella van buren	17	73014446272
-gabriella van buren	18	77309413631
-gabriella white	1	4294967485
-gabriella white	2	8589934802
-gabriella white	3	12884902250
-gabriella white	4	17179869660
-gabriella white	5	21474837034
-gabriella white	6	25769804494
-gabriella white	7	30064772020
-gabriella white	8	34359739457
-gabriella white	9	38654706851
-gabriella white	10	42949674327
-gabriella white	11	47244641635
-gabriella white	12	51539609185
-gabriella white	13	55834576520
-gabriella white	14	60129543987
-gabriella white	15	64424511433
-gabriella white	16	68719478749
-gabriella xylophone	1	4294967464
-gabriella xylophone	2	8589934981
-gabriella xylophone	3	12884902510
-gabriella xylophone	4	17179870016
-gabriella xylophone	5	21474837508
-gabriella xylophone	6	25769804952
-gabriella xylophone	7	30064772347
-gabriella xylophone	8	34359739863
-gabriella xylophone	9	38654707393
-gabriella xylophone	10	42949674846
-gabriella xylophone	11	47244642210
-gabriella xylophone	12	51539609643
-gabriella young	1	4294967310
-gabriella young	2	8589934659
-gabriella young	3	12884902152
-gabriella young	4	17179869536
-gabriella young	5	21474836904
-gabriella young	6	25769804350
-gabriella young	7	30064771836
-gabriella young	8	34359739267
-gabriella zipper	1	4294967536
-gabriella zipper	2	8589934893
-gabriella zipper	3	12884902192
-gabriella zipper	4	17179869555
-gabriella zipper	5	21474837065
-gabriella zipper	6	25769804502
-gabriella zipper	7	30064771934
-gabriella zipper	8	34359739377
-gabriella zipper	9	38654706741
-gabriella zipper	10	42949674093
-gabriella zipper	11	47244641394
-gabriella zipper	12	51539608906
-gabriella zipper	13	55834576312
-holly allen	1	4294967453
-holly allen	2	8589934749
-holly allen	3	12884902182
-holly allen	4	17179869649
-holly allen	5	21474837001
-holly allen	6	25769804533
-holly allen	7	30064772077
-holly allen	8	34359739589
-holly allen	9	38654706981
-holly allen	10	42949674308
-holly allen	11	47244641795
-holly allen	12	51539609189
-holly brown	1	4294967323
-holly brown	2	8589934756
-holly brown	3	12884902297
-holly brown	4	17179869618
-holly brown	5	21474836967
-holly brown	6	25769804352
-holly brown	7	30064771747
-holly brown	8	34359739152
-holly brown	9	38654706490
-holly carson	1	4294967480
-holly carson	2	8589934937
-holly carson	3	17179869897
-holly carson	3	17179869897
-holly carson	5	21474837351
-holly carson	6	25769804785
-holly carson	7	30064772152
-holly carson	8	34359739479
-holly carson	9	38654706889
-holly carson	10	42949674276
-holly carson	11	47244641592
-holly carson	12	51539609029
-holly davidson	1	4294967300
-holly davidson	2	8589934804
-holly davidson	3	12884902116
-holly davidson	4	17179869511
-holly davidson	5	21474837022
-holly davidson	6	25769804379
-holly davidson	7	30064771882
-holly davidson	8	34359739346
-holly davidson	9	38654706678
-holly ellison	1	4294967429
-holly ellison	2	8589934888
-holly ellison	3	12884902225
-holly ellison	4	17179869731
-holly ellison	5	21474837097
-holly ellison	6	25769804599
-holly ellison	7	30064772071
-holly ellison	8	34359739391
-holly ellison	9	38654706759
-holly ellison	10	42949674158
-holly falkner	1	4294967476
-holly falkner	2	8589934917
-holly falkner	3	12884902316
-holly falkner	4	17179869616
-holly falkner	5	21474837024
-holly falkner	6	25769804541
-holly falkner	7	30064772084
-holly falkner	8	34359739418
-holly falkner	9	38654706823
-holly falkner	10	42949674303
-holly falkner	11	51539609029
-holly falkner	11	51539609029
-holly falkner	13	55834576473
-holly falkner	14	60129543892
-holly falkner	15	64424511425
-holly falkner	16	68719478949
-holly falkner	17	73014446381
-holly falkner	18	77309413864
-holly falkner	19	81604381254
-holly falkner	20	85899348593
-holly falkner	21	90194315917
-holly falkner	22	94489283465
-holly falkner	23	98784250934
-holly falkner	24	103079218233
-holly garcia	1	4294967410
-holly garcia	2	8589934934
-holly garcia	3	12884902363
-holly garcia	4	17179869729
-holly garcia	5	21474837070
-holly garcia	6	25769804523
-holly garcia	7	30064771840
-holly garcia	8	34359739178
-holly garcia	9	38654706507
-holly garcia	10	42949674050
-holly garcia	11	47244641371
-holly garcia	12	51539608845
-holly garcia	13	55834576314
-holly garcia	14	60129543812
-holly garcia	15	64424511302
-holly hernandez	1	4294967378
-holly hernandez	2	8589934832
-holly hernandez	3	12884902341
-holly hernandez	4	17179869664
-holly hernandez	5	21474837073
-holly hernandez	6	25769804501
-holly hernandez	7	30064772007
-holly hernandez	8	34359739386
-holly hernandez	9	38654706757
-holly hernandez	10	42949674087
-holly hernandez	11	47244641630
-holly hernandez	12	51539609173
-holly hernandez	13	55834576524
-holly hernandez	14	60129544068
-holly hernandez	15	64424511613
-holly hernandez	16	68719478921
-holly hernandez	17	73014446366
-holly hernandez	18	77309413902
-holly ichabod	1	4294967467
-holly ichabod	2	8589934924
-holly ichabod	3	12884902350
-holly ichabod	4	17179869763
-holly ichabod	5	21474837105
-holly ichabod	6	25769804619
-holly ichabod	7	30064772077
-holly ichabod	8	34359739592
-holly ichabod	9	38654707114
-holly ichabod	10	42

<TRUNCATED>

[06/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_order_null.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_order_null.q.out b/ql/src/test/results/clientpositive/vector_windowing_order_null.q.out
deleted file mode 100644
index 5f0d23e..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_order_null.q.out
+++ /dev/null
@@ -1,1013 +0,0 @@
-PREHOOK: query: drop table over10k
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table over10k
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal,  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@over10k
-POSTHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal,  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over4_null' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over4_null' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: explain vectorization detail
-select i, s, b, sum(b) over (partition by i order by s nulls last,b rows unbounded preceding) from over10k limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select i, s, b, sum(b) over (partition by i order by s nulls last,b rows unbounded preceding) from over10k limit 10
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: i (type: int), s (type: string), b (type: bigint)
-              sort order: +++
-              Map-reduce partition columns: i (type: int)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 3, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: int), KEY.reducesinkkey2 (type: bigint), KEY.reducesinkkey1 (type: string)
-          outputColumnNames: _col2, _col3, _col7
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col3: bigint, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS LAST, _col3 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col3
-                        name: sum
-                        window function: GenericUDAFSumLong
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col2 (type: int), _col7 (type: string), _col3 (type: bigint), sum_window_0 (type: bigint)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 10
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select i, s, b, sum(b) over (partition by i order by s nulls last,b rows unbounded preceding) from over10k limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select i, s, b, sum(b) over (partition by i order by s nulls last,b rows unbounded preceding) from over10k limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-i	s	b	sum_window_0
-NULL	alice ichabod	NULL	NULL
-NULL	NULL	NULL	NULL
-65534	calvin miller	NULL	NULL
-65534	NULL	NULL	NULL
-65536	alice ichabod	4294967441	4294967441
-65536	alice robinson	4294967476	8589934917
-65536	bob robinson	4294967349	12884902266
-65536	calvin thompson	4294967336	17179869602
-65536	david johnson	4294967490	21474837092
-65536	david laertes	4294967431	25769804523
-PREHOOK: query: explain vectorization detail
-select d, s, f, sum(f) over (partition by d order by s,f desc nulls first rows unbounded preceding) from over10k limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select d, s, f, sum(f) over (partition by d order by s,f desc nulls first rows unbounded preceding) from over10k limit 10
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: d (type: double), s (type: string), f (type: float)
-              sort order: ++-
-              Map-reduce partition columns: d (type: double)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey2 (type: float), KEY.reducesinkkey0 (type: double), KEY.reducesinkkey1 (type: string)
-          outputColumnNames: _col4, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST, _col4 DESC NULLS FIRST
-                  partition by: _col5
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col4
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col5 (type: double), _col7 (type: string), _col4 (type: float), sum_window_0 (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 10
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select d, s, f, sum(f) over (partition by d order by s,f desc nulls first rows unbounded preceding) from over10k limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select d, s, f, sum(f) over (partition by d order by s,f desc nulls first rows unbounded preceding) from over10k limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-d	s	f	sum_window_0
-NULL	alice ichabod	NULL	NULL
-NULL	calvin miller	NULL	NULL
-0.01	NULL	NULL	NULL
-0.01	NULL	NULL	NULL
-0.01	calvin miller	8.39	8.390000343322754
-0.02	NULL	NULL	NULL
-0.02	holly polk	5.29	5.289999961853027
-0.02	wendy quirinius	25.5	30.789999961853027
-0.02	yuri laertes	37.59	68.38000011444092
-0.03	nick steinbeck	79.24	79.23999786376953
-PREHOOK: query: explain vectorization detail
-select ts, s, f, sum(f) over (partition by ts order by f asc nulls first range between current row and unbounded following) from over10k limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select ts, s, f, sum(f) over (partition by ts order by f asc nulls first range between current row and unbounded following) from over10k limit 10
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), f (type: float)
-              sort order: ++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              value expressions: s (type: string)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 7, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: float), VALUE._col6 (type: string), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col4, _col7, _col8
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col7: string, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col4
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE CURRENT~FOLLOWING(MAX)
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col8 (type: timestamp), _col7 (type: string), _col4 (type: float), sum_window_0 (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 10
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ts, s, f, sum(f) over (partition by ts order by f asc nulls first range between current row and unbounded following) from over10k limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select ts, s, f, sum(f) over (partition by ts order by f asc nulls first range between current row and unbounded following) from over10k limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-ts	s	f	sum_window_0
-2013-03-01 09:11:58.70307	NULL	NULL	1276.850001335144
-2013-03-01 09:11:58.70307	gabriella xylophone	3.17	1276.850001335144
-2013-03-01 09:11:58.70307	calvin brown	10.89	1273.68000125885
-2013-03-01 09:11:58.70307	jessica laertes	14.54	1262.7900009155273
-2013-03-01 09:11:58.70307	yuri allen	14.78	1248.2500009536743
-2013-03-01 09:11:58.70307	tom johnson	17.85	1233.4700012207031
-2013-03-01 09:11:58.70307	bob ovid	20.61	1215.6200008392334
-2013-03-01 09:11:58.70307	fred nixon	28.69	1195.0100002288818
-2013-03-01 09:11:58.70307	oscar brown	29.22	1166.3199996948242
-2013-03-01 09:11:58.70307	calvin laertes	31.17	1137.1000003814697
-PREHOOK: query: explain vectorization detail
-select t, s, d, avg(d) over (partition by t order by s,d desc nulls first rows between 5 preceding and 5 following) from over10k limit 10
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select t, s, d, avg(d) over (partition by t order by s,d desc nulls first rows between 5 preceding and 5 following) from over10k limit 10
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: t (type: tinyint), s (type: string), d (type: double)
-              sort order: ++-
-              Map-reduce partition columns: t (type: tinyint)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [0, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: tinyint), KEY.reducesinkkey2 (type: double), KEY.reducesinkkey1 (type: string)
-          outputColumnNames: _col0, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST, _col5 DESC NULLS FIRST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col5
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: ROWS PRECEDING(5)~FOLLOWING(5)
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col0 (type: tinyint), _col7 (type: string), _col5 (type: double), avg_window_0 (type: double)
-              outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 10
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select t, s, d, avg(d) over (partition by t order by s,d desc nulls first rows between 5 preceding and 5 following) from over10k limit 10
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select t, s, d, avg(d) over (partition by t order by s,d desc nulls first rows between 5 preceding and 5 following) from over10k limit 10
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-t	s	d	avg_window_0
--3	alice allen	29.44	33.20166666666666
--3	alice davidson	31.52	30.741428571428568
--3	alice falkner	49.8	27.742499999999996
--3	alice king	41.5	26.706666666666663
--3	alice king	30.76	26.306999999999995
--3	alice xylophone	16.19	24.458181818181814
--3	bob ellison	15.98	25.029090909090908
--3	bob falkner	6.75	24.216363636363635
--3	bob ichabod	18.42	20.173636363636362
--3	bob johnson	22.71	16.431818181818176
-PREHOOK: query: explain vectorization detail
-select ts, s, sum(i) over(partition by ts order by s nulls last) from over10k limit 10 offset 3
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select ts, s, sum(i) over(partition by ts order by s nulls last) from over10k limit 10 offset 3
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), s (type: string)
-              sort order: ++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              value expressions: i (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 7, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col2 (type: int), KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col2, _col7, _col8
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col7: string, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS LAST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col2
-                        name: sum
-                        window function: GenericUDAFSumLong
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col8 (type: timestamp), _col7 (type: string), sum_window_0 (type: bigint)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 10
-                Offset of rows: 3
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 10
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select ts, s, sum(i) over(partition by ts order by s nulls last) from over10k limit 10 offset 3
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select ts, s, sum(i) over(partition by ts order by s nulls last) from over10k limit 10 offset 3
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-ts	s	sum_window_0
-2013-03-01 09:11:58.70307	calvin steinbeck	262874
-2013-03-01 09:11:58.70307	david falkner	328506
-2013-03-01 09:11:58.70307	fred nixon	394118
-2013-03-01 09:11:58.70307	fred zipper	459719
-2013-03-01 09:11:58.70307	gabriella van buren	525334
-2013-03-01 09:11:58.70307	gabriella xylophone	591058
-2013-03-01 09:11:58.70307	jessica laertes	656771
-2013-03-01 09:11:58.70307	jessica polk	722558
-2013-03-01 09:11:58.70307	katie king	788310
-2013-03-01 09:11:58.70307	katie white	853920
-PREHOOK: query: explain vectorization detail
-select s, i, round(sum(d) over (partition by s order by i desc nulls last) , 3) from over10k limit 5
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, i, round(sum(d) over (partition by s order by i desc nulls last) , 3) from over10k limit 5
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string), i (type: int)
-              sort order: +-
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              value expressions: d (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), VALUE._col4 (type: double), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 DESC NULLS LAST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col5
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col2 (type: int), round(sum_window_0, 3) (type: double)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 5
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 5
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, i, round(sum(d) over (partition by s order by i desc nulls last) , 3) from over10k limit 5
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, i, round(sum(d) over (partition by s order by i desc nulls last) , 3) from over10k limit 5
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	i	_c2
-NULL	65536	0.02
-NULL	65534	0.03
-NULL	NULL	0.04
-alice allen	65758	23.59
-alice allen	65720	43.98
-PREHOOK: query: explain vectorization detail
-select s, i, round(avg(d) over (partition by s order by i desc nulls last) / 10.0 , 3) from over10k limit 5
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, i, round(avg(d) over (partition by s order by i desc nulls last) / 10.0 , 3) from over10k limit 5
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string), i (type: int)
-              sort order: +-
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              value expressions: d (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), VALUE._col4 (type: double), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 DESC NULLS LAST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col5
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col2 (type: int), round((avg_window_0 / 10.0), 3) (type: double)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 5
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 5
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, i, round(avg(d) over (partition by s order by i desc nulls last) / 10.0 , 3) from over10k limit 5
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, i, round(avg(d) over (partition by s order by i desc nulls last) / 10.0 , 3) from over10k limit 5
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	i	_c2
-NULL	65536	0.002
-NULL	65534	0.002
-NULL	NULL	0.001
-alice allen	65758	2.359
-alice allen	65720	2.199
-PREHOOK: query: explain vectorization detail
-select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),3) from over10k window w1 as (partition by s order by i nulls last) limit 5
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),3) from over10k window w1 as (partition by s order by i nulls last) limit 5
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string), i (type: int)
-              sort order: ++
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              value expressions: d (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), VALUE._col4 (type: double), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS LAST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col5
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col2 (type: int), round(((avg_window_0 + 10.0) - (avg_window_0 - 10.0)), 3) (type: double)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 5
-                Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017948 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 5
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),3) from over10k window w1 as (partition by s order by i nulls last) limit 5
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),3) from over10k window w1 as (partition by s order by i nulls last) limit 5
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	i	_c2
-NULL	65534	20.0
-NULL	65536	20.0
-NULL	NULL	20.0
-alice allen	65545	20.0
-alice allen	65557	20.0


[02/12] hive git commit: HIVE-18067 : Remove extraneous golden files

Posted by ha...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/afa9ffee/ql/src/test/results/clientpositive/vector_windowing_windowspec.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/vector_windowing_windowspec.q.out b/ql/src/test/results/clientpositive/vector_windowing_windowspec.q.out
deleted file mode 100644
index 1364bad..0000000
--- a/ql/src/test/results/clientpositive/vector_windowing_windowspec.q.out
+++ /dev/null
@@ -1,2093 +0,0 @@
-PREHOOK: query: drop table over10k
-PREHOOK: type: DROPTABLE
-POSTHOOK: query: drop table over10k
-POSTHOOK: type: DROPTABLE
-PREHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal,  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-PREHOOK: type: CREATETABLE
-PREHOOK: Output: database:default
-PREHOOK: Output: default@over10k
-POSTHOOK: query: create table over10k(
-           t tinyint,
-           si smallint,
-           i int,
-           b bigint,
-           f float,
-           d double,
-           bo boolean,
-           s string,
-	   ts timestamp, 
-           `dec` decimal,  
-           bin binary)
-       row format delimited
-       fields terminated by '|'
-POSTHOOK: type: CREATETABLE
-POSTHOOK: Output: database:default
-POSTHOOK: Output: default@over10k
-PREHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-PREHOOK: type: LOAD
-#### A masked pattern was here ####
-PREHOOK: Output: default@over10k
-POSTHOOK: query: load data local inpath '../../data/files/over10k' into table over10k
-POSTHOOK: type: LOAD
-#### A masked pattern was here ####
-POSTHOOK: Output: default@over10k
-PREHOOK: query: explain vectorization detail
-select s, sum(b) over (partition by i order by s,b rows unbounded preceding) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, sum(b) over (partition by i order by s,b rows unbounded preceding) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: i (type: int), s (type: string), b (type: bigint)
-              sort order: +++
-              Map-reduce partition columns: i (type: int)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 3, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: int), KEY.reducesinkkey2 (type: bigint), KEY.reducesinkkey1 (type: string)
-          outputColumnNames: _col2, _col3, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col3: bigint, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST, _col3 ASC NULLS FIRST
-                  partition by: _col2
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col3
-                        name: sum
-                        window function: GenericUDAFSumLong
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), sum_window_0 (type: bigint)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, sum(b) over (partition by i order by s,b rows unbounded preceding) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, sum(b) over (partition by i order by s,b rows unbounded preceding) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	sum_window_0
-alice ichabod	4294967441
-alice robinson	8589934917
-bob robinson	12884902266
-calvin thompson	17179869602
-david johnson	21474837092
-david laertes	25769804523
-david nixon	30064771904
-david nixon	34359739395
-ethan johnson	38654706752
-ethan ovid	42949674180
-ethan underhill	47244641690
-fred miller	51539609102
-fred miller	55834576592
-gabriella garcia	60129544023
-gabriella underhill	64424511330
-holly white	68719478650
-irene johnson	73014446110
-katie ellison	77309413485
-luke allen	81604380948
-mike quirinius	85899348426
-mike white	90194315855
-nick davidson	94489283385
-oscar allen	98784250693
-oscar garcia	103079218190
-oscar ichabod	107374185594
-oscar ovid	111669153102
-oscar steinbeck	115964120553
-priscilla garcia	120259087901
-priscilla white	124554055390
-priscilla xylophone	128849022850
-priscilla young	133143990191
-rachel brown	137438957640
-rachel ichabod	141733924974
-rachel xylophone	146028892291
-sarah thompson	150323859590
-sarah thompson	154618826928
-tom johnson	158913794359
-tom steinbeck	163208761724
-ulysses polk	167503729208
-victor johnson	171798696592
-wendy polk	176093663918
-xavier davidson	180388631312
-yuri ellison	184683598825
-zach allen	188978566334
-zach hernandez	193273533646
-alice ellison	4294967446
-bob carson	8589934892
-calvin brown	12884902329
-david xylophone	17179869748
-ethan white	21474837241
-fred johnson	25769804704
-fred van buren	30064772167
-gabriella ichabod	34359739606
-holly laertes	38654707054
-holly quirinius	42949674584
-jessica hernandez	47244642120
-katie robinson	51539609539
-katie thompson	55834576895
-luke nixon	60129544345
-mike garcia	64424511764
-mike hernandez	68719479285
-nick carson	73014446621
-nick davidson	77309414083
-oscar carson	81604381543
-oscar robinson	85899348869
-priscilla white	90194316274
-sarah falkner	94489283722
-sarah ichabod	98784251271
-ulysses falkner	103079218819
-victor xylophone	107374186359
-wendy garcia	111669153733
-wendy van buren	115964121147
-xavier underhill	120259088561
-yuri garcia	124554056001
-yuri quirinius	128849023443
-yuri white	133143990852
-zach falkner	137438958357
-zach ichabod	141733925776
-zach nixon	146028893205
-zach ovid	150323860576
-alice ichabod	4294967451
-alice king	8589934958
-alice robinson	12884902278
-calvin allen	17179869612
-gabriella johnson	21474837108
-gabriella nixon	25769804436
-holly falkner	30064771905
-holly hernandez	34359739256
-holly thompson	38654706595
-katie nixon	42949674112
-luke brown	47244641636
-luke davidson	51539608978
-luke white	55834576299
-mike brown	60129543641
-nick quirinius	64424511126
-oscar white	68719478551
-priscilla xylophone	73014446004
-quinn garcia	77309413317
-quinn laertes	81604380656
-rachel young	85899348171
-PREHOOK: query: explain vectorization detail
-select s, sum(f) over (partition by d order by s,f rows unbounded preceding) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, sum(f) over (partition by d order by s,f rows unbounded preceding) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: d (type: double), s (type: string), f (type: float)
-              sort order: +++
-              Map-reduce partition columns: d (type: double)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey2 (type: float), KEY.reducesinkkey0 (type: double), KEY.reducesinkkey1 (type: string)
-          outputColumnNames: _col4, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST, _col4 ASC NULLS FIRST
-                  partition by: _col5
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col4
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), sum_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, sum(f) over (partition by d order by s,f rows unbounded preceding) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, sum(f) over (partition by d order by s,f rows unbounded preceding) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	sum_window_0
-calvin miller	8.390000343322754
-holly polk	5.289999961853027
-wendy quirinius	30.789999961853027
-yuri laertes	68.38000011444092
-nick steinbeck	79.23999786376953
-katie brown	60.0
-priscilla quirinius	137.83999633789062
-tom young	186.33999633789062
-gabriella quirinius	14.359999656677246
-katie falkner	65.92999935150146
-xavier robinson	153.84000301361084
-ethan carson	40.90999984741211
-victor johnson	100.0
-jessica king	92.70999908447266
-jessica white	124.16999816894531
-zach white	170.71999740600586
-holly falkner	97.3499984741211
-quinn falkner	196.23999786376953
-victor davidson	255.95999908447266
-holly young	19.110000610351562
-nick robinson	13.329999923706055
-xavier steinbeck	48.53999900817871
-irene king	30.469999313354492
-quinn zipper	90.04000091552734
-priscilla miller	15.359999656677246
-wendy zipper	92.8000020980835
-yuri miller	153.5600004196167
-zach steinbeck	9.069999694824219
-fred nixon	50.08000183105469
-katie brown	13.300000190734863
-nick davidson	87.05000305175781
-gabriella davidson	3.940000057220459
-zach carson	70.88999700546265
-holly hernandez	48.52000045776367
-jessica quirinius	90.18000030517578
-tom xylophone	166.11000061035156
-wendy king	184.76000022888184
-gabriella brown	84.83000183105469
-quinn johnson	134.9800033569336
-yuri zipper	205.75
-david robinson	64.79000091552734
-mike nixon	153.7300033569336
-gabriella white	1.4199999570846558
-rachel davidson	98.12999904155731
-yuri garcia	9.880000114440918
-yuri zipper	104.01999950408936
-alice king	85.72000122070312
-jessica steinbeck	111.41000175476074
-katie hernandez	178.9699993133545
-katie ovid	40.0
-priscilla young	101.72999954223633
-quinn davidson	196.8400001525879
-quinn van buren	279.6400032043457
-victor steinbeck	309.6400032043457
-gabriella brown	80.6500015258789
-jessica ichabod	96.54000091552734
-zach laertes	104.50000095367432
-ethan miller	49.61000061035156
-irene carson	110.68000030517578
-irene falkner	131.42000007629395
-priscilla zipper	201.39000129699707
-tom robinson	290.75000190734863
-katie polk	38.689998626708984
-nick white	96.93999862670898
-sarah davidson	99.59999871253967
-xavier laertes	161.30999779701233
-alice ichabod	32.689998626708984
-nick polk	130.97999954223633
-gabriella robinson	90.0999984741211
-luke brown	90.71999847888947
-wendy allen	116.34999763965607
-calvin ichabod	29.059999465942383
-holly steinbeck	98.4799976348877
-gabriella carson	38.09000015258789
-holly van buren	106.89999771118164
-tom nixon	191.92999649047852
-katie laertes	75.75
-mike brown	163.97000122070312
-oscar nixon	24.020000457763672
-zach garcia	101.61999893188477
-tom polk	76.98999786376953
-mike allen	96.44999694824219
-alice johnson	1.090000033378601
-holly robinson	26.209999084472656
-priscilla thompson	111.12999725341797
-yuri young	168.73999786376953
-rachel carson	80.98999786376953
-gabriella laertes	39.81999969482422
-victor brown	78.97999954223633
-bob carson	24.149999618530273
-holly allen	68.71999931335449
-fred nixon	38.04999923706055
-rachel carson	119.60000228881836
-alice nixon	49.130001068115234
-priscilla brown	123.57999801635742
-victor falkner	42.4900016784668
-david garcia	67.27999877929688
-holly hernandez	116.36999893188477
-tom white	154.0
-rachel ellison	10.600000381469727
-PREHOOK: query: explain vectorization detail
-select s, sum(f) over (partition by ts order by f range between current row and unbounded following) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, sum(f) over (partition by ts order by f range between current row and unbounded following) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), f (type: float)
-              sort order: ++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: s (type: string)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 7, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: float), VALUE._col6 (type: string), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col4, _col7, _col8
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col7: string, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col4
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE CURRENT~FOLLOWING(MAX)
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), sum_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, sum(f) over (partition by ts order by f range between current row and unbounded following) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, sum(f) over (partition by ts order by f range between current row and unbounded following) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	sum_window_0
-gabriella xylophone	1276.850001335144
-calvin brown	1273.68000125885
-jessica laertes	1262.7900009155273
-yuri allen	1248.2500009536743
-tom johnson	1233.4700012207031
-bob ovid	1215.6200008392334
-fred nixon	1195.0100002288818
-oscar brown	1166.3199996948242
-calvin laertes	1137.1000003814697
-david falkner	1105.9300003051758
-calvin steinbeck	1067.5800018310547
-katie white	1028.9700012207031
-sarah falkner	989.4900016784668
-mike laertes	948.9500007629395
-victor ellison	907.3500022888184
-luke zipper	861.2700004577637
-rachel garcia	806.9099998474121
-wendy steinbeck	749.9700012207031
-priscilla zipper	685.0100021362305
-rachel thompson	611.4900054931641
-victor van buren	532.9100036621094
-fred zipper	451.5
-gabriella van buren	366.79000091552734
-nick carson	279.36000061035156
-katie king	188.0
-jessica polk	95.04000091552734
-oscar davidson	2368.430002987385
-xavier johnson	2367.600003004074
-rachel ovid	2365.6100029945374
-xavier davidson	2361.880002975464
-nick ellison	2353.0200033187866
-jessica robinson	2342.4000034332275
-bob king	2331.0800037384033
-ulysses xylophone	2318.2500038146973
-wendy thompson	2303.550004005432
-yuri brown	2288.590003967285
-ethan ovid	2271.010004043579
-rachel robinson	2251.9100036621094
-holly falkner	2230.9000034332275
-calvin nixon	2203.950002670288
-luke thompson	2176.7200031280518
-gabriella johnson	2147.6500034332275
-jessica brown	2117.940004348755
-quinn allen	2086.100004196167
-irene brown	2054.1600036621094
-katie zipper	2018.8400039672852
-gabriella steinbeck	1981.520004272461
-priscilla brown	1943.020004272461
-zach young	1900.9400024414062
-alice miller	1856.6400032043457
-priscilla zipper	1811.9800033569336
-rachel young	1765.1400032043457
-holly thompson	1716.2500038146973
-calvin white	1666.6100044250488
-priscilla hernandez	1616.330005645752
-fred polk	1564.240005493164
-sarah van buren	1510.9800071716309
-rachel ovid	1456.890007019043
-luke xylophone	1400.4400062561035
-yuri hernandez	1343.6800079345703
-oscar van buren	1282.2700080871582
-quinn ovid	1220.390007019043
-victor underhill	1157.360008239746
-luke king	1092.8100051879883
-calvin carson	1024.1900024414062
-jessica brown	948.0600051879883
-jessica nixon	869.0100021362305
-katie davidson	788.5800018310547
-fred king	707.1699981689453
-wendy johnson	624.3199996948242
-ulysses johnson	540.3399963378906
-katie xylophone	456.12999725341797
-ethan young	370.57999420166016
-gabriella underhill	282.6499938964844
-luke steinbeck	193.7199935913086
-bob falkner	99.44999694824219
-holly allen	1607.950005441904
-rachel ichabod	1607.590005427599
-bob carson	1607.1100054383278
-wendy miller	1606.3200054168701
-nick king	1605.0500054359436
-rachel ellison	1600.5700054168701
-yuri garcia	1591.5700054168701
-victor hernandez	1568.3000049591064
-wendy underhill	1543.1700057983398
-alice underhill	1517.830005645752
-rachel polk	1491.9200057983398
-holly nixon	1462.910005569458
-ethan nixon	1432.4400062561035
-sarah falkner	1394.490005493164
-tom hernandez	1355.1900062561035
-rachel ichabod	1309.2800064086914
-priscilla thompson	1256.8400077819824
-jessica thompson	1202.7400093078613
-ulysses carson	1146.0400085449219
-wendy falkner	1087.2700080871582
-calvin white	1025.1800079345703
-jessica ovid	956.9800109863281
-jessica johnson	885.3000106811523
-priscilla garcia	805.8400115966797
-PREHOOK: query: explain vectorization detail
-select s, avg(f) over (partition by ts order by s,f rows between current row and 5 following) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, avg(f) over (partition by ts order by s,f rows between current row and 5 following) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), s (type: string), f (type: float)
-              sort order: +++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 7, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey2 (type: float), KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col4, _col7, _col8
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col7: string, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST, _col4 ASC NULLS FIRST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col4
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: ROWS CURRENT~FOLLOWING(5)
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), avg_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, avg(f) over (partition by ts order by s,f rows between current row and 5 following) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, avg(f) over (partition by ts order by s,f rows between current row and 5 following) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	avg_window_0
-bob ovid	28.053333441416424
-calvin brown	38.73666652043661
-calvin laertes	51.493333180745445
-calvin steinbeck	46.826666514078774
-david falkner	42.81499973932902
-fred nixon	52.26333347956339
-fred zipper	62.97499990463257
-gabriella van buren	55.43666664759318
-gabriella xylophone	49.925000031789146
-jessica laertes	56.32999976476034
-jessica polk	69.13333320617676
-katie king	58.16333293914795
-katie white	54.92333253224691
-luke zipper	57.83333237965902
-mike laertes	61.86999924977621
-nick carson	61.69333299001058
-oscar brown	49.44166628519694
-priscilla zipper	52.25166670481364
-rachel garcia	53.56666787465414
-rachel thompson	54.903334617614746
-sarah falkner	44.27000093460083
-tom johnson	45.01600093841553
-victor ellison	51.80750107765198
-victor van buren	53.71666749318441
-wendy steinbeck	39.869999408721924
-yuri allen	14.779999732971191
-alice miller	51.76333204905192
-bob falkner	47.50333213806152
-bob king	45.58333269755045
-calvin carson	57.253332455952965
-calvin nixon	53.441665967305504
-calvin white	53.85499922434489
-ethan ovid	51.891666094462074
-ethan young	63.52999941507975
-fred king	53.36666615804037
-fred polk	47.83166631062826
-gabriella johnson	44.84166653951009
-gabriella steinbeck	45.1966667175293
-gabriella underhill	51.95500055948893
-holly falkner	50.538333892822266
-holly thompson	47.93333371480306
-irene brown	53.22833442687988
-jessica brown	61.600001653035484
-jessica brown	62.51333491007487
-jessica nixon	60.775001525878906
-jessica robinson	63.08166758219401
-katie davidson	66.04000091552734
-katie xylophone	61.931666692097984
-katie zipper	49.44333283106486
-luke king	43.36166621247927
-luke steinbeck	42.238332599401474
-luke thompson	33.54000013073286
-luke xylophone	37.376666873693466
-nick ellison	35.72333384553591
-oscar davidson	39.27666728695234
-oscar van buren	49.643333752950035
-priscilla brown	39.95166691144308
-priscilla hernandez	42.346666733423866
-priscilla zipper	37.166666746139526
-quinn allen	37.50833328564962
-quinn ovid	41.199999888738
-rachel ovid	44.729999939600624
-rachel ovid	46.558333237965904
-rachel robinson	47.90833361943563
-rachel young	58.40333414077759
-sarah van buren	52.74833424886068
-ulysses johnson	45.21000083287557
-ulysses xylophone	31.506667653719585
-victor underhill	31.98666767279307
-wendy johnson	31.46333380540212
-wendy thompson	24.84999978542328
-xavier davidson	26.82799973487854
-xavier johnson	31.319999754428864
-yuri brown	41.09666633605957
-yuri hernandez	52.85499954223633
-zach young	44.29999923706055
-alice underhill	38.0366666217645
-bob carson	38.7966665327549
-calvin white	51.90833304325739
-ethan ichabod	52.48833360274633
-ethan nixon	46.103333373864494
-holly allen	40.5249999165535
-holly nixon	55.85333355267843
-jessica johnson	64.11166644096375
-jessica ovid	66.54166674613953
-jessica thompson	69.09166725476582
-nick king	68.65833353996277
-oscar carson	82.59166717529297
-priscilla garcia	80.75166702270508
-priscilla hernandez	68.91500091552734
-priscilla polk	53.32166742781798
-priscilla thompson	47.56499997278055
-quinn van buren	43.383333598574005
-rachel davidson	35.253333166241646
-rachel ellison	29.356666321555775
-rachel ichabod	37.651666397849716
-rachel ichabod	41.75999959309896
-rachel polk	49.56333351135254
-sarah falkner	59.53333377838135
-tom hernandez	63.331667264302574
-PREHOOK: query: explain vectorization detail
-select s, avg(d) over (partition by t order by s,d desc rows between 5 preceding and 5 following) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, avg(d) over (partition by t order by s,d desc rows between 5 preceding and 5 following) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: t (type: tinyint), s (type: string), d (type: double)
-              sort order: ++-
-              Map-reduce partition columns: t (type: tinyint)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [0, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey0 (type: tinyint), KEY.reducesinkkey2 (type: double), KEY.reducesinkkey1 (type: string)
-          outputColumnNames: _col0, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col0: tinyint, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST, _col5 DESC NULLS LAST
-                  partition by: _col0
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col5
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: ROWS PRECEDING(5)~FOLLOWING(5)
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), avg_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, avg(d) over (partition by t order by s,d desc rows between 5 preceding and 5 following) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, avg(d) over (partition by t order by s,d desc rows between 5 preceding and 5 following) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	avg_window_0
-alice allen	33.20166666666666
-alice davidson	30.741428571428568
-alice falkner	27.742499999999996
-alice king	26.706666666666663
-alice king	26.306999999999995
-alice xylophone	24.458181818181814
-bob ellison	25.029090909090908
-bob falkner	24.216363636363635
-bob ichabod	20.173636363636362
-bob johnson	16.431818181818176
-bob polk	16.640909090909087
-bob underhill	15.266363636363632
-bob underhill	18.288181818181812
-bob van buren	18.405454545454543
-calvin ichabod	20.90363636363636
-calvin white	22.448181818181812
-david carson	24.329090909090898
-david falkner	25.01181818181817
-david garcia	22.984545454545444
-david hernandez	22.92272727272726
-ethan steinbeck	24.026363636363627
-ethan underhill	25.189090909090904
-fred ellison	27.159999999999993
-gabriella brown	25.66454545454545
-holly nixon	25.70545454545454
-holly polk	24.11818181818182
-holly steinbeck	24.49090909090909
-holly thompson	23.376363636363635
-holly underhill	19.453636363636363
-irene ellison	20.378181818181826
-irene underhill	23.510000000000012
-irene young	25.371818181818195
-jessica johnson	24.42636363636365
-jessica king	26.380000000000017
-jessica miller	23.99545454545456
-jessica white	26.866363636363655
-katie ichabod	28.520909090909115
-luke garcia	26.110909090909114
-luke ichabod	27.41909090909093
-luke king	28.713636363636375
-luke young	30.59181818181818
-mike allen	27.91545454545455
-mike king	25.526363636363644
-mike polk	24.774545454545464
-mike white	25.18363636363637
-mike xylophone	27.50818181818182
-nick nixon	26.225454545454546
-nick robinson	24.34454545454545
-oscar davidson	26.719090909090916
-oscar garcia	27.196363636363643
-oscar johnson	27.08272727272728
-oscar johnson	25.164545454545472
-oscar miller	28.059090909090916
-priscilla laertes	31.73727272727274
-priscilla quirinius	30.353636363636372
-priscilla zipper	27.961818181818195
-quinn ellison	29.40636363636366
-quinn polk	27.267272727272754
-rachel davidson	25.415454545454562
-rachel thompson	23.608181818181823
-sarah miller	21.49909090909091
-sarah robinson	23.40454545454546
-sarah xylophone	26.957272727272724
-sarah zipper	24.83545454545455
-tom hernandez	21.274545454545454
-tom hernandez	20.315454545454546
-tom polk	21.90181818181819
-tom steinbeck	20.772727272727273
-ulysses carson	21.647272727272718
-ulysses ellison	22.960909090909084
-ulysses quirinius	23.025454545454544
-ulysses robinson	23.762727272727282
-ulysses steinbeck	21.08909090909091
-victor allen	16.628181818181826
-victor hernandez	15.74909090909091
-victor robinson	18.193636363636355
-victor thompson	20.81181818181817
-victor xylophone	20.372727272727243
-wendy quirinius	20.81636363636362
-wendy robinson	19.936363636363634
-wendy xylophone	20.270909090909093
-xavier garcia	19.874000000000002
-xavier ovid	19.976666666666663
-yuri xylophone	21.89625000000001
-zach thompson	25.021428571428583
-zach young	27.77666666666668
-alice carson	18.785
-alice nixon	17.58142857142857
-alice underhill	17.072499999999998
-alice underhill	19.146666666666665
-alice xylophone	20.556
-bob falkner	19.116363636363637
-bob king	21.04
-bob ovid	20.854545454545452
-bob van buren	21.988181818181815
-bob xylophone	24.364545454545453
-calvin xylophone	26.91272727272727
-david falkner	27.31
-david laertes	28.00454545454545
-david miller	28.40090909090909
-PREHOOK: query: explain vectorization detail
-select s, sum(i) over(partition by ts order by s) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, sum(i) over(partition by ts order by s) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), s (type: string)
-              sort order: ++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: i (type: int)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 7, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: VALUE._col2 (type: int), KEY.reducesinkkey1 (type: string), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col2, _col7, _col8
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col7: string, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col7 ASC NULLS FIRST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col2
-                        name: sum
-                        window function: GenericUDAFSumLong
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), sum_window_0 (type: bigint)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, sum(i) over(partition by ts order by s) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, sum(i) over(partition by ts order by s) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	sum_window_0
-bob ovid	65748
-calvin brown	131440
-calvin laertes	197097
-calvin steinbeck	262874
-david falkner	328506
-fred nixon	394118
-fred zipper	459719
-gabriella van buren	525334
-gabriella xylophone	591058
-jessica laertes	656771
-jessica polk	722558
-katie king	788310
-katie white	853920
-luke zipper	919543
-mike laertes	985277
-nick carson	1050928
-oscar brown	1116474
-priscilla zipper	1182084
-rachel garcia	1247836
-rachel thompson	1313378
-sarah falkner	1379093
-tom johnson	1444791
-victor ellison	1510421
-victor van buren	1576006
-wendy steinbeck	1641591
-yuri allen	1707256
-alice miller	65581
-bob falkner	131319
-bob king	197015
-calvin carson	262712
-calvin nixon	328407
-calvin white	393960
-ethan ovid	459504
-ethan young	525178
-fred king	590838
-fred polk	656600
-gabriella johnson	722283
-gabriella steinbeck	787886
-gabriella underhill	853497
-holly falkner	919218
-holly thompson	985000
-irene brown	1050757
-jessica brown	1182155
-jessica brown	1182155
-jessica nixon	1247815
-jessica robinson	1313437
-katie davidson	1379172
-katie xylophone	1444746
-katie zipper	1510302
-luke king	1576084
-luke steinbeck	1641724
-luke thompson	1707324
-luke xylophone	1773102
-nick ellison	1838744
-oscar davidson	1904390
-oscar van buren	1969971
-priscilla brown	2035582
-priscilla hernandez	2101353
-priscilla zipper	2166925
-quinn allen	2232487
-quinn ovid	2298060
-rachel ovid	2429366
-rachel ovid	2429366
-rachel robinson	2495140
-rachel young	2560880
-sarah van buren	2626599
-ulysses johnson	2692259
-ulysses xylophone	2757830
-victor underhill	2823401
-wendy johnson	2889058
-wendy thompson	2954831
-xavier davidson	3020367
-xavier johnson	3086050
-yuri brown	3151628
-yuri hernandez	3217338
-zach young	3283046
-alice underhill	65705
-bob carson	131461
-calvin white	197044
-ethan ichabod	262796
-ethan nixon	328501
-holly allen	394248
-holly nixon	459928
-jessica johnson	525664
-jessica ovid	591415
-jessica thompson	657122
-nick king	722691
-oscar carson	788459
-priscilla garcia	854222
-priscilla hernandez	919979
-priscilla polk	985680
-priscilla thompson	1051347
-quinn van buren	1117102
-rachel davidson	1182710
-rachel ellison	1248448
-rachel ichabod	1379923
-rachel ichabod	1379923
-rachel polk	1445518
-sarah falkner	1511234
-tom hernandez	1576947
-PREHOOK: query: explain vectorization detail
-select f, sum(f) over (partition by ts order by f range between unbounded preceding and current row) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select f, sum(f) over (partition by ts order by f range between unbounded preceding and current row) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), f (type: float)
-              sort order: ++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: float), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col4, _col8
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col4
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col4 (type: float), sum_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select f, sum(f) over (partition by ts order by f range between unbounded preceding and current row) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select f, sum(f) over (partition by ts order by f range between unbounded preceding and current row) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-f	sum_window_0
-3.17	3.1700000762939453
-10.89	14.0600004196167
-14.54	28.600000381469727
-14.78	43.38000011444092
-17.85	61.230000495910645
-20.61	81.8400011062622
-28.69	110.53000164031982
-29.22	139.75000095367432
-31.17	170.92000102996826
-38.35	209.26999950408936
-38.61	247.88000011444092
-39.48	287.35999965667725
-40.54	327.9000005722046
-41.6	369.4999990463257
-46.08	415.58000087738037
-54.36	469.94000148773193
-56.94	526.8800001144409
-64.96	591.8399991989136
-73.52	665.35999584198
-78.58	743.9399976730347
-81.41	825.350001335144
-84.71	910.0600004196167
-87.43	997.4900007247925
-91.36	1088.850001335144
-92.96	1181.8100004196167
-95.04	1276.850001335144
-0.83	0.8299999833106995
-1.99	2.8199999928474426
-3.73	6.550000011920929
-8.86	15.409999668598175
-10.62	26.029999554157257
-11.32	37.349999248981476
-12.83	50.17999917268753
-14.7	64.87999898195267
-14.96	79.83999902009964
-17.58	97.4199989438057
-19.1	116.51999932527542
-21.01	137.52999955415726
-26.95	164.4800003170967
-27.23	191.70999985933304
-29.07	220.77999955415726
-29.71	250.4899986386299
-31.84	282.3299987912178
-31.94	314.2699993252754
-35.32	349.58999902009964
-37.32	386.90999871492386
-38.5	425.40999871492386
-42.08	467.49000054597855
-44.3	511.7899997830391
-44.66	556.4499996304512
-46.84	603.2899997830391
-48.89	652.1799991726875
-49.64	701.819998562336
-50.28	752.0999973416328
-52.09	804.1899974942207
-53.26	857.4499958157539
-54.09	911.5399959683418
-56.45	967.9899967312813
-56.76	1024.7499950528145
-61.41	1086.1599949002266
-61.88	1148.0399959683418
-63.03	1211.0699947476387
-64.55	1275.6199977993965
-68.62	1344.2400005459785
-76.13	1420.3699977993965
-79.05	1499.4200008511543
-80.43	1579.85000115633
-81.41	1661.2600048184395
-82.85	1744.1100032925606
-83.98	1828.0900066494942
-84.21	1912.3000057339668
-85.55	1997.8500087857246
-87.93	2085.7800090909004
-88.93	2174.710009396076
-94.27	2268.9800060391426
-99.45	2368.430002987385
-0.36	0.36000001430511475
-0.48	0.8400000035762787
-0.79	1.6300000250339508
-1.27	2.9000000059604645
-4.48	7.380000025033951
-9.0	16.38000002503395
-23.27	39.65000048279762
-25.13	64.77999964356422
-25.34	90.11999979615211
-25.91	116.02999964356422
-29.01	145.03999987244606
-30.47	175.50999918580055
-37.95	213.45999994874
-39.3	252.75999918580055
-45.91	298.66999903321266
-52.44	351.10999765992165
-54.1	405.20999613404274
-56.7	461.9099968969822
-58.77	520.6799973547459
-62.09	582.7699975073338
-68.2	650.9699944555759
-71.68	722.6499947607517
-79.46	802.1099938452244
-80.02	882.1299904882908
-PREHOOK: query: explain vectorization detail
-select f, sum(f) over (partition by ts order by f rows between 2 preceding and 1 preceding) from over10k limit 100
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select f, sum(f) over (partition by ts order by f rows between 2 preceding and 1 preceding) from over10k limit 100
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: ts (type: timestamp), f (type: float)
-              sort order: ++
-              Map-reduce partition columns: ts (type: timestamp)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [4, 8]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: float), KEY.reducesinkkey0 (type: timestamp)
-          outputColumnNames: _col4, _col8
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col4: float, _col8: timestamp
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col4 ASC NULLS FIRST
-                  partition by: _col8
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: sum_window_0
-                        arguments: _col4
-                        name: sum
-                        window function: GenericUDAFSumDouble
-                        window frame: ROWS PRECEDING(2)~PRECEDING(1)
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col4 (type: float), sum_window_0 (type: double)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 100
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 100
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select f, sum(f) over (partition by ts order by f rows between 2 preceding and 1 preceding) from over10k limit 100
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select f, sum(f) over (partition by ts order by f rows between 2 preceding and 1 preceding) from over10k limit 100
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-f	sum_window_0
-3.17	NULL
-10.89	3.1700000762939453
-14.54	14.0600004196167
-14.78	25.43000030517578
-17.85	29.31999969482422
-20.61	32.63000011444092
-28.69	38.46000099182129
-29.22	49.30000114440918
-31.17	57.90999984741211
-38.35	60.38999938964844
-38.61	69.51999855041504
-39.48	76.95999908447266
-40.54	78.09000015258789
-41.6	80.02000045776367
-46.08	82.13999938964844
-54.36	87.68000030517578
-56.94	100.44000244140625
-64.96	111.29999923706055
-73.52	121.89999771118164
-78.58	138.47999572753906
-81.41	152.0999984741211
-84.71	159.99000549316406
-87.43	166.12000274658203
-91.36	172.13999938964844
-92.96	178.79000091552734
-95.04	184.31999969482422
-0.83	NULL
-1.99	0.8299999833106995
-3.73	2.8199999928474426
-8.86	5.7200000286102295
-10.62	12.589999675750732
-11.32	19.479999542236328
-12.83	21.9399995803833
-14.7	24.149999618530273
-14.96	27.52999973297119
-17.58	29.65999984741211
-19.1	32.53999996185303
-21.01	36.68000030517578
-26.95	40.11000061035156
-27.23	47.96000099182129
-29.07	54.18000030517578
-29.71	56.29999923706055
-31.84	58.779998779296875
-31.94	61.54999923706055
-35.32	63.78000068664551
-37.32	67.26000022888184
-38.5	72.63999938964844
-42.08	75.81999969482422
-44.3	80.58000183105469
-44.66	86.38000106811523
-46.84	88.95999908447266
-48.89	91.5
-49.64	95.72999954223633
-50.28	98.52999877929688
-52.09	99.91999816894531
-53.26	102.36999893188477
-54.09	105.3499984741211
-56.45	107.3499984741211
-56.76	110.54000091552734
-61.41	113.20999908447266
-61.88	118.16999816894531
-63.03	123.29000091552734
-64.55	124.90999984741211
-68.62	127.58000183105469
-76.13	133.17000579833984
-79.05	144.75
-80.43	155.18000030517578
-81.41	159.4800033569336
-82.85	161.84000396728516
-83.98	164.26000213623047
-84.21	166.8300018310547
-85.55	168.19000244140625
-87.93	169.76000213623047
-88.93	173.4800033569336
-94.27	176.86000061035156
-99.45	183.1999969482422
-0.36	NULL
-0.48	0.36000001430511475
-0.79	0.8400000035762787
-1.27	1.270000010728836
-4.48	2.060000002384186
-9.0	5.75
-23.27	13.480000019073486
-25.13	32.27000045776367
-25.34	48.39999961853027
-25.91	50.46999931335449
-29.01	51.25
-30.47	54.920000076293945
-37.95	59.47999954223633
-39.3	68.42000007629395
-45.91	77.25
-52.44	85.20999908447266
-54.1	98.3499984741211
-56.7	106.53999710083008
-58.77	110.79999923706055
-62.09	115.47000122070312
-68.2	120.86000061035156
-71.68	130.28999710083008
-79.46	139.87999725341797
-80.02	151.13999938964844
-PREHOOK: query: explain vectorization detail
-select s, i, round(avg(d) over (partition by s order by i) / 10.0 , 2) from over10k limit 7
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, i, round(avg(d) over (partition by s order by i) / 10.0 , 2) from over10k limit 7
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string), i (type: int)
-              sort order: ++
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: d (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), VALUE._col4 (type: double), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col5
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col2 (type: int), round((avg_window_0 / 10.0), 2) (type: double)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 7
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 7
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, i, round(avg(d) over (partition by s order by i) / 10.0 , 2) from over10k limit 7
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, i, round(avg(d) over (partition by s order by i) / 10.0 , 2) from over10k limit 7
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	i	_c2
-alice allen	65545	2.22
-alice allen	65557	2.58
-alice allen	65600	3.38
-alice allen	65609	2.99
-alice allen	65662	2.7
-alice allen	65670	2.88
-alice allen	65720	2.76
-PREHOOK: query: explain vectorization detail
-select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i) limit 7
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i) limit 7
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string), i (type: int)
-              sort order: ++
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: d (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), VALUE._col4 (type: double), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col5
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col2 (type: int), round(((avg_window_0 + 10.0) - (avg_window_0 - 10.0)), 2) (type: double)
-              outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 7
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 7
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i) limit 7
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i) limit 7
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	i	_c2
-alice allen	65545	20.0
-alice allen	65557	20.0
-alice allen	65600	20.0
-alice allen	65609	20.0
-alice allen	65662	20.0
-alice allen	65670	20.0
-alice allen	65720	20.0
-PREHOOK: query: explain vectorization detail
-select s, i from ( select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i)) X limit 7
-PREHOOK: type: QUERY
-POSTHOOK: query: explain vectorization detail
-select s, i from ( select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i)) X limit 7
-POSTHOOK: type: QUERY
-Explain
-PLAN VECTORIZATION:
-  enabled: true
-  enabledConditionsMet: [hive.vectorized.execution.enabled IS true]
-
-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: over10k
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            TableScan Vectorization:
-                native: true
-                projectedColumnNums: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
-                projectedColumns: [t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary]
-            Reduce Output Operator
-              key expressions: s (type: string), i (type: int)
-              sort order: ++
-              Map-reduce partition columns: s (type: string)
-              Reduce Sink Vectorization:
-                  className: VectorReduceSinkOperator
-                  native: false
-                  nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
-                  nativeConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              value expressions: d (type: double)
-      Execution mode: vectorized
-      Map Vectorization:
-          enabled: true
-          enabledConditionsMet: hive.vectorized.use.vector.serde.deserialize IS true
-          inputFormatFeatureSupport: [DECIMAL_64]
-          featureSupportInUse: [DECIMAL_64]
-          inputFileFormats: org.apache.hadoop.mapred.TextInputFormat
-          allNative: false
-          usesVectorUDFAdaptor: false
-          vectorized: true
-          rowBatchContext:
-              dataColumnCount: 11
-              includeColumns: [2, 5, 7]
-              dataColumns: t:tinyint, si:smallint, i:int, b:bigint, f:float, d:double, bo:boolean, s:string, ts:timestamp, dec:decimal(10,0)/DECIMAL_64, bin:binary
-              partitionColumnCount: 0
-              scratchColumnTypeNames: []
-      Reduce Vectorization:
-          enabled: false
-          enableConditionsMet: hive.vectorized.execution.reduce.enabled IS true
-          enableConditionsNotMet: hive.execution.engine mr IN [tez, spark] IS false
-      Reduce Operator Tree:
-        Select Operator
-          expressions: KEY.reducesinkkey1 (type: int), VALUE._col4 (type: double), KEY.reducesinkkey0 (type: string)
-          outputColumnNames: _col2, _col5, _col7
-          Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-          PTF Operator
-            Function definitions:
-                Input definition
-                  input alias: ptf_0
-                  output shape: _col2: int, _col5: double, _col7: string
-                  type: WINDOWING
-                Windowing table definition
-                  input alias: ptf_1
-                  name: windowingtablefunction
-                  order by: _col2 ASC NULLS FIRST
-                  partition by: _col7
-                  raw input shape:
-                  window functions:
-                      window function definition
-                        alias: avg_window_0
-                        arguments: _col5
-                        name: avg
-                        window function: GenericUDAFAverageEvaluatorDouble
-                        window frame: RANGE PRECEDING(MAX)~CURRENT
-            Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-            Select Operator
-              expressions: _col7 (type: string), _col2 (type: int)
-              outputColumnNames: _col0, _col1
-              Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-              Limit
-                Number of rows: 7
-                Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 1 Data size: 1017544 Basic stats: COMPLETE Column stats: NONE
-                  table:
-                      input format: org.apache.hadoop.mapred.SequenceFileInputFormat
-                      output format: org.apache.hadoop.hive.ql.io.HiveSequenceFileOutputFormat
-                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
-
-  Stage: Stage-0
-    Fetch Operator
-      limit: 7
-      Processor Tree:
-        ListSink
-
-PREHOOK: query: select s, i from ( select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i)) X limit 7
-PREHOOK: type: QUERY
-PREHOOK: Input: default@over10k
-#### A masked pattern was here ####
-POSTHOOK: query: select s, i from ( select s, i, round((avg(d) over  w1 + 10.0) - (avg(d) over w1 - 10.0),2) from over10k window w1 as (partition by s order by i)) X limit 7
-POSTHOOK: type: QUERY
-POSTHOOK: Input: default@over10k
-#### A masked pattern was here ####
-s	i
-alice allen	65545
-alice allen	65557
-alice allen	65600
-alice allen	65609
-alice allen	65662
-alice allen	65670
-alice allen	65720