Skip to content

Instantly share code, notes, and snippets.

@jameswinegar
Created April 30, 2019 04:43
Show Gist options
  • Save jameswinegar/8e1cfeb4f0b4a842f9772de7ba02f3b7 to your computer and use it in GitHub Desktop.
Save jameswinegar/8e1cfeb4f0b4a842f9772de7ba02f3b7 to your computer and use it in GitHub Desktop.
w261_testing_file
Display the source blob
Display the rendered blob
Raw
{
"cells": [
{
"cell_type": "code",
"execution_count": 2,
"metadata": {},
"outputs": [],
"source": [
"from pyspark.sql import SparkSession\n",
"import os\n",
"app_name = \"wk12_demo\"\n",
"master = \"local[*]\"\n",
"ui_prefix = os.environ.get('JUPYTERHUB_SERVICE_PREFIX', '/') + 'sparkui'\n",
"\n",
"spark = SparkSession\\\n",
" .builder\\\n",
" .appName(app_name)\\\n",
" .master(master)\\\n",
" .config('spark.ui.proxyBase', ui_prefix)\\\n",
" .getOrCreate()\n",
"\n",
"sc = spark.sparkContext"
]
},
{
"cell_type": "code",
"execution_count": 3,
"metadata": {},
"outputs": [
{
"data": {
"text/html": [
"\n",
" <div>\n",
" <p><b>SparkSession - in-memory</b></p>\n",
" \n",
" <div>\n",
" <p><b>SparkContext</b></p>\n",
"\n",
" <p><a href=\"http://jupyter-winegarj:4040\">Spark UI</a></p>\n",
"\n",
" <dl>\n",
" <dt>Version</dt>\n",
" <dd><code>v2.4.2</code></dd>\n",
" <dt>Master</dt>\n",
" <dd><code>local[*]</code></dd>\n",
" <dt>AppName</dt>\n",
" <dd><code>wk12_demo</code></dd>\n",
" </dl>\n",
" </div>\n",
" \n",
" </div>\n",
" "
],
"text/plain": [
"<pyspark.sql.session.SparkSession at 0x7f2674f0e780>"
]
},
"execution_count": 3,
"metadata": {},
"output_type": "execute_result"
}
],
"source": [
"spark"
]
},
{
"cell_type": "code",
"execution_count": 4,
"metadata": {},
"outputs": [
{
"data": {
"text/plain": [
"1249975000"
]
},
"execution_count": 4,
"metadata": {},
"output_type": "execute_result"
}
],
"source": [
"rdd = sc.parallelize(list(range(50000)))\n",
"rdd.sum()"
]
},
{
"cell_type": "code",
"execution_count": 29,
"metadata": {},
"outputs": [
{
"name": "stdout",
"output_type": "stream",
"text": [
"+---------+----------------+---------------+---------------+----------------+----------------+---------------+---------------+--------------------+--------------------+--------------------+---------------------+--------------------+\n",
"| date|actual_mean_temp|actual_min_temp|actual_max_temp|average_min_temp|average_max_temp|record_min_temp|record_max_temp|record_min_temp_year|record_max_temp_year|actual_precipitation|average_precipitation|record_precipitation|\n",
"+---------+----------------+---------------+---------------+----------------+----------------+---------------+---------------+--------------------+--------------------+--------------------+---------------------+--------------------+\n",
"| 2014-7-1| 81| 70| 91| 67| 89| 56| 104| 1919| 2012| 0.00| 0.10| 5.91|\n",
"| 2014-7-2| 85| 74| 95| 68| 89| 56| 101| 2008| 1931| 0.00| 0.10| 1.53|\n",
"| 2014-7-3| 82| 71| 93| 68| 89| 56| 99| 2010| 1931| 0.14| 0.11| 2.50|\n",
"| 2014-7-4| 75| 64| 86| 68| 89| 55| 99| 1933| 1955| 0.00| 0.10| 2.63|\n",
"| 2014-7-5| 72| 60| 84| 68| 89| 57| 100| 1967| 1954| 0.00| 0.10| 1.65|\n",
"| 2014-7-6| 74| 61| 87| 68| 89| 57| 99| 1964| 1948| 0.00| 0.10| 1.95|\n",
"| 2014-7-7| 79| 67| 91| 68| 89| 55| 100| 1972| 1954| 0.00| 0.11| 2.37|\n",
"| 2014-7-8| 83| 72| 94| 68| 89| 58| 101| 1892| 2010| 0.00| 0.11| 1.87|\n",
"| 2014-7-9| 80| 71| 89| 68| 89| 57| 101| 1891| 1986| 0.15| 0.12| 3.71|\n",
"|2014-7-10| 78| 71| 85| 68| 89| 53| 101| 1961| 1926| 0.0| 0.11| 2.45|\n",
"|2014-7-11| 78| 68| 87| 68| 89| 55| 100| 1961| 1986| 0.00| 0.12| 3.10|\n",
"|2014-7-12| 79| 67| 91| 68| 89| 59| 102| 1953| 1930| 0.00| 0.11| 1.95|\n",
"|2014-7-13| 81| 69| 92| 68| 89| 56| 100| 1918| 1986| 0.00| 0.12| 2.09|\n",
"|2014-7-14| 85| 74| 96| 68| 89| 59| 102| 2007| 1954| 0.00| 0.12| 2.15|\n",
"|2014-7-15| 81| 67| 94| 68| 89| 58| 100| 2001| 1893| 0.87| 0.12| 4.61|\n",
"|2014-7-16| 76| 66| 85| 68| 89| 58| 100| 2001| 1887| 0.00| 0.12| 1.47|\n",
"|2014-7-17| 74| 63| 84| 68| 89| 62| 100| 1886| 1986| 0.00| 0.12| 4.14|\n",
"|2014-7-18| 77| 70| 83| 68| 89| 62| 102| 1896| 1887| 0.0| 0.12| 1.82|\n",
"|2014-7-19| 70| 66| 74| 68| 89| 60| 103| 2009| 1986| 0.17| 0.12| 2.30|\n",
"|2014-7-20| 74| 65| 83| 68| 89| 60| 101| 1910| 1986| 0.0| 0.12| 1.25|\n",
"+---------+----------------+---------------+---------------+----------------+----------------+---------------+---------------+--------------------+--------------------+--------------------+---------------------+--------------------+\n",
"only showing top 20 rows\n",
"\n"
]
}
],
"source": [
"df = spark.read.format('csv').option(\"header\", \"true\").load('gs://w261-testing/stats.csv')\n",
"df.show()"
]
},
{
"cell_type": "code",
"execution_count": 30,
"metadata": {},
"outputs": [
{
"name": "stdout",
"output_type": "stream",
"text": [
"+---------+----------------+---------------+---------------+----------------+----------------+---------------+---------------+--------------------+--------------------+--------------------+---------------------+--------------------+\n",
"| date|actual_mean_temp|actual_min_temp|actual_max_temp|average_min_temp|average_max_temp|record_min_temp|record_max_temp|record_min_temp_year|record_max_temp_year|actual_precipitation|average_precipitation|record_precipitation|\n",
"+---------+----------------+---------------+---------------+----------------+----------------+---------------+---------------+--------------------+--------------------+--------------------+---------------------+--------------------+\n",
"| 2014-7-1| 81| 70| 91| 67| 89| 56| 104| 1919| 2012| 0.00| 0.10| 5.91|\n",
"| 2014-7-2| 85| 74| 95| 68| 89| 56| 101| 2008| 1931| 0.00| 0.10| 1.53|\n",
"| 2014-7-3| 82| 71| 93| 68| 89| 56| 99| 2010| 1931| 0.14| 0.11| 2.50|\n",
"| 2014-7-4| 75| 64| 86| 68| 89| 55| 99| 1933| 1955| 0.00| 0.10| 2.63|\n",
"| 2014-7-5| 72| 60| 84| 68| 89| 57| 100| 1967| 1954| 0.00| 0.10| 1.65|\n",
"| 2014-7-6| 74| 61| 87| 68| 89| 57| 99| 1964| 1948| 0.00| 0.10| 1.95|\n",
"| 2014-7-7| 79| 67| 91| 68| 89| 55| 100| 1972| 1954| 0.00| 0.11| 2.37|\n",
"| 2014-7-8| 83| 72| 94| 68| 89| 58| 101| 1892| 2010| 0.00| 0.11| 1.87|\n",
"| 2014-7-9| 80| 71| 89| 68| 89| 57| 101| 1891| 1986| 0.15| 0.12| 3.71|\n",
"|2014-7-10| 78| 71| 85| 68| 89| 53| 101| 1961| 1926| 0.0| 0.11| 2.45|\n",
"|2014-7-11| 78| 68| 87| 68| 89| 55| 100| 1961| 1986| 0.00| 0.12| 3.10|\n",
"|2014-7-12| 79| 67| 91| 68| 89| 59| 102| 1953| 1930| 0.00| 0.11| 1.95|\n",
"|2014-7-13| 81| 69| 92| 68| 89| 56| 100| 1918| 1986| 0.00| 0.12| 2.09|\n",
"|2014-7-14| 85| 74| 96| 68| 89| 59| 102| 2007| 1954| 0.00| 0.12| 2.15|\n",
"|2014-7-15| 81| 67| 94| 68| 89| 58| 100| 2001| 1893| 0.87| 0.12| 4.61|\n",
"|2014-7-16| 76| 66| 85| 68| 89| 58| 100| 2001| 1887| 0.00| 0.12| 1.47|\n",
"|2014-7-17| 74| 63| 84| 68| 89| 62| 100| 1886| 1986| 0.00| 0.12| 4.14|\n",
"|2014-7-18| 77| 70| 83| 68| 89| 62| 102| 1896| 1887| 0.0| 0.12| 1.82|\n",
"|2014-7-19| 70| 66| 74| 68| 89| 60| 103| 2009| 1986| 0.17| 0.12| 2.30|\n",
"|2014-7-20| 74| 65| 83| 68| 89| 60| 101| 1910| 1986| 0.0| 0.12| 1.25|\n",
"+---------+----------------+---------------+---------------+----------------+----------------+---------------+---------------+--------------------+--------------------+--------------------+---------------------+--------------------+\n",
"only showing top 20 rows\n",
"\n"
]
}
],
"source": [
"df.write.format('csv').mode('overwrite').option(\"header\", \"true\").save('gs://w261-testing/write-test.csv')\n",
"df2 = spark.read.format('csv').option(\"header\", \"true\").load('gs://w261-testing/write-test.csv')\n",
"df2.show()"
]
},
{
"cell_type": "code",
"execution_count": 31,
"metadata": {},
"outputs": [
{
"data": {
"text/plain": [
"DataFrame[date: string, actual_mean_temp: string, actual_min_temp: string, actual_max_temp: string, average_min_temp: string, average_max_temp: string, record_min_temp: string, record_max_temp: string, record_min_temp_year: string, record_max_temp_year: string, actual_precipitation: string, average_precipitation: string, record_precipitation: string]"
]
},
"execution_count": 31,
"metadata": {},
"output_type": "execute_result"
}
],
"source": [
"df2.cache()"
]
},
{
"cell_type": "code",
"execution_count": 34,
"metadata": {},
"outputs": [
{
"data": {
"text/plain": [
"[Row(min(date)='2014-10-1', max(date)='2015-6-9', avg(actual_mean_temp)=61.04931506849315)]"
]
},
"execution_count": 34,
"metadata": {},
"output_type": "execute_result"
}
],
"source": [
"from pyspark.sql import functions as F\n",
"df2.agg(F.min('date'), F.max('date'), F.avg('actual_mean_temp')).collect()"
]
},
{
"cell_type": "code",
"execution_count": 46,
"metadata": {},
"outputs": [],
"source": [
"JAR_FILE=\"/srv/conda/hadoop/share/hadoop/tools/lib/hadoop-streaming-2.7.7.jar\"\n",
"HDFS_DIR=\"gs://w261-testing/\"\n",
"from os import environ\n",
"PATH = environ['PATH']"
]
},
{
"cell_type": "code",
"execution_count": 48,
"metadata": {},
"outputs": [
{
"name": "stdout",
"output_type": "stream",
"text": [
"Overwriting mapper.py\n"
]
}
],
"source": [
"%%writefile mapper.py\n",
"#!/usr/bin/env python\n",
"\"\"\"mapper.py\"\"\"\n",
"\n",
"import sys\n",
"\n",
"# input comes from STDIN (standard input)\n",
"for line in sys.stdin:\n",
" # remove leading and trailing whitespace\n",
" line = line.strip()\n",
" # split the line into words\n",
" words = line.split()\n",
" # increase counters\n",
" for word in words:\n",
" # write the results to STDOUT (standard output);\n",
" # what we output here will be the input for the\n",
" # Reduce step, i.e. the input for reducer.py\n",
" #\n",
" # tab-delimited; the trivial word count is 1\n",
" print('%s\\t%s' % (word, 1))"
]
},
{
"cell_type": "code",
"execution_count": 52,
"metadata": {},
"outputs": [
{
"name": "stdout",
"output_type": "stream",
"text": [
"Overwriting reducer.py\n"
]
}
],
"source": [
"%%writefile reducer.py\n",
"#!/usr/bin/env python\n",
"\"\"\"reducer.py\"\"\"\n",
"\n",
"from operator import itemgetter\n",
"import sys\n",
"\n",
"current_word = None\n",
"current_count = 0\n",
"word = None\n",
"\n",
"# input comes from STDIN\n",
"for line in sys.stdin:\n",
" # remove leading and trailing whitespace\n",
" line = line.strip()\n",
"\n",
" # parse the input we got from mapper.py\n",
" word, count = line.split('\\t', 1)\n",
"\n",
" # convert count (currently a string) to int\n",
" try:\n",
" count = int(count)\n",
" except ValueError:\n",
" # count was not a number, so silently\n",
" # ignore/discard this line\n",
" continue\n",
"\n",
" # this IF-switch only works because Hadoop sorts map output\n",
" # by key (here: word) before it is passed to the reducer\n",
" if current_word == word:\n",
" current_count += count\n",
" else:\n",
" if current_word:\n",
" # write result to STDOUT\n",
" print('%s\\t%s' % (current_word, current_count))\n",
" current_count = count\n",
" current_word = word\n",
"\n",
"# do not forget to output the last word if needed!\n",
"if current_word == word:\n",
" print('%s\\t%s' % (current_word, current_count))"
]
},
{
"cell_type": "code",
"execution_count": 53,
"metadata": {},
"outputs": [
{
"name": "stdout",
"output_type": "stream",
"text": [
"19/04/30 04:39:30 INFO Configuration.deprecation: io.bytes.per.checksum is deprecated. Instead, use dfs.bytes-per-checksum\n",
"19/04/30 04:39:30 INFO fs.TrashPolicyDefault: Namenode trash configuration: Deletion interval = 0 minutes, Emptier interval = 0 minutes.\n",
"Deleted gs://w261-testing/wc-output\n",
"19/04/30 04:39:32 INFO Configuration.deprecation: session.id is deprecated. Instead, use dfs.metrics.session-id\n",
"19/04/30 04:39:32 INFO jvm.JvmMetrics: Initializing JVM Metrics with processName=JobTracker, sessionId=\n",
"19/04/30 04:39:32 INFO jvm.JvmMetrics: Cannot initialize JVM Metrics with processName=JobTracker, sessionId= - already initialized\n",
"19/04/30 04:39:34 INFO mapred.FileInputFormat: Total input paths to process : 1\n",
"19/04/30 04:39:34 INFO mapreduce.JobSubmitter: number of splits:1\n",
"19/04/30 04:39:34 INFO mapreduce.JobSubmitter: Submitting tokens for job: job_local492881906_0001\n",
"19/04/30 04:39:34 INFO mapred.LocalDistributedCacheManager: Localized file:/srv/repo/reducer.py as file:/tmp/hadoop-jovyan/mapred/local/1556599174426/reducer.py\n",
"19/04/30 04:39:34 INFO mapred.LocalDistributedCacheManager: Localized file:/srv/repo/mapper.py as file:/tmp/hadoop-jovyan/mapred/local/1556599174427/mapper.py\n",
"19/04/30 04:39:34 INFO mapreduce.Job: The url to track the job: http://localhost:8080/\n",
"19/04/30 04:39:34 INFO mapred.LocalJobRunner: OutputCommitter set in config null\n",
"19/04/30 04:39:34 INFO mapreduce.Job: Running job: job_local492881906_0001\n",
"19/04/30 04:39:34 INFO mapred.LocalJobRunner: OutputCommitter is org.apache.hadoop.mapred.FileOutputCommitter\n",
"19/04/30 04:39:34 INFO output.FileOutputCommitter: File Output Committer Algorithm version is 1\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: Waiting for map tasks\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: Starting task: attempt_local492881906_0001_m_000000_0\n",
"19/04/30 04:39:35 INFO output.FileOutputCommitter: File Output Committer Algorithm version is 1\n",
"19/04/30 04:39:35 INFO mapred.Task: Using ResourceCalculatorProcessTree : [ ]\n",
"19/04/30 04:39:35 INFO mapred.MapTask: Processing split: gs://w261-testing/alice.txt:0+173595\n",
"19/04/30 04:39:35 INFO mapred.MapTask: numReduceTasks: 1\n",
"19/04/30 04:39:35 INFO mapred.MapTask: (EQUATOR) 0 kvi 26214396(104857584)\n",
"19/04/30 04:39:35 INFO mapred.MapTask: mapreduce.task.io.sort.mb: 100\n",
"19/04/30 04:39:35 INFO mapred.MapTask: soft limit at 83886080\n",
"19/04/30 04:39:35 INFO mapred.MapTask: bufstart = 0; bufvoid = 104857600\n",
"19/04/30 04:39:35 INFO mapred.MapTask: kvstart = 26214396; length = 6553600\n",
"19/04/30 04:39:35 INFO mapred.MapTask: Map output collector class = org.apache.hadoop.mapred.MapTask$MapOutputBuffer\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: PipeMapRed exec [/srv/repo/./mapper.py]\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.work.output.dir is deprecated. Instead, use mapreduce.task.output.dir\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: map.input.start is deprecated. Instead, use mapreduce.map.input.start\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.task.is.map is deprecated. Instead, use mapreduce.task.ismap\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.task.id is deprecated. Instead, use mapreduce.task.attempt.id\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.tip.id is deprecated. Instead, use mapreduce.task.id\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.local.dir is deprecated. Instead, use mapreduce.cluster.local.dir\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: map.input.file is deprecated. Instead, use mapreduce.map.input.file\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.skip.on is deprecated. Instead, use mapreduce.job.skiprecords\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: map.input.length is deprecated. Instead, use mapreduce.map.input.length\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.job.id is deprecated. Instead, use mapreduce.job.id\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: user.name is deprecated. Instead, use mapreduce.job.user.name\n",
"19/04/30 04:39:35 INFO Configuration.deprecation: mapred.task.partition is deprecated. Instead, use mapreduce.task.partition\n",
"19/04/30 04:39:35 INFO mapred.LineRecordReader: Found UTF-8 BOM and skipped it\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: R/W/S=1/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: R/W/S=10/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: R/W/S=100/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: R/W/S=1000/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: Records R/W=2884/1\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: MRErrorThread done\n",
"19/04/30 04:39:35 INFO streaming.PipeMapRed: mapRedFinished\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: \n",
"19/04/30 04:39:35 INFO mapred.MapTask: Starting flush of map output\n",
"19/04/30 04:39:35 INFO mapred.MapTask: Spilling map output\n",
"19/04/30 04:39:35 INFO mapred.MapTask: bufstart = 0; bufend = 226542; bufvoid = 104857600\n",
"19/04/30 04:39:35 INFO mapred.MapTask: kvstart = 26214396(104857584); kvend = 26096540(104386160); length = 117857/6553600\n",
"19/04/30 04:39:35 INFO mapreduce.Job: Job job_local492881906_0001 running in uber mode : false\n",
"19/04/30 04:39:35 INFO mapreduce.Job: map 0% reduce 0%\n",
"19/04/30 04:39:35 INFO mapred.MapTask: Finished spill 0\n",
"19/04/30 04:39:35 INFO mapred.Task: Task:attempt_local492881906_0001_m_000000_0 is done. And is in the process of committing\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: Records R/W=2884/1\n",
"19/04/30 04:39:35 INFO mapred.Task: Task 'attempt_local492881906_0001_m_000000_0' done.\n",
"19/04/30 04:39:35 INFO mapred.Task: Final Counters for attempt_local492881906_0001_m_000000_0: Counters: 22\n",
"\tFile System Counters\n",
"\t\tFILE: Number of bytes read=131179\n",
"\t\tFILE: Number of bytes written=718570\n",
"\t\tFILE: Number of read operations=0\n",
"\t\tFILE: Number of large read operations=0\n",
"\t\tFILE: Number of write operations=0\n",
"\t\tGS: Number of bytes read=173595\n",
"\t\tGS: Number of bytes written=0\n",
"\t\tGS: Number of read operations=0\n",
"\t\tGS: Number of large read operations=0\n",
"\t\tGS: Number of write operations=0\n",
"\tMap-Reduce Framework\n",
"\t\tMap input records=3736\n",
"\t\tMap output records=29465\n",
"\t\tMap output bytes=226542\n",
"\t\tMap output materialized bytes=285478\n",
"\t\tInput split bytes=79\n",
"\t\tCombine input records=0\n",
"\t\tSpilled Records=29465\n",
"\t\tFailed Shuffles=0\n",
"\t\tMerged Map outputs=0\n",
"\t\tGC time elapsed (ms)=38\n",
"\t\tTotal committed heap usage (bytes)=137433088\n",
"\tFile Input Format Counters \n",
"\t\tBytes Read=173595\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: Finishing task: attempt_local492881906_0001_m_000000_0\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: map task executor complete.\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: Waiting for reduce tasks\n",
"19/04/30 04:39:35 INFO mapred.LocalJobRunner: Starting task: attempt_local492881906_0001_r_000000_0\n",
"19/04/30 04:39:35 INFO output.FileOutputCommitter: File Output Committer Algorithm version is 1\n",
"19/04/30 04:39:35 INFO mapred.Task: Using ResourceCalculatorProcessTree : [ ]\n",
"19/04/30 04:39:35 INFO mapred.ReduceTask: Using ShuffleConsumerPlugin: org.apache.hadoop.mapreduce.task.reduce.Shuffle@76aee897\n",
"19/04/30 04:39:36 INFO reduce.MergeManagerImpl: MergerManager: memoryLimit=363285696, maxSingleShuffleLimit=90821424, mergeThreshold=239768576, ioSortFactor=10, memToMemMergeOutputsThreshold=10\n",
"19/04/30 04:39:36 INFO reduce.EventFetcher: attempt_local492881906_0001_r_000000_0 Thread started: EventFetcher for fetching Map Completion Events\n",
"19/04/30 04:39:36 INFO reduce.LocalFetcher: localfetcher#1 about to shuffle output of map attempt_local492881906_0001_m_000000_0 decomp: 285474 len: 285478 to MEMORY\n",
"19/04/30 04:39:36 INFO reduce.InMemoryMapOutput: Read 285474 bytes from map-output for attempt_local492881906_0001_m_000000_0\n",
"19/04/30 04:39:36 INFO reduce.MergeManagerImpl: closeInMemoryFile -> map-output of size: 285474, inMemoryMapOutputs.size() -> 1, commitMemory -> 0, usedMemory ->285474\n",
"19/04/30 04:39:36 INFO reduce.EventFetcher: EventFetcher is interrupted.. Returning\n",
"19/04/30 04:39:36 INFO mapred.LocalJobRunner: 1 / 1 copied.\n",
"19/04/30 04:39:36 INFO reduce.MergeManagerImpl: finalMerge called with 1 in-memory map-outputs and 0 on-disk map-outputs\n",
"19/04/30 04:39:36 INFO mapred.Merger: Merging 1 sorted segments\n",
"19/04/30 04:39:36 INFO mapred.Merger: Down to the last merge-pass, with 1 segments left of total size: 285467 bytes\n",
"19/04/30 04:39:36 INFO reduce.MergeManagerImpl: Merged 1 segments, 285474 bytes to disk to satisfy reduce memory limit\n",
"19/04/30 04:39:36 INFO reduce.MergeManagerImpl: Merging 1 files, 285478 bytes from disk\n",
"19/04/30 04:39:36 INFO reduce.MergeManagerImpl: Merging 0 segments, 0 bytes from memory into reduce\n",
"19/04/30 04:39:36 INFO mapred.Merger: Merging 1 sorted segments\n",
"19/04/30 04:39:36 INFO mapred.Merger: Down to the last merge-pass, with 1 segments left of total size: 285467 bytes\n",
"19/04/30 04:39:36 INFO mapred.LocalJobRunner: 1 / 1 copied.\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: PipeMapRed exec [/srv/repo/./reducer.py]\n",
"19/04/30 04:39:36 INFO Configuration.deprecation: mapred.job.tracker is deprecated. Instead, use mapreduce.jobtracker.address\n",
"19/04/30 04:39:36 INFO Configuration.deprecation: mapred.map.tasks is deprecated. Instead, use mapreduce.job.maps\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: R/W/S=1/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: R/W/S=10/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: R/W/S=100/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:36 INFO mapreduce.Job: map 100% reduce 0%\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: R/W/S=1000/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: R/W/S=10000/0/0 in:NA [rec/s] out:NA [rec/s]\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: Records R/W=17255/1\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: MRErrorThread done\n",
"19/04/30 04:39:36 INFO streaming.PipeMapRed: mapRedFinished\n",
"19/04/30 04:39:37 INFO mapred.Task: Task:attempt_local492881906_0001_r_000000_0 is done. And is in the process of committing\n",
"19/04/30 04:39:37 INFO mapred.LocalJobRunner: 1 / 1 copied.\n",
"19/04/30 04:39:37 INFO mapred.Task: Task attempt_local492881906_0001_r_000000_0 is allowed to commit now\n",
"19/04/30 04:39:38 INFO output.FileOutputCommitter: Saved output of task 'attempt_local492881906_0001_r_000000_0' to gs://w261-testing/wc-output/_temporary/0/task_local492881906_0001_r_000000\n",
"19/04/30 04:39:38 INFO mapred.LocalJobRunner: Records R/W=17255/1 > reduce\n",
"19/04/30 04:39:38 INFO mapred.Task: Task 'attempt_local492881906_0001_r_000000_0' done.\n",
"19/04/30 04:39:38 INFO mapred.Task: Final Counters for attempt_local492881906_0001_r_000000_0: Counters: 29\n",
"\tFile System Counters\n",
"\t\tFILE: Number of bytes read=702167\n",
"\t\tFILE: Number of bytes written=1004048\n",
"\t\tFILE: Number of read operations=0\n",
"\t\tFILE: Number of large read operations=0\n",
"\t\tFILE: Number of write operations=0\n",
"\t\tGS: Number of bytes read=173595\n",
"\t\tGS: Number of bytes written=61416\n",
"\t\tGS: Number of read operations=0\n",
"\t\tGS: Number of large read operations=0\n",
"\t\tGS: Number of write operations=0\n",
"\tMap-Reduce Framework\n",
"\t\tCombine input records=0\n",
"\t\tCombine output records=0\n",
"\t\tReduce input groups=6018\n",
"\t\tReduce shuffle bytes=285478\n",
"\t\tReduce input records=29465\n",
"\t\tReduce output records=6018\n",
"\t\tSpilled Records=29465\n",
"\t\tShuffled Maps =1\n",
"\t\tFailed Shuffles=0\n",
"\t\tMerged Map outputs=1\n",
"\t\tGC time elapsed (ms)=72\n",
"\t\tTotal committed heap usage (bytes)=184619008\n",
"\tShuffle Errors\n",
"\t\tBAD_ID=0\n",
"\t\tCONNECTION=0\n",
"\t\tIO_ERROR=0\n",
"\t\tWRONG_LENGTH=0\n",
"\t\tWRONG_MAP=0\n",
"\t\tWRONG_REDUCE=0\n",
"\tFile Output Format Counters \n",
"\t\tBytes Written=61416\n",
"19/04/30 04:39:38 INFO mapred.LocalJobRunner: Finishing task: attempt_local492881906_0001_r_000000_0\n",
"19/04/30 04:39:38 INFO mapred.LocalJobRunner: reduce task executor complete.\n",
"19/04/30 04:39:39 INFO mapreduce.Job: map 100% reduce 100%\n",
"19/04/30 04:39:41 INFO mapreduce.Job: Job job_local492881906_0001 completed successfully\n",
"19/04/30 04:39:41 INFO mapreduce.Job: Counters: 35\n",
"\tFile System Counters\n",
"\t\tFILE: Number of bytes read=833346\n",
"\t\tFILE: Number of bytes written=1722618\n",
"\t\tFILE: Number of read operations=0\n",
"\t\tFILE: Number of large read operations=0\n",
"\t\tFILE: Number of write operations=0\n",
"\t\tGS: Number of bytes read=347190\n",
"\t\tGS: Number of bytes written=61416\n",
"\t\tGS: Number of read operations=0\n",
"\t\tGS: Number of large read operations=0\n",
"\t\tGS: Number of write operations=0\n",
"\tMap-Reduce Framework\n",
"\t\tMap input records=3736\n",
"\t\tMap output records=29465\n",
"\t\tMap output bytes=226542\n",
"\t\tMap output materialized bytes=285478\n",
"\t\tInput split bytes=79\n",
"\t\tCombine input records=0\n",
"\t\tCombine output records=0\n",
"\t\tReduce input groups=6018\n",
"\t\tReduce shuffle bytes=285478\n",
"\t\tReduce input records=29465\n",
"\t\tReduce output records=6018\n",
"\t\tSpilled Records=58930\n",
"\t\tShuffled Maps =1\n",
"\t\tFailed Shuffles=0\n",
"\t\tMerged Map outputs=1\n",
"\t\tGC time elapsed (ms)=110\n",
"\t\tTotal committed heap usage (bytes)=322052096\n",
"\tShuffle Errors\n",
"\t\tBAD_ID=0\n",
"\t\tCONNECTION=0\n",
"\t\tIO_ERROR=0\n",
"\t\tWRONG_LENGTH=0\n",
"\t\tWRONG_MAP=0\n",
"\t\tWRONG_REDUCE=0\n",
"\tFile Input Format Counters \n",
"\t\tBytes Read=173595\n",
"\tFile Output Format Counters \n",
"\t\tBytes Written=61416\n",
"19/04/30 04:39:41 INFO streaming.StreamJob: Output directory: gs://w261-testing//wc-output\n"
]
}
],
"source": [
"!hdfs dfs -rm -r {HDFS_DIR}/wc-output\n",
"!hadoop jar {JAR_FILE} \\\n",
" -files reducer.py,mapper.py \\\n",
" -mapper mapper.py \\\n",
" -reducer reducer.py \\\n",
" -input {HDFS_DIR}/alice.txt \\\n",
" -output {HDFS_DIR}/wc-output \\\n",
" -numReduceTasks 1 \\\n",
" -cmdenv PATH={PATH}"
]
},
{
"cell_type": "code",
"execution_count": 56,
"metadata": {},
"outputs": [
{
"name": "stdout",
"output_type": "stream",
"text": [
"#11]\t1\r\n",
"$5,000)\t1\r\n",
"($1\t1\r\n",
"(801)\t1\r\n",
"(Alice\t4\r\n",
"(And,\t1\r\n",
"(As\t1\r\n",
"(Before\t1\r\n",
"(Dinah\t1\r\n",
"(For,\t1\r\n",
"(He\t1\r\n",
"(IF\t1\r\n",
"(In\t1\r\n",
"(It\t1\r\n",
"(Sounds\t1\r\n",
"(The\t3\r\n",
"(WITH\t1\r\n",
"(We\t1\r\n",
"(Which\t2\r\n",
"(a\t1\r\n",
"(a)\t1\r\n",
"(and\t2\r\n",
"(any\t1\r\n",
"(as\t2\r\n",
"(available\t1\r\n",
"(b)\t1\r\n",
"(c)\t1\r\n",
"(does\t1\r\n",
"(for\t1\r\n",
"(for,\t1\r\n",
"(if\t1\r\n",
"(it\t4\r\n",
"(look\t1\r\n",
"(luckily\t1\r\n",
"(not\t1\r\n",
"(or\t4\r\n",
"(pointing\t1\r\n",
"(she\t9\r\n",
"(the\t1\r\n",
"(though\t1\r\n",
"(trademark/copyright)\t1\r\n",
"(when\t1\r\n",
"(which\t1\r\n",
"(with\t1\r\n",
"(www.gutenberg.org),\t1\r\n",
"(“the\t1\r\n",
"*\t60\r\n",
"***\t6\r\n",
"*****\t2\r\n",
"-\t7\r\n",
"1.\t1\r\n",
"1.A.\t1\r\n",
"1.B.\t1\r\n",
"1.C\t1\r\n",
"1.C.\t1\r\n",
"1.D.\t1\r\n",
"1.E\t1\r\n",
"1.E.\t1\r\n",
"1.E.1\t3\r\n",
"1.E.1.\t2\r\n",
"1.E.2.\t1\r\n",
"1.E.3.\t1\r\n",
"1.E.4.\t1\r\n",
"1.E.5.\t1\r\n",
"1.E.6.\t1\r\n",
"1.E.7\t2\r\n",
"1.E.7.\t1\r\n",
"1.E.8\t2\r\n",
"1.E.8.\t2\r\n",
"1.E.9.\t3\r\n",
"1.F.\t1\r\n",
"1.F.1.\t1\r\n",
"1.F.2.\t1\r\n",
"1.F.3,\t3\r\n",
"1.F.3.\t1\r\n",
"1.F.4.\t1\r\n",
"1.F.5.\t1\r\n",
"1.F.6.\t1\r\n",
"11-0.txt\t1\r\n",
"11-0.zip\t1\r\n",
"1500\t1\r\n",
"1994\t1\r\n",
"2.\t1\r\n",
"20%\t1\r\n",
"2001,\t1\r\n",
"2008\t1\r\n",
"2016\t1\r\n",
"25,\t1\r\n",
"3\t2\r\n",
"3.\t1\r\n",
"3.0\t1\r\n",
"30\t1\r\n",
"4\t1\r\n",
"4,\t1\r\n",
"4.\t1\r\n",
"4557\t1\r\n",
"5.\t1\r\n",
"50\t1\r\n",
"501(c)(3)\t2\r\n",
"596-1887,\t1\r\n",
"6,\t1\r\n",
"60\t1\r\n",
"64-6221541.\t1\r\n",
"809\t1\r\n",
"84116,\t1\r\n",
"90\t2\r\n",
"99712.,\t1\r\n",
"A\t8\r\n",
"ACTUAL,\t1\r\n",
"ADVENTURES\t3\r\n",
"AGREE\t2\r\n",
"AGREEMENT\t1\r\n",
"AK,\t1\r\n",
"ALICE’S\t5\r\n",
"ALL\t2\r\n",
"ALL.\t1\r\n",
"AND\t4\r\n",
"ANY\t3\r\n",
"ANYTHING\t1\r\n",
"ARE\t5\r\n",
"ASCII”\t2\r\n",
"AT\t1\r\n",
"About\t1\r\n",
"Ada,’\t1\r\n",
"Additional\t1\r\n",
"Adventures\t4\r\n",
"Adventures,\t1\r\n",
"Advice\t1\r\n",
"After\t5\r\n",
"Ah,\t1\r\n",
"Alas!\t1\r\n",
"Alice\t221\r\n",
"Alice!\t3\r\n",
"Alice!’\t1\r\n",
"Alice)--‘and\t1\r\n",
"Alice,\t76\r\n",
"Alice,)\t2\r\n",
"Alice.\t54\r\n",
"Alice:\t7\r\n",
"Alice;\t16\r\n",
"Alice’s\t11\r\n",
"Alice’s,\t1\r\n",
"All\t3\r\n",
"Allow\t1\r\n",
"Always\t1\r\n",
"An\t4\r\n",
"And\t49\r\n",
"Ann!\t1\r\n",
"Ann!’\t1\r\n",
"Ann,\t2\r\n",
"Antipathies,\t1\r\n",
"Any\t1\r\n",
"Archive\t13\r\n",
"Arithmetic--Ambition,\t1\r\n",
"As\t12\r\n",
"At\t8\r\n",
"Atheling\t1\r\n",
"Australia?’\t1\r\n",
"Author:\t1\r\n",
"B.\t1\r\n",
"BE\t2\r\n",
"BEE,”\t1\r\n",
"BEFORE\t1\r\n",
"BEG\t1\r\n",
"BEST\t2\r\n",
"BOOTS\t1\r\n",
"BREACH\t2\r\n",
"BUSY\t1\r\n",
"BUT\t1\r\n",
"Be\t1\r\n",
"Beau--ootiful\t4\r\n",
"Beautiful,\t3\r\n",
"Because\t1\r\n",
"Besides,\t1\r\n",
"Between\t1\r\n",
"Bill\t2\r\n",
"Bill!\t3\r\n",
"Bill!’\t1\r\n",
"Bill,\t3\r\n",
"Bill,’\t2\r\n",
"Bill’s\t3\r\n",
"But\t15\r\n",
"But,\t2\r\n",
"By\t4\r\n",
"CAN\t4\r\n",
"CHAPTER\t12\r\n",
"CHORUS.\t2\r\n",
"CONSEQUENTIAL,\t1\r\n",
"CONTRACT\t1\r\n",
"COULD\t3\r\n",
"COULD!\t1\r\n",
"COURT.’\t1\r\n",
"CURTSEYING\t1\r\n",
"Canary\t1\r\n",
"Canterbury,\t1\r\n",
"Carroll\t4\r\n",
"Cat\t8\r\n",
"Cat,\t7\r\n",
"Cat,’\t1\r\n",
"Cat.\t5\r\n",
"Cat:\t2\r\n",
"Cat;\t1\r\n",
"Caterpillar\t11\r\n",
"Caterpillar,\t2\r\n",
"Caterpillar.\t12\r\n",
"Caterpillar;\t1\r\n",
"Caterpillar’s\t1\r\n",
"Cat’s\t2\r\n",
"Caucus-Race\t1\r\n",
"Caucus-race.’\t1\r\n",
"Caucus-race?’\t1\r\n",
"Character\t1\r\n",
"Cheshire\t6\r\n",
"Chief\t1\r\n",
"Christmas.’\t1\r\n",
"City,\t1\r\n",
"Classics\t1\r\n",
"Coils.’\t1\r\n",
"Come\t4\r\n",
"Compliance\t1\r\n",
"Conqueror,\t1\r\n",
"Conqueror.’\t1\r\n",
"Contact\t1\r\n",
"Contributions\t1\r\n",
"Copyright\t1\r\n",
"Crab\t1\r\n",
"Crab,\t1\r\n",
"Creating\t1\r\n",
"Croquet-Ground\t1\r\n",
"D,’\t1\r\n",
"DAMAGE.\t1\r\n",
"DAMAGES\t2\r\n",
"DIRECT,\t1\r\n",
"DISCLAIMER\t1\r\n",
"DISTRIBUTE\t1\r\n",
"DISTRIBUTOR\t1\r\n",
"DOES\t1\r\n",
"DONATIONS\t1\r\n",
"DON’T\t1\r\n",
"DOTH\t1\r\n",
"Date:\t2\r\n",
"Defect\t1\r\n",
"Derision.’\t1\r\n",
"Despite\t1\r\n",
"Digging\t1\r\n",
"Dinah\t4\r\n",
"Dinah!\t1\r\n",
"Dinah!’\t1\r\n",
"Dinah,\t3\r\n",
"Dinah:\t1\r\n",
"Dinah’ll\t1\r\n",
"Dinn\t1\r\n",
"Director\t1\r\n",
"Distraction,\t1\r\n",
"Do\t8\r\n",
"Dodo\t9\r\n",
"Dodo,\t3\r\n",
"Dodo.\t1\r\n",
"Domain\t1\r\n",
"Donations\t2\r\n",
"Don’t\t4\r\n",
"Dormouse\t23\r\n",
"Dormouse!\t1\r\n",
"Dormouse!’\t1\r\n",
"Dormouse,\t6\r\n",
"Dormouse,’\t2\r\n",
"Dormouse.\t3\r\n",
"Dormouse:\t1\r\n",
"Dormouse;\t2\r\n",
"Dormouse’s\t1\r\n",
"Down\t1\r\n",
"Down,\t2\r\n",
"Dr.\t2\r\n",
"Drawling,\t1\r\n",
"Drawling--the\t1\r\n",
"Drawling-master\t1\r\n",
"Duchess\t15\r\n",
"Duchess!\t3\r\n",
"Duchess,\t8\r\n",
"Duchess,’\t1\r\n",
"Duchess.\t3\r\n",
"Duchess:\t4\r\n",
"Duchess;\t4\r\n",
"Duchess?’\t1\r\n",
"Duchess’s\t3\r\n",
"Duck\t1\r\n",
"Duck.\t1\r\n",
"Duck:\t1\r\n",
"EBOOK\t2\r\n",
"EDITION\t1\r\n",
"EIN\t1\r\n",
"END\t2\r\n",
"ESQ.\t1\r\n",
"EVEN\t2\r\n",
"EVER\t1\r\n",
"EXCEPT\t1\r\n",
"EXPRESS\t1\r\n",
"Eaglet\t1\r\n",
"Eaglet,\t1\r\n",
"Eaglet.\t1\r\n",
"Edgar\t1\r\n",
"Edwin\t1\r\n",
"Either\t1\r\n",
"Elsie,\t1\r\n",
"Email\t1\r\n",
"End\t1\r\n",
"England\t1\r\n",
"English\t2\r\n",
"English!’\t1\r\n",
"English);\t1\r\n",
"English,\t1\r\n",
"English,’\t1\r\n",
"English.\t1\r\n",
"Even\t1\r\n",
"Everybody\t1\r\n",
"Everything\t1\r\n",
"Evidence\t1\r\n",
"Exactly\t1\r\n",
"Except\t2\r\n",
"Executive\t1\r\n",
"F3.\t1\r\n",
"FATHER\t2\r\n",
"FENDER,\t1\r\n",
"FIT\t1\r\n",
"FIT--”\t1\r\n",
"FITNESS\t1\r\n",
"FOOT,\t1\r\n",
"FOR\t3\r\n",
"FOUNDATION,\t1\r\n",
"FROM\t1\r\n",
"FULCRUM\t1\r\n",
"FULL\t2\r\n",
"Fainting\t1\r\n",
"Fairbanks,\t1\r\n",
"Father\t2\r\n",
"First\t2\r\n",
"First,\t4\r\n",
"Fish-Footman\t2\r\n",
"Five\t1\r\n",
"Five!\t2\r\n",
"Five,\t3\r\n",
"Five.\t1\r\n",
"Footman\t4\r\n",
"Footman,\t2\r\n",
"Footman.\t1\r\n",
"Footman’s\t1\r\n",
"For\t12\r\n",
"For,\t1\r\n",
"Forty-two.\t1\r\n",
"Foundation\t14\r\n",
"Foundation,\t4\r\n",
"Foundation.\t1\r\n",
"Foundation.”\t1\r\n",
"Foundation’s\t3\r\n",
"Foundation”\t1\r\n",
"France--\t1\r\n",
"French\t3\r\n",
"Frog-Footman\t1\r\n",
"Full\t1\r\n",
"Fury:\t1\r\n",
"GAVE\t2\r\n",
"GIVE\t1\r\n",
"GUTENBERG\t3\r\n",
"GUTENBERG-tm\t1\r\n",
"Game,\t1\r\n",
"General\t3\r\n",
"Geography.\t1\r\n",
"Go\t1\r\n",
"Good-bye,\t1\r\n",
"Grammar,\t1\r\n",
"Gregory\t1\r\n",
"Grief,\t1\r\n",
"Gryphon\t22\r\n",
"Gryphon,\t14\r\n",
"Gryphon.\t15\r\n",
"Gryphon:\t3\r\n",
"Gryphon;\t1\r\n",
"Gutenberg\t19\r\n",
"Gutenberg-tm\t53\r\n",
"Gutenberg-tm,\t1\r\n",
"Gutenberg-tm.\t1\r\n",
"Gutenberg-tm’s\t1\r\n",
"Gutenberg:\t1\r\n",
"Gutenberg’s\t2\r\n",
"Gutenberg”\t4\r\n",
"Gutenberg”),\t1\r\n",
"HAD\t1\r\n",
"HATED\t1\r\n",
"HAVE\t5\r\n",
"HE\t3\r\n",
"HEARTHRUG,\t1\r\n",
"HEARTS.\t1\r\n",
"HER\t2\r\n",
"HERE.’\t1\r\n",
"HIGH\t1\r\n",
"HIM\t2\r\n",
"HIM.’\t1\r\n",
"HIS\t1\r\n",
"Half-past\t1\r\n",
"Hardly\t1\r\n",
"Hare\t16\r\n",
"Hare,\t2\r\n",
"Hare,)\t1\r\n",
"Hare.\t11\r\n",
"Hare:\t1\r\n",
"Hart\t1\r\n",
"Hart,\t1\r\n",
"Has\t1\r\n",
"Hatter\t24\r\n",
"Hatter,\t10\r\n",
"Hatter.\t13\r\n",
"Hatter:\t6\r\n",
"Hatter;\t1\r\n",
"Hatter’s\t1\r\n",
"He\t14\r\n",
"Heads\t1\r\n",
"Hearts\t1\r\n",
"Hearts,\t5\r\n",
"Her\t3\r\n",
"Here\t5\r\n",
"Him,\t1\r\n",
"His\t1\r\n",
"How\t9\r\n",
"However,\t14\r\n",
"Hush!’\t1\r\n",
"I\t260\r\n",
"I!’\t2\r\n",
"I,\t1\r\n",
"I,’\t1\r\n",
"I--’\t1\r\n",
"I.\t1\r\n",
"I?\t1\r\n",
"IF\t1\r\n",
"II.\t1\r\n",
"III.\t1\r\n",
"IMPLIED,\t1\r\n",
"IN\t5\r\n",
"INCIDENTAL\t1\r\n",
"INCLUDING\t1\r\n",
"INDEMNITY\t1\r\n",
"INDIRECT,\t1\r\n",
"INSIDE,\t1\r\n",
"IRS.\t1\r\n",
"IS\t8\r\n",
"IT\t1\r\n",
"IT,’\t1\r\n",
"IT.\t1\r\n",
"ITS\t1\r\n",
"IV.\t1\r\n",
"IX.\t1\r\n",
"If\t17\r\n",
"Imagine\t1\r\n",
"Improve\t1\r\n",
"In\t6\r\n",
"Indeed,\t1\r\n",
"Information\t4\r\n",
"Internal\t1\r\n",
"International\t1\r\n",
"Involved\t1\r\n",
"It\t17\r\n",
"Its\t2\r\n",
"It’ll\t1\r\n",
"It’s\t6\r\n",
"I’LL\t1\r\n",
"I’M\t1\r\n",
"I’d\t7\r\n",
"I’ll\t23\r\n",
"I’m\t36\r\n",
"I’ve\t20\r\n",
"Jack-in-the-box,\t1\r\n",
"June\t1\r\n",
"Just\t5\r\n",
"KIND,\t1\r\n",
"KING\t1\r\n",
"KNOW\t1\r\n",
"King\t27\r\n",
"King,\t15\r\n",
"King.\t12\r\n",
"King:\t2\r\n",
"King;\t3\r\n",
"Kings\t1\r\n",
"King’s\t2\r\n",
"Knave\t7\r\n",
"Knave,\t1\r\n",
"Knave.\t1\r\n",
"LEAVE\t1\r\n",
"LESS,’\t1\r\n",
"LIABILITY,\t1\r\n",
"LIABLE\t1\r\n",
"LICENSE\t2\r\n",
"LIMITED\t3\r\n",
"LITTLE\t2\r\n",
"LOVE).\t1\r\n",
"Lacie,\t1\r\n",
"Lake\t1\r\n",
"Language:\t1\r\n",
"Last\t2\r\n",
"Lastly,\t1\r\n",
"Latin\t1\r\n",
"Latitude\t2\r\n",
"Laughing\t1\r\n",
"Let\t6\r\n",
"Lewis\t4\r\n",
"License\t8\r\n",
"License.\t2\r\n",
"Like\t1\r\n",
"Literary\t13\r\n",
"Little\t1\r\n",
"Lizard\t2\r\n",
"Lizard)\t1\r\n",
"Lizard,\t2\r\n",
"Lizard’s\t1\r\n",
"Lobster\t4\r\n",
"Lobster;\t1\r\n",
"London\t1\r\n",
"Long\t1\r\n",
"Longitude\t2\r\n",
"Lory\t3\r\n",
"Lory,\t3\r\n",
"Lory.\t1\r\n",
"Luckily\t1\r\n",
"M,\t1\r\n",
"M--’\t1\r\n",
"M?’\t1\r\n",
"MARMALADE’,\t1\r\n",
"ME,\t1\r\n",
"ME,’\t3\r\n",
"ME.’\t1\r\n",
"MERCHANTIBILITY\t1\r\n",
"ME’\t2\r\n",
"MILE\t1\r\n",
"MILLENNIUM\t1\r\n",
"MINE,’\t1\r\n",
"MINE.’\t1\r\n",
"MORE\t2\r\n",
"MUST\t3\r\n",
"MYSELF,\t1\r\n",
"Ma!’\t1\r\n",
"Mabel\t1\r\n",
"Mabel!\t1\r\n",
"Mabel,\t2\r\n",
"Mad\t1\r\n",
"Magpie\t1\r\n",
"Majesty\t2\r\n",
"Majesty!’\t2\r\n",
"Majesty,’\t7\r\n",
"Majesty?’\t1\r\n",
"Many\t1\r\n",
"March\t31\r\n",
"March,\t2\r\n",
"March--just\t1\r\n",
"March.’\t1\r\n",
"Mary\t3\r\n",
"May\t1\r\n",
"Ma’am,\t1\r\n",
"Melan\t1\r\n",
"Mercia\t2\r\n",
"Michael\t2\r\n",
"Mind\t1\r\n",
"Miss,\t2\r\n",
"Mission\t1\r\n",
"Mississippi\t1\r\n",
"Mock\t56\r\n",
"Morcar,\t2\r\n",
"Most\t1\r\n",
"Mouse\t17\r\n",
"Mouse!’\t1\r\n",
"Mouse,\t8\r\n",
"Mouse.\t2\r\n",
"Mouse’s\t1\r\n",
"Multiplication\t1\r\n",
"My\t1\r\n",
"Mystery,’\t1\r\n",
"NEAR\t1\r\n",
"NEGLIGENCE,\t1\r\n",
"NEVER\t2\r\n",
"NO\t3\r\n",
"NOT\t7\r\n",
"NOT!’\t1\r\n",
"NOT,\t1\r\n",
"NOTICE\t1\r\n",
"Nearly\t1\r\n",
"Never\t1\r\n",
"New\t1\r\n",
"Newby\t1\r\n",
"Next\t2\r\n",
"Nile\t1\r\n",
"No\t2\r\n",
"No,\t4\r\n",
"Nobody\t1\r\n",
"Normans--”\t1\r\n",
"North\t1\r\n",
"Northumbria,\t1\r\n",
"Northumbria--“’\t1\r\n",
"Now\t2\r\n",
"Now,\t1\r\n",
"Number\t1\r\n",
"O\t1\r\n",
"OF\t13\r\n",
"OLD,\t2\r\n",
"ONE\t2\r\n",
"ONE,\t1\r\n",
"ONE.’\t1\r\n",
"OR\t6\r\n",
"OTHER\t1\r\n",
"OURS\t1\r\n",
"OUT\t1\r\n",
"OUTSIDE.’\t1\r\n",
"OWNER,\t1\r\n",
"October\t1\r\n",
"Of\t1\r\n",
"Off\t2\r\n",
"Off--’\t1\r\n",
"Oh\t5\r\n",
"Oh!\t1\r\n",
"Oh,\t3\r\n",
"On\t4\r\n",
"Once\t1\r\n",
"One\t1\r\n",
"One,’\t1\r\n",
"Only\t1\r\n",
"Our\t1\r\n",
"Owl\t2\r\n",
"Owl,\t1\r\n",
"PARAGRAPH\t1\r\n",
"PERSONS\t1\r\n",
"PG\t1\r\n",
"PGLAF),\t1\r\n",
"PLEASE\t2\r\n",
"PLENTY\t1\r\n",
"POSSIBILITY\t1\r\n",
"PRECIOUS\t1\r\n",
"PROJECT\t4\r\n",
"PROVES\t1\r\n",
"PROVIDED\t1\r\n",
"PUNITIVE\t1\r\n",
"PURPOSE.\t1\r\n",
"Panther\t3\r\n",
"Paris\t1\r\n",
"Paris,\t1\r\n",
"Pat!\t1\r\n",
"Pat,\t1\r\n",
"Pennyworth\t2\r\n",
"Pepper\t1\r\n",
"Pig\t1\r\n",
"Pig!’\t1\r\n",
"Pigeon\t5\r\n",
"Pigeon,\t2\r\n",
"Pigeon.\t2\r\n",
"Pigeon;\t2\r\n",
"Pinch\t1\r\n",
"Please\t1\r\n",
"Please,\t1\r\n",
"Pool\t1\r\n",
"Poor\t1\r\n",
"Posting\t1\r\n",
"Pray\t1\r\n",
"Pray,\t1\r\n",
"Presently\t2\r\n",
"Prizes!’\t1\r\n",
"Professor\t1\r\n",
"Project\t78\r\n",
"Public\t1\r\n",
"Puss,’\t1\r\n",
"QUEEN\t1\r\n",
"QUITE\t2\r\n",
"Quadrille\t2\r\n",
"Quadrille,\t1\r\n",
"Quadrille?’\t1\r\n",
"Queen\t34\r\n",
"Queen!\t1\r\n",
"Queen!’\t1\r\n",
"Queen,\t17\r\n",
"Queen,’\t1\r\n",
"Queen.\t11\r\n",
"Queen:\t1\r\n",
"Queen?’\t1\r\n",
"Queens,\t1\r\n",
"Queen’s\t7\r\n",
"Quick,\t1\r\n",
"RABBIT’\t1\r\n",
"READ\t1\r\n",
"RED\t1\r\n",
"REFUND\t1\r\n",
"REMEDIES\t1\r\n",
"REPLACEMENT\t1\r\n",
"RETURNED\t1\r\n",
"RIGHT\t2\r\n",
"Rabbit\t29\r\n",
"Rabbit,\t8\r\n",
"Rabbit-Hole\t1\r\n",
"Rabbit.\t1\r\n",
"Rabbit:\t1\r\n",
"Rabbit;\t1\r\n",
"Rabbit’s\t3\r\n",
"Rabbit’s--‘Pat!\t1\r\n",
"Redistributing\t1\r\n",
"Redistribution\t1\r\n",
"Refund”\t1\r\n",
"Release\t1\r\n",
"Replacement\t1\r\n",
"Revenue\t1\r\n",
"Rome,\t1\r\n",
"Rome--no,\t1\r\n",
"Royalty\t2\r\n",
"Run\t1\r\n",
"S.\t2\r\n",
"SAID\t1\r\n",
"SEND\t1\r\n",
"SHE\t1\r\n",
"SHE,\t1\r\n",
"SHE,’\t1\r\n",
"SHE’S\t1\r\n",
"SHOES.’\t1\r\n",
"SIT\t1\r\n",
"SLUGGARD,”’\t1\r\n",
"SOME\t1\r\n",
"SOMEBODY\t1\r\n",
"SOMETHING\t1\r\n",
"SOMEWHERE,’\t1\r\n",
"SOUP!’\t1\r\n",
"START\t1\r\n",
"START:\t1\r\n",
"STRICT\t1\r\n",
"SUCH\t1\r\n",
"SWIM--”\t1\r\n",
"Said\t4\r\n",
"Salt\t1\r\n",
"Seaography:\t1\r\n",
"Section\t7\r\n",
"Sections\t1\r\n",
"See\t3\r\n",
"Sends\t1\r\n",
"Serpent!’\t1\r\n",
"Service.\t1\r\n",
"Seven\t3\r\n",
"Seven.\t1\r\n",
"Shakespeare,\t1\r\n",
"Shall\t1\r\n",
"Shark,\t1\r\n",
"She\t33\r\n",
"She’ll\t1\r\n",
"Silence\t1\r\n",
"Sing\t1\r\n",
"Sir,\t1\r\n",
"So\t23\r\n",
"Some\t3\r\n",
"Soo--oop\t2\r\n",
"Soo--oop!\t4\r\n",
"Soon\t1\r\n",
"Soup\t4\r\n",
"Soup!\t4\r\n",
"Soup!’\t1\r\n",
"Soup,\t1\r\n",
"Soup,”\t1\r\n",
"Soup?\t2\r\n",
"Special\t1\r\n",
"States\t4\r\n",
"States,\t2\r\n",
"States.\t4\r\n",
"Stigand,\t1\r\n",
"Still\t1\r\n",
"Stole\t1\r\n",
"Stop\t1\r\n",
"Story\t1\r\n",
"Stretching,\t1\r\n",
"Suddenly\t1\r\n",
"Suppress\t1\r\n",
"T!’\t1\r\n",
"THAN\t1\r\n",
"THAT\t8\r\n",
"THAT!’\t1\r\n",
"THAT.\t1\r\n",
"THAT’S\t3\r\n",
"THE\t13\r\n",
"THEIR\t1\r\n",
"THEN--she\t1\r\n",
"THERE\t1\r\n",
"THESE?’\t1\r\n",
"THEY\t1\r\n",
"THINK\t1\r\n",
"THINK,’\t1\r\n",
"THINK;\t1\r\n",
"THIS\t8\r\n",
"THIS!’\t1\r\n",
"THOSE\t1\r\n",
"THROUGH\t1\r\n",
"TO\t5\r\n",
"TOOK\t1\r\n",
"TRADEMARK\t1\r\n",
"TRUE--”\t1\r\n",
"TWO\t1\r\n",
"TWO--”\t1\r\n",
"Table\t1\r\n",
"Take\t1\r\n",
"Tale\t1\r\n",
"Tarts?\t1\r\n",
"Tea-Party\t1\r\n",
"Tears\t1\r\n",
"Tell\t3\r\n",
"Terms\t2\r\n",
"That\t3\r\n",
"That’ll\t1\r\n",
"That’s\t1\r\n",
"The\t100\r\n",
"Then\t9\r\n",
"There\t21\r\n",
"Therefore\t1\r\n",
"There’s\t1\r\n",
"These\t2\r\n",
"They\t10\r\n",
"They’re\t1\r\n",
"This\t20\r\n",
"Those\t1\r\n",
"Though\t1\r\n",
"Thus,\t1\r\n",
"Tillie;\t1\r\n",
"Time\t1\r\n",
"Time!’\t1\r\n",
"Time,\t1\r\n",
"Title:\t1\r\n",
"To\t4\r\n",
"Tortoise\t1\r\n",
"Tortoise,\t1\r\n",
"Tortoise--’\t1\r\n",
"Trims\t1\r\n",
"Turn\t1\r\n",
"Turtle\t33\r\n",
"Turtle,\t8\r\n",
"Turtle--we\t1\r\n",
"Turtle.\t9\r\n",
"Turtle.’\t1\r\n",
"Turtle:\t3\r\n",
"Turtle;\t1\r\n",
"Turtle’s\t2\r\n",
"Twinkle,\t1\r\n",
"Two\t1\r\n",
"Two!’\t1\r\n",
"Two,\t1\r\n",
"Two.\t1\r\n",
"U.S.\t3\r\n",
"UNDER\t1\r\n",
"USE\t1\r\n",
"UT\t1\r\n",
"UTF-8\t1\r\n",
"Ugh,\t1\r\n",
"Uglification,\t1\r\n",
"United\t10\r\n",
"Unless\t1\r\n",
"Updated\t1\r\n",
"Updated:\t1\r\n",
"Use\t2\r\n",
"V.\t1\r\n",
"VERY\t12\r\n",
"VI.\t1\r\n",
"VII.\t1\r\n",
"VIII.\t1\r\n",
"VOICE\t1\r\n",
"Vanilla\t2\r\n",
"Very\t1\r\n",
"Visit\t1\r\n",
"Volunteers\t1\r\n",
"WAISTCOAT-POCKET,\t1\r\n",
"WARRANTIES\t2\r\n",
"WARRANTY\t1\r\n",
"WARRANTY,\t1\r\n",
"WAS\t4\r\n",
"WASHING--extra.”’\t1\r\n",
"WATCH\t1\r\n",
"WHAT\t2\r\n",
"WHAT?\t1\r\n",
"WHAT?’\t3\r\n",
"WHATEVER?’\t1\r\n",
"WILL\t4\r\n",
"WILLIAM,’\t1\r\n",
"WILLIAM,”’\t1\r\n",
"WITH\t1\r\n",
"WONDERLAND\t3\r\n",
"WORK\t1\r\n",
"WOULD\t5\r\n",
"Waiting\t1\r\n",
"Was\t1\r\n",
"We\t2\r\n",
"Web\t3\r\n",
"West,\t1\r\n",
"What\t4\r\n",
"When\t7\r\n",
"Where\t3\r\n",
"Which\t3\r\n",
"While\t6\r\n",
"White\t22\r\n",
"Who\t6\r\n",
"Why,\t7\r\n",
"Will\t4\r\n",
"William\t3\r\n",
"William,’\t1\r\n",
"William’s\t1\r\n",
"With\t2\r\n",
"Wonderland\t2\r\n",
"Wonderland,\t3\r\n",
"Would\t3\r\n",
"Writhing,\t1\r\n",
"X.\t1\r\n",
"XI.\t1\r\n",
"XII.\t1\r\n",
"YET,’\t1\r\n",
"YOU\t13\r\n",
"YOU,\t1\r\n",
"YOU,”’\t1\r\n",
"YOU.--Come,\t1\r\n",
"YOU?’\t2\r\n",
"YOUR\t7\r\n",
"YOURS:\t1\r\n",
"Yet\t3\r\n",
"You\t18\r\n",
"You’re\t2\r\n",
"Zealand\t1\r\n",
"[EBook\t1\r\n",
"[later\t2\r\n",
"[‘I\t2\r\n",
"[‘That’s\t1\r\n",
"[‘the\t1\r\n",
"[‘which\t1\r\n",
"_I_\t2\r\n",
"a\t662\r\n",
"a--I’m\t1\r\n",
"a--’\t1\r\n",
"a-piece\t1\r\n",
"abide\t2\r\n",
"able!\t1\r\n",
"about\t91\r\n",
"about!’\t1\r\n",
"about,\t6\r\n",
"about,’\t1\r\n",
"about.\t1\r\n",
"about;\t1\r\n",
"above\t3\r\n",
"absence,\t1\r\n",
"absurd\t1\r\n",
"absurd,\t1\r\n",
"accept\t1\r\n",
"acceptance\t1\r\n",
"accepted\t1\r\n",
"accepted,\t1\r\n",
"accepting\t1\r\n",
"access\t10\r\n",
"accessed,\t1\r\n",
"accessible\t1\r\n",
"accident\t1\r\n",
"accident,\t1\r\n",
"accidentally\t1\r\n",
"accordance\t2\r\n",
"account\t1\r\n",
"accounting\t1\r\n",
"accounts\t1\r\n",
"accusation!’\t1\r\n",
"accustomed\t1\r\n",
"ache!’\t1\r\n",
"across\t5\r\n",
"act\t1\r\n",
"active\t2\r\n",
"actually\t1\r\n",
"added\t20\r\n",
"added,\t3\r\n",
"adding,\t1\r\n",
"addition\t1\r\n",
"additional\t3\r\n",
"additions\t1\r\n",
"address\t1\r\n",
"addressed\t2\r\n",
"addresses.\t1\r\n",
"addressing\t1\r\n",
"adjourn,\t1\r\n",
"adoption\t1\r\n",
"advance\t1\r\n",
"advance!\t1\r\n",
"advantage\t2\r\n",
"advantage,’\t1\r\n",
"adventures\t2\r\n",
"adventures--beginning\t1\r\n",
"adventures.’\t1\r\n",
"advice,\t1\r\n",
"advisable\t1\r\n",
"advisable--“’\t1\r\n",
"advise\t1\r\n",
"affair,\t1\r\n",
"affectionately\t1\r\n",
"afford\t1\r\n",
"afore\t1\r\n",
"afraid\t9\r\n",
"afraid,\t2\r\n",
"afraid,’\t1\r\n",
"after\t35\r\n",
"after-time,\t1\r\n",
"afterwards,\t1\r\n",
"afterwards.’\t1\r\n",
"again\t13\r\n",
"again!\t1\r\n",
"again!’\t7\r\n",
"again,\t31\r\n",
"again,’\t1\r\n",
"again--“BEFORE\t1\r\n",
"again.\t16\r\n",
"again.)\t1\r\n",
"again.’\t2\r\n",
"again:\t4\r\n",
"again:--\t2\r\n",
"again;\t2\r\n",
"again?’\t2\r\n",
"against\t10\r\n",
"age\t2\r\n",
"age,\t2\r\n",
"agent\t1\r\n",
"ago\t1\r\n",
"ago:\t1\r\n",
"agony\t1\r\n",
"agree\t9\r\n",
"agreed\t1\r\n",
"agreement\t8\r\n",
"agreement,\t6\r\n",
"agreement.\t3\r\n",
"air\t2\r\n",
"air!\t1\r\n",
"air,\t5\r\n",
"air.\t5\r\n",
"air:\t1\r\n",
"airs!\t1\r\n",
"alarm\t1\r\n",
"alarm.\t1\r\n",
"alarmed\t1\r\n",
"alas\t1\r\n",
"alas!\t2\r\n",
"alive\t1\r\n",
"alive!’\t1\r\n",
"alive;\t1\r\n",
"all\t168\r\n",
"all!\t1\r\n",
"all!’\t1\r\n",
"all,\t3\r\n",
"all,’\t3\r\n",
"all.\t4\r\n",
"all.’\t2\r\n",
"all:\t2\r\n",
"all;\t2\r\n",
"all?’\t2\r\n",
"allow\t2\r\n",
"almost\t8\r\n",
"alone\t3\r\n",
"alone!’\t1\r\n",
"alone.\t1\r\n",
"along\t5\r\n",
"along--‘Catch\t1\r\n",
"aloud,\t1\r\n",
"aloud.\t3\r\n",
"aloud;\t1\r\n",
"already\t2\r\n",
"already,\t1\r\n",
"also\t3\r\n",
"also,\t1\r\n",
"alteration,\t1\r\n",
"altered.’\t1\r\n",
"alternate\t1\r\n",
"alternately\t1\r\n",
"altogether\t1\r\n",
"altogether,\t2\r\n",
"altogether.\t1\r\n",
"altogether;\t1\r\n",
"always\t11\r\n",
"am\t13\r\n",
"am!\t1\r\n",
"am,\t1\r\n",
"among\t12\r\n",
"an\t56\r\n",
"ancient\t1\r\n",
"and\t780\r\n",
"and,\t19\r\n",
"and--oh\t2\r\n",
"anger\t1\r\n",
"anger,\t1\r\n",
"angrily\t2\r\n",
"angrily,\t3\r\n",
"angrily.\t3\r\n",
"angrily:\t1\r\n",
"angry\t3\r\n",
"angry,\t1\r\n",
"angry.\t1\r\n",
"animal\t1\r\n",
"animals\t3\r\n",
"animals,\t1\r\n",
"animal’s\t1\r\n",
"annoy,\t1\r\n",
"annoyed,’\t1\r\n",
"another\t21\r\n",
"another!\t1\r\n",
"answer\t6\r\n",
"answer,\t1\r\n",
"answer.\t1\r\n",
"answer?’\t1\r\n",
"answered\t3\r\n",
"answered,\t1\r\n",
"answers.’\t1\r\n",
"anxious\t2\r\n",
"anxious.)\t1\r\n",
"anxiously\t13\r\n",
"anxiously.\t1\r\n",
"any\t67\r\n",
"any)\t1\r\n",
"any,’\t1\r\n",
"any.\t1\r\n",
"anyone\t4\r\n",
"anyone.\t1\r\n",
"anything\t15\r\n",
"anything,\t1\r\n",
"anything.\t1\r\n",
"anything;\t2\r\n",
"anywhere\t3\r\n",
"appealed\t1\r\n",
"appear\t2\r\n",
"appear,\t1\r\n",
"appearance\t1\r\n",
"appeared\t3\r\n",
"appeared,\t3\r\n",
"appeared.\t1\r\n",
"appeared;\t1\r\n",
"appearing\t2\r\n",
"appears,\t1\r\n",
"applause,\t1\r\n",
"apples,\t2\r\n",
"applicable\t3\r\n",
"apply\t1\r\n",
"approach\t1\r\n",
"arch\t1\r\n",
"archbishop\t2\r\n",
"arches\t3\r\n",
"arches.\t1\r\n",
"are\t54\r\n",
"are!\t1\r\n",
"are!’\t1\r\n",
"are,\t2\r\n",
"are,’\t1\r\n",
"are;\t1\r\n",
"argue.\t1\r\n",
"argued\t1\r\n",
"argument\t4\r\n",
"arguments\t1\r\n",
"arise\t1\r\n",
"arm\t7\r\n",
"arm,\t5\r\n",
"arm-chair\t1\r\n",
"arm-in-arm\t1\r\n",
"arms\t5\r\n",
"arms,\t1\r\n",
"around\t2\r\n",
"around,\t1\r\n",
"arranged;\t1\r\n",
"array\t1\r\n",
"arrived,\t1\r\n",
"arrow.\t1\r\n",
"as\t246\r\n",
"as,\t3\r\n",
"ashamed\t2\r\n",
"ask\t7\r\n",
"ask!\t1\r\n",
"ask.\t1\r\n",
"ask.’\t1\r\n",
"ask:\t1\r\n",
"askance--\t1\r\n",
"asked\t8\r\n",
"asked,\t1\r\n",
"asked.\t8\r\n",
"asking\t3\r\n",
"asking!\t1\r\n",
"asking,\t1\r\n",
"asleep\t4\r\n",
"asleep,\t2\r\n",
"asleep,’\t1\r\n",
"asleep.\t1\r\n",
"assembled\t2\r\n",
"assistance\t1\r\n",
"associated\t7\r\n",
"associated)\t1\r\n",
"at\t211\r\n",
"at!”\t1\r\n",
"ate\t1\r\n",
"atom\t2\r\n",
"attached\t1\r\n",
"attempt\t1\r\n",
"attempted\t1\r\n",
"attempts\t1\r\n",
"attended\t1\r\n",
"attending\t2\r\n",
"attending!’\t1\r\n",
"attends\t1\r\n",
"audibly.\t1\r\n",
"authority\t2\r\n",
"available\t1\r\n",
"avoid\t1\r\n",
"away\t17\r\n",
"away!’\t2\r\n",
"away,\t3\r\n",
"away,’\t1\r\n",
"away--you\t1\r\n",
"away.\t3\r\n",
"away:\t1\r\n",
"awfully\t1\r\n",
"axes,’\t1\r\n",
"axis--’\t1\r\n",
"baby\t6\r\n",
"baby,\t3\r\n",
"baby--the\t1\r\n",
"baby:\t1\r\n",
"baby;\t1\r\n",
"baby?’\t1\r\n",
"back\t29\r\n",
"back!’\t2\r\n",
"back,\t4\r\n",
"back-somersault\t1\r\n",
"back.\t2\r\n",
"backs\t1\r\n",
"bad\t1\r\n",
"bad,\t1\r\n",
"bag,\t1\r\n",
"baked\t1\r\n",
"balanced\t1\r\n",
"balls\t1\r\n",
"bank,\t2\r\n",
"bank--the\t1\r\n",
"banks,\t1\r\n",
"banquet--]\t1\r\n",
"bark\t2\r\n",
"barking\t1\r\n",
"barley-sugar\t1\r\n",
"barrowful\t2\r\n",
"based\t2\r\n",
"bat!\t1\r\n",
"bat,\t1\r\n",
"bat?’\t1\r\n",
"bathing\t1\r\n",
"bats\t1\r\n",
"bats,\t1\r\n",
"bats?\t1\r\n",
"bats?’\t1\r\n",
"bawled\t1\r\n",
"be\t154\r\n",
"be!’\t1\r\n",
"be,\t1\r\n",
"be,’\t3\r\n",
"be.’\t1\r\n",
"be?’\t2\r\n",
"beak--\t1\r\n",
"bear:\t1\r\n",
"bear?--Mind\t1\r\n",
"beast,\t1\r\n",
"beasts\t1\r\n",
"beasts,\t1\r\n",
"beat\t4\r\n",
"beating\t1\r\n",
"beating.\t1\r\n",
"beauti--FUL\t1\r\n",
"beautiful\t8\r\n",
"beautifully\t2\r\n",
"beautify\t1\r\n",
"became\t2\r\n",
"because\t12\r\n",
"become\t5\r\n",
"becoming.\t1\r\n",
"bed!’\t1\r\n",
"beds\t1\r\n",
"been\t36\r\n",
"been,\t1\r\n",
"been.\t1\r\n",
"before\t20\r\n",
"before,\t11\r\n",
"before,’\t3\r\n",
"before.\t2\r\n",
"before.’\t1\r\n",
"beg\t7\r\n",
"began\t47\r\n",
"began,\t6\r\n",
"began.\t3\r\n",
"began:\t1\r\n",
"began:--\t1\r\n",
"begged\t1\r\n",
"begin\t7\r\n",
"begin,\t1\r\n",
"begin.’\t3\r\n",
"begin?’\t1\r\n",
"beginning\t12\r\n",
"beginning!’\t1\r\n",
"beginning,’\t1\r\n",
"begins\t4\r\n",
"begun\t6\r\n",
"begun.’\t1\r\n",
"beheaded!’\t2\r\n",
"beheaded,\t1\r\n",
"beheading\t1\r\n",
"behind\t12\r\n",
"behind?’\t1\r\n",
"being\t19\r\n",
"believe\t8\r\n",
"believe.’\t1\r\n",
"believed\t1\r\n",
"belong\t1\r\n",
"belongs\t2\r\n",
"beloved\t1\r\n",
"below\t1\r\n",
"below!’\t1\r\n",
"below,\t1\r\n",
"below.\t3\r\n",
"belt\t1\r\n",
"bend\t1\r\n",
"bend,\t1\r\n",
"bent\t1\r\n",
"besides\t1\r\n",
"besides,\t1\r\n",
"best\t7\r\n",
"best,\t2\r\n",
"best.\t1\r\n",
"better\t11\r\n",
"better,’\t1\r\n",
"better.’\t1\r\n",
"better’;\t1\r\n",
"between\t5\r\n",
"be”--or\t1\r\n",
"bill,\t1\r\n",
"binary,\t1\r\n",
"bird\t1\r\n",
"bird,’\t1\r\n",
"birds\t7\r\n",
"birds!\t1\r\n",
"birds,)\t1\r\n",
"birthday\t1\r\n",
"bit\t8\r\n",
"bit!’\t1\r\n",
"bit,\t2\r\n",
"bit,’\t2\r\n",
"bit.\t2\r\n",
"bit.’\t1\r\n",
"bite,’\t1\r\n",
"bite.\t1\r\n",
"bitter--and--and\t1\r\n",
"blacking,\t1\r\n",
"blades\t1\r\n",
"blame\t1\r\n",
"blasts\t2\r\n",
"bleeds;\t1\r\n",
"blew\t2\r\n",
"blow\t2\r\n",
"blown\t1\r\n",
"blows\t1\r\n",
"body\t2\r\n",
"boldly:\t1\r\n",
"bone\t1\r\n",
"bones\t1\r\n",
"book\t3\r\n",
"book,\t2\r\n",
"book,’\t2\r\n",
"book-shelves;\t1\r\n",
"books,\t1\r\n",
"boon,\t1\r\n",
"boots\t2\r\n",
"bore\t1\r\n",
"both\t16\r\n",
"bother\t1\r\n",
"bottle\t7\r\n",
"bottle,\t2\r\n",
"bottle.\t1\r\n",
"bottom\t4\r\n",
"bough\t1\r\n",
"bound\t3\r\n",
"bowed\t3\r\n",
"bowed,\t1\r\n",
"bowing\t1\r\n",
"box\t3\r\n",
"box--\t1\r\n",
"boxed\t1\r\n",
"boy,\t2\r\n",
"boy--and\t1\r\n",
"brain;\t1\r\n",
"branch\t1\r\n",
"branches\t1\r\n",
"branches,\t1\r\n",
"brass\t1\r\n",
"brave\t1\r\n",
"bread-and-butter\t2\r\n",
"bread-and-butter,\t2\r\n",
"bread-and-butter--’\t1\r\n",
"bread-and-butter.\t1\r\n",
"bread-knife.’\t1\r\n",
"break\t1\r\n",
"break.\t1\r\n",
"breath,\t3\r\n",
"breath.”\t1\r\n",
"breathe\t1\r\n",
"breathe.’\t1\r\n",
"breathe”!’\t1\r\n",
"breeze\t1\r\n",
"bright\t7\r\n",
"bright-eyed\t1\r\n",
"brightened\t2\r\n",
"bring\t2\r\n",
"bringing\t3\r\n",
"bristling\t1\r\n",
"broke\t2\r\n",
"broken\t5\r\n",
"broken.\t1\r\n",
"brother’s\t1\r\n",
"brought\t3\r\n",
"brown\t1\r\n",
"brown,\t1\r\n",
"brush,\t1\r\n",
"brushing\t1\r\n",
"burn\t2\r\n",
"burning\t1\r\n",
"burnt,\t1\r\n",
"burst\t1\r\n",
"bursting\t1\r\n",
"busily\t4\r\n",
"business\t3\r\n",
"business!’\t2\r\n",
"business,\t1\r\n",
"business,’\t1\r\n",
"business?’\t1\r\n",
"[email protected].\t1\r\n",
"busy\t1\r\n",
"but\t105\r\n",
"but,\t6\r\n",
"butter\t1\r\n",
"butter,\t1\r\n",
"butter,’\t1\r\n",
"buttercup\t1\r\n",
"buttered\t1\r\n",
"butterfly,\t1\r\n",
"buttons,\t1\r\n",
"by\t72\r\n",
"by--the\t1\r\n",
"cackled\t1\r\n",
"cake,\t2\r\n",
"cake.\t1\r\n",
"cakes\t1\r\n",
"cakes,\t1\r\n",
"cakes,’\t1\r\n",
"calculate\t1\r\n",
"calculated\t1\r\n",
"call\t5\r\n",
"called\t15\r\n",
"calling\t1\r\n",
"calmly,\t1\r\n",
"came\t38\r\n",
"came,\t2\r\n",
"camomile\t1\r\n",
"can\t37\r\n",
"can,’\t1\r\n",
"can--’\t1\r\n",
"can;--but\t1\r\n",
"candle\t2\r\n",
"candle.\t1\r\n",
"cannot\t5\r\n",
"canvas\t1\r\n",
"can’t\t27\r\n",
"capering\t1\r\n",
"capital\t4\r\n",
"card\t1\r\n",
"cardboard.)\t1\r\n",
"cards!’\t1\r\n",
"cards,\t1\r\n",
"cards:\t1\r\n",
"care\t4\r\n",
"carefully,\t3\r\n",
"cares\t2\r\n",
"carried\t4\r\n",
"carrier,’\t1\r\n",
"carry\t2\r\n",
"carrying\t2\r\n",
"cart-horse,\t1\r\n",
"cartwheels,\t1\r\n",
"case\t4\r\n",
"case,’\t1\r\n",
"cat\t7\r\n",
"cat!\t1\r\n",
"cat,’\t1\r\n",
"cat.\t1\r\n",
"cat.)\t1\r\n",
"catch\t3\r\n",
"catching\t2\r\n",
"caterpillar,\t1\r\n",
"cats\t9\r\n",
"cats!’\t1\r\n",
"cats.’\t1\r\n",
"cats:\t1\r\n",
"cats?’\t1\r\n",
"cattle\t1\r\n",
"caught\t3\r\n",
"cauldron\t2\r\n",
"cause\t3\r\n",
"cause,\t1\r\n",
"cause.\t1\r\n",
"caused\t2\r\n",
"cautiously\t2\r\n",
"cautiously:\t1\r\n",
"cease\t1\r\n",
"ceiling,\t1\r\n",
"centre\t1\r\n",
"certain\t4\r\n",
"certain!\t1\r\n",
"certainly\t8\r\n",
"certainly,’\t3\r\n",
"certainly:\t2\r\n",
"chains,\t1\r\n",
"chance\t4\r\n",
"chanced\t1\r\n",
"change\t9\r\n",
"change,\t2\r\n",
"change.\t1\r\n",
"change:\t1\r\n",
"changed\t7\r\n",
"changed,\t1\r\n",
"changes\t2\r\n",
"changing\t2\r\n",
"character,\t1\r\n",
"charge\t6\r\n",
"charges\t1\r\n",
"charges.\t1\r\n",
"charitable\t1\r\n",
"charities\t1\r\n",
"chatte?’\t1\r\n",
"cheap\t1\r\n",
"cheated\t1\r\n",
"check\t2\r\n",
"checked\t3\r\n",
"checks,\t1\r\n",
"cheeks,\t1\r\n",
"cheered,\t2\r\n",
"cheered.\t1\r\n",
"cheerfully\t1\r\n",
"cherry-tart,\t1\r\n",
"chief\t1\r\n",
"child\t3\r\n",
"child!’\t2\r\n",
"child,\t1\r\n",
"child,’\t1\r\n",
"child-life,\t1\r\n",
"child:\t1\r\n",
"child;\t1\r\n",
"child?’\t1\r\n",
"childhood:\t1\r\n",
"children\t5\r\n",
"children,\t3\r\n",
"children.\t1\r\n",
"children;\t1\r\n",
"chimney\t2\r\n",
"chimney!’\t1\r\n",
"chimney,\t2\r\n",
"chimney?--Nay,\t1\r\n",
"chimneys\t1\r\n",
"chin\t4\r\n",
"chin.\t2\r\n",
"chin:\t1\r\n",
"choice!’\t1\r\n",
"choice,\t1\r\n",
"choke\t1\r\n",
"choked\t3\r\n",
"choking\t1\r\n",
"choose\t1\r\n",
"choosing\t1\r\n",
"chorus\t2\r\n",
"chorus,\t1\r\n",
"chose\t1\r\n",
"chose,’\t1\r\n",
"chrysalis--you\t1\r\n",
"chuckled.\t1\r\n",
"circle,\t1\r\n",
"circumstances.\t1\r\n",
"civil\t2\r\n",
"civil,\t1\r\n",
"claim\t1\r\n",
"clamour\t1\r\n",
"clapping\t1\r\n",
"clasped\t1\r\n",
"claws\t1\r\n",
"claws,\t1\r\n",
"clean\t1\r\n",
"clear\t2\r\n",
"cleared\t1\r\n",
"clearer\t1\r\n",
"clearly\t1\r\n",
"clearly,’\t1\r\n",
"clever\t1\r\n",
"clever?’\t1\r\n",
"climb\t1\r\n",
"clinging\t1\r\n",
"clock\t1\r\n",
"clock.\t1\r\n",
"close\t12\r\n",
"close,\t1\r\n",
"closed\t2\r\n",
"closely\t1\r\n",
"closer\t1\r\n",
"clubs;\t1\r\n",
"coast\t1\r\n",
"coaxing\t1\r\n",
"coaxing.\t1\r\n",
"codes\t1\r\n",
"cold\t1\r\n",
"collected\t2\r\n",
"collection\t3\r\n",
"collection.\t1\r\n",
"come\t22\r\n",
"come,\t2\r\n",
"come.\t1\r\n",
"comes\t1\r\n",
"comes,\t1\r\n",
"comfits,\t1\r\n",
"comfits:\t1\r\n",
"comfort,\t1\r\n",
"comfortable,\t1\r\n",
"comfortably\t1\r\n",
"coming\t5\r\n",
"coming!’\t1\r\n",
"coming.\t2\r\n",
"commercial\t1\r\n",
"committed\t1\r\n",
"common\t1\r\n",
"commotion\t1\r\n",
"company\t1\r\n",
"compilation\t1\r\n",
"complained\t1\r\n",
"complaining\t1\r\n",
"completely.\t1\r\n",
"compliance\t3\r\n",
"compliance.\t1\r\n",
"comply\t6\r\n",
"complying\t3\r\n",
"compressed,\t1\r\n",
"computer\t2\r\n",
"computers\t1\r\n",
"computers.\t1\r\n",
"concept\t2\r\n",
"concerning\t2\r\n",
"concert\t1\r\n",
"concert!’\t1\r\n",
"concluded\t2\r\n",
"conclusion\t1\r\n",
"conclusion,\t1\r\n",
"condemn\t1\r\n",
"conduct\t1\r\n",
"confirmation\t1\r\n",
"confirmed\t1\r\n",
"confused\t3\r\n",
"confused,\t1\r\n",
"confusing\t2\r\n",
"confusing.’\t1\r\n",
"confusion\t3\r\n",
"confusion,\t2\r\n",
"conger-eel,\t1\r\n",
"conquest.\t1\r\n",
"consented\t1\r\n",
"consider\t1\r\n",
"considerable\t2\r\n",
"considered\t3\r\n",
"considering\t3\r\n",
"constant\t3\r\n",
"consultation\t1\r\n",
"contact\t3\r\n",
"contain\t2\r\n",
"containing\t1\r\n",
"contempt.\t1\r\n",
"contemptuous\t1\r\n",
"contemptuously.\t2\r\n",
"content\t1\r\n",
"continued\t7\r\n",
"continued,\t2\r\n",
"contradicted\t1\r\n",
"contributions\t1\r\n",
"conversation\t4\r\n",
"conversation.\t5\r\n",
"conversations\t1\r\n",
"conversations?’\t1\r\n",
"convert\t1\r\n",
"cook\t8\r\n",
"cook,\t2\r\n",
"cook.\t3\r\n",
"cool\t2\r\n",
"copied\t2\r\n",
"copies\t7\r\n",
"copy\t8\r\n",
"copy,\t4\r\n",
"copying\t2\r\n",
"copying,\t2\r\n",
"copyright\t12\r\n",
"corner\t1\r\n",
"corner,\t2\r\n",
"corner--No,\t1\r\n",
"corners:\t1\r\n",
"corporation\t1\r\n",
"corrupt\t1\r\n",
"cost\t3\r\n",
"cost,\t1\r\n",
"costs\t2\r\n",
"could\t63\r\n",
"could,\t7\r\n",
"could.\t4\r\n",
"couldn’t\t9\r\n",
"counting\t1\r\n",
"countries\t1\r\n",
"country\t3\r\n",
"couple?’\t1\r\n",
"couples:\t1\r\n",
"courage\t1\r\n",
"courage,\t1\r\n",
"courage.\t1\r\n",
"course\t11\r\n",
"course,\t6\r\n",
"course,’\t5\r\n",
"course--“I\t1\r\n",
"course.’\t1\r\n",
"course;\t1\r\n",
"course?’\t1\r\n",
"court\t5\r\n",
"court!\t1\r\n",
"court!’\t1\r\n",
"court,\t5\r\n",
"court,”\t1\r\n",
"court.\t3\r\n",
"court;\t1\r\n",
"courtiers,\t1\r\n",
"courtiers;\t1\r\n",
"coward!’\t1\r\n",
"crab,\t1\r\n",
"crash\t1\r\n",
"crash)--‘Now,\t1\r\n",
"crash,\t1\r\n",
"crashed\t1\r\n",
"crawled\t1\r\n",
"crawling\t1\r\n",
"crazy!’\t1\r\n",
"created\t2\r\n",
"creating\t3\r\n",
"creation\t1\r\n",
"creature\t2\r\n",
"creature,\t2\r\n",
"creatures\t6\r\n",
"creatures,\t1\r\n",
"creatures,’\t1\r\n",
"creatures.\t1\r\n",
"credit\t1\r\n",
"creep\t1\r\n",
"crept\t1\r\n",
"cried\t18\r\n",
"cried.\t2\r\n",
"cries\t1\r\n",
"crimson\t2\r\n",
"critical\t1\r\n",
"crocodile\t1\r\n",
"croquet\t3\r\n",
"croquet-ground\t1\r\n",
"croquet-ground.\t1\r\n",
"croquet.’\t2\r\n",
"croquet?’\t1\r\n",
"croqueted\t1\r\n",
"croqueting\t1\r\n",
"cross,\t1\r\n",
"cross-examine\t2\r\n",
"crossed\t3\r\n",
"crossly:\t1\r\n",
"crouched\t1\r\n",
"crowd\t4\r\n",
"crowded\t5\r\n",
"crown\t2\r\n",
"crown.\t1\r\n",
"crumbs\t1\r\n",
"crumbs,’\t1\r\n",
"crumbs.’\t1\r\n",
"cry\t3\r\n",
"crying\t2\r\n",
"cucumber-frame,\t1\r\n",
"cucumber-frames\t1\r\n",
"cunning\t1\r\n",
"cup\t1\r\n",
"cup,’\t1\r\n",
"cupboards\t2\r\n",
"cur,\t1\r\n",
"curiosity,\t2\r\n",
"curiosity.\t3\r\n",
"curious\t16\r\n",
"curious!’\t1\r\n",
"curious,\t1\r\n",
"curious.’\t1\r\n",
"curiouser!’\t1\r\n",
"curled\t2\r\n",
"curls\t1\r\n",
"curly\t1\r\n",
"currants.\t1\r\n",
"current\t1\r\n",
"curtain\t1\r\n",
"curtsey\t1\r\n",
"curving\t1\r\n",
"cushion,\t1\r\n",
"cushion;\t1\r\n",
"custard,\t1\r\n",
"custody\t2\r\n",
"cut\t5\r\n",
"cutting,’\t1\r\n",
"dainties\t1\r\n",
"daisies,\t1\r\n",
"daisy-chain\t1\r\n",
"damage\t1\r\n",
"damaged\t1\r\n",
"damages,\t1\r\n",
"damages.\t1\r\n",
"dance\t2\r\n",
"dance,’\t1\r\n",
"dance.\t5\r\n",
"dance?\t4\r\n",
"dance?”’\t1\r\n",
"dancing\t1\r\n",
"dancing.’\t1\r\n",
"dare\t5\r\n",
"daresay\t1\r\n",
"dark\t3\r\n",
"darkness\t1\r\n",
"data,\t1\r\n",
"date\t2\r\n",
"dates\t1\r\n",
"daughter\t1\r\n",
"day\t11\r\n",
"day!\t1\r\n",
"day!’\t1\r\n",
"day,\t4\r\n",
"day,’\t1\r\n",
"day--’\t1\r\n",
"day-school,\t1\r\n",
"day.\t3\r\n",
"day.’\t1\r\n",
"day:\t1\r\n",
"day;\t1\r\n",
"days\t6\r\n",
"days.\t1\r\n",
"days.’\t1\r\n",
"dead\t4\r\n",
"deal\t11\r\n",
"deal:\t1\r\n",
"dear\t6\r\n",
"dear!\t9\r\n",
"dear!’\t3\r\n",
"dear!”\t1\r\n",
"dear,\t6\r\n",
"dear,’\t1\r\n",
"dear:\t1\r\n",
"dear?’\t1\r\n",
"dears\t1\r\n",
"dears!\t1\r\n",
"dears?\t1\r\n",
"death.”’\t1\r\n",
"decided\t3\r\n",
"decidedly\t1\r\n",
"decidedly,\t3\r\n",
"declare\t1\r\n",
"declare,\t1\r\n",
"declared\t1\r\n",
"deductible\t1\r\n",
"deep\t5\r\n",
"deep,\t2\r\n",
"deepest\t1\r\n",
"deeply\t1\r\n",
"deeply,\t2\r\n",
"deeply.\t1\r\n",
"defect\t2\r\n",
"defective\t2\r\n",
"defective,\t1\r\n",
"delay\t1\r\n",
"deletions\t1\r\n",
"delight\t1\r\n",
"delight,\t2\r\n",
"delighted\t2\r\n",
"delightful\t2\r\n",
"demand\t1\r\n",
"denial;\t1\r\n",
"denied\t1\r\n",
"denied,\t1\r\n",
"denies\t1\r\n",
"deny\t2\r\n",
"denying\t1\r\n",
"depends\t2\r\n",
"derivative\t3\r\n",
"derive\t1\r\n",
"derived\t1\r\n",
"described\t1\r\n",
"deserved\t1\r\n",
"despair\t1\r\n",
"desperate\t1\r\n",
"desperately:\t1\r\n",
"destroy\t2\r\n",
"detach\t1\r\n",
"determine\t1\r\n",
"diamonds,\t1\r\n",
"did\t50\r\n",
"did!’\t1\r\n",
"did,\t3\r\n",
"did,’\t3\r\n",
"did.\t1\r\n",
"did:\t1\r\n",
"didn’t\t11\r\n",
"didn’t!’\t2\r\n",
"didn’t,’\t1\r\n",
"die.\t1\r\n",
"died\t1\r\n",
"different\t5\r\n",
"different!’\t2\r\n",
"different,\t1\r\n",
"different,’\t1\r\n",
"different.\t1\r\n",
"difficult\t2\r\n",
"difficulties,\t1\r\n",
"difficulty\t3\r\n",
"difficulty,\t1\r\n",
"dig\t1\r\n",
"digging\t2\r\n",
"diligently\t1\r\n",
"dinn--’\t1\r\n",
"dinner!’\t1\r\n",
"dinner,\t1\r\n",
"dipped\t2\r\n",
"directed\t2\r\n",
"direction\t2\r\n",
"direction,\t1\r\n",
"direction,’\t2\r\n",
"directions\t1\r\n",
"directions,\t2\r\n",
"directly\t1\r\n",
"directly,\t1\r\n",
"directly.\t1\r\n",
"disagree\t1\r\n",
"disappeared.\t1\r\n",
"disappeared;\t1\r\n",
"disappointment\t1\r\n",
"disclaim\t1\r\n",
"disclaimer\t2\r\n",
"disclaimers\t1\r\n",
"discontinue\t1\r\n",
"discover\t1\r\n",
"discovered\t1\r\n",
"disgust,\t1\r\n",
"dish\t3\r\n",
"dish?\t1\r\n",
"dishes\t1\r\n",
"dishes.\t1\r\n",
"disk\t1\r\n",
"dismay,\t1\r\n",
"disobey,\t1\r\n",
"display,\t1\r\n",
"displayed,\t1\r\n",
"displaying\t2\r\n",
"displaying,\t2\r\n",
"dispute\t2\r\n",
"distance\t1\r\n",
"distance,\t4\r\n",
"distance--but\t1\r\n",
"distance.\t2\r\n",
"distant\t2\r\n",
"distribute\t5\r\n",
"distributed\t3\r\n",
"distributed:\t1\r\n",
"distributing\t6\r\n",
"distributing,\t1\r\n",
"distribution\t6\r\n",
"dive\t1\r\n",
"do\t60\r\n",
"do!’\t3\r\n",
"do,\t7\r\n",
"do,’\t4\r\n",
"do.\t2\r\n",
"do.’\t2\r\n",
"do.”\t1\r\n",
"do:\t1\r\n",
"do:--\t1\r\n",
"do?’\t1\r\n",
"dodged\t1\r\n",
"does\t4\r\n",
"does,\t1\r\n",
"does.\t1\r\n",
"does.’\t1\r\n",
"doesn’t\t16\r\n",
"dog\t2\r\n",
"dogs\t1\r\n",
"dogs.’\t1\r\n",
"dogs?’\t1\r\n",
"dog’s\t1\r\n",
"doing\t3\r\n",
"doing!’\t1\r\n",
"doing?’\t1\r\n",
"domain\t7\r\n",
"donate\t1\r\n",
"donate,\t1\r\n",
"donate.\t1\r\n",
"donation\t1\r\n",
"donations\t11\r\n",
"donations.\t1\r\n",
"done\t10\r\n",
"done,\t1\r\n",
"done,’\t2\r\n",
"done.\t1\r\n",
"done.’\t1\r\n",
"donors\t1\r\n",
"don’t\t48\r\n",
"don’t!’\t1\r\n",
"door\t15\r\n",
"door,\t9\r\n",
"door--\t1\r\n",
"door--I\t1\r\n",
"door.\t2\r\n",
"door:\t1\r\n",
"door;\t1\r\n",
"doors\t2\r\n",
"doorway;\t1\r\n",
"doth\t2\r\n",
"double\t1\r\n",
"doubled-up\t1\r\n",
"doubling\t1\r\n",
"doubt\t1\r\n",
"doubt,\t2\r\n",
"doubt:\t1\r\n",
"doubtful\t2\r\n",
"doubtfully,\t1\r\n",
"doubtfully:\t1\r\n",
"down\t77\r\n",
"down!\t2\r\n",
"down!’\t1\r\n",
"down,\t12\r\n",
"down,’\t3\r\n",
"down--Here,\t1\r\n",
"down.\t2\r\n",
"down:\t1\r\n",
"downloading,\t1\r\n",
"downward!\t1\r\n",
"downwards,\t1\r\n",
"doze;\t1\r\n",
"dozing\t1\r\n",
"draggled\t1\r\n",
"draw\t4\r\n",
"draw,\t1\r\n",
"draw,’\t1\r\n",
"draw?’\t1\r\n",
"drawing\t1\r\n",
"dreadful\t1\r\n",
"dreadful,’\t1\r\n",
"dreadfully\t6\r\n",
"dream\t3\r\n",
"dream!’\t1\r\n",
"dream,\t1\r\n",
"dream.\t1\r\n",
"dream:--\t1\r\n",
"dreamed\t1\r\n",
"dreaming\t1\r\n",
"dreamy\t1\r\n",
"dressed,\t1\r\n",
"drew\t5\r\n",
"dried\t1\r\n",
"driest\t1\r\n",
"drink\t4\r\n",
"drinking.\t1\r\n",
"dripping\t1\r\n",
"drive\t1\r\n",
"drop\t1\r\n",
"dropped\t4\r\n",
"dropped,\t1\r\n",
"dropping\t1\r\n",
"drowned\t1\r\n",
"drunk\t2\r\n",
"dry\t7\r\n",
"dry,\t1\r\n",
"duck\t1\r\n",
"dull\t2\r\n",
"dull!’\t1\r\n",
"dunce?\t1\r\n",
"e--e--evening,\t3\r\n",
"e-mail)\t1\r\n",
"eBook\t5\r\n",
"eBook,\t1\r\n",
"eBooks\t3\r\n",
"eBooks,\t2\r\n",
"eBooks.\t2\r\n",
"each\t8\r\n",
"eager\t3\r\n",
"eagerly\t3\r\n",
"eagerly,\t3\r\n",
"eagerly.\t1\r\n",
"eagerly:\t1\r\n",
"ear\t2\r\n",
"ear,\t1\r\n",
"ear.\t3\r\n",
"earls\t2\r\n",
"earnestly,\t1\r\n",
"earnestly.\t1\r\n",
"ears\t4\r\n",
"ears--’\t1\r\n",
"earth\t1\r\n",
"earth!\t1\r\n",
"earth.\t2\r\n",
"easily\t4\r\n",
"easy\t2\r\n",
"easy.\t1\r\n",
"eat\t16\r\n",
"eaten\t1\r\n",
"eating\t1\r\n",
"eats\t1\r\n",
"eat”\t1\r\n",
"edge\t3\r\n",
"edition.\t1\r\n",
"editions\t5\r\n",
"editions,\t1\r\n",
"educational\t1\r\n",
"educations--in\t1\r\n",
"eel\t1\r\n",
"eels,\t1\r\n",
"effect\t1\r\n",
"effect,\t1\r\n",
"effect:\t1\r\n",
"effort\t1\r\n",
"effort,\t1\r\n",
"efforts\t2\r\n",
"efforts,\t1\r\n",
"egg!’\t1\r\n",
"eggs\t1\r\n",
"eggs,\t3\r\n",
"eggs,’\t1\r\n",
"either\t6\r\n",
"either!’\t1\r\n",
"either,\t2\r\n",
"elbow\t2\r\n",
"elbow.’\t1\r\n",
"elbows\t1\r\n",
"elect\t1\r\n",
"electronic\t27\r\n",
"electronically\t1\r\n",
"electronically,\t1\r\n",
"elegant\t1\r\n",
"eleventh\t1\r\n",
"else\t8\r\n",
"else.\t2\r\n",
"else’s\t1\r\n",
"else”--but,\t1\r\n",
"email\t2\r\n",
"emphasis,\t1\r\n",
"employee\t1\r\n",
"employees\t2\r\n",
"empty:\t1\r\n",
"encoding:\t1\r\n",
"encourage\t1\r\n",
"encouraged\t1\r\n",
"encouraging\t2\r\n",
"end\t12\r\n",
"end!\t1\r\n",
"end,\t1\r\n",
"end,’\t1\r\n",
"end.’\t1\r\n",
"end:\t1\r\n",
"ending\t1\r\n",
"energetic\t1\r\n",
"engaged\t1\r\n",
"engraved\t1\r\n",
"enjoy\t1\r\n",
"enormous\t1\r\n",
"enough\t10\r\n",
"enough!’\t1\r\n",
"enough,\t2\r\n",
"enough,’\t1\r\n",
"enough--I\t1\r\n",
"enough.’\t1\r\n",
"enough;\t2\r\n",
"ensuring\t1\r\n",
"entangled\t2\r\n",
"entirely\t2\r\n",
"entity\t3\r\n",
"entrance\t1\r\n",
"equipment\t1\r\n",
"equipment.\t2\r\n",
"errors,\t1\r\n",
"escape\t1\r\n",
"escape!’\t1\r\n",
"escape,\t1\r\n",
"escape;\t1\r\n",
"especially\t1\r\n",
"est\t1\r\n",
"even\t18\r\n",
"evening,\t2\r\n",
"ever\t16\r\n",
"ever,’\t2\r\n",
"ever:\t1\r\n",
"ever;\t1\r\n",
"every\t12\r\n",
"everybody\t5\r\n",
"everything\t9\r\n",
"everything’s\t1\r\n",
"evidence\t3\r\n",
"evidence,’\t3\r\n",
"evidently\t1\r\n",
"exact\t1\r\n",
"exactly\t5\r\n",
"examining\t1\r\n",
"excellent\t2\r\n",
"except\t4\r\n",
"exclaimed\t4\r\n",
"exclaimed,\t1\r\n",
"exclaimed.\t1\r\n",
"exclamation\t1\r\n",
"exclusion\t1\r\n",
"execute\t1\r\n",
"executed\t2\r\n",
"executed,\t3\r\n",
"executed.’\t1\r\n",
"executes\t1\r\n",
"execution--once\t1\r\n",
"execution.\t1\r\n",
"execution.’\t1\r\n",
"executioner\t3\r\n",
"executioner,\t1\r\n",
"executioner:\t1\r\n",
"executioner’s\t1\r\n",
"executions\t2\r\n",
"exempt\t2\r\n",
"existence;\t1\r\n",
"exists\t1\r\n",
"expected:\t1\r\n",
"expecting\t3\r\n",
"expend\t1\r\n",
"expense\t1\r\n",
"expenses,\t2\r\n",
"experiment\t1\r\n",
"experiment?’\t1\r\n",
"explain\t8\r\n",
"explained,’\t1\r\n",
"explanation\t1\r\n",
"explanation.\t2\r\n",
"explanation;\t1\r\n",
"exporting\t1\r\n",
"expressing\t1\r\n",
"expression\t1\r\n",
"extent\t1\r\n",
"extraordinary\t2\r\n",
"extras?’\t1\r\n",
"extremely\t1\r\n",
"extremely--’\t1\r\n",
"eye\t4\r\n",
"eye,\t1\r\n",
"eye;\t2\r\n",
"eyelids,\t1\r\n",
"eyes\t18\r\n",
"eyes,\t5\r\n",
"eyes--and\t1\r\n",
"eyes.\t2\r\n",
"eyes.--‘Tell\t1\r\n",
"eyes:\t1\r\n",
"eyes;\t1\r\n",
"face\t7\r\n",
"face,\t4\r\n",
"face--and\t1\r\n",
"face.\t3\r\n",
"faces\t2\r\n",
"faces,\t2\r\n",
"faces.\t1\r\n",
"facility:\t1\r\n",
"fact\t2\r\n",
"fact,\t4\r\n",
"fact.\t1\r\n",
"fact.’\t1\r\n",
"fading\t1\r\n",
"failure.\t1\r\n",
"faint\t1\r\n",
"faintly\t1\r\n",
"fair\t1\r\n",
"fairly,’\t1\r\n",
"fairy-tales,\t1\r\n",
"fall\t6\r\n",
"fall,\t1\r\n",
"fallen\t4\r\n",
"falling\t2\r\n",
"familiarly\t1\r\n",
"family\t1\r\n",
"fan\t8\r\n",
"fan!\t1\r\n",
"fan,\t1\r\n",
"fancied\t2\r\n",
"fancy\t3\r\n",
"fancy,\t2\r\n",
"fancy--Who’s\t1\r\n",
"fancying\t1\r\n",
"fanned\t1\r\n",
"fanning\t1\r\n",
"far\t9\r\n",
"far!”\t1\r\n",
"far,\t1\r\n",
"far,’\t2\r\n",
"farm-yard--while\t1\r\n",
"farmer,\t1\r\n",
"farther\t1\r\n",
"fashion,\t1\r\n",
"fashion.’\t1\r\n",
"fast\t4\r\n",
"faster\t1\r\n",
"faster,\t1\r\n",
"faster?”\t1\r\n",
"fat;\t1\r\n",
"father,\t1\r\n",
"father;\t1\r\n",
"favoured\t1\r\n",
"favourite\t1\r\n",
"fear\t4\r\n",
"feared\t1\r\n",
"feather\t1\r\n",
"feathers,\t1\r\n",
"federal\t2\r\n",
"fee\t8\r\n",
"feeble\t1\r\n",
"feeble,\t1\r\n",
"feebly\t1\r\n",
"feel\t8\r\n",
"feeling\t6\r\n",
"feeling!’\t1\r\n",
"feelings\t1\r\n",
"feelings.\t1\r\n",
"fees\t2\r\n",
"fees,\t1\r\n",
"fees.\t1\r\n",
"feet\t11\r\n",
"feet!\t1\r\n",
"feet!’\t1\r\n",
"feet,\t6\r\n",
"fell\t6\r\n",
"fellow!\t1\r\n",
"fellow!’\t1\r\n",
"fellow?\t1\r\n",
"fellow?’\t1\r\n",
"fellows\t1\r\n",
"felt\t23\r\n",
"ferrets\t1\r\n",
"ferrets!\t1\r\n",
"fetch\t5\r\n",
"few\t10\r\n",
"fidgeted.\t1\r\n",
"field\t1\r\n",
"fifteen\t1\r\n",
"fifth\t1\r\n",
"fig?’\t1\r\n",
"fight\t2\r\n",
"fighting\t1\r\n",
"figure\t1\r\n",
"figure!’\t1\r\n",
"figure,’\t1\r\n",
"figures!’\t1\r\n",
"file\t2\r\n",
"files\t2\r\n",
"filled\t3\r\n",
"fills\t1\r\n",
"financial\t1\r\n",
"find\t20\r\n",
"find?’\t1\r\n",
"finding\t3\r\n",
"finds\t1\r\n",
"fine\t2\r\n",
"finger\t3\r\n",
"finger,\t1\r\n",
"finger;\t1\r\n",
"finish\t4\r\n",
"finish,\t1\r\n",
"finished\t7\r\n",
"finished,\t2\r\n",
"finished,’\t1\r\n",
"finished.\t1\r\n",
"finished.’\t1\r\n",
"finishing\t1\r\n",
"fire,\t3\r\n",
"fire-irons\t1\r\n",
"fireplace\t1\r\n",
"first\t28\r\n",
"first!’\t1\r\n",
"first,\t7\r\n",
"first,’\t2\r\n",
"first--they\t1\r\n",
"first--verdict\t1\r\n",
"first.\t1\r\n",
"first.’\t1\r\n",
"first;\t2\r\n",
"fish\t2\r\n",
"fish)--and\t1\r\n",
"fish,\t1\r\n",
"fishes\t1\r\n",
"fit)\t1\r\n",
"fits,\t1\r\n",
"fitted!\t1\r\n",
"five\t1\r\n",
"fix\t2\r\n",
"fixed\t1\r\n",
"flame\t1\r\n",
"flamingo\t2\r\n",
"flamingo,\t1\r\n",
"flamingo.\t1\r\n",
"flamingo:\t1\r\n",
"flamingoes,\t1\r\n",
"flapper\t1\r\n",
"flappers,\t1\r\n",
"flashed\t1\r\n",
"flat\t1\r\n",
"flat,\t1\r\n",
"flavour\t1\r\n",
"flew\t1\r\n",
"flinging\t1\r\n",
"flock\t1\r\n",
"floor,\t2\r\n",
"floor:\t1\r\n",
"flower-beds\t1\r\n",
"flower-pot\t1\r\n",
"flowers\t2\r\n",
"flown\t1\r\n",
"flung\t1\r\n",
"flurry\t1\r\n",
"flustered\t1\r\n",
"fluttered\t1\r\n",
"fly\t1\r\n",
"fly,\t1\r\n",
"fly;\t1\r\n",
"flying\t1\r\n",
"folded\t1\r\n",
"folded,\t2\r\n",
"folding\t1\r\n",
"follow\t2\r\n",
"follow,\t1\r\n",
"followed\t8\r\n",
"following\t3\r\n",
"follows\t2\r\n",
"follows:--\t1\r\n",
"fond\t3\r\n",
"fond--of--of\t1\r\n",
"foolish\t1\r\n",
"foot\t5\r\n",
"foot!\t1\r\n",
"foot,\t2\r\n",
"foot.\t1\r\n",
"footman\t3\r\n",
"footmen,\t1\r\n",
"footsteps\t1\r\n",
"footsteps,\t1\r\n",
"for\t146\r\n",
"for,\t2\r\n",
"for.’\t1\r\n",
"for?’\t2\r\n",
"for?”’\t1\r\n",
"forehead\t2\r\n",
"forepaws\t1\r\n",
"forget\t2\r\n",
"forgetting\t3\r\n",
"forgot\t2\r\n",
"forgotten\t6\r\n",
"fork\t1\r\n",
"form\t2\r\n",
"form,\t1\r\n",
"form.\t2\r\n",
"format\t4\r\n",
"formats\t2\r\n",
"forth\t8\r\n",
"fortunately\t1\r\n",
"forwards\t1\r\n",
"found\t31\r\n",
"found:\t1\r\n",
"fountains,\t1\r\n",
"fountains.\t1\r\n",
"four\t6\r\n",
"fourth.’\t1\r\n",
"free\t7\r\n",
"free,\t1\r\n",
"freely\t4\r\n",
"friend\t2\r\n",
"friend.\t1\r\n",
"friends\t2\r\n",
"fright\t1\r\n",
"fright.\t1\r\n",
"frighten\t1\r\n",
"frightened\t7\r\n",
"frog\t1\r\n",
"frog;\t1\r\n",
"from\t45\r\n",
"from,’\t1\r\n",
"from.\t1\r\n",
"from:\t1\r\n",
"from?’\t1\r\n",
"front\t2\r\n",
"frontispiece\t1\r\n",
"frowning\t3\r\n",
"frowning,\t1\r\n",
"frying-pan\t1\r\n",
"full\t16\r\n",
"fumbled\t1\r\n",
"fun\t1\r\n",
"fun!’\t1\r\n",
"fun?’\t1\r\n",
"funny\t3\r\n",
"fur\t2\r\n",
"fur.\t1\r\n",
"furious\t1\r\n",
"furiously,\t1\r\n",
"furrow\t1\r\n",
"furrows;\t1\r\n",
"further\t2\r\n",
"further.\t1\r\n",
"further:\t1\r\n",
"fury,\t1\r\n",
"future\t3\r\n",
"gained\t1\r\n",
"gallons\t1\r\n",
"game\t6\r\n",
"game,\t2\r\n",
"game,’\t1\r\n",
"game.\t1\r\n",
"game.’\t1\r\n",
"games\t1\r\n",
"game’s\t1\r\n",
"garden\t4\r\n",
"garden!’\t1\r\n",
"garden,\t5\r\n",
"garden--how\t1\r\n",
"garden.\t3\r\n",
"garden.”’\t1\r\n",
"garden:\t1\r\n",
"gardeners\t4\r\n",
"gardeners,\t4\r\n",
"gather\t1\r\n",
"gave\t13\r\n",
"gay\t1\r\n",
"gazing\t1\r\n",
"[email protected]\t1\r\n",
"general\t3\r\n",
"generally\t5\r\n",
"generally,\t2\r\n",
"generations\t1\r\n",
"generations.\t1\r\n",
"gently\t3\r\n",
"get\t43\r\n",
"getting\t21\r\n",
"getting!’\t1\r\n",
"get”\t1\r\n",
"giddy.’\t2\r\n",
"girl\t3\r\n",
"girl,’\t1\r\n",
"girls\t3\r\n",
"give\t12\r\n",
"given\t2\r\n",
"giving\t2\r\n",
"glad\t11\r\n",
"glanced\t1\r\n",
"glaring\t1\r\n",
"glass\t4\r\n",
"glass,\t2\r\n",
"glass.\t1\r\n",
"glass.)\t1\r\n",
"glass;\t1\r\n",
"globe\t1\r\n",
"gloomily:\t1\r\n",
"gloves\t5\r\n",
"gloves,\t3\r\n",
"gloves--that\t1\r\n",
"gloves.\t1\r\n",
"gloves:\t1\r\n",
"go\t38\r\n",
"go!\t1\r\n",
"go,\t4\r\n",
"go,’\t2\r\n",
"go.\t1\r\n",
"go?”\t1\r\n",
"goals\t1\r\n",
"goes\t7\r\n",
"going\t26\r\n",
"going,\t1\r\n",
"golden\t7\r\n",
"goldfish\t2\r\n",
"gone\t9\r\n",
"gone,\t3\r\n",
"gone.\t1\r\n",
"good\t23\r\n",
"good,\t1\r\n",
"good-natured,\t1\r\n",
"good-naturedly\t1\r\n",
"goose!\t1\r\n",
"goose,\t1\r\n",
"got\t45\r\n",
"govern\t1\r\n",
"graceful\t1\r\n",
"grand\t2\r\n",
"grand,\t1\r\n",
"grant\t1\r\n",
"granted\t1\r\n",
"grass\t2\r\n",
"grass,\t2\r\n",
"gratefully\t1\r\n",
"grave\t3\r\n",
"gravely,\t2\r\n",
"gravely.\t1\r\n",
"gravy,\t1\r\n",
"grazed\t1\r\n",
"great\t39\r\n",
"green\t3\r\n",
"green,\t1\r\n",
"grew\t1\r\n",
"grey\t1\r\n",
"grin\t1\r\n",
"grin,\t3\r\n",
"grin,’\t1\r\n",
"grin.’\t1\r\n",
"grinned\t2\r\n",
"grinned;\t1\r\n",
"grinning\t1\r\n",
"grins\t1\r\n",
"gross\t1\r\n",
"ground\t2\r\n",
"ground,\t1\r\n",
"ground--and\t1\r\n",
"ground.’\t1\r\n",
"group\t1\r\n",
"grow\t13\r\n",
"growing\t6\r\n",
"growing,\t4\r\n",
"growing.’\t1\r\n",
"growl\t1\r\n",
"growl,\t2\r\n",
"growled\t1\r\n",
"growling,’\t1\r\n",
"growls\t1\r\n",
"grown\t7\r\n",
"grumbled:\t1\r\n",
"grunt,’\t1\r\n",
"grunted\t3\r\n",
"grunted,\t1\r\n",
"guard\t1\r\n",
"guess\t2\r\n",
"guess,\t1\r\n",
"guessed\t3\r\n",
"guests\t2\r\n",
"guests,\t1\r\n",
"guilt,’\t1\r\n",
"guinea-pig\t1\r\n",
"guinea-pig,\t1\r\n",
"guinea-pigs\t1\r\n",
"guinea-pigs!’\t1\r\n",
"guinea-pigs,\t2\r\n",
"had\t175\r\n",
"had!’\t1\r\n",
"had,\t1\r\n",
"hadn’t\t7\r\n",
"hair\t5\r\n",
"hair!\t1\r\n",
"hair.”\t1\r\n",
"half\t21\r\n",
"half-past\t1\r\n",
"hall\t1\r\n",
"hall,\t5\r\n",
"hall.\t1\r\n",
"hall:\t1\r\n",
"hall;\t1\r\n",
"hand\t11\r\n",
"hand,\t6\r\n",
"hand,’\t1\r\n",
"hand.\t1\r\n",
"handed\t3\r\n",
"hands\t6\r\n",
"hands,\t5\r\n",
"hands;\t1\r\n",
"handsome\t1\r\n",
"handwriting?’\t1\r\n",
"hanging\t3\r\n",
"happen\t5\r\n",
"happen,\t1\r\n",
"happen,’\t1\r\n",
"happen:\t1\r\n",
"happened\t3\r\n",
"happened,\t2\r\n",
"happened.\t1\r\n",
"happened.)\t1\r\n",
"happening.\t1\r\n",
"happens\t2\r\n",
"happens!’\t1\r\n",
"happens.\t1\r\n",
"happens;\t1\r\n",
"happy\t1\r\n",
"hard\t8\r\n",
"hardly\t11\r\n",
"harm\t1\r\n",
"harmless\t1\r\n",
"has\t8\r\n",
"hasn’t\t2\r\n",
"haste,\t1\r\n",
"hastily\t7\r\n",
"hastily,\t4\r\n",
"hastily.\t4\r\n",
"hastily;\t1\r\n",
"hat,’\t1\r\n",
"hatching\t1\r\n",
"hate\t1\r\n",
"hate--C\t1\r\n",
"hatter.’\t1\r\n",
"hatters\t1\r\n",
"have\t77\r\n",
"haven’t\t7\r\n",
"haven’t,’\t1\r\n",
"having\t10\r\n",
"he\t96\r\n",
"he?’\t1\r\n",
"head\t29\r\n",
"head!\t1\r\n",
"head!’\t7\r\n",
"head!”’\t1\r\n",
"head,\t3\r\n",
"head--\t1\r\n",
"head--Brandy\t1\r\n",
"head.\t5\r\n",
"head:\t1\r\n",
"heads\t7\r\n",
"heads!’\t1\r\n",
"heads.\t1\r\n",
"head’s\t1\r\n",
"heap\t1\r\n",
"hear\t15\r\n",
"heard\t29\r\n",
"heard!’\t1\r\n",
"hearing\t3\r\n",
"hearing.\t1\r\n",
"heart\t2\r\n",
"hearth\t1\r\n",
"hearts.\t1\r\n",
"heavy\t2\r\n",
"hedge!’\t1\r\n",
"hedge.\t1\r\n",
"hedgehog\t5\r\n",
"hedgehog,\t1\r\n",
"hedgehog.\t1\r\n",
"hedgehogs\t1\r\n",
"hedgehogs,\t1\r\n",
"hedgehogs;\t1\r\n",
"hedges,’\t1\r\n",
"heels\t1\r\n",
"height\t4\r\n",
"height.\t1\r\n",
"held\t4\r\n",
"help\t11\r\n",
"help,\t1\r\n",
"helped\t1\r\n",
"helpless\t1\r\n",
"her\t203\r\n",
"her,\t18\r\n",
"her,’\t1\r\n",
"her.\t13\r\n",
"her:\t5\r\n",
"her;\t3\r\n",
"here\t14\r\n",
"here!\t2\r\n",
"here!’\t1\r\n",
"here,\t6\r\n",
"here,’\t5\r\n",
"here.\t2\r\n",
"here.’\t2\r\n",
"here;\t1\r\n",
"here?\t2\r\n",
"here?’\t4\r\n",
"hers\t3\r\n",
"hers--she\t1\r\n",
"herself\t40\r\n",
"herself,\t31\r\n",
"herself.\t8\r\n",
"herself;\t4\r\n",
"he’d\t1\r\n",
"he’ll\t1\r\n",
"he’s\t1\r\n",
"hid\t1\r\n",
"hide\t1\r\n",
"high\t3\r\n",
"high).\t1\r\n",
"high,\t3\r\n",
"high,’\t2\r\n",
"high.\t3\r\n",
"high:\t3\r\n",
"highest\t1\r\n",
"him\t21\r\n",
"him!\t2\r\n",
"him),\t1\r\n",
"him,\t4\r\n",
"him,)\t1\r\n",
"him,’\t2\r\n",
"him--How\t1\r\n",
"him--it\t1\r\n",
"him.\t2\r\n",
"him:\t3\r\n",
"him;\t1\r\n",
"himself\t4\r\n",
"himself,\t1\r\n",
"himself:\t1\r\n",
"hint\t1\r\n",
"hint;\t1\r\n",
"hippopotamus,\t1\r\n",
"his\t93\r\n",
"hiss\t1\r\n",
"histories\t1\r\n",
"history\t1\r\n",
"history,\t4\r\n",
"history,’\t1\r\n",
"history.\t1\r\n",
"hit\t2\r\n",
"hoarse\t2\r\n",
"hoarse,\t1\r\n",
"hoarsely\t1\r\n",
"hold\t7\r\n",
"holder\t1\r\n",
"holder),\t1\r\n",
"holder,\t1\r\n",
"holder.\t1\r\n",
"holding\t2\r\n",
"holding,\t1\r\n",
"holiday?’\t1\r\n",
"hollow\t1\r\n",
"home\t1\r\n",
"home!\t1\r\n",
"home,’\t1\r\n",
"home;\t1\r\n",
"home?’\t1\r\n",
"honest\t1\r\n",
"honour!’\t2\r\n",
"honour,\t1\r\n",
"honour:\t1\r\n",
"hookah\t4\r\n",
"hookah,\t1\r\n",
"hope\t4\r\n",
"hoped)\t1\r\n",
"hopeful\t1\r\n",
"hopeless\t1\r\n",
"hoping\t3\r\n",
"hot\t4\r\n",
"hot,\t1\r\n",
"hot-tempered,’\t1\r\n",
"hour\t2\r\n",
"hours\t3\r\n",
"hours,\t1\r\n",
"house\t8\r\n",
"house!’\t1\r\n",
"house,\t9\r\n",
"housemaid,’\t1\r\n",
"houses,\t1\r\n",
"how\t41\r\n",
"however,\t6\r\n",
"howled\t1\r\n",
"howling\t3\r\n",
"http://gutenberg.org/license).\t1\r\n",
"http://pglaf.org\t2\r\n",
"http://pglaf.org/donate\t1\r\n",
"http://pglaf.org/fundraising.\t1\r\n",
"http://www.gutenberg.org\t1\r\n",
"http://www.gutenberg.org/1/11/\t1\r\n",
"http://www.pglaf.org.\t1\r\n",
"humble\t1\r\n",
"humbly:\t1\r\n",
"humbly;\t1\r\n",
"hundred\t1\r\n",
"hundreds\t1\r\n",
"hung\t1\r\n",
"hungry\t2\r\n",
"hungry,\t1\r\n",
"hunting\t3\r\n",
"hurried\t11\r\n",
"hurriedly\t2\r\n",
"hurry\t4\r\n",
"hurry,\t1\r\n",
"hurry.\t3\r\n",
"hurry:\t1\r\n",
"hurry;\t2\r\n",
"hurrying\t1\r\n",
"hurt\t2\r\n",
"hurt,\t1\r\n",
"hush!’\t1\r\n",
"hypertext\t1\r\n",
"idea\t14\r\n",
"idea,’\t1\r\n",
"identification\t1\r\n",
"identify,\t1\r\n",
"idiotic!’\t1\r\n",
"if\t73\r\n",
"if--if\t1\r\n",
"ignorant\t1\r\n",
"ill.’\t2\r\n",
"imagine\t1\r\n",
"imitated\t1\r\n",
"immediate\t3\r\n",
"immediately\t3\r\n",
"immense\t1\r\n",
"impatient\t1\r\n",
"impatiently,\t2\r\n",
"impatiently:\t2\r\n",
"impatiently;\t1\r\n",
"impertinent,’\t1\r\n",
"implied\t1\r\n",
"important\t4\r\n",
"important,’\t1\r\n",
"imposed\t1\r\n",
"impossible\t2\r\n",
"impossible.\t1\r\n",
"in\t401\r\n",
"in.\t1\r\n",
"in.’\t1\r\n",
"in:\t2\r\n",
"in?’\t3\r\n",
"inaccurate\t1\r\n",
"incessantly\t1\r\n",
"inches\t6\r\n",
"inclined\t1\r\n",
"include\t1\r\n",
"included\t2\r\n",
"included.\t1\r\n",
"includes\t1\r\n",
"including\t7\r\n",
"incomplete,\t1\r\n",
"increasing\t1\r\n",
"indeed\t3\r\n",
"indeed!’\t6\r\n",
"indeed,\t1\r\n",
"indeed,’\t2\r\n",
"indeed.\t1\r\n",
"indeed:\t1\r\n",
"indeed:--\t1\r\n",
"indemnify\t1\r\n",
"indicate\t1\r\n",
"indicating\t1\r\n",
"indignant\t1\r\n",
"indignantly,\t1\r\n",
"indignantly.\t3\r\n",
"indirectly\t1\r\n",
"individual\t4\r\n",
"information\t2\r\n",
"information:\t1\r\n",
"infringement,\t1\r\n",
"injure\t1\r\n",
"ink,\t1\r\n",
"inkstand\t1\r\n",
"inquired\t1\r\n",
"inquisitively,\t1\r\n",
"inside,\t1\r\n",
"insolence\t1\r\n",
"instance,\t3\r\n",
"instantly\t3\r\n",
"instantly,\t2\r\n",
"instead\t2\r\n",
"instead!’\t1\r\n",
"insult\t1\r\n",
"intellectual\t2\r\n",
"interest\t1\r\n",
"interesting\t3\r\n",
"interesting,\t1\r\n",
"interesting.\t1\r\n",
"interpreted\t1\r\n",
"interrupt\t1\r\n",
"interrupted\t5\r\n",
"interrupted,\t2\r\n",
"interrupted.\t1\r\n",
"interrupted:\t1\r\n",
"interrupting\t2\r\n",
"into\t67\r\n",
"introduce\t2\r\n",
"introduced\t1\r\n",
"invalidity\t1\r\n",
"invent\t1\r\n",
"invented\t1\r\n",
"invitation\t2\r\n",
"invited\t1\r\n",
"invited,’\t1\r\n",
"inwards,\t1\r\n",
"irritated\t1\r\n",
"is\t89\r\n",
"is!\t1\r\n",
"is!’\t3\r\n",
"is,\t16\r\n",
"is,’\t2\r\n",
"is--oh\t1\r\n",
"is--’\t1\r\n",
"is--“Be\t1\r\n",
"is--“Birds\t1\r\n",
"is--“Oh,\t1\r\n",
"is--“Take\t1\r\n",
"is--“The\t1\r\n",
"is.’\t3\r\n",
"is?’\t1\r\n",
"isn’t\t6\r\n",
"isn’t,’\t1\r\n",
"it\t356\r\n",
"it!\t1\r\n",
"it!--That\t1\r\n",
"it!’\t7\r\n",
"it),\t2\r\n",
"it,\t41\r\n",
"it,)\t1\r\n",
"it,’\t18\r\n",
"it--once\t1\r\n",
"it--’\t1\r\n",
"it.\t15\r\n",
"it.)\t2\r\n",
"it.’\t9\r\n",
"it:\t9\r\n",
"it;\t9\r\n",
"it?)\t1\r\n",
"it?’\t11\r\n",
"its\t60\r\n",
"itself\t8\r\n",
"itself,\t4\r\n",
"itself,)\t1\r\n",
"itself.\t1\r\n",
"it’ll\t6\r\n",
"it’s\t25\r\n",
"jar\t2\r\n",
"jaw,\t1\r\n",
"jaws\t1\r\n",
"jaws!’\t1\r\n",
"jelly-fish\t1\r\n",
"jogged\t1\r\n",
"join\t9\r\n",
"joined\t2\r\n",
"joined):--\t1\r\n",
"journey,\t1\r\n",
"joys,\t1\r\n",
"judge,\t3\r\n",
"judge,’\t1\r\n",
"judging\t1\r\n",
"jumped\t5\r\n",
"jumped;\t1\r\n",
"jumping\t4\r\n",
"juror\t1\r\n",
"jurors\t3\r\n",
"jurors.’\t1\r\n",
"jury\t9\r\n",
"jury,\t4\r\n",
"jury,”\t1\r\n",
"jury--’\t1\r\n",
"jury-box\t1\r\n",
"jury-box,\t2\r\n",
"jury-box,’\t1\r\n",
"jury.\t2\r\n",
"jurymen\t2\r\n",
"jurymen.\t2\r\n",
"just\t43\r\n",
"justice\t1\r\n",
"keep\t10\r\n",
"keep,\t1\r\n",
"keeping\t4\r\n",
"kept\t13\r\n",
"kettle\t1\r\n",
"key\t5\r\n",
"key,\t3\r\n",
"key;\t1\r\n",
"kick\t2\r\n",
"kick,\t1\r\n",
"kid\t5\r\n",
"kill\t1\r\n",
"killing\t1\r\n",
"kills\t1\r\n",
"kind\t6\r\n",
"kind,’\t1\r\n",
"kindly\t1\r\n",
"kindly,\t1\r\n",
"king,’\t1\r\n",
"kiss\t1\r\n",
"kissed\t1\r\n",
"kitchen\t2\r\n",
"kitchen,\t1\r\n",
"kitchen.\t1\r\n",
"knee\t1\r\n",
"knee,\t3\r\n",
"knee.\t1\r\n",
"kneel\t1\r\n",
"knelt\t1\r\n",
"knew\t13\r\n",
"knew)\t1\r\n",
"knew,\t1\r\n",
"knife\t1\r\n",
"knife,\t1\r\n",
"knock,\t1\r\n",
"knocked.\t1\r\n",
"knocking,\t1\r\n",
"knocking,’\t2\r\n",
"knot!’\t1\r\n",
"knot,\t1\r\n",
"know\t45\r\n",
"know!’\t2\r\n",
"know,\t7\r\n",
"know,’\t8\r\n",
"know--No\t1\r\n",
"know--and\t1\r\n",
"know--’\t4\r\n",
"know.\t8\r\n",
"know.’\t9\r\n",
"know?’\t2\r\n",
"knowing\t2\r\n",
"knowledge\t1\r\n",
"knowledge,\t1\r\n",
"knowledge.\t1\r\n",
"known\t1\r\n",
"knows\t2\r\n",
"knuckles.\t1\r\n",
"label\t1\r\n",
"label,\t1\r\n",
"labelled\t1\r\n",
"lad!--Here,\t1\r\n",
"ladder?--Why,\t1\r\n",
"lady\t2\r\n",
"lady,’\t1\r\n",
"laid\t2\r\n",
"lamps\t1\r\n",
"land\t1\r\n",
"languid,\t1\r\n",
"lap\t2\r\n",
"large\t32\r\n",
"large,\t1\r\n",
"larger\t3\r\n",
"larger,\t3\r\n",
"larger:\t1\r\n",
"largest\t1\r\n",
"lark,\t1\r\n",
"last\t25\r\n",
"last!’\t1\r\n",
"last,\t5\r\n",
"last:\t1\r\n",
"lasted\t1\r\n",
"lasted.)\t1\r\n",
"late\t3\r\n",
"late!’\t1\r\n",
"late,\t1\r\n",
"late.’\t1\r\n",
"lately,\t1\r\n",
"later.\t1\r\n",
"laugh;\t1\r\n",
"laughed\t1\r\n",
"laughed,\t1\r\n",
"laughing:\t1\r\n",
"laughter.\t1\r\n",
"law\t1\r\n",
"law,\t1\r\n",
"law.\t1\r\n",
"law:\t1\r\n",
"laws\t7\r\n",
"laws.\t1\r\n",
"lay\t4\r\n",
"lazily\t1\r\n",
"lazy\t1\r\n",
"leaders,\t1\r\n",
"leading\t1\r\n",
"leaning\t2\r\n",
"leant\t1\r\n",
"leap\t1\r\n",
"learn\t5\r\n",
"learn!\t2\r\n",
"learn?’\t1\r\n",
"learned\t1\r\n",
"learning\t2\r\n",
"learnt\t2\r\n",
"least\t7\r\n",
"least,\t1\r\n",
"least--at\t1\r\n",
"leave\t6\r\n",
"leaves\t2\r\n",
"leaves,\t2\r\n",
"leaves.\t1\r\n",
"leaves:\t1\r\n",
"leaving\t1\r\n",
"led\t4\r\n",
"ledge\t1\r\n",
"left\t13\r\n",
"left,\t1\r\n",
"lefthand\t2\r\n",
"legal\t2\r\n",
"legally\t1\r\n",
"legs\t3\r\n",
"length\t1\r\n",
"less\t3\r\n",
"lessen\t1\r\n",
"lesson\t1\r\n",
"lesson-book.\t1\r\n",
"lesson-books!’\t1\r\n",
"lessons\t4\r\n",
"lessons!’\t1\r\n",
"lessons,\t1\r\n",
"lessons,’\t2\r\n",
"lessons:\t1\r\n",
"lessons?’\t1\r\n",
"lest\t1\r\n",
"let\t7\r\n",
"letter\t1\r\n",
"letter,\t3\r\n",
"letters.\t1\r\n",
"let’s\t3\r\n",
"liability\t1\r\n",
"liability,\t1\r\n",
"library\t1\r\n",
"license\t1\r\n",
"license,\t2\r\n",
"licensed\t1\r\n",
"licking\t1\r\n",
"lie\t2\r\n",
"lieu\t2\r\n",
"life\t2\r\n",
"life!\t1\r\n",
"life!’\t2\r\n",
"life,\t2\r\n",
"life.\t3\r\n",
"life.’\t1\r\n",
"life;\t1\r\n",
"lifted\t1\r\n",
"like\t74\r\n",
"like!’\t1\r\n",
"like,\t2\r\n",
"like,’\t3\r\n",
"like.’\t1\r\n",
"like:\t1\r\n",
"like?’\t1\r\n",
"liked\t3\r\n",
"liked,\t2\r\n",
"liked.’\t1\r\n",
"likely\t4\r\n",
"likes.’\t1\r\n",
"like”!’\t1\r\n",
"limbs\t1\r\n",
"limitation\t3\r\n",
"limited\t2\r\n",
"line\t1\r\n",
"line:\t1\r\n",
"lines!’\t1\r\n",
"linked\t2\r\n",
"links\t3\r\n",
"lips.\t1\r\n",
"list\t2\r\n",
"list,\t1\r\n",
"listen\t4\r\n",
"listen,\t1\r\n",
"listen.\t2\r\n",
"listened,\t1\r\n",
"listeners\t1\r\n",
"listening,\t2\r\n",
"listening:\t1\r\n",
"lit\t1\r\n",
"little\t117\r\n",
"little!\t1\r\n",
"little!’\t1\r\n",
"little,\t3\r\n",
"little,’\t1\r\n",
"little--“’\t1\r\n",
"little.\t1\r\n",
"live\t7\r\n",
"live.\t1\r\n",
"lived\t3\r\n",
"livery\t1\r\n",
"livery,\t1\r\n",
"livery:\t1\r\n",
"lives\t1\r\n",
"lives.\t1\r\n",
"living\t1\r\n",
"lobster\t1\r\n",
"lobster--’\t1\r\n",
"lobsters\t3\r\n",
"lobsters!’\t1\r\n",
"lobsters,\t3\r\n",
"located\t4\r\n",
"locations\t1\r\n",
"locations.\t1\r\n",
"lock,\t1\r\n",
"locked;\t1\r\n",
"locks\t1\r\n",
"locks,\t1\r\n",
"lodging\t1\r\n",
"lonely\t2\r\n",
"long\t30\r\n",
"long,\t1\r\n",
"long;\t1\r\n",
"longed\t2\r\n",
"longer\t2\r\n",
"longer!’\t1\r\n",
"look\t25\r\n",
"look!\t1\r\n",
"look-out\t1\r\n",
"looked\t45\r\n",
"looking\t30\r\n",
"looking-glass.\t1\r\n",
"loose\t2\r\n",
"lose\t1\r\n",
"losing\t1\r\n",
"lost\t1\r\n",
"lost,\t1\r\n",
"lost:\t1\r\n",
"lot\t1\r\n",
"loud\t3\r\n",
"loud,\t2\r\n",
"loud.\t1\r\n",
"louder\t1\r\n",
"loudly\t2\r\n",
"loudly.\t1\r\n",
"love,\t2\r\n",
"loveliest\t1\r\n",
"lovely\t2\r\n",
"loving\t1\r\n",
"low\t7\r\n",
"low,\t6\r\n",
"low-spirited.\t1\r\n",
"low.\t1\r\n",
"lower,’\t1\r\n",
"lowing\t1\r\n",
"lullaby\t1\r\n",
"lying\t8\r\n",
"m--’\t1\r\n",
"ma\t1\r\n",
"machine\t1\r\n",
"machines\t1\r\n",
"mad\t5\r\n",
"mad,\t1\r\n",
"mad--at\t1\r\n",
"mad.\t2\r\n",
"mad.’\t3\r\n",
"mad?’\t2\r\n",
"made\t29\r\n",
"made.\t1\r\n",
"magic\t1\r\n",
"main\t1\r\n",
"maintaining\t1\r\n",
"make\t29\r\n",
"makes\t12\r\n",
"making\t8\r\n",
"mallets\t1\r\n",
"man\t1\r\n",
"man,\t2\r\n",
"man,’\t1\r\n",
"man.’\t1\r\n",
"manage\t6\r\n",
"manage?’\t1\r\n",
"managed\t3\r\n",
"managed?\t1\r\n",
"managing\t1\r\n",
"manner\t1\r\n",
"manner,\t1\r\n",
"manners\t1\r\n",
"many\t13\r\n",
"maps\t1\r\n",
"marched\t1\r\n",
"mark\t2\r\n",
"mark;\t1\r\n",
"marked\t7\r\n",
"marked,\t1\r\n",
"master\t2\r\n",
"master,\t1\r\n",
"matter\t8\r\n",
"matter,’\t1\r\n",
"matters\t2\r\n",
"maximum\t1\r\n",
"may\t26\r\n",
"maybe,’\t1\r\n",
"mayn’t\t1\r\n",
"me\t46\r\n",
"me!\t3\r\n",
"me,\t3\r\n",
"me,’\t5\r\n",
"me.’\t1\r\n",
"me?\t1\r\n",
"me?’\t2\r\n",
"meal,\t1\r\n",
"mean\t7\r\n",
"mean,\t1\r\n",
"mean,’\t2\r\n",
"meaning\t7\r\n",
"meaning.\t1\r\n",
"means\t5\r\n",
"means,\t1\r\n",
"means--to--make--anything--prettier.’\t1\r\n",
"means.’\t1\r\n",
"meant\t4\r\n",
"meant,’\t1\r\n",
"meanwhile\t1\r\n",
"measure\t1\r\n",
"meat,\t1\r\n",
"medium\t3\r\n",
"medium,\t2\r\n",
"meekly\t1\r\n",
"meekly:\t1\r\n",
"meet\t3\r\n",
"meeting\t1\r\n",
"melancholy\t6\r\n",
"memorandum\t1\r\n",
"memory,\t1\r\n",
"mentioned\t3\r\n",
"merely\t2\r\n",
"merrily\t1\r\n",
"messages\t2\r\n",
"met\t4\r\n",
"method\t1\r\n",
"methods\t1\r\n",
"mice\t3\r\n",
"mice--oh,\t1\r\n",
"middle\t3\r\n",
"middle,\t3\r\n",
"middle-aged\t1\r\n",
"middle.\t1\r\n",
"might\t27\r\n",
"might,\t1\r\n",
"mile\t1\r\n",
"miles\t3\r\n",
"milk\t1\r\n",
"milk-jug\t1\r\n",
"mind\t4\r\n",
"mind!’\t1\r\n",
"mind,\t2\r\n",
"mind,’\t1\r\n",
"mind.’\t1\r\n",
"minded\t1\r\n",
"minding\t1\r\n",
"mine\t3\r\n",
"mine,\t1\r\n",
"mine,’\t1\r\n",
"mine--a\t1\r\n",
"mineral,\t1\r\n",
"minute\t15\r\n",
"minute!’\t1\r\n",
"minute,\t4\r\n",
"minute.\t1\r\n",
"minutes\t7\r\n",
"minutes,\t2\r\n",
"minutes.\t2\r\n",
"mischief,\t1\r\n",
"miserable\t2\r\n",
"miss\t1\r\n",
"missed\t2\r\n",
"mission\t3\r\n",
"mistake\t2\r\n",
"mistake;\t1\r\n",
"mixed\t2\r\n",
"moderate.\t1\r\n",
"modern,\t1\r\n",
"modification,\t1\r\n",
"modified\t1\r\n",
"moment\t21\r\n",
"moment!’\t1\r\n",
"moment,\t5\r\n",
"moment.\t1\r\n",
"moment:\t1\r\n",
"moment’s\t2\r\n",
"money\t3\r\n",
"month\t1\r\n",
"month,\t1\r\n",
"moon,\t1\r\n",
"moral\t6\r\n",
"moral,\t1\r\n",
"morals\t1\r\n",
"more\t38\r\n",
"more!’\t1\r\n",
"more,\t4\r\n",
"more--As\t1\r\n",
"more.\t1\r\n",
"more.’\t1\r\n",
"more:\t1\r\n",
"more;\t1\r\n",
"morning\t1\r\n",
"morning,\t2\r\n",
"morning,’\t1\r\n",
"morning?\t1\r\n",
"morsel\t1\r\n",
"most\t10\r\n",
"mostly\t1\r\n",
"mostly,’\t1\r\n",
"mournful\t1\r\n",
"mournfully.\t1\r\n",
"mouse\t3\r\n",
"mouse!’)\t1\r\n",
"mouse,\t3\r\n",
"mouse--O\t1\r\n",
"mouse--a\t1\r\n",
"mouse--of\t1\r\n",
"mouse--to\t1\r\n",
"mouse-traps,\t1\r\n",
"mouse:\t1\r\n",
"mouse?\t1\r\n",
"mouth\t7\r\n",
"mouth,\t2\r\n",
"mouth;\t1\r\n",
"mouths\t1\r\n",
"mouths--and\t1\r\n",
"mouths.\t1\r\n",
"mouths;\t1\r\n",
"move\t2\r\n",
"move.\t1\r\n",
"moved\t4\r\n",
"moved.\t1\r\n",
"moving\t3\r\n",
"much\t41\r\n",
"much!’\t2\r\n",
"much,\t2\r\n",
"much,’\t5\r\n",
"much.\t1\r\n",
"muchness--you\t1\r\n",
"muchness?’\t1\r\n",
"muchness”--did\t1\r\n",
"muddle\t1\r\n",
"murder\t1\r\n",
"murdering\t1\r\n",
"muscular\t1\r\n",
"mushroom\t4\r\n",
"mushroom,\t3\r\n",
"mushroom,’\t1\r\n",
"music,\t1\r\n",
"music.’\t2\r\n",
"must\t48\r\n",
"must,\t2\r\n",
"must,’\t1\r\n",
"mustard\t2\r\n",
"mustard-mine\t1\r\n",
"muttered\t2\r\n",
"muttering\t3\r\n",
"my\t55\r\n",
"myself\t2\r\n",
"myself,\t1\r\n",
"myself,’\t2\r\n",
"myself.’\t1\r\n",
"name\t9\r\n",
"name,\t1\r\n",
"name:\t1\r\n",
"named\t1\r\n",
"names\t1\r\n",
"names,’\t1\r\n",
"narrow\t1\r\n",
"narrow,\t1\r\n",
"nasty,\t1\r\n",
"natural\t3\r\n",
"natural);\t1\r\n",
"near\t13\r\n",
"near.\t1\r\n",
"nearer\t4\r\n",
"nearer,\t1\r\n",
"nearly\t11\r\n",
"neat\t1\r\n",
"neatly\t2\r\n",
"necessarily\t1\r\n",
"neck\t6\r\n",
"neck,\t1\r\n",
"need,\t1\r\n",
"needn’t\t3\r\n",
"needs\t1\r\n",
"neighbour\t1\r\n",
"neighbouring\t1\r\n",
"neither\t2\r\n",
"nervous\t4\r\n",
"nervous,\t1\r\n",
"nest.\t1\r\n",
"network\t1\r\n",
"never\t37\r\n",
"never!\t1\r\n",
"never!’\t1\r\n",
"never-ending\t1\r\n",
"nevertheless\t1\r\n",
"never’)\t1\r\n",
"new\t7\r\n",
"newsletter\t1\r\n",
"newspapers,\t1\r\n",
"next\t20\r\n",
"next!\t2\r\n",
"next!’\t1\r\n",
"next,\t2\r\n",
"next.\t3\r\n",
"nibbled\t2\r\n",
"nibbling\t3\r\n",
"nice\t5\r\n",
"nice,\t1\r\n",
"nicely\t2\r\n",
"night\t1\r\n",
"night!\t1\r\n",
"night-air\t1\r\n",
"night?\t1\r\n",
"nine\t4\r\n",
"no\t72\r\n",
"no!\t2\r\n",
"no!’\t1\r\n",
"nobody\t3\r\n",
"nobody,\t2\r\n",
"nodded.\t1\r\n",
"noise\t3\r\n",
"noises,\t1\r\n",
"non\t1\r\n",
"none\t3\r\n",
"none,\t1\r\n",
"nonproprietary\t1\r\n",
"nonsense\t1\r\n",
"nonsense!’\t2\r\n",
"nonsense,’\t1\r\n",
"nonsense.\t1\r\n",
"nonsense.’\t1\r\n",
"nor\t2\r\n",
"nose\t1\r\n",
"nose,\t3\r\n",
"nose--\t1\r\n",
"nose.\t1\r\n",
"nose;\t1\r\n",
"nose’;\t1\r\n",
"not\t122\r\n",
"not!’\t1\r\n",
"not,\t9\r\n",
"not,’\t6\r\n",
"not.\t2\r\n",
"not.’\t2\r\n",
"not?’\t1\r\n",
"note-book\t1\r\n",
"note-book,\t1\r\n",
"nothing\t22\r\n",
"nothing,\t2\r\n",
"nothing.\t3\r\n",
"nothing.’\t1\r\n",
"nothing:\t1\r\n",
"nothing;\t1\r\n",
"notice\t7\r\n",
"noticed\t7\r\n",
"noticed,\t1\r\n",
"noticing\t1\r\n",
"notifies\t1\r\n",
"notion\t3\r\n",
"not’;\t1\r\n",
"now\t23\r\n",
"now!\t1\r\n",
"now!’\t3\r\n",
"now,\t6\r\n",
"now,’\t4\r\n",
"now--Don’t\t1\r\n",
"now--but\t1\r\n",
"now.\t1\r\n",
"now.’\t4\r\n",
"now?\t1\r\n",
"now?’\t2\r\n",
"nowhere\t2\r\n",
"number\t7\r\n",
"numerous\t1\r\n",
"nurse\t1\r\n",
"nurse!\t1\r\n",
"nurse--and\t1\r\n",
"nursing\t3\r\n",
"obliged\t3\r\n",
"oblong\t1\r\n",
"obsolete,\t1\r\n",
"obstacle\t1\r\n",
"obtain\t3\r\n",
"obtaining\t2\r\n",
"occasional\t1\r\n",
"occasionally;\t1\r\n",
"occur:\t1\r\n",
"occurred\t2\r\n",
"odd\t1\r\n",
"of\t596\r\n",
"of?’\t3\r\n",
"off\t38\r\n",
"off).\t1\r\n",
"off,\t14\r\n",
"off,’\t1\r\n",
"off.\t5\r\n",
"off.’\t1\r\n",
"off;\t1\r\n",
"off?’\t1\r\n",
"offend\t1\r\n",
"offended\t7\r\n",
"offended!’\t1\r\n",
"offended,\t1\r\n",
"offended.\t1\r\n",
"offer\t2\r\n",
"offers\t1\r\n",
"office\t2\r\n",
"officer\t1\r\n",
"officers\t3\r\n",
"officers:\t1\r\n",
"official\t3\r\n",
"often\t4\r\n",
"often,\t2\r\n",
"oh\t1\r\n",
"oh!\t2\r\n",
"oh,\t3\r\n",
"ointment--one\t1\r\n",
"old\t14\r\n",
"old,\t2\r\n",
"old,’\t3\r\n",
"older\t2\r\n",
"oldest\t1\r\n",
"on\t148\r\n",
"on!’\t6\r\n",
"on!”\t1\r\n",
"on,\t28\r\n",
"on.\t8\r\n",
"on.’\t2\r\n",
"on:\t2\r\n",
"on;\t1\r\n",
"on?\t1\r\n",
"on?’\t2\r\n",
"once\t18\r\n",
"once,\t5\r\n",
"once.\t2\r\n",
"once.’\t2\r\n",
"once:\t1\r\n",
"once;\t1\r\n",
"one\t78\r\n",
"one!\t1\r\n",
"one,\t6\r\n",
"one,’\t3\r\n",
"one--but\t1\r\n",
"one--the\t1\r\n",
"one;\t2\r\n",
"one?’\t1\r\n",
"ones\t1\r\n",
"oneself\t1\r\n",
"one’s\t1\r\n",
"onions.’\t1\r\n",
"online\t4\r\n",
"only\t45\r\n",
"only,\t1\r\n",
"open\t6\r\n",
"open,\t1\r\n",
"opened\t9\r\n",
"opened,\t1\r\n",
"opening\t3\r\n",
"opinion,’\t1\r\n",
"opportunities\t1\r\n",
"opportunity\t9\r\n",
"opposite\t1\r\n",
"or\t137\r\n",
"order\t2\r\n",
"order,’\t1\r\n",
"ordered\t2\r\n",
"ordered.\t1\r\n",
"ordered’;\t1\r\n",
"ordering\t2\r\n",
"organized\t1\r\n",
"original\t1\r\n",
"originator\t1\r\n",
"ornamented\t2\r\n",
"other\t39\r\n",
"other,\t5\r\n",
"other--Bill!\t1\r\n",
"other.\t2\r\n",
"other.’\t1\r\n",
"other:\t3\r\n",
"other;\t2\r\n",
"others\t4\r\n",
"others!’\t1\r\n",
"others.\t3\r\n",
"otherwise\t2\r\n",
"otherwise,\t1\r\n",
"otherwise.”’\t1\r\n",
"ought\t13\r\n",
"ought!\t1\r\n",
"our\t11\r\n",
"ourselves,\t1\r\n",
"out\t97\r\n",
"out,\t13\r\n",
"out-of-the-way\t3\r\n",
"out.\t2\r\n",
"out.”\t1\r\n",
"outdated\t1\r\n",
"outside\t3\r\n",
"outside,\t1\r\n",
"outside,’\t1\r\n",
"outside.\t1\r\n",
"over\t31\r\n",
"over!’\t3\r\n",
"over)\t1\r\n",
"over,\t2\r\n",
"over.\t2\r\n",
"over;\t1\r\n",
"overcome\t1\r\n",
"overhead;\t1\r\n",
"owed\t1\r\n",
"own\t9\r\n",
"own.\t1\r\n",
"owner\t3\r\n",
"owner,\t1\r\n",
"owns\t2\r\n",
"oyster!’\t1\r\n",
"o’clock\t3\r\n",
"pace,’\t1\r\n",
"pack\t4\r\n",
"pack,\t1\r\n",
"page\t2\r\n",
"pages\t1\r\n",
"paid\t6\r\n",
"paint\t1\r\n",
"painting\t2\r\n",
"pair\t5\r\n",
"pairs\t1\r\n",
"pale\t2\r\n",
"pale,\t2\r\n",
"panted\t1\r\n",
"panting,\t2\r\n",
"paper\t4\r\n",
"paper.\t1\r\n",
"paperwork\t1\r\n",
"paragraph\t10\r\n",
"paragraphs\t3\r\n",
"parchment\t2\r\n",
"pardon!’\t4\r\n",
"pardon,\t1\r\n",
"pardon,’\t1\r\n",
"pardoned.’\t1\r\n",
"part\t5\r\n",
"part.’\t1\r\n",
"particular\t3\r\n",
"particular--Here,\t1\r\n",
"particular.\t1\r\n",
"particular;\t1\r\n",
"particularly\t1\r\n",
"partner!’\t1\r\n",
"partners--’\t1\r\n",
"parts\t1\r\n",
"party\t8\r\n",
"party.\t1\r\n",
"pass\t1\r\n",
"passage\t1\r\n",
"passage,\t2\r\n",
"passage:\t1\r\n",
"passed\t4\r\n",
"passed;\t1\r\n",
"passing\t1\r\n",
"passion,\t2\r\n",
"passion.\t1\r\n",
"passionate\t1\r\n",
"past\t1\r\n",
"patience\t1\r\n",
"patiently\t1\r\n",
"patiently.\t1\r\n",
"patriotic\t1\r\n",
"patted\t1\r\n",
"pattering\t3\r\n",
"pattern\t1\r\n",
"pause.\t1\r\n",
"pause:\t1\r\n",
"paused\t1\r\n",
"paw\t1\r\n",
"paw,\t2\r\n",
"paws\t2\r\n",
"paws!\t1\r\n",
"paws.\t1\r\n",
"pay\t1\r\n",
"paying\t2\r\n",
"payments\t3\r\n",
"pebbles\t2\r\n",
"peeped\t3\r\n",
"peeping\t1\r\n",
"peering\t1\r\n",
"pegs.\t1\r\n",
"pence.\t1\r\n",
"pencil\t1\r\n",
"pencils\t1\r\n",
"people\t13\r\n",
"people!\t1\r\n",
"people,’\t1\r\n",
"people.\t1\r\n",
"pepper\t5\r\n",
"pepper-box\t1\r\n",
"perfectly\t4\r\n",
"perform,\t1\r\n",
"performances\t1\r\n",
"performed,\t1\r\n",
"performing,\t3\r\n",
"perhaps\t12\r\n",
"perhaps,’\t1\r\n",
"perhaps?’\t1\r\n",
"periodic\t1\r\n",
"permanent\t1\r\n",
"permission\t6\r\n",
"permission.\t1\r\n",
"permitted\t3\r\n",
"persisted\t1\r\n",
"persisted.\t1\r\n",
"person\t6\r\n",
"person!’\t1\r\n",
"person,\t1\r\n",
"personal\t2\r\n",
"pet:\t1\r\n",
"phrase\t4\r\n",
"physical\t2\r\n",
"picked\t3\r\n",
"picking\t2\r\n",
"picture.)\t1\r\n",
"pictured\t1\r\n",
"pictures\t4\r\n",
"pie\t1\r\n",
"pie--’\t1\r\n",
"pie-crust,\t1\r\n",
"piece\t5\r\n",
"pieces\t2\r\n",
"pieces.\t1\r\n",
"pig,\t4\r\n",
"pig,’\t2\r\n",
"pig-baby\t1\r\n",
"pigeon\t1\r\n",
"pigs\t1\r\n",
"pigs,\t1\r\n",
"pinch\t1\r\n",
"pinched\t2\r\n",
"pine-apple,\t1\r\n",
"pink\t1\r\n",
"piteous\t1\r\n",
"pitied\t1\r\n",
"pity\t1\r\n",
"pity!”?’\t1\r\n",
"pity.\t1\r\n",
"place\t7\r\n",
"place,\t2\r\n",
"placed\t1\r\n",
"places!’\t1\r\n",
"places--ALL,’\t1\r\n",
"plainly\t1\r\n",
"plan\t1\r\n",
"plan!’\t1\r\n",
"plan,\t1\r\n",
"plan.’\t1\r\n",
"planning\t1\r\n",
"plate\t2\r\n",
"plate.\t1\r\n",
"plates\t1\r\n",
"plates,\t1\r\n",
"play\t8\r\n",
"played\t1\r\n",
"players\t2\r\n",
"players,\t2\r\n",
"playing\t2\r\n",
"pleaded\t3\r\n",
"pleasant\t1\r\n",
"pleasanter\t1\r\n",
"please\t9\r\n",
"please!\t1\r\n",
"please,\t3\r\n",
"please:\t1\r\n",
"pleased\t5\r\n",
"pleased,\t1\r\n",
"pleased.\t1\r\n",
"pleases!’\t1\r\n",
"pleasing\t1\r\n",
"pleasure\t2\r\n",
"plenty\t1\r\n",
"pocket\t1\r\n",
"pocket)\t1\r\n",
"pocket,\t2\r\n",
"pocket?’\t1\r\n",
"pointed\t1\r\n",
"pointing\t3\r\n",
"poker\t1\r\n",
"poky\t1\r\n",
"politely\t1\r\n",
"politely,\t3\r\n",
"politely:\t1\r\n",
"politely;\t1\r\n",
"pool\t6\r\n",
"pool,\t2\r\n",
"pool--she\t1\r\n",
"pool?\t1\r\n",
"poor\t25\r\n",
"pop\t1\r\n",
"pope,\t1\r\n",
"porpoise\t1\r\n",
"porpoise,\t1\r\n",
"porpoise.’\t1\r\n",
"porpoise?”’\t1\r\n",
"position\t2\r\n",
"positively\t1\r\n",
"possessed\t1\r\n",
"possession.\t1\r\n",
"possible\t1\r\n",
"possibly\t3\r\n",
"posted\t5\r\n",
"pounds!\t1\r\n",
"pour\t1\r\n",
"poured\t1\r\n",
"powdered\t1\r\n",
"practically\t1\r\n",
"practice\t1\r\n",
"prepare\t1\r\n",
"prepare)\t1\r\n",
"present\t1\r\n",
"present!’\t1\r\n",
"present--at\t1\r\n",
"presented\t1\r\n",
"presents\t2\r\n",
"preserve\t1\r\n",
"pressed\t3\r\n",
"pressing\t1\r\n",
"pretend\t1\r\n",
"pretending\t1\r\n",
"pretexts\t1\r\n",
"pretty\t1\r\n",
"prevent\t2\r\n",
"previous\t1\r\n",
"principal\t1\r\n",
"print\t1\r\n",
"printed\t3\r\n",
"prison,’\t1\r\n",
"prisoner\t1\r\n",
"prisoner’s\t1\r\n",
"prize\t1\r\n",
"prizes.\t1\r\n",
"prizes.’\t1\r\n",
"prizes?’\t1\r\n",
"problem.\t1\r\n",
"proceed,’\t1\r\n",
"proceed.\t1\r\n",
"processing\t1\r\n",
"procession\t2\r\n",
"procession,\t2\r\n",
"procession,’\t1\r\n",
"processions;\t1\r\n",
"produce\t1\r\n",
"produced\t2\r\n",
"producing\t1\r\n",
"production,\t1\r\n",
"profit\t1\r\n",
"profits\t1\r\n",
"prohibition\t1\r\n",
"prominently\t2\r\n",
"promise.\t1\r\n",
"promised\t1\r\n",
"promising,\t1\r\n",
"promoting\t2\r\n",
"promotion\t1\r\n",
"pronounced\t1\r\n",
"proofread\t1\r\n",
"proper\t3\r\n",
"property\t2\r\n",
"proposal.\t1\r\n",
"proprietary\t1\r\n",
"prosecute\t1\r\n",
"protect\t2\r\n",
"protection.\t1\r\n",
"proud\t2\r\n",
"prove\t1\r\n",
"proved\t2\r\n",
"proves\t1\r\n",
"provide\t6\r\n",
"provide,\t1\r\n",
"provided\t3\r\n",
"providing\t4\r\n",
"provision\t1\r\n",
"provisions.\t1\r\n",
"provoking\t1\r\n",
"public\t8\r\n",
"puffed\t1\r\n",
"pulled\t1\r\n",
"pulling\t1\r\n",
"pun!’\t1\r\n",
"punching\t1\r\n",
"punished\t1\r\n",
"puppy\t5\r\n",
"puppy;\t1\r\n",
"puppy’s\t1\r\n",
"purple.\t1\r\n",
"purpose\t1\r\n",
"purring\t1\r\n",
"purring,\t1\r\n",
"push\t1\r\n",
"put\t31\r\n",
"putting\t3\r\n",
"puzzle!’\t1\r\n",
"puzzled\t5\r\n",
"puzzled,\t1\r\n",
"puzzled.\t2\r\n",
"puzzled.)\t1\r\n",
"puzzling\t4\r\n",
"quarrel\t1\r\n",
"quarrelled\t1\r\n",
"quarrelling\t2\r\n",
"queer\t9\r\n",
"queer,\t1\r\n",
"queer-looking\t1\r\n",
"queer-shaped\t1\r\n",
"queerest\t1\r\n",
"question\t7\r\n",
"question,\t4\r\n",
"question,’\t1\r\n",
"question.\t3\r\n",
"question;\t1\r\n",
"question?’\t1\r\n",
"questions\t2\r\n",
"questions,\t1\r\n",
"questions.--How\t1\r\n",
"quick\t1\r\n",
"quicker.\t1\r\n",
"quickly\t2\r\n",
"quiet\t2\r\n",
"quietly\t4\r\n",
"quietly,\t1\r\n",
"quite\t53\r\n",
"quiver\t1\r\n",
"rabbit\t1\r\n",
"rabbit!\t1\r\n",
"rabbit-hole\t2\r\n",
"rabbit-hole--and\t1\r\n",
"rabbits.\t1\r\n",
"race\t2\r\n",
"race-course,\t1\r\n",
"railway\t1\r\n",
"railway,’\t1\r\n",
"raised\t2\r\n",
"raising\t1\r\n",
"ran\t13\r\n",
"ran,\t1\r\n",
"ran.\t1\r\n",
"ran;\t1\r\n",
"rapidly:\t1\r\n",
"rapidly;\t1\r\n",
"rapped\t1\r\n",
"rat-hole:\t1\r\n",
"rate\t4\r\n",
"rate!\t1\r\n",
"rate,\t2\r\n",
"rate,’\t1\r\n",
"rate:\t1\r\n",
"rather\t25\r\n",
"rats\t1\r\n",
"rattle\t1\r\n",
"rattling\t2\r\n",
"raven\t1\r\n",
"ravens\t1\r\n",
"raving\t2\r\n",
"raw.’\t1\r\n",
"re-use\t2\r\n",
"reach\t4\r\n",
"reaching\t2\r\n",
"read\t10\r\n",
"read,\t1\r\n",
"read:--\t1\r\n",
"readable\t2\r\n",
"readily:\t1\r\n",
"reading\t3\r\n",
"reading,\t1\r\n",
"ready\t7\r\n",
"ready?\t1\r\n",
"real\t3\r\n",
"reality--the\t1\r\n",
"really\t9\r\n",
"really?’\t1\r\n",
"rearing\t1\r\n",
"reason\t8\r\n",
"reason,\t1\r\n",
"reasonable\t2\r\n",
"reasons.\t1\r\n",
"receipt\t2\r\n",
"receive\t3\r\n",
"received\t6\r\n",
"receiving\t1\r\n",
"recognised\t1\r\n",
"recovered\t2\r\n",
"red-hot\t1\r\n",
"red.\t1\r\n",
"redistribute\t1\r\n",
"redistributing\t1\r\n",
"redistribution.\t1\r\n",
"reduced\t1\r\n",
"reeds--the\t1\r\n",
"references\t2\r\n",
"refreshments!’\t1\r\n",
"refund\t6\r\n",
"refund.\t2\r\n",
"refused\t1\r\n",
"registered\t2\r\n",
"regular\t2\r\n",
"regulating\t1\r\n",
"relief.\t2\r\n",
"relieved\t1\r\n",
"remain\t2\r\n",
"remained\t3\r\n",
"remaining\t2\r\n",
"remark\t3\r\n",
"remark,\t4\r\n",
"remark.\t3\r\n",
"remarkable\t2\r\n",
"remarked\t1\r\n",
"remarked,\t2\r\n",
"remarked.\t5\r\n",
"remarked:\t1\r\n",
"remarked;\t1\r\n",
"remarking\t2\r\n",
"remarking,\t1\r\n",
"remarks\t1\r\n",
"remarks,\t1\r\n",
"remarks,’\t1\r\n",
"remedies--’\t1\r\n",
"remember\t12\r\n",
"remember,’\t2\r\n",
"remembered\t5\r\n",
"remembering\t1\r\n",
"reminding\t1\r\n",
"remove\t1\r\n",
"removed\t1\r\n",
"removed!’\t1\r\n",
"removed,’\t1\r\n",
"removed.\t1\r\n",
"renamed.\t1\r\n",
"repeat\t6\r\n",
"repeated\t8\r\n",
"repeated,\t2\r\n",
"repeating\t3\r\n",
"replace\t1\r\n",
"replacement\t3\r\n",
"replied\t14\r\n",
"replied,\t5\r\n",
"replied.\t5\r\n",
"replied:\t2\r\n",
"replied;\t3\r\n",
"reply\t1\r\n",
"reply,\t1\r\n",
"reply.\t3\r\n",
"reported\t1\r\n",
"reports,\t1\r\n",
"representations\t1\r\n",
"request,\t1\r\n",
"require\t1\r\n",
"required\t1\r\n",
"requirements\t2\r\n",
"requirements,\t1\r\n",
"requirements.\t1\r\n",
"research\t1\r\n",
"research.\t1\r\n",
"resource,\t1\r\n",
"respect.\t1\r\n",
"respectable\t1\r\n",
"respectful\t1\r\n",
"rest\t9\r\n",
"rest,\t1\r\n",
"resting\t2\r\n",
"restrictions\t2\r\n",
"result\t1\r\n",
"retire\t1\r\n",
"return\t3\r\n",
"returned\t1\r\n",
"returning,\t1\r\n",
"returns.\t1\r\n",
"rich\t1\r\n",
"riddle\t1\r\n",
"riddles\t1\r\n",
"riddles.--I\t1\r\n",
"ridge\t1\r\n",
"ridges\t1\r\n",
"ridiculous\t1\r\n",
"right\t22\r\n",
"right!’\t1\r\n",
"right,\t3\r\n",
"right,’\t3\r\n",
"right-hand\t1\r\n",
"right;\t1\r\n",
"right?’\t1\r\n",
"righthand\t1\r\n",
"rightly\t1\r\n",
"ring,\t2\r\n",
"ringlets\t1\r\n",
"ringlets,\t1\r\n",
"riper\t1\r\n",
"rippling\t1\r\n",
"rise\t1\r\n",
"rises\t1\r\n",
"rising\t1\r\n",
"roared\t1\r\n",
"roast\t1\r\n",
"rock,\t1\r\n",
"roof\t5\r\n",
"roof.\t1\r\n",
"room\t8\r\n",
"room!\t1\r\n",
"room!’\t2\r\n",
"room,\t1\r\n",
"room.\t1\r\n",
"roots\t1\r\n",
"rope--Will\t1\r\n",
"rose\t1\r\n",
"rose-tree\t1\r\n",
"rose-tree,\t2\r\n",
"roses\t1\r\n",
"roses.\t1\r\n",
"roses?’\t1\r\n",
"rosetree;\t1\r\n",
"roughly\t1\r\n",
"round\t30\r\n",
"round!”’\t1\r\n",
"round,\t7\r\n",
"round.\t3\r\n",
"row\t2\r\n",
"royal\t2\r\n",
"royalties\t1\r\n",
"royalties.\t1\r\n",
"royalty\t1\r\n",
"rubbed\t1\r\n",
"rubbing\t2\r\n",
"rude,\t1\r\n",
"rude.’\t1\r\n",
"rudeness\t1\r\n",
"rule\t2\r\n",
"rule,\t1\r\n",
"rule:\t1\r\n",
"rules\t4\r\n",
"rules,\t1\r\n",
"rumbling\t1\r\n",
"run\t3\r\n",
"running\t8\r\n",
"rush\t2\r\n",
"rushed\t1\r\n",
"rustled\t1\r\n",
"rustling\t1\r\n",
"s/he\t1\r\n",
"sad\t2\r\n",
"sad?’\t1\r\n",
"sadly\t2\r\n",
"sadly.\t2\r\n",
"sadly:--\t1\r\n",
"safe\t2\r\n",
"sage,\t1\r\n",
"said\t416\r\n",
"said,\t26\r\n",
"said,)\t1\r\n",
"said,’\t1\r\n",
"said--’\t3\r\n",
"said.\t4\r\n",
"said:\t3\r\n",
"said;\t2\r\n",
"salmon,\t1\r\n",
"salt\t2\r\n",
"same\t22\r\n",
"same,\t2\r\n",
"sand\t1\r\n",
"sands\t1\r\n",
"sang\t2\r\n",
"sat\t17\r\n",
"saucepan\t1\r\n",
"saucepans,\t1\r\n",
"saucer\t1\r\n",
"savage\t3\r\n",
"savage!’\t1\r\n",
"save\t1\r\n",
"saves\t1\r\n",
"saw\t13\r\n",
"saw.\t1\r\n",
"say\t35\r\n",
"say!’\t1\r\n",
"say,\t5\r\n",
"say,’\t4\r\n",
"say--that’s\t1\r\n",
"say.\t1\r\n",
"say.)\t1\r\n",
"say.’\t2\r\n",
"say?’\t1\r\n",
"saying\t11\r\n",
"saying,\t3\r\n",
"saying.’\t1\r\n",
"says\t4\r\n",
"scale!\t1\r\n",
"scaly\t1\r\n",
"scattered\t1\r\n",
"school\t4\r\n",
"school,’\t1\r\n",
"schoolroom,\t1\r\n",
"scolded\t1\r\n",
"scrambling\t1\r\n",
"scratching\t1\r\n",
"scream\t1\r\n",
"scream,\t1\r\n",
"screamed\t4\r\n",
"screaming\t1\r\n",
"scroll\t1\r\n",
"scroll,\t1\r\n",
"sea\t2\r\n",
"sea!’\t1\r\n",
"sea!”\t1\r\n",
"sea,\t3\r\n",
"sea,’\t1\r\n",
"sea--’\t1\r\n",
"sea-shore--’\t1\r\n",
"sea.\t3\r\n",
"sea.’\t1\r\n",
"search\t2\r\n",
"seaside\t1\r\n",
"seated\t1\r\n",
"second\t6\r\n",
"secondly,\t2\r\n",
"secret,\t1\r\n",
"secure\t1\r\n",
"see\t48\r\n",
"see!’\t1\r\n",
"see,\t11\r\n",
"see,’\t1\r\n",
"see--how\t1\r\n",
"see.’\t1\r\n",
"see:\t3\r\n",
"seeing\t1\r\n",
"seem\t7\r\n",
"seem,\t1\r\n",
"seemed\t27\r\n",
"seems\t4\r\n",
"seems,’\t1\r\n",
"seen\t12\r\n",
"seen,\t1\r\n",
"seen--everything\t1\r\n",
"seen:\t1\r\n",
"see”!’\t1\r\n",
"seldom\t1\r\n",
"sell\t1\r\n",
"sell,’\t1\r\n",
"send\t1\r\n",
"sending\t3\r\n",
"sensation\t1\r\n",
"sensation,\t1\r\n",
"sense\t1\r\n",
"sense,\t2\r\n",
"sent\t3\r\n",
"sentence\t6\r\n",
"sentence,\t1\r\n",
"sentenced\t1\r\n",
"series\t1\r\n",
"seriously,\t1\r\n",
"serpent!’\t1\r\n",
"serpent,\t2\r\n",
"serpent.\t1\r\n",
"serpent;\t1\r\n",
"serpent?’\t1\r\n",
"serpents\t2\r\n",
"serpents!\t1\r\n",
"set\t23\r\n",
"setting\t1\r\n",
"settle\t1\r\n",
"settled\t3\r\n",
"settling\t1\r\n",
"seven\t1\r\n",
"several\t5\r\n",
"severely\t3\r\n",
"severely.\t1\r\n",
"severity;\t1\r\n",
"sh!’\t1\r\n",
"shade:\t1\r\n",
"shake\t1\r\n",
"shaking\t3\r\n",
"shall\t23\r\n",
"shall!’\t1\r\n",
"shan’t\t4\r\n",
"shan’t!\t1\r\n",
"shape\t1\r\n",
"shaped\t2\r\n",
"share\t2\r\n",
"shared\t2\r\n",
"sharing\t2\r\n",
"sharks\t1\r\n",
"sharp\t6\r\n",
"sharply\t1\r\n",
"sharply,\t1\r\n",
"sharply.\t1\r\n",
"sharply;\t1\r\n",
"she\t484\r\n",
"she,\t4\r\n",
"shedding\t1\r\n",
"sheep-bells,\t1\r\n",
"shelves\t1\r\n",
"shepherd\t1\r\n",
"she’d\t1\r\n",
"she’ll\t2\r\n",
"she’s\t3\r\n",
"shifting\t1\r\n",
"shilling\t1\r\n",
"shillings\t1\r\n",
"shingle--will\t1\r\n",
"shining\t1\r\n",
"shiny?’\t1\r\n",
"shiver.\t1\r\n",
"shock\t1\r\n",
"shoes\t5\r\n",
"shoes!’\t1\r\n",
"shook\t9\r\n",
"shore,\t2\r\n",
"shore.\t1\r\n",
"short\t4\r\n",
"shorter,\t1\r\n",
"shorter.’\t1\r\n",
"should\t29\r\n",
"shoulder\t3\r\n",
"shoulder,\t1\r\n",
"shoulders\t2\r\n",
"shoulders,\t1\r\n",
"shoulders.\t1\r\n",
"shouldn’t\t5\r\n",
"shouted\t9\r\n",
"shouting\t2\r\n",
"show\t3\r\n",
"shower\t2\r\n",
"showing\t2\r\n",
"shriek\t3\r\n",
"shriek,\t2\r\n",
"shrieked\t1\r\n",
"shrieks,\t1\r\n",
"shrill\t3\r\n",
"shrill,\t2\r\n",
"shrimp\t1\r\n",
"shrink\t1\r\n",
"shrinking\t4\r\n",
"shut\t4\r\n",
"shut.\t1\r\n",
"shutting\t2\r\n",
"shyly,\t1\r\n",
"side\t12\r\n",
"side,\t3\r\n",
"side.\t2\r\n",
"sides\t4\r\n",
"sigh,\t1\r\n",
"sigh.\t1\r\n",
"sigh:\t2\r\n",
"sighed\t5\r\n",
"sighing\t2\r\n",
"sighing.\t1\r\n",
"sight\t2\r\n",
"sight,\t4\r\n",
"sight.\t1\r\n",
"sight:\t2\r\n",
"sight;\t1\r\n",
"sign\t1\r\n",
"signed\t2\r\n",
"signifies\t1\r\n",
"signify:\t1\r\n",
"silence\t3\r\n",
"silence,\t2\r\n",
"silence.\t5\r\n",
"silence:\t1\r\n",
"silent\t3\r\n",
"silent,\t2\r\n",
"silent.\t2\r\n",
"simple\t5\r\n",
"simpleton.’\t1\r\n",
"simply\t2\r\n",
"simply--“Never\t1\r\n",
"since\t4\r\n",
"sing\t3\r\n",
"sing,’\t1\r\n",
"sing?’\t1\r\n",
"singers\t1\r\n",
"singers.\t1\r\n",
"singing\t2\r\n",
"sink\t1\r\n",
"sir,\t3\r\n",
"sir,’\t1\r\n",
"sir--’\t1\r\n",
"sir’\t1\r\n",
"sister\t5\r\n",
"sister,\t2\r\n",
"sister;\t1\r\n",
"sisters,’\t1\r\n",
"sisters--they\t1\r\n",
"sister’s\t1\r\n",
"sit\t5\r\n",
"site\t4\r\n",
"sits\t1\r\n",
"sitting\t10\r\n",
"six\t2\r\n",
"sixpence.\t1\r\n",
"size\t6\r\n",
"size,\t1\r\n",
"size,’\t1\r\n",
"size:\t3\r\n",
"size;\t1\r\n",
"size?\t1\r\n",
"sizes\t1\r\n",
"skimming\t1\r\n",
"skirt,\t1\r\n",
"skurried\t1\r\n",
"sky\t1\r\n",
"sky!\t1\r\n",
"sky-rocket!’\t1\r\n",
"sky.\t2\r\n",
"slate\t1\r\n",
"slate--Oh,\t1\r\n",
"slate-pencil,\t1\r\n",
"slate.\t1\r\n",
"slates\t1\r\n",
"slates,\t4\r\n",
"slates.\t1\r\n",
"slates;\t1\r\n",
"slates’ll\t1\r\n",
"sleep\t4\r\n",
"sleep,\t1\r\n",
"sleepy\t3\r\n",
"sleepy,\t1\r\n",
"sleepy;\t1\r\n",
"sleep”\t1\r\n",
"slightest\t1\r\n",
"slipped\t2\r\n",
"slipped,\t1\r\n",
"slippery;\t1\r\n",
"slowly\t6\r\n",
"slowly,\t2\r\n",
"small\t10\r\n",
"small,\t1\r\n",
"small.\t1\r\n",
"smaller,\t3\r\n",
"smallest\t2\r\n",
"smile.\t1\r\n",
"smile:\t1\r\n",
"smiled\t2\r\n",
"smiling\t2\r\n",
"smoke\t1\r\n",
"smoking\t2\r\n",
"snail\t1\r\n",
"snail,\t1\r\n",
"snail.\t1\r\n",
"snappishly.\t1\r\n",
"snatch\t2\r\n",
"sneeze\t1\r\n",
"sneeze,\t1\r\n",
"sneezed\t1\r\n",
"sneezes:\t1\r\n",
"sneezes;\t1\r\n",
"sneezing\t4\r\n",
"sneezing,\t1\r\n",
"sneezing.\t1\r\n",
"snorting\t1\r\n",
"snout\t1\r\n",
"so\t104\r\n",
"so,\t7\r\n",
"so,’\t5\r\n",
"so--and\t1\r\n",
"so.\t2\r\n",
"so.’\t1\r\n",
"sob,\t1\r\n",
"sobbed\t1\r\n",
"sobbing\t2\r\n",
"sobbing,’\t1\r\n",
"sobs\t2\r\n",
"sobs,\t1\r\n",
"sobs.\t1\r\n",
"soft\t1\r\n",
"softly\t1\r\n",
"soldier\t1\r\n",
"soldiers\t8\r\n",
"soldiers,\t2\r\n",
"solemn\t3\r\n",
"solemnly\t2\r\n",
"solemnly,\t1\r\n",
"solemnly.\t1\r\n",
"solicit\t2\r\n",
"solicitation\t1\r\n",
"solid\t1\r\n",
"some\t47\r\n",
"somebody\t3\r\n",
"somebody,\t1\r\n",
"somebody.’\t1\r\n",
"somehow\t1\r\n",
"someone\t1\r\n",
"somersault\t1\r\n",
"something\t14\r\n",
"something!’\t1\r\n",
"something,\t1\r\n",
"something;\t1\r\n",
"sometimes\t4\r\n",
"sometimes,\t1\r\n",
"somewhere\t1\r\n",
"somewhere.’\t1\r\n",
"son,\t1\r\n",
"song\t1\r\n",
"song,\t4\r\n",
"song.\t1\r\n",
"song?’\t1\r\n",
"soon\t23\r\n",
"soon.\t1\r\n",
"sooner\t2\r\n",
"soothing\t1\r\n",
"sorrow,\t1\r\n",
"sorrow?’\t1\r\n",
"sorrowful\t2\r\n",
"sorrows,\t1\r\n",
"sorry\t1\r\n",
"sort\t17\r\n",
"sort!’\t1\r\n",
"sort,’\t1\r\n",
"sort.\t1\r\n",
"sorts\t3\r\n",
"sound\t3\r\n",
"sound.]\t1\r\n",
"sounded\t5\r\n",
"sounds\t3\r\n",
"soup\t1\r\n",
"soup!’\t1\r\n",
"soup,\t1\r\n",
"soup.\t1\r\n",
"sour--and\t1\r\n",
"spades,\t1\r\n",
"speak\t8\r\n",
"speak,\t2\r\n",
"speak--and\t1\r\n",
"speak.\t1\r\n",
"speak?’\t1\r\n",
"speaker,’\t1\r\n",
"speaking\t2\r\n",
"speaking,\t3\r\n",
"specific\t1\r\n",
"specified\t2\r\n",
"spectacles\t1\r\n",
"spectacles,\t1\r\n",
"spectacles.\t1\r\n",
"speech\t1\r\n",
"speech,\t1\r\n",
"speech.\t1\r\n",
"speed\t1\r\n",
"spell\t1\r\n",
"spite\t1\r\n",
"splash!\t1\r\n",
"splashed\t1\r\n",
"splashing\t2\r\n",
"splendidly\t1\r\n",
"spoke\t4\r\n",
"spoke,\t5\r\n",
"spoke--fancy\t1\r\n",
"spoke.\t6\r\n",
"spoke;\t1\r\n",
"spoken\t1\r\n",
"spoon\t1\r\n",
"spoon:\t1\r\n",
"spot.’\t1\r\n",
"sprawling\t1\r\n",
"spread\t4\r\n",
"spreading\t1\r\n",
"squeaked.\t1\r\n",
"squeaking\t2\r\n",
"squeeze\t1\r\n",
"squeezed\t1\r\n",
"staff.\t1\r\n",
"stairs!\t1\r\n",
"stairs!’\t1\r\n",
"stairs.\t1\r\n",
"stalk\t1\r\n",
"stamping\t2\r\n",
"stand\t4\r\n",
"stand,\t1\r\n",
"standing\t1\r\n",
"star-fish,’\t1\r\n",
"staring\t3\r\n",
"start\t1\r\n",
"started\t2\r\n",
"startled\t2\r\n",
"state\t6\r\n",
"statements\t1\r\n",
"states\t4\r\n",
"state’s\t1\r\n",
"station.)\t1\r\n",
"status\t4\r\n",
"stay\t4\r\n",
"stay!’\t1\r\n",
"stays\t1\r\n",
"steady\t1\r\n",
"steam-engine\t1\r\n",
"sternly.\t1\r\n",
"stick,\t4\r\n",
"sticks\t1\r\n",
"stiff.\t1\r\n",
"still\t12\r\n",
"stingy\t1\r\n",
"stirring\t2\r\n",
"stockings\t1\r\n",
"stole\t1\r\n",
"stood\t7\r\n",
"stool\t1\r\n",
"stoop\t1\r\n",
"stoop?\t1\r\n",
"stop\t3\r\n",
"stop.\t1\r\n",
"stop.’\t1\r\n",
"stopped\t3\r\n",
"stopping\t1\r\n",
"stored,\t1\r\n",
"story\t2\r\n",
"story!’\t2\r\n",
"story,’\t1\r\n",
"story.\t1\r\n",
"story.’\t1\r\n",
"straight\t2\r\n",
"straightened\t1\r\n",
"straightening\t1\r\n",
"strange\t4\r\n",
"strange,\t1\r\n",
"strength,\t1\r\n",
"stretched\t2\r\n",
"stretching\t1\r\n",
"strings:\t1\r\n",
"struck\t2\r\n",
"stuff\t1\r\n",
"stuff,’\t1\r\n",
"stuff?\t1\r\n",
"stupid\t1\r\n",
"stupid),\t1\r\n",
"stupid?’\t1\r\n",
"stupidest\t1\r\n",
"stupidly\t1\r\n",
"subdued\t1\r\n",
"subject\t3\r\n",
"subject!\t1\r\n",
"subject,’\t1\r\n",
"subject.\t2\r\n",
"subjects\t1\r\n",
"submitted\t1\r\n",
"subscribe\t1\r\n",
"succeeded\t3\r\n",
"such\t45\r\n",
"sudden\t5\r\n",
"suddenly\t9\r\n",
"suddenly,\t1\r\n",
"suddenly:\t2\r\n",
"suet;\t1\r\n",
"sugar\t1\r\n",
"suit\t3\r\n",
"sulkily\t2\r\n",
"sulky\t2\r\n",
"sulky,\t1\r\n",
"summer\t2\r\n",
"sun,\t1\r\n",
"sun.\t1\r\n",
"supple\t1\r\n",
"support\t3\r\n",
"support.\t1\r\n",
"suppose\t8\r\n",
"suppose,\t1\r\n",
"suppose.’\t1\r\n",
"suppose?’\t2\r\n",
"suppressed\t3\r\n",
"suppressed.\t1\r\n",
"sure\t16\r\n",
"sure!\t1\r\n",
"sure,\t2\r\n",
"sure;\t1\r\n",
"surprise\t1\r\n",
"surprise,\t2\r\n",
"surprise.\t2\r\n",
"surprised\t6\r\n",
"surprised,\t1\r\n",
"survive\t1\r\n",
"swallow\t1\r\n",
"swallowed\t1\r\n",
"swallowing\t1\r\n",
"swam\t5\r\n",
"swamp\t1\r\n",
"sweet-tempered.\t1\r\n",
"swim\t1\r\n",
"swim,\t1\r\n",
"swim.\t1\r\n",
"swimming\t2\r\n",
"synonymous\t1\r\n",
"table\t7\r\n",
"table,\t5\r\n",
"table,’\t1\r\n",
"table.\t3\r\n",
"table:\t1\r\n",
"tail\t3\r\n",
"tail,\t3\r\n",
"tail.\t2\r\n",
"tail;\t1\r\n",
"tails\t3\r\n",
"take\t18\r\n",
"taken\t4\r\n",
"takes\t3\r\n",
"taking\t5\r\n",
"tale\t1\r\n",
"tale!’\t1\r\n",
"tale,\t1\r\n",
"talk\t10\r\n",
"talk!’\t1\r\n",
"talk,’\t1\r\n",
"talk.\t1\r\n",
"talk:\t1\r\n",
"talking\t12\r\n",
"talking!’\t1\r\n",
"talking.\t2\r\n",
"talking:\t1\r\n",
"taller\t1\r\n",
"taller,\t1\r\n",
"tarts\t3\r\n",
"tarts,\t3\r\n",
"taste\t2\r\n",
"tasted\t2\r\n",
"tasted--’\t1\r\n",
"tastes!\t1\r\n",
"taught\t4\r\n",
"tax\t6\r\n",
"taxes.\t1\r\n",
"tea\t5\r\n",
"tea,\t1\r\n",
"tea,’\t3\r\n",
"tea--not\t1\r\n",
"tea--’\t1\r\n",
"tea-party\t1\r\n",
"tea-things\t1\r\n",
"tea-time,\t1\r\n",
"tea-time.\t1\r\n",
"tea-tray\t1\r\n",
"tea.\t1\r\n",
"tea;\t1\r\n",
"teaching\t1\r\n",
"teacup\t3\r\n",
"teacups\t2\r\n",
"teapot.\t1\r\n",
"tears\t4\r\n",
"tears!\t1\r\n",
"tears,\t3\r\n",
"tears.\t2\r\n",
"teases.’\t1\r\n",
"teeth,\t1\r\n",
"telescope\t1\r\n",
"telescope!\t1\r\n",
"telescope.’\t1\r\n",
"telescopes:\t1\r\n",
"tell\t26\r\n",
"telling\t2\r\n",
"tells\t2\r\n",
"temper\t1\r\n",
"temper!’\t1\r\n",
"temper,\t1\r\n",
"temper,’\t1\r\n",
"temper.\t1\r\n",
"ten\t5\r\n",
"terms\t20\r\n",
"terribly\t1\r\n",
"terrier,\t1\r\n",
"terror.\t1\r\n",
"than\t24\r\n",
"thank\t1\r\n",
"thanked\t1\r\n",
"that\t226\r\n",
"that!\t2\r\n",
"that!’\t7\r\n",
"that,\t5\r\n",
"that,’\t9\r\n",
"that--only\t1\r\n",
"that.’\t3\r\n",
"that:\t3\r\n",
"that;\t1\r\n",
"that?--It\t1\r\n",
"that?’\t6\r\n",
"thatched\t1\r\n",
"that’s\t13\r\n",
"the\t1664\r\n",
"the--’\t1\r\n",
"their\t50\r\n",
"theirs,\t1\r\n",
"them\t49\r\n",
"them!’\t5\r\n",
"them,\t21\r\n",
"them,’\t3\r\n",
"them--all\t1\r\n",
"them--and\t2\r\n",
"them--‘I\t1\r\n",
"them--’\t1\r\n",
"them.\t2\r\n",
"them.’\t2\r\n",
"them:\t1\r\n",
"themselves\t2\r\n",
"themselves.”’\t1\r\n",
"then\t50\r\n",
"then!--Bill’s\t1\r\n",
"then!’\t2\r\n",
"then,\t6\r\n",
"then,’\t6\r\n",
"then--I\t1\r\n",
"then--always\t1\r\n",
"then.’\t2\r\n",
"then;\t1\r\n",
"then?\t1\r\n",
"then?’\t1\r\n",
"there\t44\r\n",
"there,\t1\r\n",
"there,’\t2\r\n",
"there.\t2\r\n",
"there’s\t15\r\n",
"these\t14\r\n",
"they\t109\r\n",
"they’d\t3\r\n",
"they’ll\t4\r\n",
"they’re\t9\r\n",
"they’ve\t1\r\n",
"thick\t1\r\n",
"thimble,\t2\r\n",
"thimble,’\t1\r\n",
"thimble’;\t1\r\n",
"thin--and\t1\r\n",
"thing\t35\r\n",
"thing!’\t6\r\n",
"thing,\t4\r\n",
"thing,’\t3\r\n",
"thing.\t1\r\n",
"things\t21\r\n",
"things!\t1\r\n",
"things!’\t4\r\n",
"things,\t2\r\n",
"things--I\t1\r\n",
"things--everything\t1\r\n",
"things--’\t1\r\n",
"things?’\t1\r\n",
"think\t37\r\n",
"think!\t1\r\n",
"think!’\t1\r\n",
"think,\t2\r\n",
"think,’\t2\r\n",
"think--’\t3\r\n",
"think.’\t1\r\n",
"think:\t1\r\n",
"think?’\t2\r\n",
"thinking\t10\r\n",
"thirteen,\t1\r\n",
"thirty\t1\r\n",
"this\t122\r\n",
"this),\t1\r\n",
"this,\t17\r\n",
"this,’\t1\r\n",
"this.\t1\r\n",
"this:\t2\r\n",
"this:--\t2\r\n",
"this;\t2\r\n",
"this?’\t1\r\n",
"thistle\t1\r\n",
"thistle,\t1\r\n",
"thoroughly\t2\r\n",
"those\t9\r\n",
"though\t6\r\n",
"though),\t1\r\n",
"though,\t1\r\n",
"though.\t1\r\n",
"thought\t63\r\n",
"thought),\t1\r\n",
"thought,\t6\r\n",
"thought.\t2\r\n",
"thought:\t1\r\n",
"thought;\t1\r\n",
"thoughtfully\t1\r\n",
"thoughtfully.\t2\r\n",
"thoughtfully:\t1\r\n",
"thoughts\t2\r\n",
"thousand\t2\r\n",
"three\t23\r\n",
"three,\t1\r\n",
"three-legged\t2\r\n",
"three.’\t1\r\n",
"threw\t2\r\n",
"throat!’\t1\r\n",
"throat,’\t1\r\n",
"throne\t1\r\n",
"through\t14\r\n",
"through,’\t1\r\n",
"throughout\t1\r\n",
"throw\t3\r\n",
"throwing\t2\r\n",
"thrown\t1\r\n",
"thump!\t2\r\n",
"thunder,\t1\r\n",
"thunderstorm.\t1\r\n",
"tide\t1\r\n",
"tidy\t1\r\n",
"tie\t1\r\n",
"tied\t1\r\n",
"tight\t1\r\n",
"till\t19\r\n",
"time\t46\r\n",
"time!\t2\r\n",
"time).\t1\r\n",
"time,\t6\r\n",
"time,’\t5\r\n",
"time.\t2\r\n",
"time.)\t1\r\n",
"time.’\t1\r\n",
"time?’\t1\r\n",
"times\t6\r\n",
"timid\t3\r\n",
"timidly\t2\r\n",
"timidly,\t4\r\n",
"timidly.\t1\r\n",
"timidly:\t1\r\n",
"timidly;\t1\r\n",
"tinkling\t1\r\n",
"tiny\t4\r\n",
"tipped\t1\r\n",
"tiptoe,\t2\r\n",
"tired\t7\r\n",
"tittered\t1\r\n",
"to\t773\r\n",
"to,\t7\r\n",
"to,’\t1\r\n",
"to--to\t1\r\n",
"to--’\t1\r\n",
"to-day!\t1\r\n",
"to-day.’\t1\r\n",
"to-day?’\t1\r\n",
"to-night,\t1\r\n",
"to.’\t1\r\n",
"to?\t1\r\n",
"to?’\t3\r\n",
"toast,)\t1\r\n",
"today.\t1\r\n",
"toes\t1\r\n",
"toes.’\t1\r\n",
"toes?’\t1\r\n",
"toffee,\t1\r\n",
"together\t2\r\n",
"together!’\t1\r\n",
"together,\t1\r\n",
"together.\t2\r\n",
"together.’\t1\r\n",
"together.”’\t1\r\n",
"together:\t1\r\n",
"told\t6\r\n",
"tomorrow--’\t1\r\n",
"tone\t8\r\n",
"tone,\t16\r\n",
"tone.\t9\r\n",
"tone:\t5\r\n",
"tone;\t2\r\n",
"tones\t2\r\n",
"tongue\t1\r\n",
"tongue!’\t2\r\n",
"tongue,\t1\r\n",
"too\t21\r\n",
"too,\t1\r\n",
"too,’\t1\r\n",
"too.’\t1\r\n",
"too:\t1\r\n",
"took\t23\r\n",
"top\t8\r\n",
"tops\t1\r\n",
"toss\t1\r\n",
"tossing\t3\r\n",
"touch\t1\r\n",
"tougher\t1\r\n",
"towards\t1\r\n",
"toys\t1\r\n",
"trademark\t3\r\n",
"trademark,\t3\r\n",
"trademark.\t3\r\n",
"trampled\t1\r\n",
"transcribe\t1\r\n",
"transcription\t1\r\n",
"treacle\t2\r\n",
"treacle,’\t1\r\n",
"treacle-well--eh,\t1\r\n",
"treacle-well.’\t1\r\n",
"treading\t2\r\n",
"treat.\t1\r\n",
"treated\t1\r\n",
"treatment\t1\r\n",
"tree\t3\r\n",
"tree.\t2\r\n",
"trees\t5\r\n",
"trees,\t2\r\n",
"tremble.\t1\r\n",
"trembled\t2\r\n",
"trembling\t6\r\n",
"tremulous\t1\r\n",
"trial\t4\r\n",
"trial,\t1\r\n",
"trial.’\t1\r\n",
"trial:\t1\r\n",
"trials,\t1\r\n",
"trial’s\t3\r\n",
"trickling\t1\r\n",
"tricks\t1\r\n",
"tried\t18\r\n",
"tried.\t1\r\n",
"triumphantly,\t1\r\n",
"triumphantly.\t1\r\n",
"trot\t1\r\n",
"trotting\t2\r\n",
"trouble\t4\r\n",
"trouble!’\t1\r\n",
"trouble,\t1\r\n",
"true):\t1\r\n",
"true,’\t1\r\n",
"true.)\t1\r\n",
"trumpet\t1\r\n",
"trumpet,\t2\r\n",
"trusts\t1\r\n",
"truth:\t1\r\n",
"truthful\t1\r\n",
"try\t12\r\n",
"trying\t11\r\n",
"trying,\t1\r\n",
"trying--’\t1\r\n",
"trying.’\t1\r\n",
"tucked\t3\r\n",
"tulip-roots\t1\r\n",
"tumbled\t1\r\n",
"tumbling\t2\r\n",
"tunnel\t1\r\n",
"tureen!\t1\r\n",
"turkey,\t1\r\n",
"turn\t6\r\n",
"turn-up\t1\r\n",
"turn;\t1\r\n",
"turned\t16\r\n",
"turning\t12\r\n",
"turns\t1\r\n",
"turns,\t2\r\n",
"turtles\t1\r\n",
"turtles,\t1\r\n",
"tut,\t1\r\n",
"twelfth?’\t1\r\n",
"twelve\t2\r\n",
"twelve,\t1\r\n",
"twelve?\t1\r\n",
"twentieth\t1\r\n",
"twenty\t1\r\n",
"twenty-four\t1\r\n",
"twice\t1\r\n",
"twice,\t3\r\n",
"twice--’\t1\r\n",
"twinkle,\t3\r\n",
"twinkle--’\t1\r\n",
"twinkle--“’\t1\r\n",
"twinkled\t1\r\n",
"twinkling\t3\r\n",
"twinkling!\t1\r\n",
"twist\t2\r\n",
"two\t20\r\n",
"two,\t9\r\n",
"two.\t1\r\n",
"two:\t1\r\n",
"types\t1\r\n",
"uglify\t1\r\n",
"uglifying!’\t1\r\n",
"ugly\t1\r\n",
"ugly;\t1\r\n",
"unable\t1\r\n",
"uncivil.\t1\r\n",
"uncomfortable\t1\r\n",
"uncomfortable,\t1\r\n",
"uncomfortable.\t2\r\n",
"uncomfortably\t1\r\n",
"uncommon\t1\r\n",
"uncommonly\t1\r\n",
"uncorked\t1\r\n",
"under\t21\r\n",
"underneath\t1\r\n",
"understand\t5\r\n",
"understand,\t1\r\n",
"understand.\t1\r\n",
"understood\t1\r\n",
"undertone\t1\r\n",
"undertone,\t1\r\n",
"undo\t1\r\n",
"undoing\t1\r\n",
"uneasily\t1\r\n",
"uneasily,\t1\r\n",
"uneasy:\t1\r\n",
"unenforceability\t1\r\n",
"unfolded\t2\r\n",
"unfortunate\t3\r\n",
"unhappy\t1\r\n",
"unhappy.\t1\r\n",
"uniform\t1\r\n",
"unjust\t1\r\n",
"unless\t4\r\n",
"unlink\t1\r\n",
"unlocking\t1\r\n",
"unpleasant\t2\r\n",
"unrolled\t2\r\n",
"unsolicited\t1\r\n",
"until\t4\r\n",
"untwist\t1\r\n",
"unusually\t1\r\n",
"unwillingly\t1\r\n",
"up\t83\r\n",
"up!’\t1\r\n",
"up,\t10\r\n",
"up,’\t2\r\n",
"up.’\t2\r\n",
"up:\t1\r\n",
"upon\t28\r\n",
"upright\t1\r\n",
"upset\t2\r\n",
"upset,\t1\r\n",
"upsetting\t1\r\n",
"upstairs,\t1\r\n",
"us\t10\r\n",
"us!”’\t1\r\n",
"us,\t2\r\n",
"us,’\t1\r\n",
"us.\t1\r\n",
"use\t24\r\n",
"use,\t2\r\n",
"used\t15\r\n",
"used--and\t1\r\n",
"useful,\t2\r\n",
"user\t2\r\n",
"user,\t1\r\n",
"using\t6\r\n",
"usual\t1\r\n",
"usual,\t1\r\n",
"usual,’\t1\r\n",
"usual.\t2\r\n",
"usually\t2\r\n",
"usurpation\t1\r\n",
"vague\t1\r\n",
"vanished\t3\r\n",
"vanished.\t1\r\n",
"vanishing\t1\r\n",
"variations.\t1\r\n",
"variety\t1\r\n",
"various\t2\r\n",
"vegetable.\t1\r\n",
"velvet\t1\r\n",
"venture\t3\r\n",
"ventured\t4\r\n",
"verdict,’\t3\r\n",
"verse\t1\r\n",
"verse,’\t2\r\n",
"verse.’\t1\r\n",
"verses\t3\r\n",
"verses.’\t1\r\n",
"version\t1\r\n",
"very\t127\r\n",
"viewed,\t1\r\n",
"viewing,\t1\r\n",
"vinegar\t1\r\n",
"violates\t1\r\n",
"violence\t1\r\n",
"violent\t2\r\n",
"violently\t2\r\n",
"violently,\t2\r\n",
"virus,\t1\r\n",
"visit\t1\r\n",
"visit:\t1\r\n",
"voice\t17\r\n",
"voice,\t15\r\n",
"voice--the\t1\r\n",
"voice.\t10\r\n",
"voice:\t1\r\n",
"voice:--\t1\r\n",
"voice;\t2\r\n",
"voices\t2\r\n",
"voices--‘Hold\t1\r\n",
"void\t1\r\n",
"volunteer\t1\r\n",
"volunteers\t5\r\n",
"vote\t1\r\n",
"vulgar\t1\r\n",
"wag\t1\r\n",
"wags\t1\r\n",
"waist,’\t1\r\n",
"waistcoat-pocket,\t1\r\n",
"wait,\t1\r\n",
"waited\t9\r\n",
"waited.\t2\r\n",
"waiting\t7\r\n",
"waiting!’\t1\r\n",
"walk\t4\r\n",
"walk!”\t1\r\n",
"walked\t10\r\n",
"walking\t5\r\n",
"walks\t1\r\n",
"walrus\t1\r\n",
"wander\t1\r\n",
"wandered\t2\r\n",
"wandering\t1\r\n",
"wandering,\t1\r\n",
"want\t9\r\n",
"wanted\t4\r\n",
"wants\t2\r\n",
"warning,’\t1\r\n",
"warranties\t1\r\n",
"was\t329\r\n",
"was!\t1\r\n",
"was!’\t1\r\n",
"was)\t1\r\n",
"was,\t14\r\n",
"was,’\t3\r\n",
"was.’\t1\r\n",
"was:\t2\r\n",
"wash\t2\r\n",
"washing\t1\r\n",
"washing?’\t1\r\n",
"wasn’t\t11\r\n",
"waste\t1\r\n",
"wasting\t2\r\n",
"watch\t5\r\n",
"watch!’\t1\r\n",
"watch,’\t1\r\n",
"watched\t2\r\n",
"watching\t3\r\n",
"water\t2\r\n",
"water,\t1\r\n",
"water-well,’\t1\r\n",
"water.\t1\r\n",
"waters\t1\r\n",
"waving\t5\r\n",
"way\t39\r\n",
"way!\t1\r\n",
"way,\t7\r\n",
"way--never\t1\r\n",
"way--’\t1\r\n",
"way.\t3\r\n",
"way:--\t1\r\n",
"way?\t1\r\n",
"way?’,\t1\r\n",
"ways\t2\r\n",
"we\t23\r\n",
"weak\t2\r\n",
"wearily.\t1\r\n",
"web\t3\r\n",
"week\t2\r\n",
"week:\t1\r\n",
"weeks!’\t1\r\n",
"welcome\t1\r\n",
"well\t27\r\n",
"well!\t1\r\n",
"well,\t1\r\n",
"well,’\t2\r\n",
"well--’\t1\r\n",
"well.\t2\r\n",
"well?’\t2\r\n",
"went\t79\r\n",
"went,\t2\r\n",
"went.\t2\r\n",
"wept\t1\r\n",
"were\t82\r\n",
"were,’\t1\r\n",
"were.\t1\r\n",
"weren’t\t1\r\n",
"were’,\t1\r\n",
"wet\t1\r\n",
"wet,\t1\r\n",
"we’re\t1\r\n",
"we’ve\t2\r\n",
"what\t86\r\n",
"what?\t1\r\n",
"what?’\t2\r\n",
"whatever\t1\r\n",
"whatever,’\t1\r\n",
"whatsoever.\t2\r\n",
"what’s\t2\r\n",
"when\t67\r\n",
"whenever\t1\r\n",
"where\t10\r\n",
"where--’\t1\r\n",
"where.’\t1\r\n",
"whereupon\t1\r\n",
"wherever\t2\r\n",
"whether\t11\r\n",
"which\t44\r\n",
"which),\t1\r\n",
"which?’\t1\r\n",
"while\t15\r\n",
"while,\t4\r\n",
"whiles.’\t1\r\n",
"whiskers!\t1\r\n",
"whiskers!’\t1\r\n",
"whiskers,\t1\r\n",
"whisper\t1\r\n",
"whisper,\t1\r\n",
"whisper.)\t1\r\n",
"whispered\t4\r\n",
"whispered,\t1\r\n",
"whispers\t1\r\n",
"whistle\t1\r\n",
"whistling.\t1\r\n",
"white\t6\r\n",
"white,\t1\r\n",
"white;\t1\r\n",
"whiting\t3\r\n",
"whiting!’\t1\r\n",
"whiting,’\t2\r\n",
"whiting.\t1\r\n",
"whiting?’\t1\r\n",
"who\t51\r\n",
"whole\t13\r\n",
"whom\t2\r\n",
"whose\t2\r\n",
"why\t7\r\n",
"why,\t2\r\n",
"why.\t1\r\n",
"wide\t2\r\n",
"wide,\t1\r\n",
"wider.\t1\r\n",
"widest\t2\r\n",
"wife;\t1\r\n",
"wig,\t1\r\n",
"wig.’\t1\r\n",
"wild\t2\r\n",
"wildly\t2\r\n",
"will\t29\r\n",
"win,\t1\r\n",
"wind,\t2\r\n",
"window!’\t1\r\n",
"window,\t5\r\n",
"window.’\t1\r\n",
"window?’\t1\r\n",
"wine,’\t2\r\n",
"wings.\t1\r\n",
"wink\t2\r\n",
"winter\t1\r\n",
"wise\t2\r\n",
"wish\t22\r\n",
"with\t214\r\n",
"with,\t1\r\n",
"with,’\t2\r\n",
"with.\t1\r\n",
"with.’\t1\r\n",
"with;\t1\r\n",
"with?’\t1\r\n",
"within\t5\r\n",
"within--a\t1\r\n",
"without\t32\r\n",
"without--Maybe\t1\r\n",
"witness\t4\r\n",
"witness!’\t2\r\n",
"witness,’\t1\r\n",
"witness.\t1\r\n",
"witness.’\t2\r\n",
"wits!’\t1\r\n",
"woke\t1\r\n",
"woman--but\t1\r\n",
"woman;\t1\r\n",
"won,\t1\r\n",
"won?’\t1\r\n",
"wonder\t15\r\n",
"wonder?’\t3\r\n",
"wondered\t1\r\n",
"wonderful\t2\r\n",
"wondering\t7\r\n",
"won’t\t21\r\n",
"won’t!’\t1\r\n",
"won’t,\t1\r\n",
"won’t’\t1\r\n",
"wood\t2\r\n",
"wood,\t1\r\n",
"wood,’\t1\r\n",
"wood--(she\t1\r\n",
"wood.\t3\r\n",
"wooden\t1\r\n",
"word\t8\r\n",
"word)\t1\r\n",
"word,\t2\r\n",
"words\t14\r\n",
"words,\t1\r\n",
"words,’\t1\r\n",
"words.’\t1\r\n",
"words:\t2\r\n",
"words:--\t2\r\n",
"wore\t1\r\n",
"work\t39\r\n",
"work,\t8\r\n",
"work.\t5\r\n",
"works\t22\r\n",
"works!’\t1\r\n",
"works,\t5\r\n",
"works.\t5\r\n",
"world\t6\r\n",
"world!\t1\r\n",
"worm.\t1\r\n",
"worried.\t1\r\n",
"worry\t1\r\n",
"worse\t2\r\n",
"worse.\t1\r\n",
"worth\t4\r\n",
"would\t68\r\n",
"would,\t1\r\n",
"would,’\t1\r\n",
"wouldn’t\t12\r\n",
"wow!\t2\r\n",
"wow!’\t2\r\n",
"wrapping\t1\r\n",
"wretched\t2\r\n",
"wriggling\t1\r\n",
"write\t5\r\n",
"writing\t7\r\n",
"writing-desk?’\t1\r\n",
"writing-desks,\t1\r\n",
"written\t9\r\n",
"wrong\t2\r\n",
"wrong!’\t1\r\n",
"wrong,\t2\r\n",
"wrote\t3\r\n",
"www.gutenberg.org\t2\r\n",
"yards\t1\r\n",
"yawned\t2\r\n",
"yawning\t1\r\n",
"yawning.\t1\r\n",
"ye;\t1\r\n",
"year\t2\r\n",
"years,\t2\r\n",
"yelled\t1\r\n",
"yelp\t1\r\n",
"yer\t4\r\n",
"yesterday\t2\r\n",
"yesterday,\t1\r\n",
"yet\t6\r\n",
"yet!’\t1\r\n",
"yet,\t3\r\n",
"yet,’\t4\r\n",
"yet--Oh!\t1\r\n",
"yet--and\t1\r\n",
"yet--it’s\t1\r\n",
"yet.’\t2\r\n",
"yet?’\t2\r\n",
"you\t301\r\n",
"you!\t2\r\n",
"you!)\t1\r\n",
"you!’\t3\r\n",
"you,\t25\r\n",
"you,’\t6\r\n",
"you--all\t1\r\n",
"you--are\t1\r\n",
"you.\t1\r\n",
"you.’\t1\r\n",
"you:\t1\r\n",
"you?\t2\r\n",
"you?’\t7\r\n",
"young\t5\r\n",
"your\t62\r\n",
"yours\t1\r\n",
"yours.”’\t1\r\n",
"yourself\t5\r\n",
"yourself!’\t1\r\n",
"yourself,\t1\r\n",
"yourself,’\t1\r\n",
"yourself.’\t2\r\n",
"youth,\t3\r\n",
"youth,’\t3\r\n",
"you’d\t8\r\n",
"you’ll\t4\r\n",
"you’re\t15\r\n",
"you’ve\t5\r\n",
"zigzag,\t1\r\n",
"‘--I\t1\r\n",
"‘--Mystery,\t1\r\n",
"‘--and\t2\r\n",
"‘--as\t1\r\n",
"‘--but\t1\r\n",
"‘--change\t1\r\n",
"‘--for\t1\r\n",
"‘--it\t1\r\n",
"‘--likely\t1\r\n",
"‘--or\t1\r\n",
"‘--so\t2\r\n",
"‘--that\t1\r\n",
"‘--well\t1\r\n",
"‘--where’s\t1\r\n",
"‘--yes,\t1\r\n",
"‘--you\t1\r\n",
"‘A\t9\r\n",
"‘ARE\t1\r\n",
"‘AS-IS’\t1\r\n",
"‘After\t1\r\n",
"‘Ah!\t2\r\n",
"‘Ah,\t2\r\n",
"‘Ahem!’\t1\r\n",
"‘Alice!’\t1\r\n",
"‘All\t2\r\n",
"‘An\t1\r\n",
"‘And\t17\r\n",
"‘Anything\t1\r\n",
"‘Are\t4\r\n",
"‘As\t3\r\n",
"‘At\t1\r\n",
"‘Back\t1\r\n",
"‘Beautiful\t2\r\n",
"‘Begin\t1\r\n",
"‘Behead\t1\r\n",
"‘Boots\t1\r\n",
"‘Bring\t1\r\n",
"‘But\t19\r\n",
"‘But,\t1\r\n",
"‘By-the-bye,\t1\r\n",
"‘Call\t4\r\n",
"‘Can\t1\r\n",
"‘Can’t\t1\r\n",
"‘Certainly\t1\r\n",
"‘Change\t1\r\n",
"‘Cheshire\t1\r\n",
"‘Chorus\t1\r\n",
"‘Collar\t1\r\n",
"‘Come\t6\r\n",
"‘Come,\t9\r\n",
"‘Consider\t2\r\n",
"‘Consider,\t1\r\n",
"‘Curiouser\t1\r\n",
"‘DRINK\t2\r\n",
"‘Dear,\t1\r\n",
"‘Did\t3\r\n",
"‘Digging\t1\r\n",
"‘Dinah’ll\t1\r\n",
"‘Dinah’s\t1\r\n",
"‘Do\t8\r\n",
"‘Does\t2\r\n",
"‘Don’t\t4\r\n",
"‘Drink\t1\r\n",
"‘Drive\t1\r\n",
"‘EAT\t1\r\n",
"‘EVERYBODY\t1\r\n",
"‘Each\t1\r\n",
"‘Everybody\t1\r\n",
"‘Everything’s\t1\r\n",
"‘Exactly\t2\r\n",
"‘Explain\t2\r\n",
"‘Fetch\t1\r\n",
"‘Fifteenth,’\t1\r\n",
"‘First\t1\r\n",
"‘For\t1\r\n",
"‘Found\t2\r\n",
"‘Fourteenth\t1\r\n",
"‘From\t1\r\n",
"‘Fury\t1\r\n",
"‘Get\t2\r\n",
"‘Give\t3\r\n",
"‘Go\t2\r\n",
"‘HE\t1\r\n",
"‘Hadn’t\t1\r\n",
"‘Hand\t1\r\n",
"‘Have\t3\r\n",
"‘He\t4\r\n",
"‘Herald,\t1\r\n",
"‘Here!\t2\r\n",
"‘Here!’\t1\r\n",
"‘Hjckrrh!’\t1\r\n",
"‘Hm!\t1\r\n",
"‘Hold\t3\r\n",
"‘How\t15\r\n",
"‘Hush!\t1\r\n",
"‘I\t121\r\n",
"‘I--I\t1\r\n",
"‘I--I’m\t1\r\n",
"‘IF\t1\r\n",
"‘IT\t1\r\n",
"‘Idiot!’\t1\r\n",
"‘If\t13\r\n",
"‘In\t5\r\n",
"‘Is\t3\r\n",
"‘It\t24\r\n",
"‘It’s\t15\r\n",
"‘It’s--it’s\t1\r\n",
"‘I’M\t1\r\n",
"‘I’VE\t1\r\n",
"‘I’d\t4\r\n",
"‘I’ll\t5\r\n",
"‘I’m\t19\r\n",
"‘I’ve\t13\r\n",
"‘Just\t2\r\n",
"‘Keep\t1\r\n",
"‘Leave\t1\r\n",
"‘Let\t3\r\n",
"‘Let’s\t1\r\n",
"‘Look\t1\r\n",
"‘Mary\t1\r\n",
"‘May\t1\r\n",
"‘Mine\t1\r\n",
"‘Mouse\t1\r\n",
"‘My\t2\r\n",
"‘Nearly\t1\r\n",
"‘Never\t1\r\n",
"‘Never!’\t1\r\n",
"‘No\t1\r\n",
"‘No,\t9\r\n",
"‘No,’\t2\r\n",
"‘Nobody\t2\r\n",
"‘Nonsense!’\t1\r\n",
"‘Nor\t1\r\n",
"‘Not\t9\r\n",
"‘Nothing\t3\r\n",
"‘Nothing,’\t1\r\n",
"‘Now\t4\r\n",
"‘Now,\t4\r\n",
"‘O\t1\r\n",
"‘ORANGE\t1\r\n",
"‘Of\t11\r\n",
"‘Off\t8\r\n",
"‘Oh\t2\r\n",
"‘Oh!\t2\r\n",
"‘Oh,\t19\r\n",
"‘Once\t1\r\n",
"‘Once,’\t1\r\n",
"‘One\t2\r\n",
"‘One,\t2\r\n",
"‘Only\t2\r\n",
"‘Or\t1\r\n",
"‘Ou\t1\r\n",
"‘Pepper,\t1\r\n",
"‘Perhaps\t3\r\n",
"‘Please\t3\r\n",
"‘Please,\t1\r\n",
"‘Poor\t1\r\n",
"‘Pray\t1\r\n",
"‘Prizes!\t1\r\n",
"‘Read\t1\r\n",
"‘Really,\t2\r\n",
"‘Reeling\t1\r\n",
"‘Repeat,\t1\r\n",
"‘Right,\t1\r\n",
"‘Rule\t1\r\n",
"‘SHE\t1\r\n",
"‘Same\t1\r\n",
"‘Seals,\t1\r\n",
"‘Sentence\t1\r\n",
"‘Serpent!’\t1\r\n",
"‘Serpent,\t1\r\n",
"‘Seven\t1\r\n",
"‘Sh!\t1\r\n",
"‘Shall\t1\r\n",
"‘Shan’t,’\t1\r\n",
"‘She\t2\r\n",
"‘She’d\t1\r\n",
"‘She’s\t2\r\n",
"‘Shy,\t1\r\n",
"‘Silence\t1\r\n",
"‘Silence!’\t1\r\n",
"‘Sit\t1\r\n",
"‘Sixteenth,’\t1\r\n",
"‘So\t4\r\n",
"‘Soles\t1\r\n",
"‘Somebody\t1\r\n",
"‘Soo--oop\t1\r\n",
"‘Speak\t2\r\n",
"‘Stand\t1\r\n",
"‘Stolen!’\t1\r\n",
"‘Stuff\t1\r\n",
"‘Stupid\t1\r\n",
"‘Suppose\t2\r\n",
"‘Sure\t1\r\n",
"‘Sure,\t3\r\n",
"‘Swim\t1\r\n",
"‘THAT\t2\r\n",
"‘Take\t2\r\n",
"‘Talking\t1\r\n",
"‘Tell\t1\r\n",
"‘Ten\t1\r\n",
"‘Thank\t3\r\n",
"‘That\t6\r\n",
"‘That’s\t14\r\n",
"‘The\t15\r\n",
"‘Their\t1\r\n",
"‘Then\t11\r\n",
"‘Then,\t1\r\n",
"‘There\t4\r\n",
"‘There’s\t6\r\n",
"‘They\t9\r\n",
"‘They’re\t2\r\n",
"‘Thinking\t1\r\n",
"‘This\t2\r\n",
"‘To\t1\r\n",
"‘Treacle,’\t2\r\n",
"‘Turn\t2\r\n",
"‘Tut,\t1\r\n",
"‘Twenty-four\t1\r\n",
"‘Twinkle,\t1\r\n",
"‘Two\t2\r\n",
"‘UNimportant,\t2\r\n",
"‘Ugh!’\t1\r\n",
"‘Up,\t1\r\n",
"‘VERY\t1\r\n",
"‘Very\t3\r\n",
"‘Very,’\t1\r\n",
"‘W.\t1\r\n",
"‘Wake\t2\r\n",
"‘We\t8\r\n",
"‘Well!\t2\r\n",
"‘Well!’\t1\r\n",
"‘Well,\t20\r\n",
"‘What\t32\r\n",
"‘What!\t1\r\n",
"‘What’s\t2\r\n",
"‘When\t3\r\n",
"‘Where\t1\r\n",
"‘Where’s\t1\r\n",
"‘Which\t3\r\n",
"‘Who\t6\r\n",
"‘Whoever\t1\r\n",
"‘Who’s\t1\r\n",
"‘Why\t7\r\n",
"‘Why,\t8\r\n",
"‘Why,’\t2\r\n",
"‘Why?’\t2\r\n",
"‘With\t1\r\n",
"‘Would\t5\r\n",
"‘Wouldn’t\t1\r\n",
"‘Wow!\t2\r\n",
"‘Write\t1\r\n",
"‘YOU\t1\r\n",
"‘YOU’D\t1\r\n",
"‘Yes!’\t1\r\n",
"‘Yes,\t8\r\n",
"‘Yes,’\t3\r\n",
"‘You\t30\r\n",
"‘You!’\t1\r\n",
"‘Your\t2\r\n",
"‘You’d\t1\r\n",
"‘You’ll\t2\r\n",
"‘You’re\t6\r\n",
"‘You’ve\t1\r\n",
"‘a\t2\r\n",
"‘advance\t1\r\n",
"‘after\t1\r\n",
"‘all\t1\r\n",
"‘allow\t1\r\n",
"‘and\t38\r\n",
"‘any\t1\r\n",
"‘are\t2\r\n",
"‘arrum.’)\t1\r\n",
"‘as\t4\r\n",
"‘at\t2\r\n",
"‘because\t3\r\n",
"‘besides,\t1\r\n",
"‘but\t19\r\n",
"‘chop\t1\r\n",
"‘creatures,’\t1\r\n",
"‘crumbs\t1\r\n",
"‘don’t\t2\r\n",
"‘either\t1\r\n",
"‘em\t3\r\n",
"‘explanations\t1\r\n",
"‘fetch\t1\r\n",
"‘flamingoes\t1\r\n",
"‘for\t6\r\n",
"‘he\t2\r\n",
"‘he’s\t1\r\n",
"‘his\t1\r\n",
"‘how\t1\r\n",
"‘however,\t1\r\n",
"‘if\t7\r\n",
"‘important,’\t1\r\n",
"‘important--unimportant--unimportant--important--’\t1\r\n",
"‘in\t3\r\n",
"‘is\t1\r\n",
"‘it\t5\r\n",
"‘it’ll\t1\r\n",
"‘it’s\t8\r\n",
"‘jury-men’\t1\r\n",
"‘just\t1\r\n",
"‘leave\t1\r\n",
"‘let’s\t1\r\n",
"‘lives\t2\r\n",
"‘living\t1\r\n",
"‘moral,’\t1\r\n",
"‘nine\t1\r\n",
"‘no\t1\r\n",
"‘not\t2\r\n",
"‘now\t1\r\n",
"‘of\t1\r\n",
"‘on\t1\r\n",
"‘one\t1\r\n",
"‘only\t1\r\n",
"‘only,\t1\r\n",
"‘or\t5\r\n",
"‘poison,’\t2\r\n",
"‘really\t1\r\n",
"‘shall\t1\r\n",
"‘she\t1\r\n",
"‘she’s\t1\r\n",
"‘sit\t1\r\n",
"‘so\t3\r\n",
"‘some\t1\r\n",
"‘stupid\t1\r\n",
"‘stupid,’\t1\r\n",
"‘tell\t1\r\n",
"‘than\t1\r\n",
"‘that\t7\r\n",
"‘that’s\t1\r\n",
"‘the\t5\r\n",
"‘there’s\t1\r\n",
"‘they--you’ve\t1\r\n",
"‘they’d\t1\r\n",
"‘they’re\t1\r\n",
"‘this\t1\r\n",
"‘three\t1\r\n",
"‘till\t2\r\n",
"‘tis\t2\r\n",
"‘to\t4\r\n",
"‘unimportant.’\t1\r\n",
"‘unless\t1\r\n",
"‘until\t1\r\n",
"‘was,\t1\r\n",
"‘we\t3\r\n",
"‘we’re\t1\r\n",
"‘what\t2\r\n",
"‘what’s\t1\r\n",
"‘when\t2\r\n",
"‘whenever\t1\r\n",
"‘why\t2\r\n",
"‘why,\t1\r\n",
"‘without\t1\r\n",
"‘you\t8\r\n",
"‘’Tis\t2\r\n",
"‘“--found\t1\r\n",
"‘“Miss\t1\r\n",
"‘“WE\t1\r\n",
"‘“What\t1\r\n",
"‘“Will\t1\r\n",
"“--SAID\t1\r\n",
"“Come\t1\r\n",
"“Coming\t1\r\n",
"“Defects,”\t1\r\n",
"“Edwin\t1\r\n",
"“French,\t1\r\n",
"“HOW\t1\r\n",
"“He’s\t1\r\n",
"“How\t1\r\n",
"“I\t7\r\n",
"“Information\t1\r\n",
"“I’ll\t2\r\n",
"“Keep\t1\r\n",
"“Let\t1\r\n",
"“Plain\t2\r\n",
"“Project\t5\r\n",
"“Right\t1\r\n",
"“Such\t1\r\n",
"“THEY\t1\r\n",
"“There\t2\r\n",
"“There’s\t1\r\n",
"“Too\t1\r\n",
"“Turtle\t1\r\n",
"“Twinkle,\t1\r\n",
"“Uglification,”’\t1\r\n",
"“Up\t1\r\n",
"“What\t2\r\n",
"“Who\t1\r\n",
"“William\t1\r\n",
"“With\t1\r\n",
"“YOU\t1\r\n",
"“You\t2\r\n",
"“come\t1\r\n",
"“it”\t2\r\n",
"“much\t1\r\n",
"“poison”\t1\r\n",
"“purpose”?’\t1\r\n",
"“‘TIS\t1\r\n"
]
}
],
"source": [
"!hdfs dfs -cat {HDFS_DIR}/wc-output/part-00000"
]
},
{
"cell_type": "code",
"execution_count": null,
"metadata": {},
"outputs": [],
"source": []
}
],
"metadata": {
"kernelspec": {
"display_name": "Python 3",
"language": "python",
"name": "python3"
},
"language_info": {
"codemirror_mode": {
"name": "ipython",
"version": 3
},
"file_extension": ".py",
"mimetype": "text/x-python",
"name": "python",
"nbconvert_exporter": "python",
"pygments_lexer": "ipython3",
"version": "3.7.2"
}
},
"nbformat": 4,
"nbformat_minor": 2
}
Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment