You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by mm...@apache.org on 2015/11/01 05:32:50 UTC

[05/10] hive git commit: HIVE-12290 Native Vector ReduceSink (Matt McCline, reviewed by Gopal V)

http://git-wip-us.apache.org/repos/asf/hive/blob/409db57d/ql/src/test/results/clientpositive/tez/vector_reduce2.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/tez/vector_reduce2.q.out b/ql/src/test/results/clientpositive/tez/vector_reduce2.q.out
new file mode 100644
index 0000000..81038ff
--- /dev/null
+++ b/ql/src/test/results/clientpositive/tez/vector_reduce2.q.out
@@ -0,0 +1,2167 @@
+PREHOOK: query: -- SORT_QUERY_RESULTS
+
+create table vectortab2k(
+            t tinyint,
+            si smallint,
+            i int,
+            b bigint,
+            f float,
+            d double,
+            dc decimal(38,18),
+            bo boolean,
+            s string,
+            s2 string,
+            ts timestamp,
+            ts2 timestamp,
+            dt date)
+ROW FORMAT DELIMITED FIELDS TERMINATED BY '|'
+STORED AS TEXTFILE
+PREHOOK: type: CREATETABLE
+PREHOOK: Output: database:default
+PREHOOK: Output: default@vectortab2k
+POSTHOOK: query: -- SORT_QUERY_RESULTS
+
+create table vectortab2k(
+            t tinyint,
+            si smallint,
+            i int,
+            b bigint,
+            f float,
+            d double,
+            dc decimal(38,18),
+            bo boolean,
+            s string,
+            s2 string,
+            ts timestamp,
+            ts2 timestamp,
+            dt date)
+ROW FORMAT DELIMITED FIELDS TERMINATED BY '|'
+STORED AS TEXTFILE
+POSTHOOK: type: CREATETABLE
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@vectortab2k
+PREHOOK: query: LOAD DATA LOCAL INPATH '../../data/files/vectortab2k' OVERWRITE INTO TABLE vectortab2k
+PREHOOK: type: LOAD
+#### A masked pattern was here ####
+PREHOOK: Output: default@vectortab2k
+POSTHOOK: query: LOAD DATA LOCAL INPATH '../../data/files/vectortab2k' OVERWRITE INTO TABLE vectortab2k
+POSTHOOK: type: LOAD
+#### A masked pattern was here ####
+POSTHOOK: Output: default@vectortab2k
+PREHOOK: query: create table vectortab2korc(
+            t tinyint,
+            si smallint,
+            i int,
+            b bigint,
+            f float,
+            d double,
+            dc decimal(38,18),
+            bo boolean,
+            s string,
+            s2 string,
+            ts timestamp,
+            ts2 timestamp,
+            dt date)
+STORED AS ORC
+PREHOOK: type: CREATETABLE
+PREHOOK: Output: database:default
+PREHOOK: Output: default@vectortab2korc
+POSTHOOK: query: create table vectortab2korc(
+            t tinyint,
+            si smallint,
+            i int,
+            b bigint,
+            f float,
+            d double,
+            dc decimal(38,18),
+            bo boolean,
+            s string,
+            s2 string,
+            ts timestamp,
+            ts2 timestamp,
+            dt date)
+STORED AS ORC
+POSTHOOK: type: CREATETABLE
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@vectortab2korc
+PREHOOK: query: INSERT INTO TABLE vectortab2korc SELECT * FROM vectortab2k
+PREHOOK: type: QUERY
+PREHOOK: Input: default@vectortab2k
+PREHOOK: Output: default@vectortab2korc
+POSTHOOK: query: INSERT INTO TABLE vectortab2korc SELECT * FROM vectortab2k
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@vectortab2k
+POSTHOOK: Output: default@vectortab2korc
+POSTHOOK: Lineage: vectortab2korc.b SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:b, type:bigint, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.bo SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:bo, type:boolean, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.d SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:d, type:double, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.dc SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:dc, type:decimal(38,18), comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.dt SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:dt, type:date, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.f SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:f, type:float, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.i SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:i, type:int, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.s SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:s, type:string, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.s2 SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:s2, type:string, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.si SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:si, type:smallint, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.t SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:t, type:tinyint, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.ts SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:ts, type:timestamp, comment:null), ]
+POSTHOOK: Lineage: vectortab2korc.ts2 SIMPLE [(vectortab2k)vectortab2k.FieldSchema(name:ts2, type:timestamp, comment:null), ]
+PREHOOK: query: explain
+select s, i, s2 from vectortab2korc order by s, i, s2
+PREHOOK: type: QUERY
+POSTHOOK: query: explain
+select s, i, s2 from vectortab2korc order by s, i, s2
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Tez
+      Edges:
+        Reducer 2 <- Map 1 (SIMPLE_EDGE)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: vectortab2korc
+                  Statistics: Num rows: 2000 Data size: 918712 Basic stats: COMPLETE Column stats: NONE
+                  Select Operator
+                    expressions: s (type: string), i (type: int), s2 (type: string)
+                    outputColumnNames: _col0, _col1, _col2
+                    Statistics: Num rows: 2000 Data size: 918712 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: _col0 (type: string), _col1 (type: int), _col2 (type: string)
+                      sort order: +++
+                      Statistics: Num rows: 2000 Data size: 918712 Basic stats: COMPLETE Column stats: NONE
+            Execution mode: vectorized
+        Reducer 2 
+            Execution mode: vectorized
+            Reduce Operator Tree:
+              Select Operator
+                expressions: KEY.reducesinkkey0 (type: string), KEY.reducesinkkey1 (type: int), KEY.reducesinkkey2 (type: string)
+                outputColumnNames: _col0, _col1, _col2
+                Statistics: Num rows: 2000 Data size: 918712 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 2000 Data size: 918712 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select s, i, s2 from vectortab2korc order by s, i, s2
+PREHOOK: type: QUERY
+PREHOOK: Input: default@vectortab2korc
+#### A masked pattern was here ####
+POSTHOOK: query: select s, i, s2 from vectortab2korc order by s, i, s2
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@vectortab2korc
+#### A masked pattern was here ####
+	-1036720157	david king
+	-1125605439	ethan zipper
+	-1180153422	nick ovid
+	-1198465530	rachel quirinius
+	-1232183416	sarah underhill
+	-125419186	zach laertes
+	-1351437382	alice xylophone
+	-1369253050	katie white
+	-1411407810	xavier brown
+	-1442424087	luke ichabod
+	-1556127172	fred nixon
+	-1605045257	calvin ovid
+	-1656822229	priscilla ichabod
+	-1674623501	gabriella ichabod
+	-1741895392	rachel underhill
+	-1822850051	calvin ovid
+	-1830870295	david quirinius
+	-1862095575	tom ichabod
+	-1871446009	david johnson
+	-1933192293	rachel white
+	-1939362279	sarah carson
+	-1952235832	
+	-1974972123	rachel laertes
+	-199587670	priscilla miller
+	-2007662579	wendy quirinius
+	-2074079977	wendy white
+	-213198503	holly allen
+	-2136052026	
+	-234278308	rachel robinson
+	-397683105	
+	-44426049	victor polk
+	-507015439	holly underhill
+	-507250351	ethan king
+	-595769210	bob polk
+	-598552521	holly carson
+	-600315936	priscilla garcia
+	-694520014	quinn steinbeck
+	-737624128	victor falkner
+	-785261879	
+	-87470856	irene miller
+	-934008333	ethan ovid
+	1000106109	ethan brown
+	1013517056	xavier ovid
+	1070989126	fred carson
+	1107502179	oscar brown
+	1112783661	nick king
+	1117805438	calvin zipper
+	1141303816	quinn xylophone
+	1271280812	mike hernandez
+	1273798925	priscilla thompson
+	1283898734	irene nixon
+	1284956108	ulysses johnson
+	1318606691	quinn young
+	1425362689	mike quirinius
+	1513689502	bob allen
+	1640192895	fred laertes
+	1647411522	mike ellison
+	1660278264	priscilla ellison
+	1695098246	holly underhill
+	1765173148	yuri polk
+	187718349	quinn thompson
+	1956887369	bob king
+	1968813171	sarah miller
+	196980893	mike johnson
+	2018442973	tom falkner
+	2081243058	
+	2126491387	oscar underhill
+	2144365072	bob nixon
+	229688868	tom davidson
+	230954385	wendy robinson
+	273256071	ulysses white
+	330302407	calvin davidson
+	397255100	zach brown
+	434679307	katie carson
+	435426302	ulysses hernandez
+	44628821	gabriella carson
+	449788961	priscilla ichabod
+	536876888	wendy young
+	546555204	victor thompson
+	548375173	priscilla xylophone
+	644934949	irene hernandez
+	669484010	yuri ovid
+	742059797	quinn quirinius
+	765656980	victor thompson
+	771827308	luke white
+	826143442	zach zipper
+	906074599	wendy nixon
+	976870621	calvin polk
+	996831203	quinn quirinius
+	NULL	
+	NULL	bob davidson
+	NULL	jessica white
+	NULL	quinn zipper
+	NULL	ulysses falkner
+american history	-1045771991	yuri king
+american history	-1079231269	victor carson
+american history	-1092872261	
+american history	-1168823523	fred white
+american history	-1210907929	yuri ellison
+american history	-123529324	luke underhill
+american history	-1240912824	david brown
+american history	-1289501869	irene king
+american history	-1312782341	ethan robinson
+american history	-1333770335	david miller
+american history	-1409508377	katie laertes
+american history	-1434562279	
+american history	-1527024213	ethan laertes
+american history	-1660344634	nick polk
+american history	-1668736016	xavier allen
+american history	-1701492480	jessica carson
+american history	-1721763321	david davidson
+american history	-1755088362	oscar ovid
+american history	-1870912732	holly hernandez
+american history	-1900894010	xavier van buren
+american history	-1940205653	david xylophone
+american history	-2144138362	victor laertes
+american history	-226635871	alice davidson
+american history	-316678117	holly brown
+american history	-329336519	luke robinson
+american history	-396852483	jessica nixon
+american history	-455114104	sarah zipper
+american history	-469870330	wendy van buren
+american history	-564495517	sarah steinbeck
+american history	-573787626	priscilla nixon
+american history	-695775663	yuri king
+american history	-705887590	ethan white
+american history	-71449585	fred brown
+american history	-853606287	alice van buren
+american history	-870900240	
+american history	-990781312	victor xylophone
+american history	1008698636	ethan polk
+american history	1082837515	jessica carson
+american history	1106995930	sarah ovid
+american history	1153811197	victor brown
+american history	1187495452	xavier ellison
+american history	1190554937	bob ovid
+american history	1204834275	katie thompson
+american history	1219616145	quinn quirinius
+american history	1240875512	david quirinius
+american history	1300798829	katie garcia
+american history	1310360849	mike van buren
+american history	1367179645	fred falkner
+american history	1495575878	quinn king
+american history	1543611951	tom quirinius
+american history	1550112473	victor carson
+american history	1556919269	yuri white
+american history	156101201	katie white
+american history	1604076720	david xylophone
+american history	1616782308	jessica quirinius
+american history	1660088606	ulysses nixon
+american history	1797164732	holly thompson
+american history	198017473	nick brown
+american history	2051470532	rachel zipper
+american history	214068706	bob thompson
+american history	290921475	tom thompson
+american history	316438994	sarah white
+american history	458190500	calvin xylophone
+american history	604460005	priscilla king
+american history	636901402	bob quirinius
+american history	672919099	
+american history	731241198	xavier davidson
+american history	747122546	david thompson
+american history	84231802	holly laertes
+american history	874824958	ethan king
+american history	916057807	katie ellison
+american history	92777932	ulysses davidson
+american history	95356298	tom ovid
+american history	977624089	ulysses ellison
+american history	985634256	quinn miller
+american history	NULL	alice king
+american history	NULL	irene allen
+american history	NULL	oscar nixon
+american history	NULL	sarah quirinius
+american history	NULL	wendy johnson
+biology	-1006768637	mike xylophone
+biology	-1031592590	yuri miller
+biology	-1050029724	wendy king
+biology	-1054609414	
+biology	-1062159435	oscar zipper
+biology	-1065248998	sarah ellison
+biology	-1098379914	holly johnson
+biology	-113253627	david robinson
+biology	-1147471772	quinn polk
+biology	-1227085134	victor robinson
+biology	-1231821948	luke young
+biology	-1262842192	ulysses quirinius
+biology	-1344287228	holly davidson
+biology	-1359838019	quinn miller
+biology	-1424770359	katie davidson
+biology	-1464762852	bob garcia
+biology	-1491722659	ethan laertes
+biology	-1568536214	ethan ichabod
+biology	-1628799508	alice underhill
+biology	-1644966759	calvin quirinius
+biology	-1726585032	katie polk
+biology	-1733560816	david davidson
+biology	-1805915233	ulysses brown
+biology	-1836166334	zach ellison
+biology	-194270271	luke johnson
+biology	-2011708220	katie zipper
+biology	-2065080832	priscilla falkner
+biology	-2086352100	holly king
+biology	-217785690	mike miller
+biology	-235238928	quinn hernandez
+biology	-236700442	holly carson
+biology	-270683864	zach robinson
+biology	-345542922	tom steinbeck
+biology	-348628614	katie johnson
+biology	-352146259	xavier van buren
+biology	-36682325	fred laertes
+biology	-387395264	
+biology	-457341338	nick robinson
+biology	-519978947	bob van buren
+biology	-524189419	xavier van buren
+biology	-707108808	quinn johnson
+biology	-7929246	calvin thompson
+biology	-837506172	
+biology	-858439361	
+biology	-938342473	wendy thompson
+biology	-946349935	oscar white
+biology	-983874694	wendy carson
+biology	1012696613	david hernandez
+biology	1090344463	sarah van buren
+biology	1102561039	priscilla carson
+biology	1119976718	yuri laertes
+biology	1130840708	zach garcia
+biology	1184001017	ulysses ovid
+biology	1373871781	ethan ellison
+biology	1395450272	zach xylophone
+biology	149701884	oscar thompson
+biology	1509573831	wendy hernandez
+biology	152654715	xavier steinbeck
+biology	1533817551	david underhill
+biology	1565313938	oscar carson
+biology	1595326878	
+biology	1645753684	wendy falkner
+biology	1747664003	priscilla ellison
+biology	1814570016	fred carson
+biology	1851654062	yuri carson
+biology	1851805558	ulysses white
+biology	196581473	ethan johnson
+biology	1969239701	yuri nixon
+biology	198624903	fred ichabod
+biology	2022944702	
+biology	2045579147	jessica van buren
+biology	29680001	david thompson
+biology	304860245	mike miller
+biology	315055746	ethan white
+biology	470575409	jessica falkner
+biology	524808	calvin van buren
+biology	663222148	quinn zipper
+biology	670667262	wendy carson
+biology	710856472	bob allen
+biology	765084282	ulysses johnson
+biology	766737781	sarah zipper
+biology	780859673	katie van buren
+biology	810157660	wendy falkner
+biology	814544198	wendy johnson
+biology	825977391	irene young
+biology	843282593	zach van buren
+biology	85774760	mike underhill
+biology	868714547	zach falkner
+biology	899810881	quinn garcia
+biology	94220511	oscar brown
+biology	NULL	holly young
+chemistry	-1048181367	holly robinson
+chemistry	-1100641049	luke miller
+chemistry	-1128317466	ethan young
+chemistry	-1146055387	quinn van buren
+chemistry	-1210261177	tom johnson
+chemistry	-1218581850	ethan ovid
+chemistry	-1218592418	gabriella ovid
+chemistry	-1326025787	calvin garcia
+chemistry	-1352545619	yuri carson
+chemistry	-1380191654	wendy steinbeck
+chemistry	-1380678829	gabriella nixon
+chemistry	-1407817977	tom quirinius
+chemistry	-1478812842	sarah robinson
+chemistry	-1484787952	wendy davidson
+chemistry	-1516259168	priscilla falkner
+chemistry	-1599905147	mike miller
+chemistry	-1754347372	nick allen
+chemistry	-1818380492	jessica young
+chemistry	-1875699183	bob polk
+chemistry	-1878838836	tom ellison
+chemistry	-1903090602	sarah ellison
+chemistry	-2032576637	quinn nixon
+chemistry	-203911033	calvin carson
+chemistry	-2087815643	fred young
+chemistry	-2133145181	yuri thompson
+chemistry	-310343273	holly carson
+chemistry	-392713245	tom carson
+chemistry	-395499919	wendy zipper
+chemistry	-423074450	irene ellison
+chemistry	-423945469	fred brown
+chemistry	-480058682	jessica nixon
+chemistry	-496915240	oscar allen
+chemistry	-514010922	yuri laertes
+chemistry	-758973175	alice ovid
+chemistry	-799249885	quinn ichabod
+chemistry	-940504641	victor robinson
+chemistry	-971615370	calvin allen
+chemistry	1126157283	wendy xylophone
+chemistry	1137950964	
+chemistry	1281159709	priscilla davidson
+chemistry	1295073553	sarah king
+chemistry	1301426600	irene hernandez
+chemistry	1330219997	holly xylophone
+chemistry	1385883394	fred brown
+chemistry	1398486099	sarah robinson
+chemistry	1420099773	ulysses falkner
+chemistry	1575300276	ulysses allen
+chemistry	1652349607	victor young
+chemistry	1664736741	jessica king
+chemistry	170870820	alice ichabod
+chemistry	1718167702	quinn king
+chemistry	184879574	quinn davidson
+chemistry	1883400319	irene allen
+chemistry	1895282160	wendy van buren
+chemistry	1928365430	alice thompson
+chemistry	1998185704	quinn hernandez
+chemistry	2008211296	
+chemistry	2090496825	wendy polk
+chemistry	2111462911	katie zipper
+chemistry	217476429	jessica thompson
+chemistry	254921167	priscilla allen
+chemistry	436093771	katie davidson
+chemistry	43983130	luke allen
+chemistry	505902480	ulysses garcia
+chemistry	514833409	katie nixon
+chemistry	541923995	rachel miller
+chemistry	563507584	katie robinson
+chemistry	605946758	calvin ellison
+chemistry	648935848	luke laertes
+chemistry	652118640	holly ellison
+chemistry	683320224	nick carson
+chemistry	794783516	mike van buren
+chemistry	830944953	irene davidson
+chemistry	842283345	gabriella underhill
+chemistry	964810954	tom ellison
+chemistry	991397535	luke nixon
+chemistry	NULL	katie hernandez
+chemistry	NULL	victor polk
+chemistry	NULL	victor steinbeck
+debate	-1179668872	wendy garcia
+debate	-1184620079	wendy falkner
+debate	-1210550573	bob king
+debate	-1366059787	bob ellison
+debate	-1371840597	jessica xylophone
+debate	-1511162508	calvin van buren
+debate	-1534238977	katie steinbeck
+debate	-1614194712	alice laertes
+debate	-1700451326	rachel ichabod
+debate	-1726479726	victor davidson
+debate	-1745449855	
+debate	-1921909135	ethan hernandez
+debate	-2071851852	ethan ichabod
+debate	-207899360	tom ellison
+debate	-223311809	gabriella miller
+debate	-273937943	sarah steinbeck
+debate	-290558484	ulysses allen
+debate	-298221893	fred zipper
+debate	-453739759	priscilla king
+debate	-483740394	ethan polk
+debate	-491882534	ethan garcia
+debate	-500921094	irene van buren
+debate	-511198293	rachel ichabod
+debate	-532755480	rachel van buren
+debate	-538812082	xavier king
+debate	-624029057	irene robinson
+debate	-628446314	
+debate	-655118881	bob laertes
+debate	-66010816	rachel davidson
+debate	-664111469	katie king
+debate	-674478103	ethan van buren
+debate	-728015067	
+debate	-896274896	zach johnson
+debate	-912429611	sarah steinbeck
+debate	-993029335	oscar laertes
+debate	-997463353	xavier white
+debate	1012230484	sarah polk
+debate	1061638369	mike polk
+debate	1083855659	alice johnson
+debate	1159353899	ulysses polk
+debate	133276416	jessica young
+debate	1352649032	ethan miller
+debate	1482983157	quinn johnson
+debate	1566607834	david brown
+debate	1579460630	xavier ellison
+debate	1592467112	yuri thompson
+debate	1673218677	xavier falkner
+debate	1766517223	
+debate	1920863389	priscilla xylophone
+debate	1938788165	quinn steinbeck
+debate	1951869763	yuri brown
+debate	1969650228	bob white
+debate	2005560498	alice king
+debate	2044130430	luke brown
+debate	291866793	nick hernandez
+debate	323919214	sarah davidson
+debate	435407142	david allen
+debate	44595790	xavier brown
+debate	564349193	tom laertes
+debate	58313734	fred ovid
+debate	60847311	oscar young
+debate	618321042	tom xylophone
+debate	667283966	jessica king
+debate	818313200	sarah johnson
+debate	873035819	calvin johnson
+debate	879500678	mike king
+debate	904604938	mike steinbeck
+debate	945683736	gabriella quirinius
+debate	NULL	mike van buren
+debate	NULL	nick xylophone
+debate	NULL	rachel allen
+education	-1021859098	irene brown
+education	-1078579367	katie nixon
+education	-1138530007	
+education	-1240048334	sarah ellison
+education	-1272838092	gabriella brown
+education	-1283465451	xavier quirinius
+education	-1421396891	irene zipper
+education	-1429346144	zach miller
+education	-1439424023	zach white
+education	-1471147786	nick brown
+education	-1497098905	gabriella nixon
+education	-1506324615	alice ellison
+education	-1517536924	ulysses ellison
+education	-170643477	oscar johnson
+education	-1770250407	victor davidson
+education	-1867014618	nick zipper
+education	-2009569943	alice laertes
+education	-2015780444	calvin underhill
+education	-2027812975	wendy davidson
+education	-267130580	fred steinbeck
+education	-295751373	ulysses carson
+education	-337586880	gabriella steinbeck
+education	-371779520	fred xylophone
+education	-374337252	bob davidson
+education	-434656160	quinn white
+education	-521886983	tom underhill
+education	-560322190	ulysses ellison
+education	-591879497	david garcia
+education	-596963345	yuri ovid
+education	-688296901	bob zipper
+education	-722294882	quinn quirinius
+education	-733756717	fred zipper
+education	-749042352	katie young
+education	-839512271	priscilla steinbeck
+education	-966979668	alice falkner
+education	-9958400	zach miller
+education	1027147837	ethan zipper
+education	1107258026	quinn steinbeck
+education	1136976809	katie garcia
+education	1194243726	luke miller
+education	1304812803	ethan quirinius
+education	1370723240	
+education	1372224352	tom underhill
+education	1410516523	yuri ovid
+education	1412102605	ulysses hernandez
+education	1447462863	tom nixon
+education	1452244326	wendy quirinius
+education	1493555718	katie thompson
+education	1552351592	gabriella underhill
+education	1568180994	alice underhill
+education	1602631923	sarah laertes
+education	1625699061	ethan johnson
+education	1626868156	tom garcia
+education	1636364987	alice white
+education	1767019352	yuri carson
+education	177294487	tom quirinius
+education	1802498539	quinn garcia
+education	1829544791	tom miller
+education	1836499981	yuri davidson
+education	1893512909	ethan ichabod
+education	1902676205	david brown
+education	2076370203	bob thompson
+education	2134433675	irene ovid
+education	2140632003	david davidson
+education	219415594	calvin steinbeck
+education	232405034	quinn robinson
+education	277582670	tom underhill
+education	315973457	fred davidson
+education	413090363	rachel king
+education	418182899	luke xylophone
+education	453613037	holly allen
+education	472901914	zach miller
+education	492120544	tom xylophone
+education	516479816	wendy ellison
+education	622925063	rachel miller
+education	66182203	quinn ichabod
+education	713031549	oscar johnson
+education	793047956	mike laertes
+education	879289168	
+education	NULL	ethan davidson
+education	NULL	mike van buren
+education	NULL	sarah garcia
+education	NULL	zach miller
+forestry	-1081766449	holly ichabod
+forestry	-1106469823	wendy thompson
+forestry	-1134786190	katie allen
+forestry	-1230459100	mike laertes
+forestry	-1249011023	alice van buren
+forestry	-1345391395	yuri falkner
+forestry	-1358159222	quinn king
+forestry	-1402821064	luke brown
+forestry	-1454941039	victor underhill
+forestry	-1541281934	bob quirinius
+forestry	-1688105985	sarah garcia
+forestry	-1728171376	rachel carson
+forestry	-1826997220	luke polk
+forestry	-2041825946	jessica falkner
+forestry	-310584775	nick van buren
+forestry	-346607939	
+forestry	-454598288	xavier young
+forestry	-470798506	wendy carson
+forestry	-536315467	luke allen
+forestry	-559270035	zach polk
+forestry	-561932449	yuri ovid
+forestry	-619311578	
+forestry	-859535015	bob garcia
+forestry	-866304147	holly young
+forestry	-886741158	nick quirinius
+forestry	-932525608	zach quirinius
+forestry	-958165276	calvin johnson
+forestry	-980869630	oscar falkner
+forestry	-987995271	oscar davidson
+forestry	1002519329	mike king
+forestry	1033836308	david thompson
+forestry	1153089364	bob falkner
+forestry	1202593021	rachel carson
+forestry	1346627771	
+forestry	1447438548	david thompson
+forestry	1464695860	alice hernandez
+forestry	1517488324	luke quirinius
+forestry	152891873	irene underhill
+forestry	1575091509	quinn thompson
+forestry	1583280136	bob carson
+forestry	1594107168	jessica underhill
+forestry	1626884085	nick robinson
+forestry	1677494300	victor van buren
+forestry	172075892	sarah nixon
+forestry	1751468853	tom ellison
+forestry	1776456512	ulysses thompson
+forestry	1796013407	wendy underhill
+forestry	1815882183	fred robinson
+forestry	1848935036	mike van buren
+forestry	1861276585	alice underhill
+forestry	1882932986	ulysses nixon
+forestry	1933545427	victor allen
+forestry	1958701268	ulysses miller
+forestry	2058640744	wendy polk
+forestry	2080412555	fred van buren
+forestry	2097519027	sarah laertes
+forestry	259204652	victor white
+forestry	284646137	alice van buren
+forestry	340929437	quinn brown
+forestry	374283948	wendy laertes
+forestry	3999930	fred thompson
+forestry	415234946	bob brown
+forestry	477857533	jessica ovid
+forestry	530274409	fred quirinius
+forestry	566646177	calvin ovid
+forestry	584084934	tom van buren
+forestry	633813435	oscar king
+forestry	768198315	oscar brown
+forestry	860658464	fred brown
+forestry	922373046	nick miller
+forestry	950545385	priscilla carson
+forestry	962091264	tom polk
+forestry	NULL	david davidson
+forestry	NULL	david nixon
+forestry	NULL	holly ellison
+forestry	NULL	wendy allen
+geology	-1004204053	luke johnson
+geology	-1017629298	wendy brown
+geology	-1039040287	xavier quirinius
+geology	-1081328752	luke johnson
+geology	-1127100849	oscar white
+geology	-1141801925	oscar young
+geology	-120692484	calvin white
+geology	-1288198020	luke zipper
+geology	-1379039356	yuri white
+geology	-1439293109	priscilla nixon
+geology	-1538558250	zach young
+geology	-158233823	
+geology	-158848747	sarah ellison
+geology	-1620148746	nick robinson
+geology	-1798573685	ulysses white
+geology	-181122344	irene davidson
+geology	-1831957182	sarah garcia
+geology	-1878572820	ulysses underhill
+geology	-1918847735	priscilla miller
+geology	-1947868215	
+geology	-1968097621	ulysses hernandez
+geology	-1998652546	ethan thompson
+geology	-203416622	nick miller
+geology	-2042647152	holly steinbeck
+geology	-296195507	victor thompson
+geology	-36038293	holly allen
+geology	-491377296	calvin zipper
+geology	-533281137	jessica allen
+geology	-553349593	alice ovid
+geology	-575513309	ulysses ichabod
+geology	-588160623	david van buren
+geology	-630900418	oscar steinbeck
+geology	-679230165	bob brown
+geology	-682333536	ulysses steinbeck
+geology	-693249555	nick king
+geology	-817093900	priscilla polk
+geology	-841268868	ulysses ellison
+geology	-909127123	rachel xylophone
+geology	1028204648	bob falkner
+geology	1136548971	
+geology	1203482872	david underhill
+geology	127917714	
+geology	1301997393	victor van buren
+geology	1312270193	oscar falkner
+geology	1317690178	holly miller
+geology	1394370866	mike carson
+geology	141492068	ethan polk
+geology	1425456189	
+geology	1475025489	alice davidson
+geology	1503176016	david nixon
+geology	1505168716	
+geology	1550375386	sarah carson
+geology	1701817607	tom hernandez
+geology	1860113703	priscilla young
+geology	1996235654	mike underhill
+geology	2013178181	tom laertes
+geology	2040926345	yuri underhill
+geology	2068538934	quinn polk
+geology	278601840	ulysses king
+geology	283618733	quinn ovid
+geology	287239980	katie johnson
+geology	297577612	bob ovid
+geology	314232856	fred thompson
+geology	345556325	irene laertes
+geology	373031319	alice johnson
+geology	440393309	sarah ovid
+geology	447426619	alice quirinius
+geology	458910170	holly ellison
+geology	550186724	jessica polk
+geology	589546540	david hernandez
+geology	596595603	tom johnson
+geology	722737062	irene brown
+geology	824743780	priscilla falkner
+geology	915505006	luke hernandez
+geology	975932228	victor carson
+geology	NULL	mike ichabod
+history	-1024500955	rachel thompson
+history	-1066775085	katie zipper
+history	-1144976744	katie robinson
+history	-1412187081	gabriella robinson
+history	-1431196400	ulysses johnson
+history	-1446132523	ulysses polk
+history	-1459528251	quinn ellison
+history	-1575588203	calvin zipper
+history	-1594957608	ethan xylophone
+history	-1603071732	calvin nixon
+history	-1625062942	tom young
+history	-1627366321	david allen
+history	-178568841	nick quirinius
+history	-1801684055	calvin steinbeck
+history	-186600427	sarah thompson
+history	-189393743	irene ellison
+history	-1900369503	gabriella thompson
+history	-1949698319	
+history	-1989378509	
+history	-202409329	bob zipper
+history	-2076460151	bob ichabod
+history	-306214368	mike steinbeck
+history	-4393552	rachel ichabod
+history	-445353909	quinn davidson
+history	-45439614	david ichabod
+history	-499533481	oscar underhill
+history	-549167249	holly nixon
+history	-800799595	luke ovid
+history	-807242371	quinn xylophone
+history	-817383093	quinn davidson
+history	-846450672	david white
+history	-882028850	xavier ovid
+history	-88576126	ethan allen
+history	-891543038	holly carson
+history	-906986958	wendy johnson
+history	1033609549	irene johnson
+history	1141595012	xavier steinbeck
+history	1142098316	yuri van buren
+history	1164895226	
+history	1238986437	ulysses underhill
+history	1352739140	luke miller
+history	1467284000	victor nixon
+history	1500437122	bob laertes
+history	1665724041	luke laertes
+history	1669519977	wendy ichabod
+history	1754025802	victor steinbeck
+history	1772349172	victor van buren
+history	1784291853	yuri falkner
+history	1807358029	calvin brown
+history	1813010930	quinn ovid
+history	1844415080	holly xylophone
+history	253621570	calvin carson
+history	278643258	xavier ichabod
+history	283322761	ethan ichabod
+history	334208532	bob zipper
+history	363981930	
+history	44009986	rachel young
+history	488559595	ethan hernandez
+history	523289079	gabriella ellison
+history	62293025	sarah falkner
+history	696229550	bob brown
+history	742866312	victor zipper
+history	760466914	
+history	786565385	quinn van buren
+history	805672638	irene thompson
+history	877053605	holly falkner
+history	901084309	jessica quirinius
+history	917891418	quinn carson
+history	919363072	mike zipper
+history	930008274	priscilla zipper
+history	998793176	xavier falkner
+history	NULL	ethan van buren
+history	NULL	katie ellison
+history	NULL	zach miller
+industrial engineering	-1011125931	zach ichabod
+industrial engineering	-1078397698	david robinson
+industrial engineering	-1108723753	luke quirinius
+industrial engineering	-1156193121	yuri johnson
+industrial engineering	-1247325089	calvin falkner
+industrial engineering	-1259611508	calvin brown
+industrial engineering	-1665164127	victor polk
+industrial engineering	-1706867123	calvin allen
+industrial engineering	-1718163874	priscilla white
+industrial engineering	-1730740504	xavier laertes
+industrial engineering	-1908696083	
+industrial engineering	-1946023520	irene brown
+industrial engineering	-2022383454	gabriella underhill
+industrial engineering	-211669740	alice allen
+industrial engineering	-2119539915	holly carson
+industrial engineering	-2122509553	nick nixon
+industrial engineering	-2137168636	katie garcia
+industrial engineering	-373034494	ethan polk
+industrial engineering	-379643543	david quirinius
+industrial engineering	-399643110	ethan johnson
+industrial engineering	-44559184	priscilla garcia
+industrial engineering	-616724730	mike brown
+industrial engineering	-841634659	victor nixon
+industrial engineering	-890374552	gabriella polk
+industrial engineering	1074488452	tom polk
+industrial engineering	1081187102	oscar brown
+industrial engineering	1111985530	wendy falkner
+industrial engineering	1222217404	luke steinbeck
+industrial engineering	1258721737	jessica nixon
+industrial engineering	1336365018	gabriella hernandez
+industrial engineering	1409872356	katie white
+industrial engineering	1483580941	oscar allen
+industrial engineering	15020431	ulysses zipper
+industrial engineering	1516236846	bob steinbeck
+industrial engineering	1577999613	quinn ovid
+industrial engineering	1712411993	quinn garcia
+industrial engineering	1742536084	sarah robinson
+industrial engineering	206942178	zach miller
+industrial engineering	2084666529	mike brown
+industrial engineering	2114363167	calvin falkner
+industrial engineering	215759857	sarah steinbeck
+industrial engineering	290601612	calvin white
+industrial engineering	376076075	katie king
+industrial engineering	386741352	sarah ichabod
+industrial engineering	414645489	yuri young
+industrial engineering	430686478	ulysses polk
+industrial engineering	470993066	luke garcia
+industrial engineering	480849725	priscilla ovid
+industrial engineering	494570380	jessica ichabod
+industrial engineering	52667480	david ichabod
+industrial engineering	574069547	tom falkner
+industrial engineering	674547678	tom johnson
+industrial engineering	748185058	alice quirinius
+industrial engineering	776606164	alice laertes
+industrial engineering	851975276	xavier xylophone
+industrial engineering	868717604	
+industrial engineering	879290165	mike young
+industrial engineering	990246086	holly allen
+industrial engineering	NULL	alice young
+industrial engineering	NULL	calvin steinbeck
+industrial engineering	NULL	katie ichabod
+industrial engineering	NULL	katie robinson
+industrial engineering	NULL	priscilla brown
+joggying	-1017027298	victor young
+joggying	-1096013673	nick falkner
+joggying	-1111937842	irene white
+joggying	-1117019030	calvin xylophone
+joggying	-1202975006	alice ichabod
+joggying	-1218871391	priscilla steinbeck
+joggying	-122391516	alice garcia
+joggying	-1270523286	victor nixon
+joggying	-1302592941	quinn steinbeck
+joggying	-1305139473	mike underhill
+joggying	-1313618168	xavier hernandez
+joggying	-1339495001	wendy ichabod
+joggying	-1524081566	ethan van buren
+joggying	-1524554771	luke johnson
+joggying	-1563676282	victor polk
+joggying	-1602792666	yuri brown
+joggying	-161884324	oscar nixon
+joggying	-1622653291	oscar hernandez
+joggying	-1904737684	ethan nixon
+joggying	-1918651448	mike davidson
+joggying	-1948257321	tom hernandez
+joggying	-2112149052	calvin robinson
+joggying	-2119724898	holly young
+joggying	-267554590	david van buren
+joggying	-337073639	priscilla nixon
+joggying	-540401598	david brown
+joggying	-570632618	victor laertes
+joggying	-656478771	tom quirinius
+joggying	-779743333	ethan white
+joggying	-870624802	calvin davidson
+joggying	-896261100	katie davidson
+joggying	1012843193	ulysses xylophone
+joggying	1052255272	fred carson
+joggying	1173098061	calvin brown
+joggying	1216287232	jessica polk
+joggying	1336194583	tom underhill
+joggying	1377144283	
+joggying	144499388	zach miller
+joggying	1450881368	david robinson
+joggying	1478365409	calvin white
+joggying	1535954353	xavier carson
+joggying	1572563948	zach laertes
+joggying	1645067708	luke ichabod
+joggying	1759741857	nick steinbeck
+joggying	1773417290	oscar brown
+joggying	177837042	katie ovid
+joggying	1835749815	wendy carson
+joggying	1905812339	oscar polk
+joggying	2133950868	
+joggying	218917585	quinn ellison
+joggying	344239980	david hernandez
+joggying	391186487	nick allen
+joggying	479566810	oscar brown
+joggying	514046604	mike hernandez
+joggying	587206979	alice zipper
+joggying	63706286	katie johnson
+joggying	658850444	ulysses ovid
+joggying	65956045	nick laertes
+joggying	686081268	holly laertes
+joggying	700341242	victor king
+joggying	706823078	calvin ovid
+joggying	780938234	luke falkner
+joggying	826519029	holly hernandez
+joggying	865013617	fred miller
+joggying	889772203	
+joggying	908943372	fred ovid
+joggying	972835688	victor quirinius
+joggying	NULL	calvin johnson
+joggying	NULL	luke falkner
+joggying	NULL	luke steinbeck
+joggying	NULL	mike garcia
+joggying	NULL	quinn johnson
+joggying	NULL	quinn nixon
+kindergarten	-1052493316	mike van buren
+kindergarten	-1057522129	ethan quirinius
+kindergarten	-1091003492	holly robinson
+kindergarten	-1116100266	priscilla ovid
+kindergarten	-1140071443	mike laertes
+kindergarten	-1155174991	luke robinson
+kindergarten	-1205034356	
+kindergarten	-1213081886	fred allen
+kindergarten	-1228063838	
+kindergarten	-1299159155	alice ellison
+kindergarten	-1838281337	ulysses carson
+kindergarten	-1851680302	fred van buren
+kindergarten	-187804718	calvin miller
+kindergarten	-1880783574	irene zipper
+kindergarten	-1919939921	xavier van buren
+kindergarten	-1988508336	bob young
+kindergarten	-269702086	holly ellison
+kindergarten	-370093295	bob thompson
+kindergarten	-41242237	rachel johnson
+kindergarten	-533227056	
+kindergarten	-574475259	wendy polk
+kindergarten	-583908704	fred allen
+kindergarten	-632803945	xavier white
+kindergarten	-664856187	alice xylophone
+kindergarten	-677778959	calvin quirinius
+kindergarten	-738157651	david allen
+kindergarten	-789126455	irene steinbeck
+kindergarten	-828724467	tom king
+kindergarten	-835107230	sarah carson
+kindergarten	-835198551	rachel van buren
+kindergarten	-890552359	sarah young
+kindergarten	-922875124	fred nixon
+kindergarten	-935723237	
+kindergarten	1036391201	victor ovid
+kindergarten	1042237722	gabriella falkner
+kindergarten	1056997296	jessica laertes
+kindergarten	1190302173	priscilla ichabod
+kindergarten	1202720813	katie ovid
+kindergarten	1307148254	jessica xylophone
+kindergarten	1540680149	mike white
+kindergarten	1582537271	jessica garcia
+kindergarten	1590744669	quinn white
+kindergarten	1605596441	calvin ovid
+kindergarten	1634441052	rachel steinbeck
+kindergarten	1709983738	wendy zipper
+kindergarten	1787826883	sarah allen
+kindergarten	1830870769	ulysses robinson
+kindergarten	2048533360	
+kindergarten	2066707767	zach thompson
+kindergarten	2089198703	victor ichabod
+kindergarten	346562088	zach quirinius
+kindergarten	459269456	mike nixon
+kindergarten	488014426	holly thompson
+kindergarten	56316391	sarah polk
+kindergarten	615619268	xavier underhill
+kindergarten	693331761	priscilla thompson
+kindergarten	88774647	priscilla miller
+kindergarten	963854010	mike robinson
+kindergarten	NULL	david young
+kindergarten	NULL	irene ovid
+kindergarten	NULL	nick laertes
+linguistics	-101960322	ethan robinson
+linguistics	-1124028213	katie ellison
+linguistics	-121162464	luke davidson
+linguistics	-1248781172	calvin quirinius
+linguistics	-1341627565	fred van buren
+linguistics	-1356601829	tom robinson
+linguistics	-139448716	irene brown
+linguistics	-1447263708	yuri miller
+linguistics	-1462604138	
+linguistics	-1533934649	calvin thompson
+linguistics	-1534307678	yuri young
+linguistics	-1699049982	yuri carson
+linguistics	-1721368386	wendy brown
+linguistics	-1889139541	irene davidson
+linguistics	-1890963712	tom ellison
+linguistics	-19116270	zach davidson
+linguistics	-1928197479	calvin falkner
+linguistics	-1967660827	
+linguistics	-2057666812	fred thompson
+linguistics	-2096425960	gabriella polk
+linguistics	-297664578	quinn zipper
+linguistics	-336625622	yuri underhill
+linguistics	-343173797	fred ellison
+linguistics	-370901197	katie laertes
+linguistics	-379174037	yuri robinson
+linguistics	-472303419	rachel garcia
+linguistics	-579916775	priscilla ovid
+linguistics	-605370177	priscilla davidson
+linguistics	-671853199	fred falkner
+linguistics	-684022323	victor falkner
+linguistics	-764412063	victor falkner
+linguistics	-768305191	rachel johnson
+linguistics	-839176151	bob white
+linguistics	-897622427	tom van buren
+linguistics	-90029636	wendy laertes
+linguistics	-922200749	ulysses polk
+linguistics	1121512594	xavier king
+linguistics	1145627305	jessica ellison
+linguistics	1198701102	sarah underhill
+linguistics	1225312439	alice ellison
+linguistics	1275228381	david young
+linguistics	1392980712	victor carson
+linguistics	1416850873	bob polk
+linguistics	161210995	priscilla thompson
+linguistics	1637295757	
+linguistics	1809795770	david ichabod
+linguistics	1914993018	yuri laertes
+linguistics	1991072829	mike ichabod
+linguistics	2018249426	jessica steinbeck
+linguistics	2038381675	quinn ichabod
+linguistics	2057486961	alice laertes
+linguistics	2081152819	gabriella underhill
+linguistics	209430502	victor falkner
+linguistics	43672187	alice johnson
+linguistics	605141554	luke xylophone
+linguistics	65172363	sarah ovid
+linguistics	712625264	jessica brown
+linguistics	712816880	alice king
+linguistics	735600165	katie thompson
+linguistics	746904285	fred laertes
+linguistics	75823003	oscar king
+linguistics	776459017	wendy steinbeck
+linguistics	819069589	zach thompson
+linguistics	849859032	irene quirinius
+linguistics	881673558	nick underhill
+linguistics	NULL	calvin robinson
+linguistics	NULL	luke allen
+linguistics	NULL	mike zipper
+linguistics	NULL	wendy underhill
+mathematics	-1061859761	victor nixon
+mathematics	-1112062809	victor nixon
+mathematics	-1129489281	tom ellison
+mathematics	-1198036877	
+mathematics	-1254129998	ulysses brown
+mathematics	-1319753324	yuri ellison
+mathematics	-1421860505	yuri nixon
+mathematics	-1423467446	mike quirinius
+mathematics	-1424027104	rachel laertes
+mathematics	-1544877665	katie quirinius
+mathematics	-1554130090	sarah zipper
+mathematics	-158420748	ethan davidson
+mathematics	-1651993300	yuri steinbeck
+mathematics	-1735287250	david allen
+mathematics	-175727228	fred ovid
+mathematics	-180280420	bob laertes
+mathematics	-1857500489	oscar ellison
+mathematics	-1892816721	sarah van buren
+mathematics	-191704948	wendy carson
+mathematics	-1974257754	jessica nixon
+mathematics	-2081809883	gabriella brown
+mathematics	-2117280385	zach xylophone
+mathematics	-234758376	ethan van buren
+mathematics	-23865350	irene falkner
+mathematics	-295186284	rachel thompson
+mathematics	-402441123	zach ichabod
+mathematics	-40284975	
+mathematics	-496870819	tom quirinius
+mathematics	-599396052	quinn zipper
+mathematics	-71305062	ethan young
+mathematics	-765102534	oscar king
+mathematics	-76654979	zach van buren
+mathematics	-809805200	
+mathematics	-816661030	priscilla steinbeck
+mathematics	-835002549	katie ovid
+mathematics	-856843296	jessica polk
+mathematics	-893863493	zach miller
+mathematics	-917062754	ethan polk
+mathematics	-938762477	ethan steinbeck
+mathematics	-94709066	oscar garcia
+mathematics	1054864168	jessica carson
+mathematics	1127080164	ulysses carson
+mathematics	1196151988	jessica king
+mathematics	1198172036	ethan ellison
+mathematics	1224662770	calvin van buren
+mathematics	1229172951	quinn hernandez
+mathematics	1335803002	david young
+mathematics	1363568842	ulysses white
+mathematics	1377359511	ethan davidson
+mathematics	1384071499	zach garcia
+mathematics	139661585	priscilla quirinius
+mathematics	1404346934	irene quirinius
+mathematics	1443426396	
+mathematics	1489169773	
+mathematics	1505665168	
+mathematics	1640445482	jessica xylophone
+mathematics	1785455842	ulysses robinson
+mathematics	1832650234	alice garcia
+mathematics	195281533	tom thompson
+mathematics	1974939899	gabriella steinbeck
+mathematics	2064448036	alice steinbeck
+mathematics	318631333	ulysses davidson
+mathematics	338805871	priscilla falkner
+mathematics	375106978	luke ichabod
+mathematics	485105934	irene laertes
+mathematics	491758252	tom falkner
+mathematics	740883263	quinn nixon
+mathematics	748358417	ulysses brown
+mathematics	881695885	zach laertes
+mathematics	NULL	david ovid
+mathematics	NULL	jessica carson
+mathematics	NULL	nick xylophone
+mathematics	NULL	oscar ellison
+mathematics	NULL	quinn garcia
+mathematics	NULL	zach steinbeck
+nap time	-103219371	xavier zipper
+nap time	-116484575	ulysses quirinius
+nap time	-1183469360	alice king
+nap time	-1343327	oscar king
+nap time	-16094879	quinn king
+nap time	-1669227632	calvin robinson
+nap time	-1818456584	fred garcia
+nap time	-1849091666	oscar carson
+nap time	-1851280202	fred hernandez
+nap time	-1992388855	jessica hernandez
+nap time	-2111312205	katie nixon
+nap time	-292588406	calvin steinbeck
+nap time	-309571354	gabriella steinbeck
+nap time	-337829479	yuri garcia
+nap time	-359943425	victor miller
+nap time	-397951021	katie falkner
+nap time	-434747475	jessica underhill
+nap time	-490337498	jessica falkner
+nap time	-504529358	mike allen
+nap time	-607667405	ethan young
+nap time	-626484313	ethan underhill
+nap time	-665623523	sarah johnson
+nap time	-805288503	xavier hernandez
+nap time	-913906252	calvin ovid
+nap time	-946830673	wendy underhill
+nap time	-971203543	quinn miller
+nap time	-982238309	calvin polk
+nap time	1166237779	irene steinbeck
+nap time	1273877405	calvin nixon
+nap time	1372705672	victor thompson
+nap time	1516165279	zach johnson
+nap time	1520375588	david steinbeck
+nap time	1571267481	gabriella underhill
+nap time	1775355987	david ovid
+nap time	1818213677	xavier ichabod
+nap time	2013444562	ulysses white
+nap time	2031604236	quinn johnson
+nap time	2080249726	ethan robinson
+nap time	2145269593	priscilla steinbeck
+nap time	2146312499	calvin allen
+nap time	215508794	ulysses van buren
+nap time	268888160	bob hernandez
+nap time	398960205	tom king
+nap time	503752931	irene miller
+nap time	516843026	victor ichabod
+nap time	595836061	priscilla johnson
+nap time	618991041	quinn underhill
+nap time	738356485	ethan king
+nap time	785382955	gabriella garcia
+nap time	922553769	jessica ichabod
+nap time	92834720	bob falkner
+nap time	950997304	nick thompson
+nap time	962712814	ulysses brown
+nap time	980732494	holly polk
+nap time	NULL	jessica johnson
+nap time	NULL	wendy young
+opthamology	-1079633326	katie robinson
+opthamology	-1104268719	ulysses brown
+opthamology	-1126628450	sarah hernandez
+opthamology	-1226425562	mike robinson
+opthamology	-1234163924	holly miller
+opthamology	-1244527286	bob carson
+opthamology	-1364322216	holly hernandez
+opthamology	-1422780798	bob davidson
+opthamology	-1502924486	rachel nixon
+opthamology	-1561738723	fred underhill
+opthamology	-1616030844	irene falkner
+opthamology	-1652600376	victor zipper
+opthamology	-1655030261	oscar ovid
+opthamology	-1676261015	katie polk
+opthamology	-1709117770	calvin miller
+opthamology	-1769423338	gabriella johnson
+opthamology	-177025818	yuri young
+opthamology	-181523892	sarah quirinius
+opthamology	-1901806083	luke xylophone
+opthamology	-1960344717	holly steinbeck
+opthamology	-1969751342	victor ichabod
+opthamology	-1979314577	oscar underhill
+opthamology	-2081501748	priscilla falkner
+opthamology	-287400633	gabriella thompson
+opthamology	-327648289	rachel robinson
+opthamology	-332125121	ethan white
+opthamology	-360113158	bob king
+opthamology	-400501472	fred van buren
+opthamology	-406264741	mike robinson
+opthamology	-41864614	victor king
+opthamology	-425196209	sarah nixon
+opthamology	-442839889	sarah davidson
+opthamology	-4943292	oscar quirinius
+opthamology	-505879576	holly steinbeck
+opthamology	-759911896	katie white
+opthamology	-78240945	yuri underhill
+opthamology	-800975421	rachel thompson
+opthamology	100270148	victor ellison
+opthamology	1044196568	holly white
+opthamology	1063524922	
+opthamology	1069486136	victor ichabod
+opthamology	1134416796	quinn thompson
+opthamology	1142481557	mike falkner
+opthamology	117620760	katie polk
+opthamology	1211873318	oscar ellison
+opthamology	1281277970	fred young
+opthamology	1305668933	calvin allen
+opthamology	1336951982	oscar hernandez
+opthamology	144428297	rachel falkner
+opthamology	1603612975	gabriella steinbeck
+opthamology	1632769786	sarah zipper
+opthamology	1678220496	
+opthamology	1752520642	
+opthamology	1852725744	david garcia
+opthamology	2065408093	priscilla polk
+opthamology	2069258195	nick allen
+opthamology	266601601	irene quirinius
+opthamology	307333276	wendy polk
+opthamology	340384179	david thompson
+opthamology	39723411	bob ellison
+opthamology	402173272	quinn garcia
+opthamology	461680901	quinn zipper
+opthamology	491016124	luke allen
+opthamology	511836073	calvin ellison
+opthamology	609917172	luke ovid
+opthamology	6266567	jessica van buren
+opthamology	718692886	victor white
+opthamology	759899363	wendy van buren
+opthamology	787925706	xavier robinson
+opthamology	816439627	jessica polk
+opthamology	819875108	irene underhill
+opthamology	936133387	gabriella van buren
+opthamology	955171928	
+opthamology	NULL	
+opthamology	NULL	yuri ichabod
+philosophy	-1096771844	ethan van buren
+philosophy	-1109134719	katie hernandez
+philosophy	-1131684944	quinn white
+philosophy	-1196808950	irene polk
+philosophy	-120704505	luke king
+philosophy	-1319686435	jessica steinbeck
+philosophy	-1345085327	bob johnson
+philosophy	-1460613213	priscilla brown
+philosophy	-1477897348	nick ovid
+philosophy	-1489628668	tom quirinius
+philosophy	-1538978853	
+philosophy	-1545572711	victor underhill
+philosophy	-1603374745	alice zipper
+philosophy	-1679120527	jessica quirinius
+philosophy	-1699044525	nick zipper
+philosophy	-1744964279	oscar zipper
+philosophy	-1770229099	alice miller
+philosophy	-1811563127	jessica hernandez
+philosophy	-1817938378	sarah laertes
+philosophy	-1819075185	luke miller
+philosophy	-1949359208	alice carson
+philosophy	-2042831105	
+philosophy	-2053551539	jessica zipper
+philosophy	-2077771325	fred brown
+philosophy	-217930632	rachel robinson
+philosophy	-340951385	xavier robinson
+philosophy	-42151403	calvin young
+philosophy	-436386350	victor young
+philosophy	-47662800	zach polk
+philosophy	-540820650	sarah davidson
+philosophy	-606214770	holly king
+philosophy	-745678338	priscilla steinbeck
+philosophy	-752222556	tom allen
+philosophy	-884796655	oscar robinson
+philosophy	-938756287	fred steinbeck
+philosophy	-985817478	nick ovid
+philosophy	-996953616	victor zipper
+philosophy	1204325852	calvin ovid
+philosophy	1314531900	jessica king
+philosophy	1319589591	
+philosophy	1406029775	
+philosophy	1541249928	calvin miller
+philosophy	1569269522	ethan xylophone
+philosophy	1756592797	luke ovid
+philosophy	1772545157	gabriella laertes
+philosophy	1942004879	katie xylophone
+philosophy	1972940844	nick quirinius
+philosophy	2009215103	bob thompson
+philosophy	2083836439	sarah davidson
+philosophy	2100839074	calvin ovid
+philosophy	2124297747	ethan carson
+philosophy	22308780	mike ovid
+philosophy	344989592	
+philosophy	390124976	gabriella laertes
+philosophy	41063276	wendy brown
+philosophy	626941809	victor ellison
+philosophy	631711489	victor johnson
+philosophy	684561551	oscar van buren
+philosophy	737149747	sarah davidson
+philosophy	789871166	david ovid
+philosophy	825677248	alice miller
+philosophy	888896424	zach white
+philosophy	889733679	priscilla zipper
+philosophy	89366322	wendy underhill
+philosophy	936752497	ethan nixon
+philosophy	NULL	xavier hernandez
+quiet hour	-1001529082	wendy nixon
+quiet hour	-1012329052	david quirinius
+quiet hour	-1026746699	rachel hernandez
+quiet hour	-1058166020	oscar robinson
+quiet hour	-117723745	oscar white
+quiet hour	-1403154847	luke ellison
+quiet hour	-1464514590	nick garcia
+quiet hour	-1493282775	
+quiet hour	-1505397109	rachel xylophone
+quiet hour	-1655396452	mike hernandez
+quiet hour	-1668974292	bob falkner
+quiet hour	-1727003541	
+quiet hour	-191434898	sarah underhill
+quiet hour	-191899537	rachel thompson
+quiet hour	-2028355450	quinn thompson
+quiet hour	-2069439395	nick steinbeck
+quiet hour	-357680544	holly white
+quiet hour	-407089271	wendy carson
+quiet hour	-448060992	alice miller
+quiet hour	-464804906	luke ellison
+quiet hour	-512198016	katie miller
+quiet hour	-742707249	yuri underhill
+quiet hour	-774406989	oscar zipper
+quiet hour	-941433219	oscar white
+quiet hour	-950738312	ulysses johnson
+quiet hour	-971698865	bob carson
+quiet hour	-99916247	ethan white
+quiet hour	1002132158	mike nixon
+quiet hour	1182390248	fred xylophone
+quiet hour	1216016081	ulysses garcia
+quiet hour	121663320	bob ovid
+quiet hour	1260101584	yuri allen
+quiet hour	1293876597	mike brown
+quiet hour	1359437295	rachel white
+quiet hour	1366402722	gabriella robinson
+quiet hour	1390704286	mike miller
+quiet hour	1393262450	ulysses johnson
+quiet hour	1437057145	luke johnson
+quiet hour	14573904	gabriella thompson
+quiet hour	1488440165	irene steinbeck
+quiet hour	1614297403	zach falkner
+quiet hour	1739911574	ulysses ovid
+quiet hour	1743671220	alice quirinius
+quiet hour	1807877618	holly ichabod
+quiet hour	1847210729	sarah polk
+quiet hour	1870464222	
+quiet hour	1880017800	bob nixon
+quiet hour	1893632113	priscilla quirinius
+quiet hour	1978171687	alice johnson
+quiet hour	1990792684	nick carson
+quiet hour	2029657999	mike ichabod
+quiet hour	203688965	yuri garcia
+quiet hour	2100377172	quinn allen
+quiet hour	2127682701	sarah garcia
+quiet hour	257821327	bob ellison
+quiet hour	410340192	calvin brown
+quiet hour	592011541	tom garcia
+quiet hour	619884480	katie king
+quiet hour	669871113	ethan laertes
+quiet hour	704038411	quinn van buren
+quiet hour	735732067	rachel ovid
+quiet hour	76381404	rachel garcia
+quiet hour	856986735	
+quiet hour	882762933	holly white
+quiet hour	NULL	mike garcia
+quiet hour	NULL	priscilla ellison
+quiet hour	NULL	zach falkner
+religion	-1043413503	mike allen
+religion	-1063673827	irene miller
+religion	-1144920802	ulysses king
+religion	-1197602595	alice steinbeck
+religion	-1216206795	xavier young
+religion	-1247229632	victor robinson
+religion	-1343425152	wendy xylophone
+religion	-1432316859	alice laertes
+religion	-1552053883	calvin xylophone
+religion	-1626062014	jessica allen
+religion	-1643714866	luke ovid
+religion	-1701502632	mike xylophone
+religion	-1749415887	ulysses steinbeck
+religion	-1802746460	mike robinson
+religion	-1884780525	oscar xylophone
+religion	-192181579	luke allen
+religion	-1969235238	fred thompson
+religion	-201554470	luke brown
+religion	-2052386812	tom robinson
+religion	-20660936	david hernandez
+religion	-214166042	jessica falkner
+religion	-2146432765	nick van buren
+religion	-38458614	calvin polk
+religion	-409673169	fred johnson
+religion	-419335927	sarah van buren
+religion	-618505946	nick white
+religion	-667383951	alice white
+religion	-670925379	ethan ovid
+religion	-71433796	mike johnson
+religion	-76430653	nick robinson
+religion	-772236518	
+religion	-853967587	irene thompson
+religion	-939348081	mike johnson
+religion	1022214896	luke quirinius
+religion	1061043704	mike underhill
+religion	1075444504	luke robinson
+religion	1182646662	fred ellison
+religion	1228837108	fred davidson
+religion	129675822	alice ichabod
+religion	1318956413	victor falkner
+religion	1336842978	oscar steinbeck
+religion	1363459426	bob laertes
+religion	1436480682	ethan falkner
+religion	1456367662	quinn xylophone
+religion	1472487454	priscilla steinbeck
+religion	1499399891	ulysses carson
+religion	1592153312	ulysses young
+religion	1597303154	
+religion	166320811	nick allen
+religion	177391521	oscar falkner
+religion	1845797092	alice zipper
+religion	1891680787	
+religion	1910930064	jessica steinbeck
+religion	1911809937	david allen
+religion	194754262	luke carson
+religion	2009890220	nick underhill
+religion	2070969353	zach davidson
+religion	210728566	fred xylophone
+religion	2125311222	alice polk
+religion	493977568	nick polk
+religion	51376784	fred young
+religion	550594651	nick garcia
+religion	596802082	david brown
+religion	597657990	david falkner
+religion	673904922	calvin steinbeck
+religion	824836988	ethan king
+religion	829101712	calvin garcia
+religion	895763504	bob steinbeck
+religion	914062370	luke robinson
+religion	947846543	quinn garcia
+religion	NULL	gabriella allen
+religion	NULL	irene ichabod
+religion	NULL	luke carson
+religion	NULL	mike nixon
+religion	NULL	nick allen
+religion	NULL	xavier van buren
+study skills	-1164833898	rachel white
+study skills	-1212524805	tom steinbeck
+study skills	-1242677422	zach young
+study skills	-1266138408	gabriella steinbeck
+study skills	-1318045616	irene young
+study skills	-136514115	irene ovid
+study skills	-1392487784	irene carson
+study skills	-1419573027	holly ichabod
+study skills	-1528033060	ulysses ichabod
+study skills	-1669848306	holly thompson
+study skills	-1719427168	mike ichabod
+study skills	-1762037754	ulysses van buren
+study skills	-1784633305	zach laertes
+study skills	-1856034030	gabriella nixon
+study skills	-1914072976	alice ovid
+study skills	-1937640350	oscar robinson
+study skills	-1955647385	irene steinbeck
+study skills	-235819331	yuri xylophone
+study skills	-283378057	ulysses xylophone
+study skills	-314935936	yuri ellison
+study skills	-318206520	nick xylophone
+study skills	-359194591	zach young
+study skills	-414207254	quinn carson
+study skills	-425103007	tom brown
+study skills	-442732016	
+study skills	-507955215	fred xylophone
+study skills	-535056977	wendy laertes
+study skills	-621365995	ethan johnson
+study skills	-648766606	tom polk
+study skills	-758231588	calvin steinbeck
+study skills	-849551464	oscar davidson
+study skills	-851663638	gabriella robinson
+study skills	-887663189	katie laertes
+study skills	-887790938	priscilla ichabod
+study skills	-897586947	wendy van buren
+study skills	-978892011	xavier underhill
+study skills	-99205196	priscilla hernandez
+study skills	1004241194	calvin hernandez
+study skills	1028092807	ulysses quirinius
+study skills	1076088102	rachel quirinius
+study skills	1091736925	yuri nixon
+study skills	1115197541	ethan quirinius
+study skills	1131663263	david laertes
+study skills	1222935237	gabriella garcia
+study skills	1286367391	jessica brown
+study skills	1316931	priscilla brown
+study skills	1321678350	ulysses ovid
+study skills	1343581455	mike robinson
+study skills	1386071996	bob zipper
+study skills	1415647436	quinn carson
+study skills	1426152053	bob falkner
+study skills	1506907734	wendy quirinius
+study skills	1522208504	fred hernandez
+study skills	1523657918	fred brown
+study skills	1570238232	david polk
+study skills	160290374	tom hernandez
+study skills	1620529246	katie underhill
+study skills	1650573576	alice quirinius
+study skills	1668446119	calvin ellison
+study skills	1677197847	gabriella ellison
+study skills	1743696703	rachel van buren
+study skills	1750433588	ethan ovid
+study skills	1805139501	katie thompson
+study skills	1888675011	wendy white
+study skills	1911834442	priscilla white
+study skills	198539698	priscilla allen
+study skills	1992977592	quinn garcia
+study skills	2032271149	mike falkner
+study skills	482977302	jessica robinson
+study skills	526502851	oscar king
+study skills	631207613	tom garcia
+study skills	867587289	alice white
+study skills	895945459	katie underhill
+study skills	925032386	david polk
+study skills	958866509	xavier white
+study skills	NULL	jessica miller
+study skills	NULL	katie carson
+topology	-1058356124	jessica white
+topology	-1061222139	xavier garcia
+topology	-1067083033	tom davidson
+topology	-1216166764	nick king
+topology	-1240208945	ethan quirinius
+topology	-1269216718	wendy nixon
+topology	-1406691044	fred johnson
+topology	-1462331586	gabriella xylophone
+topology	-1568646283	rachel brown
+topology	-1800413845	katie hernandez
+topology	-1817096156	yuri miller
+topology	-1955545912	irene ellison
+topology	-2024003241	
+topology	-2065287410	rachel quirinius
+topology	-2147071655	rachel falkner
+topology	-303747347	ethan nixon
+topology	-370798230	katie van buren
+topology	-40407627	quinn underhill
+topology	-462541618	jessica xylophone
+topology	-522450861	david white
+topology	-534991774	wendy falkner
+topology	-601946913	ulysses robinson
+topology	-628790799	holly nixon
+topology	-707228984	alice ovid
+topology	-714270951	calvin xylophone
+topology	-728541537	victor xylophone
+topology	-734921821	zach carson
+topology	-743680989	priscilla thompson
+topology	-938112972	rachel polk
+topology	-954480325	mike thompson
+topology	-973128166	tom garcia
+topology	1003667927	mike polk
+topology	1059212450	tom zipper
+topology	1124269631	katie ovid
+topology	1148500740	luke thompson
+topology	1151752586	tom zipper
+topology	1309976380	victor davidson
+topology	1316369941	rachel ovid
+topology	1469775272	quinn falkner
+topology	1621606222	priscilla young
+topology	1646811064	katie johnson
+topology	1677444379	david laertes
+topology	174310705	tom king
+topology	176792505	oscar thompson
+topology	1783034168	quinn young
+topology	1895751360	ethan underhill
+topology	1924741890	jessica quirinius
+topology	1987336880	fred ichabod
+topology	2017314998	oscar miller
+topology	2075919195	holly hernandez
+topology	217823040	rachel xylophone
+topology	335359004	bob ichabod
+topology	350802495	ulysses carson
+topology	477584560	fred steinbeck
+topology	527598540	luke ovid
+topology	531459992	jessica thompson
+topology	538268118	fred laertes
+topology	557053197	
+topology	661659208	mike nixon
+topology	734267314	yuri polk
+topology	791096295	david garcia
+topology	850625480	zach allen
+topology	860708524	yuri steinbeck
+topology	960187615	calvin zipper
+topology	989475408	jessica brown
+topology	NULL	mike van buren
+topology	NULL	oscar nixon
+topology	NULL	oscar thompson
+topology	NULL	priscilla brown
+undecided	-1070951602	
+undecided	-1106685577	ulysses ovid
+undecided	-1324624386	oscar young
+undecided	-1353470095	priscilla xylophone
+undecided	-1554325042	victor van buren
+undecided	-1562552002	katie brown
+undecided	-1583445177	luke xylophone
+undecided	-1938290238	jessica allen
+undecided	-1974777102	oscar ellison
+undecided	-1984079412	holly ichabod
+undecided	-2016985611	calvin ovid
+undecided	-202035134	katie underhill
+undecided	-2124994385	ethan young
+undecided	-216495498	luke zipper
+undecided	-361944328	david white
+undecided	-373038706	priscilla ovid
+undecided	-432218419	nick white
+undecided	-51612681	calvin ichabod
+undecided	-53587991	mike xylophone
+undecided	-558456218	yuri xylophone
+undecided	-590374062	victor thompson
+undecided	-733239404	
+undecided	-828522499	priscilla quirinius
+undecided	-956668825	ethan van buren
+undecided	1042184256	bob miller
+undecided	1129173487	luke johnson
+undecided	1205391962	calvin miller
+undecided	1265528735	ethan robinson
+undecided	127051381	
+undecided	1328225044	mike garcia
+undecided	1332042427	
+undecided	1333214263	quinn falkner
+undecided	1338047392	victor ovid
+undecided	1347876055	david quirinius
+undecided	1362740312	irene underhill
+undecided	1376818328	sarah ellison
+undecided	1504919241	calvin miller
+undecided	1563120121	nick polk
+undecided	1731764471	katie quirinius
+undecided	1765874562	mike ovid
+undecided	1805308672	xavier thompson
+undecided	1825828852	quinn white
+undecided	1918230406	
+undecided	1950882901	xavier allen
+undecided	1961954939	nick ovid
+undecided	1978200605	quinn underhill
+undecided	2068018858	rachel ichabod
+undecided	2102440065	tom van buren
+undecided	260463232	ethan davidson
+undecided	272086526	wendy xylophone
+undecided	372099650	luke robinson
+undecided	37461818	jessica davidson
+undecided	407098216	priscilla garcia
+undecided	536235636	jessica garcia
+undecided	564366133	alice xylophone
+undecided	596242714	tom miller
+undecided	596280431	bob johnson
+undecided	656187584	victor xylophone
+undecided	658008867	alice hernandez
+undecided	69110370	fred ichabod
+undecided	727802564	fred ellison
+undecided	821316302	mike brown
+undecided	829055499	mike steinbeck
+undecided	914583645	nick hernandez
+undecided	978044705	jessica white
+undecided	NULL	gabriella thompson
+undecided	NULL	zach garcia
+values clariffication	-1026458834	irene ovid
+values clariffication	-1111814111	irene van buren
+values clariffication	-1212433954	mike underhill
+values clariffication	-1236536142	quinn ellison
+values clariffication	-1261099087	sarah van buren
+values clariffication	-1289665817	
+values clariffication	-1362178985	quinn laertes
+values clariffication	-1369302744	quinn thompson
+values clariffication	-1391183008	ulysses brown
+values clariffication	-144862954	sarah ovid
+values clariffication	-1469463456	ethan zipper
+values clariffication	-1484033125	xavier ellison
+values clariffication	-1545388906	bob ellison
+values clariffication	-1621814212	
+values clariffication	-1738775004	mike hernandez
+values clariffication	-1743938290	holly quirinius
+values clariffication	-1759354458	mike ellison
+values clariffication	-1765795567	
+values clariffication	-1769037737	victor underhill
+values clariffication	-1897998366	
+values clariffication	-1933374662	priscilla ovid
+values clariffication	-1945738830	sarah carson
+values clariffication	-1954890941	gabriella van buren
+values clariffication	-1977762695	oscar quirinius
+values clariffication	-2098078720	ethan steinbeck
+values clariffication	-215703544	yuri thompson
+values clariffication	-224865887	fred nixon
+values clariffication	-244778184	luke underhill
+values clariffication	-362603422	rachel falkner
+values clariffication	-369183838	wendy xylophone
+values clariffication	-373541958	priscilla quirinius
+values clariffication	-385247581	ethan steinbeck
+values clariffication	-588547970	
+values clariffication	-66112513	calvin brown
+values clariffication	-837503491	quinn robinson
+values clariffication	-847235873	oscar young
+values clariffication	-901778330	david young
+values clariffication	-928013434	ulysses hernandez
+values clariffication	-933324607	rachel young
+values clariffication	1017953606	gabriella brown
+values clariffication	1081920048	tom thompson
+values clariffication	1114521964	victor garcia
+values clariffication	1130043800	david davidson
+values clariffication	128430191	ulysses ovid
+values clariffication	1290381132	xavier falkner
+values clariffication	1393506704	david white
+values clariffication	1418228573	
+values clariffication	1421779455	luke young
+values clariffication	1430614653	david brown
+values clariffication	1473503196	holly davidson
+values clariffication	1493152791	ethan allen
+values clariffication	1638471881	quinn xylophone
+values clariffication	1668094749	luke carson
+values clariffication	1679381813	rachel ovid
+values clariffication	1686537335	zach quirinius
+values clariffication	1701761102	
+values clariffication	1817671655	yuri van buren
+values clariffication	1916363472	xavier white
+values clariffication	1925283040	yuri white
+values clariffication	1941527322	katie ellison
+values clariffication	2142592987	
+values clariffication	311478497	irene hernandez
+values clariffication	33234633	yuri van buren
+values clariffication	368170021	
+values clariffication	476919973	calvin garcia
+values clariffication	524317972	ulysses miller
+values clariffication	528218910	calvin young
+values clariffication	601376532	calvin miller
+values clariffication	631954352	xavier ellison
+values clariffication	641695802	victor davidson
+values clariffication	659397992	fred brown
+values clariffication	672266669	jessica underhill
+values clariffication	758926227	
+values clariffication	76299337	luke zipper
+values clariffication	773730574	holly polk
+values clariffication	8040290	holly ichabod
+values clariffication	832465439	
+values clariffication	859140926	jessica robinson
+values clariffication	929560791	david polk
+values clariffication	987917448	irene zipper
+values clariffication	NULL	fred quirinius
+values clariffication	NULL	fred xylophone
+values clariffication	NULL	gabriella van buren
+values clariffication	NULL	priscilla quirinius
+wind surfing	-1078214868	victor ellison
+wind surfing	-1095938490	victor robinson
+wind surfing	-1153978907	fred robinson
+wind surfing	-1201785350	quinn thompson
+wind surfing	-1222897252	zach white
+wind surfing	-1322736153	jessica polk
+wind surfing	-1340213051	rachel ovid
+wind surfing	-1426893312	
+wind surfing	-1437126017	yuri garcia
+wind surfing	-1447140800	mike underhill
+wind surfing	-146961490	alice ellison
+wind surfing	-1565785026	nick garcia
+wind surfing	-1578387726	tom thompson
+wind surfing	-163859725	zach laertes
+wind surfing	-1642207005	sarah garcia
+wind surfing	-1716506227	david garcia
+wind surfing	-1754203978	katie miller
+wind surfing	-1758125445	ethan brown
+wind surfing	-1817564067	rachel davidson
+wind surfing	-1820436871	alice thompson
+wind surfing	-1829691116	fred ellison
+wind surfing	-1832606512	jessica van buren
+wind surfing	-1873004551	irene zipper
+wind surfing	-18917438	sarah nixon
+wind surfing	-1914210382	rachel steinbeck
+wind surfing	-1924909143	tom young
+wind surfing	-2019287179	alice young
+wind surfing	-2037628236	luke xylophone
+wind surfing	-206177972	david hernandez
+wind surfing	-240529113	alice king
+wind surfing	-249150336	mike allen
+wind surfing	-253084551	wendy ichabod
+wind surfing	-300717684	sarah ovid
+wind surfing	-311437801	nick miller
+wind surfing	-409404534	luke nixon
+wind surfing	-45460011	mike nixon
+wind surfing	-469749219	calvin underhill
+wind surfing	-54793232	jessica van buren
+wind surfing	-571587579	katie underhill
+wind surfing	-592568201	fred steinbeck
+wind surfing	-829717122	
+wind surfing	-838656526	holly allen
+wind surfing	-915104901	yuri carson
+wind surfing	-916344293	nick thompson
+wind surfing	-951728053	ethan ovid
+wind surfing	104004730	holly zipper
+wind surfing	1045719941	oscar allen
+wind surfing	1050809633	tom garcia
+wind surfing	106847364	luke garcia
+wind surfing	107680423	ulysses ellison
+wind surfing	1102069050	oscar polk
+wind surfing	1103797891	nick underhill
+wind surfing	1109664665	nick king
+wind surfing	1182595271	sarah allen
+wind surfing	1191238870	xavier xylophone
+wind surfing	1251556414	xavier ellison
+wind surfing	1260480653	katie nixon
+wind surfing	1342923026	rachel laertes
+wind surfing	1434588588	nick allen
+wind surfing	1566958573	jessica allen
+wind surfing	1667594394	jessica zipper
+wind surfing	167432368	priscilla hernandez
+wind surfing	1767359228	zach brown
+wind surfing	1796950944	ulysses garcia
+wind surfing	1846184880	zach ellison
+wind surfing	1920662116	tom hernandez
+wind surfing	1934970004	rachel steinbeck
+wind surfing	1949494660	calvin nixon
+wind surfing	234452496	victor robinson
+wind surfing	239078089	zach quirinius
+wind surfing	270090617	holly laertes
+wind surfing	371383749	jessica quirinius
+wind surfing	37730738	david steinbeck
+wind surfing	388707554	nick thompson
+wind surfing	476858779	wendy underhill
+wind surfing	48554395	gabriella allen
+wind surfing	541118710	calvin van buren
+wind surfing	581259902	yuri ellison
+wind surfing	590719541	
+wind surfing	658636280	alice white
+wind surfing	659343542	irene thompson
+wind surfing	661380540	quinn thompson
+wind surfing	693876030	yuri king
+wind surfing	715333063	mike young
+wind surfing	77063155	zach brown
+wind surfing	824235855	bob polk
+wind surfing	866084887	david polk
+wind surfing	872554087	jessica xylophone
+wind surfing	923353533	ethan king
+wind surfing	987734049	alice hernandez
+xylophone band	-1030565036	xavier king
+xylophone band	-1079086534	alice polk
+xylophone band	-1114208576	jessica hernandez
+xylophone band	-1117358187	ulysses falkner
+xylophone band	-1146649990	ethan ichabod
+xylophone band	-1257859205	mike garcia
+xylophone band	-1280919769	
+xylophone band	-1349876582	fred davidson
+xylophone band	-1430903652	bob zipper
+xylophone band	-1444011944	jessica miller
+xylophone band	-1565671389	bob underhill
+xylophone band	-1606567895	holly nixon
+xylophone band	-1648991909	holly white
+xylophone band	-1702587308	
+xylophone band	-1731820254	luke robinson
+xylophone band	-1850492820	victor miller
+xylophone band	-1858443953	tom zipper
+xylophone band	-1881263242	ulysses zipper
+xylophone band	-1953605752	oscar xylophone
+xylophone band	-1989778424	luke falkner
+xylophone band	-2017279089	alice ellison
+xylophone band	-2043805661	yuri robinson
+xylophone band	-2066134281	alice zipper
+xylophone band	-2076886223	ethan carson
+xylophone band	-2138343289	xavier davidson
+xylophone band	-318380015	katie ichabod
+xylophone band	-393723522	gabriella carson
+xylophone band	-412333994	mike ichabod
+xylophone band	-423190290	nick underhill
+xylophone band	-603273425	ethan steinbeck
+xylophone band	-675125724	nick garcia
+xylophone band	-726879427	calvin young
+xylophone band	-765190882	mike white
+xylophone band	-909024258	ethan carson
+xylophone band	-914329027	zach xylophone
+xylophone band	-916495008	priscilla polk
+xylophone band	-932921363	alice xylophone
+xylophone band	1094778643	zach king
+xylophone band	115470151	mike ellison
+xylophone band	1179528290	luke falkner
+xylophone band	1256676429	mike ovid
+xylophone band	1333148555	katie allen
+xylophone band	1440427914	katie garcia
+xylophone band	1517915751	quinn ovid
+xylophone band	1519993904	gabriella ellison
+xylophone band	1544482684	priscilla quirinius
+xylophone band	1768399622	ulysses king
+xylophone band	197056787	xavier white
+xylophone band	2052773366	katie carson
+xylophone band	206121314	xavier brown
+xylophone band	26270580	oscar hernandez
+xylophone band	323817967	yuri king
+xylophone band	343362793	nick johnson
+xylophone band	471464395	calvin allen
+xylophone band	492639283	bob van buren
+xylophone band	522895626	luke davidson
+xylophone band	583458404	fred falkner
+xylophone band	596045726	calvin quirinius
+xylophone band	626251612	nick young
+xylophone band	6526476	sarah brown
+xylophone band	656636097	luke carson
+xylophone band	688547276	
+xylophone band	720703232	oscar garcia
+xylophone band	882331889	katie zipper
+xylophone band	923980398	katie van buren
+xylophone band	945911081	xavier miller
+xylophone band	955267058	quinn carson
+xylophone band	977292235	luke van buren
+xylophone band	994798486	ulysses ellison
+xylophone band	997193329	david johnson
+xylophone band	NULL	jessica quirinius
+yard duty	-1032306832	katie davidson
+yard duty	-1038565721	wendy laertes
+yard duty	-1249134513	priscilla underhill
+yard duty	-1274158260	oscar ichabod
+yard duty	-1404921781	rachel miller
+yard duty	-1458382451	gabriella brown
+yard duty	-1463884101	katie ichabod
+yard duty	-1531040609	rachel davidson
+yard duty	-1609864597	ethan hernandez
+yard duty	-1621721177	nick thompson
+yard duty	-1635301453	luke ichabod
+yard duty	-186764959	xavier steinbeck
+yard duty	-1871209811	fred polk
+yard duty	-1909635960	priscilla quirinius
+yard duty	-1983567458	nick laertes
+yard duty	-20639382	mike falkner
+yard duty	-251576563	luke laertes
+yard duty	-291577538	irene white
+yard duty	-300429552	calvin johnson
+yard duty	-463071187	quinn young
+yard duty	-520725912	victor king
+yard duty	-534894953	xavier ovid
+yard duty	-607285491	sarah thompson
+yard duty	-625788713	katie robinson
+yard duty	-693207128	jessica xylophone
+yard duty	-714594143	priscilla brown
+yard duty	-797889292	oscar miller
+yard duty	-812431220	holly robinson
+yard duty	-884109192	alice zipper
+yard duty	-892839693	wendy davidson
+yard duty	1001732850	yuri king
+yard duty	1022707418	
+yard duty	115111911	priscilla allen
+yard duty	1194089079	nick falkner
+yard duty	1304431147	priscilla thompson
+yard duty	1332181668	ulysses laertes
+yard duty	1458051497	wendy garcia
+yard duty	1464703053	david white
+yard duty	1516149502	david ichabod
+yard duty	1625751062	jessica nixon
+yard duty	1678261510	wendy davidson
+yard duty	1796486238	bob nixon
+yard duty	1912175355	alice nixon
+yard duty	2042816480	zach steinbeck
+yard duty	210003006	xavier falkner
+yard duty	2133492883	gabriella thompson
+yard duty	252169185	katie laertes
+yard duty	25400543	quinn robinson
+yard duty	259524903	bob nixon
+yard duty	467753905	gabriella xylophone
+yard duty	538766635	irene laertes
+yard duty	615661052	bob ellison
+yard duty	654939016	katie steinbeck
+yard duty	692666133	mike miller
+yard duty	703111607	nick young
+yard duty	745725681	mike polk
+yard duty	770574055	
+yard duty	881396599	luke white
+yard duty	900992177	fred king
+yard duty	932774185	bob king
+yard duty	NULL	calvin ichabod
+yard duty	NULL	gabriella ovid
+yard duty	NULL	holly hernandez
+yard duty	NULL	irene garcia
+yard duty	NULL	rachel steinbeck
+yard duty	NULL	tom miller
+yard duty	NULL	zach hernandez
+zync studies	-1009249550	calvin laertes
+zync studies	-1141652793	sarah ovid
+zync studies	-1171326281	irene xylophone
+zync studies	-1196101029	david king
+zync studies	-134686276	oscar nixon
+zync studies	-1348149160	oscar hernandez
+zync studies	-1423477356	katie ovid
+zync studies	-1425942083	katie zipper
+zync studies	-1625800024	fred falkner
+zync studies	-1703620970	calvin allen
+zync studies	-1709246310	yuri polk
+zync studies	-1749841790	katie thompson
+zync studies	-1804244259	sarah thompson
+zync studies	-1808960215	ethan davidson
+zync studies	-1880877824	tom quirinius
+zync studies	-207546600	jessica van buren
+zync studies	-2144241640	quinn ichabod
+zync studies	-308225568	yuri white
+zync studies	-329695030	holly van buren
+zync studies	-340462064	calvin quirinius
+zync studies	-37773326	fred hernandez
+zync studies	-37876543	bob van buren
+zync studies	-423378447	oscar white
+zync studies	-43858652	mike king
+zync studies	-449333854	katie white
+zync studies	-604362582	gabriella ichabod
+zync studies	-641062448	wendy carson
+zync studies	-876122064	sarah ellison
+zync studies	-901079162	fred ovid
+zync studies	-906545548	xavier falkner
+zync studies	-968377273	
+zync studies	107941738	wendy nixon
+zync studies	1103878879	gabriella xylophone
+zync studies	1107757211	zach robinson
+zync studies	1257621270	katie miller
+zync studies	1303632852	quinn robinson
+zync studies	131031898	calvin allen
+zync studies	135341845	rachel young
+zync studies	1372982791	ulysses robinson
+zync studies	142722637	xavier quirinius
+zync studies	1471913583	rachel robinson
+zync studies	1485934602	tom garcia
+zync studies	1524010024	zach xylophone
+zync studies	1618123796	ethan ichabod
+zync studies	1650676897	sarah nixon
+zync studies	1687784247	bob king
+zync studies	1723691683	
+zync studies	1769324649	alice johnson
+zync studies	187893585	luke ichabod
+zync studies	2013376408	priscilla allen
+zync studies	206454818	rachel allen
+zync studies	2090044777	
+zync studies	2125479431	tom davidson
+zync studies	2144454927	irene young
+zync studies	25644069	holly falkner
+zync studies	30036142	wendy polk
+zync studies	352214248	calvin allen
+zync studies	407233168	katie young
+zync studies	474795096	mike young
+zync studies	476704350	sarah polk
+zync studies	492968645	sarah underhill
+zync studies	587797446	priscilla ellison
+zync studies	854230650	ethan laertes
+zync studies	869288953	alice miller
+zync studies	929751599	
+zync studies	NULL	holly young
+zync studies	NULL	holly zipper
+zync studies	NULL	priscilla young
+zync studies	NULL	quinn quirinius
+zync studies	NULL	yuri polk