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:26 UTC

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

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>