You are viewing a plain text version of this content. The canonical link for it is here.
Posted to server-dev@james.apache.org by bt...@apache.org on 2018/07/31 02:32:22 UTC

[05/24] james-project git commit: JAMES-2501 Create a SpamAssassin backend project

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamd.java
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamd.java b/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamd.java
new file mode 100644
index 0000000..d98b5a0
--- /dev/null
+++ b/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamd.java
@@ -0,0 +1,101 @@
+/****************************************************************
+ * Licensed to the Apache Software Foundation (ASF) under one   *
+ * or more contributor license agreements.  See the NOTICE file *
+ * distributed with this work for additional information        *
+ * regarding copyright ownership.  The ASF licenses this file   *
+ * to you under the Apache License, Version 2.0 (the            *
+ * "License"); you may not use this file except in compliance   *
+ * with the License.  You may obtain a copy of the License at   *
+ *                                                              *
+ *   http://www.apache.org/licenses/LICENSE-2.0                 *
+ *                                                              *
+ * Unless required by applicable law or agreed to in writing,   *
+ * software distributed under the License is distributed on an  *
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY       *
+ * KIND, either express or implied.  See the License for the    *
+ * specific language governing permissions and limitations      *
+ * under the License.                                           *
+ ****************************************************************/
+package org.apache.james.spamassassin.mock;
+
+import static org.apache.commons.io.output.NullOutputStream.NULL_OUTPUT_STREAM;
+
+import java.io.BufferedReader;
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.io.OutputStream;
+import java.net.ServerSocket;
+import java.net.Socket;
+import java.nio.charset.StandardCharsets;
+
+import org.apache.commons.io.IOUtils;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import com.google.common.base.Preconditions;
+
+/**
+ * This class can be used to run a mocked SPAMD daemon
+ */
+public class MockSpamd implements Runnable {
+    private static final Logger LOGGER = LoggerFactory.getLogger(MockSpamd.class);
+
+    /**
+     * Mailcontent which is 100% spam
+     */
+    public static final String GTUBE = "-SPAM-";
+    public static final String NOT_SPAM = "Spam: False ; 3 / 5";
+    public static final String SPAM = "Spam: True ; 1000 / 5";
+
+    private ServerSocket socket;
+    private boolean isBinded;
+
+    public MockSpamd() {
+        isBinded = false;
+    }
+
+    public int getPort() {
+        Preconditions.checkState(isBinded, "SpamD mock server is not binded");
+        return socket.getLocalPort();
+    }
+
+    public void bind() throws IOException {
+        socket = new ServerSocket(0);
+        isBinded = true;
+    }
+
+    @Override
+    public void run() {
+        try (ServerSocket serverSocket = socket;
+            Socket spamd = serverSocket.accept();
+             BufferedReader in = new BufferedReader(new InputStreamReader(spamd.getInputStream()));
+             OutputStream out = spamd.getOutputStream()) {
+
+            handleRequest(in, out);
+        } catch (IOException e) {
+            LOGGER.error("Exception while handling answer", e);
+        }
+    }
+
+    private void handleRequest(BufferedReader in, OutputStream out) throws IOException {
+        if (isSpam(in)) {
+            out.write(SPAM.getBytes());
+        } else {
+            out.write(NOT_SPAM.getBytes());
+        }
+        out.flush();
+    }
+
+    private boolean isSpam(BufferedReader in) throws IOException {
+        try {
+            return in.lines()
+                .anyMatch(line -> line.contains(GTUBE));
+        } finally {
+            consume(in);
+        }
+    }
+
+    private void consume(BufferedReader in) throws IOException {
+        IOUtils.copy(in, NULL_OUTPUT_STREAM, StandardCharsets.UTF_8);
+    }
+}

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamdTestRule.java
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamdTestRule.java b/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamdTestRule.java
new file mode 100644
index 0000000..9712a42
--- /dev/null
+++ b/third-party/spamassassin/src/test/java/org/apache/james/spamassassin/mock/MockSpamdTestRule.java
@@ -0,0 +1,46 @@
+/****************************************************************
+ * Licensed to the Apache Software Foundation (ASF) under one   *
+ * or more contributor license agreements.  See the NOTICE file *
+ * distributed with this work for additional information        *
+ * regarding copyright ownership.  The ASF licenses this file   *
+ * to you under the Apache License, Version 2.0 (the            *
+ * "License"); you may not use this file except in compliance   *
+ * with the License.  You may obtain a copy of the License at   *
+ *                                                              *
+ *   http://www.apache.org/licenses/LICENSE-2.0                 *
+ *                                                              *
+ * Unless required by applicable law or agreed to in writing,   *
+ * software distributed under the License is distributed on an  *
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY       *
+ * KIND, either express or implied.  See the License for the    *
+ * specific language governing permissions and limitations      *
+ * under the License.                                           *
+ ****************************************************************/
+
+package org.apache.james.spamassassin.mock;
+
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+
+import org.junit.rules.ExternalResource;
+
+public class MockSpamdTestRule extends ExternalResource {
+
+    private ExecutorService executor = Executors.newSingleThreadExecutor();
+    private MockSpamd spamd = new MockSpamd();
+
+    @Override
+    protected void before() throws Throwable {
+        spamd.bind();
+        executor.execute(spamd);
+    }
+
+    public int getPort() {
+        return spamd.getPort();
+    }
+
+    @Override
+    protected void after() {
+        executor.shutdownNow();
+    }
+}

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/docker/spamassassin/Dockerfile
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/docker/spamassassin/Dockerfile b/third-party/spamassassin/src/test/resources/docker/spamassassin/Dockerfile
new file mode 100644
index 0000000..ad1187a
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/docker/spamassassin/Dockerfile
@@ -0,0 +1,43 @@
+FROM postgres:10.3
+
+ENV SPAMASSASSIN_VERSION 3.4.1
+
+RUN apt-get update && \
+    DEBIAN_FRONTEND=noninteractive apt-get install --no-install-recommends -y \
+        gpg \
+        libio-socket-ip-perl \
+        libmail-dkim-perl \
+        libnet-ident-perl \
+        libsocket-getaddrinfo-perl \
+        pyzor \
+        razor \
+        libdbi-perl \
+        libdbd-pg-perl \
+        spamassassin=${SPAMASSASSIN_VERSION}* && \
+    apt-get clean && \
+    rm -rf /var/lib/apt/lists/*
+
+RUN mkdir -p /etc/spamassassin/sa-update-keys && \
+    chmod 700 /etc/spamassassin/sa-update-keys && \
+    chown debian-spamd:debian-spamd /etc/spamassassin/sa-update-keys && \
+    mkdir -p /var/lib/spamassassin/.pyzor && \
+    chmod 700 /var/lib/spamassassin/.pyzor && \
+    echo "public.pyzor.org:24441" > /var/lib/spamassassin/.pyzor/servers && \
+    chmod 600 /var/lib/spamassassin/.pyzor/servers && \
+    chown -R debian-spamd:debian-spamd /var/lib/spamassassin/.pyzor
+
+RUN sed -i 's/^logfile = .*$/logfile = \/dev\/stderr/g' /etc/razor/razor-agent.conf
+
+COPY spamd.sh /
+COPY rule-update.sh /
+COPY run.sh /
+RUN chmod 755 /spamd.sh /rule-update.sh /run.sh
+
+COPY local.cf /etc/spamassassin/
+
+# Bayes database will be created automatically by Postres
+COPY bayes_pg.sql /docker-entrypoint-initdb.d/
+
+EXPOSE 783
+
+ENTRYPOINT ["/spamd.sh"]

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/docker/spamassassin/bayes_pg.sql
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/docker/spamassassin/bayes_pg.sql b/third-party/spamassassin/src/test/resources/docker/spamassassin/bayes_pg.sql
new file mode 100644
index 0000000..ef96472
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/docker/spamassassin/bayes_pg.sql
@@ -0,0 +1,119 @@
+
+CREATE TABLE bayes_expire (
+  id integer NOT NULL default '0',
+  runtime integer NOT NULL default '0'
+) WITHOUT OIDS;
+
+CREATE INDEX bayes_expire_idx1 ON bayes_expire (id);
+
+CREATE TABLE bayes_global_vars (
+  variable varchar(30) NOT NULL default '',
+  value varchar(200) NOT NULL default '',
+  PRIMARY KEY  (variable)
+) WITHOUT OIDS;
+
+INSERT INTO bayes_global_vars VALUES ('VERSION','3');
+
+CREATE TABLE bayes_seen (
+  id integer NOT NULL default '0',
+  msgid varchar(200) NOT NULL default '',
+  flag character(1) NOT NULL default '',
+  PRIMARY KEY  (id,msgid)
+) WITHOUT OIDS;
+
+CREATE TABLE bayes_token (
+  id integer NOT NULL default '0',
+  token bytea NOT NULL default '',
+  spam_count integer NOT NULL default '0',
+  ham_count integer NOT NULL default '0',
+  atime integer NOT NULL default '0',
+  PRIMARY KEY  (id,token)
+) WITHOUT OIDS;
+
+CREATE INDEX bayes_token_idx1 ON bayes_token (token);
+
+ALTER TABLE bayes_token SET (fillfactor=95);
+
+CREATE TABLE bayes_vars (
+  id serial NOT NULL,
+  username varchar(200) NOT NULL default '',
+  spam_count integer NOT NULL default '0',
+  ham_count integer NOT NULL default '0',
+  token_count integer NOT NULL default '0',
+  last_expire integer NOT NULL default '0',
+  last_atime_delta integer NOT NULL default '0',
+  last_expire_reduce integer NOT NULL default '0',
+  oldest_token_age integer NOT NULL default '2147483647',
+  newest_token_age integer NOT NULL default '0',
+  PRIMARY KEY  (id)
+) WITHOUT OIDS;
+
+CREATE UNIQUE INDEX bayes_vars_idx1 ON bayes_vars (username);
+
+CREATE OR REPLACE FUNCTION greatest_int (integer, integer)
+ RETURNS INTEGER
+ IMMUTABLE STRICT
+ AS 'SELECT CASE WHEN $1 < $2 THEN $2 ELSE $1 END;'
+ LANGUAGE SQL;
+
+CREATE OR REPLACE FUNCTION least_int (integer, integer)
+ RETURNS INTEGER
+ IMMUTABLE STRICT
+ AS 'SELECT CASE WHEN $1 < $2 THEN $1 ELSE $2 END;'
+ LANGUAGE SQL;
+
+CREATE OR REPLACE FUNCTION put_tokens(INTEGER,
+                                      BYTEA[],
+                                      INTEGER,
+                                      INTEGER,
+                                      INTEGER)
+RETURNS VOID AS ' 
+DECLARE
+  inuserid      ALIAS FOR $1;
+  intokenary    ALIAS FOR $2;
+  inspam_count  ALIAS FOR $3;
+  inham_count   ALIAS FOR $4;
+  inatime       ALIAS FOR $5;
+  _token BYTEA;
+  new_tokens INTEGER := 0;
+BEGIN
+  for i in array_lower(intokenary, 1) .. array_upper(intokenary, 1)
+  LOOP
+    _token := intokenary[i];
+    UPDATE bayes_token
+       SET spam_count = greatest_int(spam_count + inspam_count, 0),
+           ham_count = greatest_int(ham_count + inham_count, 0),
+           atime = greatest_int(atime, inatime)
+     WHERE id = inuserid 
+       AND token = _token;
+    IF NOT FOUND THEN 
+      -- we do not insert negative counts, just return true
+      IF NOT (inspam_count < 0 OR inham_count < 0) THEN
+        INSERT INTO bayes_token (id, token, spam_count, ham_count, atime) 
+        VALUES (inuserid, _token, inspam_count, inham_count, inatime); 
+        IF FOUND THEN
+          new_tokens := new_tokens + 1;
+        END IF;
+      END IF;
+    END IF;
+  END LOOP;
+
+  IF new_tokens > 0 AND inatime > 0 THEN
+    UPDATE bayes_vars
+       SET token_count = token_count + new_tokens,
+           newest_token_age = greatest_int(newest_token_age, inatime),
+           oldest_token_age = least_int(oldest_token_age, inatime)
+     WHERE id = inuserid;
+  ELSIF new_tokens > 0 AND NOT inatime > 0 THEN
+    UPDATE bayes_vars
+       SET token_count = token_count + new_tokens
+     WHERE id = inuserid;
+  ELSIF NOT new_tokens > 0 AND inatime > 0 THEN
+    UPDATE bayes_vars
+       SET newest_token_age = greatest_int(newest_token_age, inatime),
+           oldest_token_age = least_int(oldest_token_age, inatime)
+     WHERE id = inuserid;
+  END IF;
+  RETURN;
+END; 
+' LANGUAGE 'plpgsql'; 

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/docker/spamassassin/local.cf
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/docker/spamassassin/local.cf b/third-party/spamassassin/src/test/resources/docker/spamassassin/local.cf
new file mode 100644
index 0000000..6005e55
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/docker/spamassassin/local.cf
@@ -0,0 +1,97 @@
+# This is the right place to customize your installation of SpamAssassin.
+#
+# See 'perldoc Mail::SpamAssassin::Conf' for details of what can be
+# tweaked.
+#
+# Only a small subset of options are listed below
+#
+###########################################################################
+
+#   Add *****SPAM***** to the Subject header of spam e-mails
+#
+# rewrite_header Subject *****SPAM*****
+
+
+#   Save spam messages as a message/rfc822 MIME attachment instead of
+#   modifying the original message (0: off, 2: use text/plain instead)
+#
+# report_safe 1
+
+
+#   Set which networks or hosts are considered 'trusted' by your mail
+#   server (i.e. not spammers)
+#
+# trusted_networks 212.17.35.
+
+
+#   Set file-locking method (flock is not safe over NFS, but is faster)
+#
+# lock_method flock
+
+
+#   Set the threshold at which a message is considered spam (default: 5.0)
+#
+# required_score 5.0
+
+
+#   Use Bayesian classifier (default: 1)
+#
+use_bayes 1
+
+
+#   Bayesian classifier auto-learning (default: 1)
+#
+#bayes_auto_learn 1
+
+bayes_store_module Mail::SpamAssassin::BayesStore::PgSQL
+
+bayes_sql_dsn DBI:Pg:dbname=postgres;host=localhost
+bayes_sql_username postgres
+
+bayes_min_spam_num 1
+bayes_min_ham_num 1
+
+
+#   Set headers which may provide inappropriate cues to the Bayesian
+#   classifier
+#
+# bayes_ignore_header X-Bogosity
+# bayes_ignore_header X-Spam-Flag
+# bayes_ignore_header X-Spam-Status
+
+
+#   Whether to decode non- UTF-8 and non-ASCII textual parts and recode
+#   them to UTF-8 before the text is given over to rules processing.
+#
+# normalize_charset 1
+
+#   Some shortcircuiting, if the plugin is enabled
+# 
+ifplugin Mail::SpamAssassin::Plugin::Shortcircuit
+#
+#   default: strongly-whitelisted mails are *really* whitelisted now, if the
+#   shortcircuiting plugin is active, causing early exit to save CPU load.
+#   Uncomment to turn this on
+#
+# shortcircuit USER_IN_WHITELIST       on
+# shortcircuit USER_IN_DEF_WHITELIST   on
+# shortcircuit USER_IN_ALL_SPAM_TO     on
+# shortcircuit SUBJECT_IN_WHITELIST    on
+
+#   the opposite; blacklisted mails can also save CPU
+#
+# shortcircuit USER_IN_BLACKLIST       on
+# shortcircuit USER_IN_BLACKLIST_TO    on
+# shortcircuit SUBJECT_IN_BLACKLIST    on
+
+#   if you have taken the time to correctly specify your "trusted_networks",
+#   this is another good way to save CPU
+#
+# shortcircuit ALL_TRUSTED             on
+
+#   and a well-trained bayes DB can save running rules, too
+#
+# shortcircuit BAYES_99                spam
+# shortcircuit BAYES_00                ham
+
+endif # Mail::SpamAssassin::Plugin::Shortcircuit

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/docker/spamassassin/rule-update.sh
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/docker/spamassassin/rule-update.sh b/third-party/spamassassin/src/test/resources/docker/spamassassin/rule-update.sh
new file mode 100755
index 0000000..2867735
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/docker/spamassassin/rule-update.sh
@@ -0,0 +1,7 @@
+#!/bin/bash
+
+while true; do
+    sleep 1m
+    su debian-spamd -c 'sa-update' && kill -HUP `cat /var/run/spamd.pid`
+    sleep 1d
+done

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/docker/spamassassin/run.sh
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/docker/spamassassin/run.sh b/third-party/spamassassin/src/test/resources/docker/spamassassin/run.sh
new file mode 100755
index 0000000..b4a1351
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/docker/spamassassin/run.sh
@@ -0,0 +1,9 @@
+#!/bin/bash
+set -m
+
+/rule-update.sh &
+/spamd.sh &
+
+pids=`jobs -p`
+
+wait

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/docker/spamassassin/spamd.sh
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/docker/spamassassin/spamd.sh b/third-party/spamassassin/src/test/resources/docker/spamassassin/spamd.sh
new file mode 100755
index 0000000..2093cf8
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/docker/spamassassin/spamd.sh
@@ -0,0 +1,15 @@
+#!/bin/bash
+
+echo "Run Postgres"
+/usr/local/bin/docker-entrypoint.sh postgres &
+
+echo "Run spamd"
+spamd --username debian-spamd \
+      --nouser-config \
+      --syslog stderr \
+      --pidfile /var/run/spamd.pid \
+      --helper-home-dir /var/lib/spamassassin \
+      --ip-address \
+      --allowed-ips 0.0.0.0/0 \
+      --allow-tell \
+      --debug bayes,learn

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/eml/spam.eml
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/eml/spam.eml b/third-party/spamassassin/src/test/resources/eml/spam.eml
new file mode 100755
index 0000000..faf3402
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/eml/spam.eml
@@ -0,0 +1,152 @@
+Return-Path: <us...@james.org>
+Subject: Fwd: Invitation: (Aucun objet) - ven. 20 janv. 2017 14:00 - 15:00
+ (CET) (user@james.org)
+To: <us...@james.org>
+From: user <us...@james.org>
+Message-ID: <f1...@james.org>
+Date: Thu, 19 Jan 2017 20:36:37 +0100
+MIME-Version: 1.0
+In-Reply-To: <00...@google.com>
+Content-Type: multipart/mixed;
+ boundary="------------17D96D411CBD55D8239A8C1F"
+
+This is a multi-part message in MIME format.
+--------------17D96D411CBD55D8239A8C1F
+Content-Type: multipart/alternative;
+ boundary="------------64D716A3DDAEC185D3E67448"
+
+
+--------------64D716A3DDAEC185D3E67448
+Content-Type: text/plain; charset=utf-8; format=flowed
+Content-Transfer-Encoding: 8bit
+
+
+
+
+-------- Message transéré --------
+Sujet : 	Invitation: (Aucun objet) - ven. 20 janv. 2017 14:00 - 15:00
+(CET) (user@james.org)
+Date : 	Thu, 19 Jan 2017 19:18:23 +0000
+De : 	<us...@james.org>
+Répondre à : 	user@james.org
+Pour : 	user@james.org
+
+
+
+
+--------------64D716A3DDAEC185D3E67448
+Content-Type: text/html; charset=utf-8
+Content-Transfer-Encoding: 8bit
+
+<html>
+  <head>
+
+    <meta http-equiv="content-type" content="text/html; charset=utf-8">
+  </head>
+  <body bgcolor="#FFFFFF" text="#000000">
+    <p><br>
+    </p>
+    <div class="moz-forward-container"><br>
+      <br>
+      -------- Message transéré --------
+      <table class="moz-email-headers-table" border="0" cellpadding="0"
+        cellspacing="0">
+        <tbody>
+          <tr>
+            <th align="RIGHT" valign="BASELINE" nowrap="nowrap">Sujet :
+            </th>
+            <td>Invitation: (Aucun objet) - ven. 20 janv. 2017 14:00 -
+              15:00 (CET) (<a class="moz-txt-link-abbreviated" href="mailto:user@james.org">user@james.org</a>)</td>
+          </tr>
+          <tr>
+            <th align="RIGHT" valign="BASELINE" nowrap="nowrap">Date : </th>
+            <td>Thu, 19 Jan 2017 19:18:23 +0000</td>
+          </tr>
+          <tr>
+            <th align="RIGHT" valign="BASELINE" nowrap="nowrap">De : </th>
+            <td>User <a class="moz-txt-link-rfc2396E" href="mailto:user@james.org">&lt;user@james.org&gt;</a></td>
+          </tr>
+          <tr>
+            <th align="RIGHT" valign="BASELINE" nowrap="nowrap">Répondre
+              Ã Â : </th>
+            <td><a class="moz-txt-link-abbreviated" href="mailto:user@james.org">user@james.org</a></td>
+          </tr>
+          <tr>
+            <th align="RIGHT" valign="BASELINE" nowrap="nowrap">Pour : </th>
+            <td><a class="moz-txt-link-abbreviated" href="mailto:user@james.org">user@james.org</a></td>
+          </tr>
+        </tbody>
+      </table>
+      <br>
+      <br>
+    </div>
+  </body>
+</html>
+
+--------------64D716A3DDAEC185D3E67448--
+
+--------------17D96D411CBD55D8239A8C1F
+Content-Type: text/calendar;
+ name="Portion de message joint"
+Content-Transfer-Encoding: 8bit
+Content-Disposition: attachment;
+ filename="Portion de message joint"
+
+BEGIN:VCALENDAR
+PRODID:-//Google Inc//Google Calendar 70.9054//EN
+VERSION:2.0
+CALSCALE:GREGORIAN
+METHOD:REQUEST
+BEGIN:VEVENT
+DTSTART:20170120T130000Z
+DTEND:20170120T140000Z
+DTSTAMP:20170119T191823Z
+ORGANIZER;CN=User:mailto:user@james.org
+UID:ah86k5m342bmcrbe9khkkhln00@google.com
+ATTENDEE;CUTYPE=INDIVIDUAL;ROLE=REQ-PARTICIPANT;PARTSTAT=NEEDS-ACTION;RSVP=
+ TRUE;CN=user@james.org;X-NUM-GUESTS=0:mailto:user@james.org
+ATTENDEE;CUTYPE=INDIVIDUAL;ROLE=REQ-PARTICIPANT;PARTSTAT=ACCEPTED;RSVP=TRUE
+ ;CN=User;X-NUM-GUESTS=0:mailto:user@james.org
+CREATED:20170119T191823Z
+DESCRIPTION:Affichez votre evenement sur la page https://www.google.com/cal
+ endar/event?action=VIEW&eid=YWg4Nms1bTM0MmJtY3JiZTlraGtraGxuMDAgYWR1cHJhdEB
+ saW5hZ29yYS5jb20&tok=MTkjYW50ZHVwcmF0QGdtYWlsLmNvbTg1OTM5NWM4MGRlYmE1YTI4Nz
+ RjN2UyNjU0M2YyZmQ4NzRkNThhYTQ&ctz=Europe/Paris&hl=fr.
+LAST-MODIFIED:20170119T191823Z
+LOCATION:
+SEQUENCE:0
+STATUS:CONFIRMED
+SUMMARY:
+TRANSP:OPAQUE
+END:VEVENT
+END:VCALENDAR
+
+
+--------------17D96D411CBD55D8239A8C1F
+Content-Type: application/ics;
+ name="invite.ics"
+Content-Transfer-Encoding: base64
+Content-Disposition: attachment;
+ filename="invite.ics"
+
+QkVHSU46VkNBTEVOREFSDQpQUk9ESUQ6LS8vR29vZ2xlIEluYy8vR29vZ2xlIENhbGVuZGFy
+IDcwLjkwNTQvL0VODQpWRVJTSU9OOjIuMA0KQ0FMU0NBTEU6R1JFR09SSUFODQpNRVRIT0Q6
+UkVRVUVTVA0KQkVHSU46VkVWRU5UDQpEVFNUQVJUOjIwMTcwMTIwVDEzMDAwMFoNCkRURU5E
+OjIwMTcwMTIwVDE0MDAwMFoNCkRUU1RBTVA6MjAxNzAxMTlUMTkxODIzWg0KT1JHQU5JWkVS
+O0NOPUFudG9pbmUgRHVwcmF0Om1haWx0bzphbnRkdXByYXRAZ21haWwuY29tDQpVSUQ6YWg4
+Nms1bTM0MmJtY3JiZTlraGtraGxuMDBAZ29vZ2xlLmNvbQ0KQVRURU5ERUU7Q1VUWVBFPUlO
+RElWSURVQUw7Uk9MRT1SRVEtUEFSVElDSVBBTlQ7UEFSVFNUQVQ9TkVFRFMtQUNUSU9OO1JT
+VlA9DQogVFJVRTtDTj1hZHVwcmF0QGxpbmFnb3JhLmNvbTtYLU5VTS1HVUVTVFM9MDptYWls
+dG86YWR1cHJhdEBsaW5hZ29yYS5jb20NCkFUVEVOREVFO0NVVFlQRT1JTkRJVklEVUFMO1JP
+TEU9UkVRLVBBUlRJQ0lQQU5UO1BBUlRTVEFUPUFDQ0VQVEVEO1JTVlA9VFJVRQ0KIDtDTj1B
+bnRvaW5lIER1cHJhdDtYLU5VTS1HVUVTVFM9MDptYWlsdG86YW50ZHVwcmF0QGdtYWlsLmNv
+bQ0KQ1JFQVRFRDoyMDE3MDExOVQxOTE4MjNaDQpERVNDUklQVElPTjpBZmZpY2hleiB2b3Ry
+ZSDDqXbDqW5lbWVudCBzdXIgbGEgcGFnZSBodHRwczovL3d3dy5nb29nbGUuY29tL2NhbA0K
+IGVuZGFyL2V2ZW50P2FjdGlvbj1WSUVXJmVpZD1ZV2c0Tm1zMWJUTTBNbUp0WTNKaVpUbHJh
+R3RyYUd4dU1EQWdZV1IxY0hKaGRFQg0KIHNhVzVoWjI5eVlTNWpiMjAmdG9rPU1Ua2pZVzUw
+WkhWd2NtRjBRR2R0WVdsc0xtTnZiVGcxT1RNNU5XTTRNR1JsWW1FMVlUSTROeg0KIFJqTjJV
+eU5qVTBNMll5Wm1RNE56UmtOVGhoWVRRJmN0ej1FdXJvcGUvUGFyaXMmaGw9ZnIuDQpMQVNU
+LU1PRElGSUVEOjIwMTcwMTE5VDE5MTgyM1oNCkxPQ0FUSU9OOg0KU0VRVUVOQ0U6MA0KU1RB
+VFVTOkNPTkZJUk1FRA0KU1VNTUFSWToNClRSQU5TUDpPUEFRVUUNCkVORDpWRVZFTlQNCkVO
+RDpWQ0FMRU5EQVINCg==
+--------------17D96D411CBD55D8239A8C1F--

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham1
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham1 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham1
new file mode 100644
index 0000000..c50bb11
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham1
@@ -0,0 +1,113 @@
+From exmh-workers-admin@redhat.com  Thu Aug 22 12:36:23 2002
+Return-Path: <ex...@spamassassin.taint.org>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id D03E543C36
+	for <zz...@localhost>; Thu, 22 Aug 2002 07:36:16 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 12:36:16 +0100 (IST)
+Received: from listman.spamassassin.taint.org (listman.spamassassin.taint.org [66.187.233.211]) by
+    dogma.slashnull.org (8.11.6/8.11.6) with ESMTP id g7MBYrZ04811 for
+    <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 12:34:53 +0100
+Received: from listman.spamassassin.taint.org (localhost.localdomain [127.0.0.1]) by
+    listman.redhat.com (Postfix) with ESMTP id 8386540858; Thu, 22 Aug 2002
+    07:35:02 -0400 (EDT)
+Delivered-To: exmh-workers@listman.spamassassin.taint.org
+Received: from int-mx1.corp.spamassassin.taint.org (int-mx1.corp.spamassassin.taint.org
+    [172.16.52.254]) by listman.redhat.com (Postfix) with ESMTP id 10CF8406D7
+    for <ex...@listman.redhat.com>; Thu, 22 Aug 2002 07:34:10 -0400
+    (EDT)
+Received: (from mail@localhost) by int-mx1.corp.spamassassin.taint.org (8.11.6/8.11.6)
+    id g7MBY7g11259 for exmh-workers@listman.redhat.com; Thu, 22 Aug 2002
+    07:34:07 -0400
+Received: from mx1.spamassassin.taint.org (mx1.spamassassin.taint.org [172.16.48.31]) by
+    int-mx1.corp.redhat.com (8.11.6/8.11.6) with SMTP id g7MBY7Y11255 for
+    <ex...@redhat.com>; Thu, 22 Aug 2002 07:34:07 -0400
+Received: from ratree.psu.ac.th ([202.28.97.6]) by mx1.spamassassin.taint.org
+    (8.11.6/8.11.6) with SMTP id g7MBIhl25223 for <ex...@redhat.com>;
+    Thu, 22 Aug 2002 07:18:55 -0400
+Received: from delta.cs.mu.OZ.AU (delta.coe.psu.ac.th [172.30.0.98]) by
+    ratree.psu.ac.th (8.11.6/8.11.6) with ESMTP id g7MBWel29762;
+    Thu, 22 Aug 2002 18:32:40 +0700 (ICT)
+Received: from munnari.OZ.AU (localhost [127.0.0.1]) by delta.cs.mu.OZ.AU
+    (8.11.6/8.11.6) with ESMTP id g7MBQPW13260; Thu, 22 Aug 2002 18:26:25
+    +0700 (ICT)
+From: Robert Elz <kr...@munnari.OZ.AU>
+To: Chris Garrigues <cw...@DeepEddy.Com>
+Cc: exmh-workers@spamassassin.taint.org
+Subject: Re: New Sequences Window
+In-Reply-To: <10...@deepeddy.vircio.com>
+References: <10...@deepeddy.vircio.com>
+    <10...@deepeddy.vircio.com> <96...@munnari.OZ.AU>
+    <10...@deepeddy.vircio.com>
+    <10...@deepeddy.vircio.com>
+MIME-Version: 1.0
+Content-Type: text/plain; charset=us-ascii
+Message-Id: <13...@munnari.OZ.AU>
+X-Loop: exmh-workers@spamassassin.taint.org
+Sender: exmh-workers-admin@spamassassin.taint.org
+Errors-To: exmh-workers-admin@spamassassin.taint.org
+X-Beenthere: exmh-workers@spamassassin.taint.org
+X-Mailman-Version: 2.0.1
+Precedence: bulk
+List-Help: <mailto:exmh-workers-request@spamassassin.taint.org?subject=help>
+List-Post: <ma...@spamassassin.taint.org>
+List-Subscribe: <https://listman.spamassassin.taint.org/mailman/listinfo/exmh-workers>,
+    <mailto:exmh-workers-request@redhat.com?subject=subscribe>
+List-Id: Discussion list for EXMH developers <exmh-workers.spamassassin.taint.org>
+List-Unsubscribe: <https://listman.spamassassin.taint.org/mailman/listinfo/exmh-workers>,
+    <mailto:exmh-workers-request@redhat.com?subject=unsubscribe>
+List-Archive: <https://listman.spamassassin.taint.org/mailman/private/exmh-workers/>
+Date: Thu, 22 Aug 2002 18:26:25 +0700
+
+    Date:        Wed, 21 Aug 2002 10:54:46 -0500
+    From:        Chris Garrigues <cw...@DeepEddy.Com>
+    Message-ID:  <10...@deepeddy.vircio.com>
+
+
+  | I can't reproduce this error.
+
+For me it is very repeatable... (like every time, without fail).
+
+This is the debug log of the pick happening ...
+
+18:19:03 Pick_It {exec pick +inbox -list -lbrace -lbrace -subject ftp -rbrace -rbrace} {4852-4852 -sequence mercury}
+18:19:03 exec pick +inbox -list -lbrace -lbrace -subject ftp -rbrace -rbrace 4852-4852 -sequence mercury
+18:19:04 Ftoc_PickMsgs {{1 hit}}
+18:19:04 Marking 1 hits
+18:19:04 tkerror: syntax error in expression "int ...
+
+Note, if I run the pick command by hand ...
+
+delta$ pick +inbox -list -lbrace -lbrace -subject ftp -rbrace -rbrace  4852-4852 -sequence mercury
+1 hit
+
+That's where the "1 hit" comes from (obviously).  The version of nmh I'm
+using is ...
+
+delta$ pick -version
+pick -- nmh-1.0.4 [compiled on fuchsia.cs.mu.OZ.AU at Sun Mar 17 14:55:56 ICT 2002]
+
+And the relevant part of my .mh_profile ...
+
+delta$ mhparam pick
+-seq sel -list
+
+
+Since the pick command works, the sequence (actually, both of them, the
+one that's explicit on the command line, from the search popup, and the
+one that comes from .mh_profile) do get created.
+
+kre
+
+ps: this is still using the version of the code form a day ago, I haven't
+been able to reach the cvs repository today (local routing issue I think).
+
+
+
+_______________________________________________
+Exmh-workers mailing list
+Exmh-workers@redhat.com
+https://listman.redhat.com/mailman/listinfo/exmh-workers
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham2
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham2 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham2
new file mode 100644
index 0000000..7a5b23a
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham2
@@ -0,0 +1,73 @@
+From Steve_Burt@cursor-system.com  Thu Aug 22 12:46:39 2002
+Return-Path: <St...@cursor-system.com>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id BE12E43C34
+	for <zz...@localhost>; Thu, 22 Aug 2002 07:46:38 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 12:46:38 +0100 (IST)
+Received: from n20.grp.scd.yahoo.com (n20.grp.scd.yahoo.com
+    [66.218.66.76]) by dogma.slashnull.org (8.11.6/8.11.6) with SMTP id
+    g7MBkTZ05087 for <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 12:46:29 +0100
+X-Egroups-Return: sentto-2242572-52726-1030016790-zzzz=spamassassin.taint.org@returns.groups.yahoo.com
+Received: from [66.218.67.196] by n20.grp.scd.yahoo.com with NNFMP;
+    22 Aug 2002 11:46:30 -0000
+X-Sender: steve.burt@cursor-system.com
+X-Apparently-To: zzzzteana@yahoogroups.com
+Received: (EGP: mail-8_1_0_1); 22 Aug 2002 11:46:29 -0000
+Received: (qmail 11764 invoked from network); 22 Aug 2002 11:46:29 -0000
+Received: from unknown (66.218.66.217) by m3.grp.scd.yahoo.com with QMQP;
+    22 Aug 2002 11:46:29 -0000
+Received: from unknown (HELO mailgateway.cursor-system.com) (62.189.7.27)
+    by mta2.grp.scd.yahoo.com with SMTP; 22 Aug 2002 11:46:29 -0000
+Received: from exchange1.cps.local (unverified) by
+    mailgateway.cursor-system.com (Content Technologies SMTPRS 4.2.10) with
+    ESMTP id <T5...@mailgateway.cursor-system.com> for
+    <fo...@yahoogroups.com>; Thu, 22 Aug 2002 13:14:10 +0100
+Received: by exchange1.cps.local with Internet Mail Service (5.5.2653.19)
+    id <PXX6AT23>; Thu, 22 Aug 2002 12:46:27 +0100
+Message-Id: <5E...@exchange1.cps.local>
+To: "'zzzzteana@yahoogroups.com'" <zz...@yahoogroups.com>
+X-Mailer: Internet Mail Service (5.5.2653.19)
+X-Egroups-From: Steve Burt <st...@cursor-system.com>
+From: Steve Burt <St...@cursor-system.com>
+X-Yahoo-Profile: pyruse
+MIME-Version: 1.0
+Mailing-List: list zzzzteana@yahoogroups.com; contact
+    forteana-owner@yahoogroups.com
+Delivered-To: mailing list zzzzteana@yahoogroups.com
+Precedence: bulk
+List-Unsubscribe: <ma...@yahoogroups.com>
+Date: Thu, 22 Aug 2002 12:46:18 +0100
+Subject: [zzzzteana] RE: Alexander
+Reply-To: zzzzteana@yahoogroups.com
+Content-Type: text/plain; charset=US-ASCII
+Content-Transfer-Encoding: 7bit
+
+Martin A posted:
+Tassos Papadopoulos, the Greek sculptor behind the plan, judged that the
+ limestone of Mount Kerdylio, 70 miles east of Salonika and not far from the
+ Mount Athos monastic community, was ideal for the patriotic sculpture. 
+ 
+ As well as Alexander's granite features, 240 ft high and 170 ft wide, a
+ museum, a restored amphitheatre and car park for admiring crowds are
+planned
+---------------------
+So is this mountain limestone or granite?
+If it's limestone, it'll weather pretty fast.
+
+------------------------ Yahoo! Groups Sponsor ---------------------~-->
+4 DVDs Free +s&p Join Now
+http://us.click.yahoo.com/pt6YBB/NXiEAA/mG3HAA/7gSolB/TM
+---------------------------------------------------------------------~->
+
+To unsubscribe from this group, send an email to:
+forteana-unsubscribe@egroups.com
+
+ 
+
+Your use of Yahoo! Groups is subject to http://docs.yahoo.com/info/terms/ 
+
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham3
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham3 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham3
new file mode 100644
index 0000000..c7cfbc8
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham3
@@ -0,0 +1,82 @@
+From timc@2ubh.com  Thu Aug 22 13:52:59 2002
+Return-Path: <ti...@2ubh.com>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id 0314547C66
+	for <zz...@localhost>; Thu, 22 Aug 2002 08:52:58 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 13:52:59 +0100 (IST)
+Received: from n16.grp.scd.yahoo.com (n16.grp.scd.yahoo.com
+    [66.218.66.71]) by dogma.slashnull.org (8.11.6/8.11.6) with SMTP id
+    g7MCrdZ07070 for <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 13:53:39 +0100
+X-Egroups-Return: sentto-2242572-52733-1030020820-zzzz=spamassassin.taint.org@returns.groups.yahoo.com
+Received: from [66.218.67.198] by n16.grp.scd.yahoo.com with NNFMP;
+    22 Aug 2002 12:53:40 -0000
+X-Sender: timc@2ubh.com
+X-Apparently-To: zzzzteana@yahoogroups.com
+Received: (EGP: mail-8_1_0_1); 22 Aug 2002 12:53:39 -0000
+Received: (qmail 76099 invoked from network); 22 Aug 2002 12:53:39 -0000
+Received: from unknown (66.218.66.218) by m5.grp.scd.yahoo.com with QMQP;
+    22 Aug 2002 12:53:39 -0000
+Received: from unknown (HELO rhenium.btinternet.com) (194.73.73.93) by
+    mta3.grp.scd.yahoo.com with SMTP; 22 Aug 2002 12:53:39 -0000
+Received: from host217-36-23-185.in-addr.btopenworld.com ([217.36.23.185])
+    by rhenium.btinternet.com with esmtp (Exim 3.22 #8) id 17hrT0-0004gj-00
+    for forteana@yahoogroups.com; Thu, 22 Aug 2002 13:53:38 +0100
+X-Mailer: Microsoft Outlook Express Macintosh Edition - 4.5 (0410)
+To: zzzzteana <zz...@yahoogroups.com>
+X-Priority: 3
+Message-Id: <E1...@rhenium.btinternet.com>
+From: "Tim Chapman" <ti...@2ubh.com>
+X-Yahoo-Profile: tim2ubh
+MIME-Version: 1.0
+Mailing-List: list zzzzteana@yahoogroups.com; contact
+    forteana-owner@yahoogroups.com
+Delivered-To: mailing list zzzzteana@yahoogroups.com
+Precedence: bulk
+List-Unsubscribe: <ma...@yahoogroups.com>
+Date: Thu, 22 Aug 2002 13:52:38 +0100
+Subject: [zzzzteana] Moscow bomber
+Reply-To: zzzzteana@yahoogroups.com
+Content-Type: text/plain; charset=US-ASCII
+Content-Transfer-Encoding: 7bit
+
+Man Threatens Explosion In Moscow 
+
+Thursday August 22, 2002 1:40 PM
+MOSCOW (AP) - Security officers on Thursday seized an unidentified man who
+said he was armed with explosives and threatened to blow up his truck in
+front of Russia's Federal Security Services headquarters in Moscow, NTV
+television reported.
+The officers seized an automatic rifle the man was carrying, then the man
+got out of the truck and was taken into custody, NTV said. No other details
+were immediately available.
+The man had demanded talks with high government officials, the Interfax and
+ITAR-Tass news agencies said. Ekho Moskvy radio reported that he wanted to
+talk with Russian President Vladimir Putin.
+Police and security forces rushed to the Security Service building, within
+blocks of the Kremlin, Red Square and the Bolshoi Ballet, and surrounded the
+man, who claimed to have one and a half tons of explosives, the news
+agencies said. Negotiations continued for about one and a half hours outside
+the building, ITAR-Tass and Interfax reported, citing witnesses.
+The man later drove away from the building, under police escort, and drove
+to a street near Moscow's Olympic Penta Hotel, where authorities held
+further negotiations with him, the Moscow police press service said. The
+move appeared to be an attempt by security services to get him to a more
+secure location. 
+
+------------------------ Yahoo! Groups Sponsor ---------------------~-->
+4 DVDs Free +s&p Join Now
+http://us.click.yahoo.com/pt6YBB/NXiEAA/mG3HAA/7gSolB/TM
+---------------------------------------------------------------------~->
+
+To unsubscribe from this group, send an email to:
+forteana-unsubscribe@egroups.com
+
+ 
+
+Your use of Yahoo! Groups is subject to http://docs.yahoo.com/info/terms/ 
+
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham4
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham4 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham4
new file mode 100644
index 0000000..9a726c2
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham4
@@ -0,0 +1,78 @@
+From irregulars-admin@tb.tf  Thu Aug 22 14:23:39 2002
+Return-Path: <ir...@tb.tf>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id 9DAE147C66
+	for <zz...@localhost>; Thu, 22 Aug 2002 09:23:38 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 14:23:38 +0100 (IST)
+Received: from web.tb.tf (route-64-131-126-36.telocity.com
+    [64.131.126.36]) by dogma.slashnull.org (8.11.6/8.11.6) with ESMTP id
+    g7MDGOZ07922 for <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 14:16:24 +0100
+Received: from web.tb.tf (localhost.localdomain [127.0.0.1]) by web.tb.tf
+    (8.11.6/8.11.6) with ESMTP id g7MDP9I16418; Thu, 22 Aug 2002 09:25:09
+    -0400
+Received: from red.harvee.home (red [192.168.25.1] (may be forged)) by
+    web.tb.tf (8.11.6/8.11.6) with ESMTP id g7MDO4I16408 for
+    <ir...@tb.tf>; Thu, 22 Aug 2002 09:24:04 -0400
+Received: from prserv.net (out4.prserv.net [32.97.166.34]) by
+    red.harvee.home (8.11.6/8.11.6) with ESMTP id g7MDFBD29237 for
+    <ir...@tb.tf>; Thu, 22 Aug 2002 09:15:12 -0400
+Received: from [209.202.248.109]
+    (slip-32-103-249-10.ma.us.prserv.net[32.103.249.10]) by prserv.net (out4)
+    with ESMTP id <2002082213150220405qu8jce>; Thu, 22 Aug 2002 13:15:07 +0000
+MIME-Version: 1.0
+X-Sender: @ (Unverified)
+Message-Id: <p04330137b98a941c58a8@[209.202.248.109]>
+To: undisclosed-recipient: ;
+From: Monty Solomon <mo...@roscom.com>
+Content-Type: text/plain; charset="us-ascii"
+Subject: [IRR] Klez: The Virus That  Won't Die
+Sender: irregulars-admin@tb.tf
+Errors-To: irregulars-admin@tb.tf
+X-Beenthere: irregulars@tb.tf
+X-Mailman-Version: 2.0.6
+Precedence: bulk
+List-Help: <mailto:irregulars-request@tb.tf?subject=help>
+List-Post: <ma...@tb.tf>
+List-Subscribe: <http://tb.tf/mailman/listinfo/irregulars>,
+    <mailto:irregulars-request@tb.tf?subject=subscribe>
+List-Id: New home of the TBTF Irregulars mailing list <irregulars.tb.tf>
+List-Unsubscribe: <http://tb.tf/mailman/listinfo/irregulars>,
+    <mailto:irregulars-request@tb.tf?subject=unsubscribe>
+List-Archive: <http://tb.tf/mailman/private/irregulars/>
+Date: Thu, 22 Aug 2002 09:15:25 -0400
+
+Klez: The Virus That Won't Die
+ 
+Already the most prolific virus ever, Klez continues to wreak havoc.
+
+Andrew Brandt
+>>From the September 2002 issue of PC World magazine
+Posted Thursday, August 01, 2002
+
+
+The Klez worm is approaching its seventh month of wriggling across 
+the Web, making it one of the most persistent viruses ever. And 
+experts warn that it may be a harbinger of new viruses that use a 
+combination of pernicious approaches to go from PC to PC.
+
+Antivirus software makers Symantec and McAfee both report more than 
+2000 new infections daily, with no sign of letup at press time. The 
+British security firm MessageLabs estimates that 1 in every 300 
+e-mail messages holds a variation of the Klez virus, and says that 
+Klez has already surpassed last summer's SirCam as the most prolific 
+virus ever.
+
+And some newer Klez variants aren't merely nuisances--they can carry 
+other viruses in them that corrupt your data.
+
+...
+
+http://www.pcworld.com/news/article/0,aid,103259,00.asp
+_______________________________________________
+Irregulars mailing list
+Irregulars@tb.tf
+http://tb.tf/mailman/listinfo/irregulars
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham5
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham5 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham5
new file mode 100644
index 0000000..57b6801
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham5
@@ -0,0 +1,77 @@
+From Stewart.Smith@ee.ed.ac.uk  Thu Aug 22 14:44:26 2002
+Return-Path: <St...@ee.ed.ac.uk>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id EC69D47C66
+	for <zz...@localhost>; Thu, 22 Aug 2002 09:44:25 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 14:44:25 +0100 (IST)
+Received: from n6.grp.scd.yahoo.com (n6.grp.scd.yahoo.com [66.218.66.90])
+    by dogma.slashnull.org (8.11.6/8.11.6) with SMTP id g7MDcOZ08504 for
+    <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 14:38:25 +0100
+X-Egroups-Return: sentto-2242572-52736-1030023506-zzzz=spamassassin.taint.org@returns.groups.yahoo.com
+Received: from [66.218.67.192] by n6.grp.scd.yahoo.com with NNFMP;
+    22 Aug 2002 13:38:26 -0000
+X-Sender: Stewart.Smith@ee.ed.ac.uk
+X-Apparently-To: zzzzteana@yahoogroups.com
+Received: (EGP: mail-8_1_0_1); 22 Aug 2002 13:38:25 -0000
+Received: (qmail 48882 invoked from network); 22 Aug 2002 13:38:25 -0000
+Received: from unknown (66.218.66.218) by m10.grp.scd.yahoo.com with QMQP;
+    22 Aug 2002 13:38:25 -0000
+Received: from unknown (HELO postbox.ee.ed.ac.uk) (129.215.80.253) by
+    mta3.grp.scd.yahoo.com with SMTP; 22 Aug 2002 13:38:24 -0000
+Received: from ee.ed.ac.uk (sxs@dunblane [129.215.34.86]) by
+    postbox.ee.ed.ac.uk (8.11.0/8.11.0) with ESMTP id g7MDcNi28645 for
+    <fo...@yahoogroups.com>; Thu, 22 Aug 2002 14:38:23 +0100 (BST)
+Message-Id: <3D...@ee.ed.ac.uk>
+Organization: Scottish Microelectronics Centre
+User-Agent: Mozilla/5.0 (X11; U; SunOS sun4u; en-US; rv:1.1b) Gecko/20020628
+X-Accept-Language: en, en-us
+To: zzzzteana@yahoogroups.com
+References: <3D...@localhost>
+From: Stewart Smith <St...@ee.ed.ac.uk>
+X-Yahoo-Profile: stochasticus
+MIME-Version: 1.0
+Mailing-List: list zzzzteana@yahoogroups.com; contact
+    forteana-owner@yahoogroups.com
+Delivered-To: mailing list zzzzteana@yahoogroups.com
+Precedence: bulk
+List-Unsubscribe: <ma...@yahoogroups.com>
+Date: Thu, 22 Aug 2002 14:38:22 +0100
+Subject: Re: [zzzzteana] Nothing like mama used to make
+Reply-To: zzzzteana@yahoogroups.com
+Content-Type: text/plain; charset=US-ASCII
+Content-Transfer-Encoding: 7bit
+
+>  in adding cream to spaghetti carbonara, which has the same effect on pasta as
+>  making a pizza a deep-pie; 
+
+I just had to jump in here as Carbonara is one of my favourites to make and ask 
+what the hell are you supposed to use instead of cream?  I've never seen a 
+recipe that hasn't used this.  Personally I use low fat creme fraiche because it 
+works quite nicely but the only time I've seen an supposedly authentic recipe 
+for carbonara  it was identical to mine (cream, eggs and lots of fresh parmesan) 
+except for the creme fraiche.
+
+Stew
+-- 
+Stewart Smith
+Scottish Microelectronics Centre, University of Edinburgh.
+http://www.ee.ed.ac.uk/~sxs/
+
+
+------------------------ Yahoo! Groups Sponsor ---------------------~-->
+4 DVDs Free +s&p Join Now
+http://us.click.yahoo.com/pt6YBB/NXiEAA/mG3HAA/7gSolB/TM
+---------------------------------------------------------------------~->
+
+To unsubscribe from this group, send an email to:
+forteana-unsubscribe@egroups.com
+
+ 
+
+Your use of Yahoo! Groups is subject to http://docs.yahoo.com/info/terms/ 
+
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham6
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham6 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham6
new file mode 100644
index 0000000..f3231fe
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham6
@@ -0,0 +1,74 @@
+From martin@srv0.ems.ed.ac.uk  Thu Aug 22 14:54:39 2002
+Return-Path: <ma...@srv0.ems.ed.ac.uk>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id 16FC743F99
+	for <zz...@localhost>; Thu, 22 Aug 2002 09:54:38 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 14:54:39 +0100 (IST)
+Received: from n14.grp.scd.yahoo.com (n14.grp.scd.yahoo.com
+    [66.218.66.69]) by dogma.slashnull.org (8.11.6/8.11.6) with SMTP id
+    g7MDoxZ08960 for <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 14:50:59 +0100
+X-Egroups-Return: sentto-2242572-52737-1030024261-zzzz=spamassassin.taint.org@returns.groups.yahoo.com
+Received: from [66.218.66.95] by n14.grp.scd.yahoo.com with NNFMP;
+    22 Aug 2002 13:51:01 -0000
+X-Sender: martin@srv0.ems.ed.ac.uk
+X-Apparently-To: zzzzteana@yahoogroups.com
+Received: (EGP: mail-8_1_0_1); 22 Aug 2002 13:51:00 -0000
+Received: (qmail 71894 invoked from network); 22 Aug 2002 13:51:00 -0000
+Received: from unknown (66.218.66.218) by m7.grp.scd.yahoo.com with QMQP;
+    22 Aug 2002 13:51:00 -0000
+Received: from unknown (HELO haymarket.ed.ac.uk) (129.215.128.53) by
+    mta3.grp.scd.yahoo.com with SMTP; 22 Aug 2002 13:51:00 -0000
+Received: from srv0.ems.ed.ac.uk (srv0.ems.ed.ac.uk [129.215.117.0]) by
+    haymarket.ed.ac.uk (8.11.6/8.11.6) with ESMTP id g7MDow310334 for
+    <fo...@yahoogroups.com>; Thu, 22 Aug 2002 14:50:59 +0100 (BST)
+Received: from EMS-SRV0/SpoolDir by srv0.ems.ed.ac.uk (Mercury 1.44);
+    22 Aug 02 14:50:58 +0000
+Received: from SpoolDir by EMS-SRV0 (Mercury 1.44); 22 Aug 02 14:50:31 +0000
+Organization: Management School
+To: zzzzteana@yahoogroups.com
+Message-Id: <3D...@localhost>
+Priority: normal
+In-Reply-To: <3D...@ee.ed.ac.uk>
+X-Mailer: Pegasus Mail for Windows (v4.01)
+Content-Description: Mail message body
+From: "Martin Adamson" <ma...@srv0.ems.ed.ac.uk>
+MIME-Version: 1.0
+Mailing-List: list zzzzteana@yahoogroups.com; contact
+    forteana-owner@yahoogroups.com
+Delivered-To: mailing list zzzzteana@yahoogroups.com
+Precedence: bulk
+List-Unsubscribe: <ma...@yahoogroups.com>
+Date: Thu, 22 Aug 2002 14:50:31 +0100
+Subject: Re: [zzzzteana] Nothing like mama used to make
+Reply-To: zzzzteana@yahoogroups.com
+Content-Type: text/plain; charset=US-ASCII
+Content-Transfer-Encoding: 7bit
+
+
+> I just had to jump in here as Carbonara is one of my favourites to make and 
+> ask 
+> what the hell are you supposed to use instead of cream? 
+
+Isn't it just basically a mixture of beaten egg and bacon (or pancetta, 
+really)? You mix in the raw egg to the cooked pasta and the heat of the pasta 
+cooks the egg. That's my understanding.
+
+Martin
+
+------------------------ Yahoo! Groups Sponsor ---------------------~-->
+4 DVDs Free +s&p Join Now
+http://us.click.yahoo.com/pt6YBB/NXiEAA/mG3HAA/7gSolB/TM
+---------------------------------------------------------------------~->
+
+To unsubscribe from this group, send an email to:
+forteana-unsubscribe@egroups.com
+
+ 
+
+Your use of Yahoo! Groups is subject to http://docs.yahoo.com/info/terms/ 
+
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham7
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham7 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham7
new file mode 100644
index 0000000..a65f9b4
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham7
@@ -0,0 +1,88 @@
+From martin@srv0.ems.ed.ac.uk  Thu Aug 22 14:54:40 2002
+Return-Path: <ma...@srv0.ems.ed.ac.uk>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id E3D7B47C66
+	for <zz...@localhost>; Thu, 22 Aug 2002 09:54:39 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 14:54:40 +0100 (IST)
+Received: from n11.grp.scd.yahoo.com (n11.grp.scd.yahoo.com
+    [66.218.66.66]) by dogma.slashnull.org (8.11.6/8.11.6) with SMTP id
+    g7MDt8Z09193 for <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 14:55:10 +0100
+X-Egroups-Return: sentto-2242572-52738-1030024499-zzzz=spamassassin.taint.org@returns.groups.yahoo.com
+Received: from [66.218.66.94] by n11.grp.scd.yahoo.com with NNFMP;
+    22 Aug 2002 13:55:03 -0000
+X-Sender: martin@srv0.ems.ed.ac.uk
+X-Apparently-To: zzzzteana@yahoogroups.com
+Received: (EGP: mail-8_1_0_1); 22 Aug 2002 13:54:59 -0000
+Received: (qmail 43039 invoked from network); 22 Aug 2002 13:54:58 -0000
+Received: from unknown (66.218.66.216) by m1.grp.scd.yahoo.com with QMQP;
+    22 Aug 2002 13:54:58 -0000
+Received: from unknown (HELO haymarket.ed.ac.uk) (129.215.128.53) by
+    mta1.grp.scd.yahoo.com with SMTP; 22 Aug 2002 13:54:58 -0000
+Received: from srv0.ems.ed.ac.uk (srv0.ems.ed.ac.uk [129.215.117.0]) by
+    haymarket.ed.ac.uk (8.11.6/8.11.6) with ESMTP id g7MDsv311745 for
+    <fo...@yahoogroups.com>; Thu, 22 Aug 2002 14:54:57 +0100 (BST)
+Received: from EMS-SRV0/SpoolDir by srv0.ems.ed.ac.uk (Mercury 1.44);
+    22 Aug 02 14:54:56 +0000
+Received: from SpoolDir by EMS-SRV0 (Mercury 1.44); 22 Aug 02 14:54:29 +0000
+Organization: Management School
+To: zzzzteana@yahoogroups.com
+Message-Id: <3D...@localhost>
+Priority: normal
+X-Mailer: Pegasus Mail for Windows (v4.01)
+Content-Description: Mail message body
+From: "Martin Adamson" <ma...@srv0.ems.ed.ac.uk>
+MIME-Version: 1.0
+Mailing-List: list zzzzteana@yahoogroups.com; contact
+    forteana-owner@yahoogroups.com
+Delivered-To: mailing list zzzzteana@yahoogroups.com
+Precedence: bulk
+List-Unsubscribe: <ma...@yahoogroups.com>
+Date: Thu, 22 Aug 2002 14:54:25 +0100
+Subject: [zzzzteana] Playboy wants to go out with a bang
+Reply-To: zzzzteana@yahoogroups.com
+Content-Type: text/plain; charset=ISO-8859-1
+Content-Transfer-Encoding: 8bit
+X-MIME-Autoconverted: from quoted-printable to 8bit by dogma.slashnull.org
+    id g7MDt8Z09193
+
+The Scotsman - 22 August 2002
+
+ Playboy wants to go out with a bang 
+ 
+ 
+ AN AGEING Berlin playboy has come up with an unusual offer to lure women into
+ his bed - by promising the last woman he sleeps with an inheritance of 250,000
+ (�160,000). 
+ 
+ Rolf Eden, 72, a Berlin disco owner famous for his countless sex partners,
+ said he could imagine no better way to die than in the arms of an attractive
+ young woman - preferably under 30. 
+ 
+ "I put it all in my last will and testament - the last woman who sleeps with
+ me gets all the money," Mr Eden told Bild newspaper. 
+ 
+ "I want to pass away in the most beautiful moment of my life. First a lot of
+ fun with a beautiful woman, then wild sex, a final orgasm - and it will all
+ end with a heart attack and then I�m gone." 
+ 
+ Mr Eden, who is selling his nightclub this year, said applications should be
+ sent in quickly because of his age. "It could end very soon," he said.
+
+
+------------------------ Yahoo! Groups Sponsor ---------------------~-->
+4 DVDs Free +s&p Join Now
+http://us.click.yahoo.com/pt6YBB/NXiEAA/mG3HAA/7gSolB/TM
+---------------------------------------------------------------------~->
+
+To unsubscribe from this group, send an email to:
+forteana-unsubscribe@egroups.com
+
+ 
+
+Your use of Yahoo! Groups is subject to http://docs.yahoo.com/info/terms/ 
+
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham8
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham8 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham8
new file mode 100644
index 0000000..c245926
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham8
@@ -0,0 +1,85 @@
+From Stewart.Smith@ee.ed.ac.uk  Thu Aug 22 15:05:07 2002
+Return-Path: <St...@ee.ed.ac.uk>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id EF86747C67
+	for <zz...@localhost>; Thu, 22 Aug 2002 10:05:00 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 15:05:01 +0100 (IST)
+Received: from n34.grp.scd.yahoo.com (n34.grp.scd.yahoo.com
+    [66.218.66.102]) by dogma.slashnull.org (8.11.6/8.11.6) with SMTP id
+    g7ME1MZ09279 for <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 15:01:22 +0100
+X-Egroups-Return: sentto-2242572-52739-1030024883-zzzz=spamassassin.taint.org@returns.groups.yahoo.com
+Received: from [66.218.67.195] by n34.grp.scd.yahoo.com with NNFMP;
+    22 Aug 2002 14:01:23 -0000
+X-Sender: Stewart.Smith@ee.ed.ac.uk
+X-Apparently-To: zzzzteana@yahoogroups.com
+Received: (EGP: mail-8_1_0_1); 22 Aug 2002 14:01:23 -0000
+Received: (qmail 45116 invoked from network); 22 Aug 2002 14:01:22 -0000
+Received: from unknown (66.218.66.218) by m2.grp.scd.yahoo.com with QMQP;
+    22 Aug 2002 14:01:22 -0000
+Received: from unknown (HELO postbox.ee.ed.ac.uk) (129.215.80.253) by
+    mta3.grp.scd.yahoo.com with SMTP; 22 Aug 2002 14:01:22 -0000
+Received: from ee.ed.ac.uk (sxs@dunblane [129.215.34.86]) by
+    postbox.ee.ed.ac.uk (8.11.0/8.11.0) with ESMTP id g7ME1Li02942 for
+    <fo...@yahoogroups.com>; Thu, 22 Aug 2002 15:01:21 +0100 (BST)
+Message-Id: <3D...@ee.ed.ac.uk>
+Organization: Scottish Microelectronics Centre
+User-Agent: Mozilla/5.0 (X11; U; SunOS sun4u; en-US; rv:1.1b) Gecko/20020628
+X-Accept-Language: en, en-us
+To: zzzzteana@yahoogroups.com
+References: <3D...@localhost>
+From: Stewart Smith <St...@ee.ed.ac.uk>
+X-Yahoo-Profile: stochasticus
+MIME-Version: 1.0
+Mailing-List: list zzzzteana@yahoogroups.com; contact
+    forteana-owner@yahoogroups.com
+Delivered-To: mailing list zzzzteana@yahoogroups.com
+Precedence: bulk
+List-Unsubscribe: <ma...@yahoogroups.com>
+Date: Thu, 22 Aug 2002 15:01:20 +0100
+Subject: Re: [zzzzteana] Nothing like mama used to make
+Reply-To: zzzzteana@yahoogroups.com
+Content-Type: text/plain; charset=US-ASCII
+Content-Transfer-Encoding: 7bit
+
+Martin Adamson wrote:
+> 
+> Isn't it just basically a mixture of beaten egg and bacon (or pancetta, 
+> really)? You mix in the raw egg to the cooked pasta and the heat of the pasta 
+> cooks the egg. That's my understanding.
+> 
+
+You're probably right, mine's just the same but with the cream added to the 
+eggs.  I guess I should try it without.  Actually looking on the internet for a 
+recipe I found this one from possibly one of the scariest people I've ever seen, 
+and he's a US Congressman:
+<http://www.virtualcities.com/ons/me/gov/megvjb1.htm>
+
+That's one of the worst non-smiles ever.
+
+Stew
+ps. Apologies if any of the list's Maine residents voted for this man, you won't 
+do it again once you've seen this pic.
+
+-- 
+Stewart Smith
+Scottish Microelectronics Centre, University of Edinburgh.
+http://www.ee.ed.ac.uk/~sxs/
+
+
+------------------------ Yahoo! Groups Sponsor ---------------------~-->
+4 DVDs Free +s&p Join Now
+http://us.click.yahoo.com/pt6YBB/NXiEAA/mG3HAA/7gSolB/TM
+---------------------------------------------------------------------~->
+
+To unsubscribe from this group, send an email to:
+forteana-unsubscribe@egroups.com
+
+ 
+
+Your use of Yahoo! Groups is subject to http://docs.yahoo.com/info/terms/ 
+
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham9
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham9 b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham9
new file mode 100644
index 0000000..df071f6
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/ham/ham9
@@ -0,0 +1,176 @@
+From martin@srv0.ems.ed.ac.uk  Thu Aug 22 15:05:07 2002
+Return-Path: <ma...@srv0.ems.ed.ac.uk>
+Delivered-To: zzzz@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id 7A0C347C68
+	for <zz...@localhost>; Thu, 22 Aug 2002 10:05:03 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for zzzz@localhost (single-drop); Thu, 22 Aug 2002 15:05:03 +0100 (IST)
+Received: from n34.grp.scd.yahoo.com (n34.grp.scd.yahoo.com
+    [66.218.66.102]) by dogma.slashnull.org (8.11.6/8.11.6) with SMTP id
+    g7ME1rZ09290 for <zz...@spamassassin.taint.org>; Thu, 22 Aug 2002 15:01:54 +0100
+X-Egroups-Return: sentto-2242572-52740-1030024915-zzzz=spamassassin.taint.org@returns.groups.yahoo.com
+Received: from [66.218.67.194] by n34.grp.scd.yahoo.com with NNFMP;
+    22 Aug 2002 14:01:55 -0000
+X-Sender: martin@srv0.ems.ed.ac.uk
+X-Apparently-To: zzzzteana@yahoogroups.com
+Received: (EGP: mail-8_1_0_1); 22 Aug 2002 14:01:55 -0000
+Received: (qmail 59494 invoked from network); 22 Aug 2002 14:01:55 -0000
+Received: from unknown (66.218.66.218) by m12.grp.scd.yahoo.com with QMQP;
+    22 Aug 2002 14:01:55 -0000
+Received: from unknown (HELO haymarket.ed.ac.uk) (129.215.128.53) by
+    mta3.grp.scd.yahoo.com with SMTP; 22 Aug 2002 14:01:54 -0000
+Received: from srv0.ems.ed.ac.uk (srv0.ems.ed.ac.uk [129.215.117.0]) by
+    haymarket.ed.ac.uk (8.11.6/8.11.6) with ESMTP id g7ME1r313981 for
+    <fo...@yahoogroups.com>; Thu, 22 Aug 2002 15:01:53 +0100 (BST)
+Received: from EMS-SRV0/SpoolDir by srv0.ems.ed.ac.uk (Mercury 1.44);
+    22 Aug 02 15:01:52 +0000
+Received: from SpoolDir by EMS-SRV0 (Mercury 1.44); 22 Aug 02 15:01:34 +0000
+Organization: Management School
+To: zzzzteana@yahoogroups.com
+Message-Id: <3D...@localhost>
+Priority: normal
+X-Mailer: Pegasus Mail for Windows (v4.01)
+Content-Description: Mail message body
+From: "Martin Adamson" <ma...@srv0.ems.ed.ac.uk>
+MIME-Version: 1.0
+Mailing-List: list zzzzteana@yahoogroups.com; contact
+    forteana-owner@yahoogroups.com
+Delivered-To: mailing list zzzzteana@yahoogroups.com
+Precedence: bulk
+List-Unsubscribe: <ma...@yahoogroups.com>
+Date: Thu, 22 Aug 2002 15:01:33 +0100
+Subject: [zzzzteana] Meaningful sentences
+Reply-To: zzzzteana@yahoogroups.com
+Content-Type: text/plain; charset=ISO-8859-1
+Content-Transfer-Encoding: 8bit
+X-MIME-Autoconverted: from quoted-printable to 8bit by dogma.slashnull.org
+    id g7ME1rZ09290
+
+The Scotsman
+
+ Thu 22 Aug 2002 
+
+ Meaningful sentences 
+ 
+ Tracey Lawson 
+ 
+ 
+ If you ever wanted to look like "one of the most dangerous inmates in prison
+ history", as one judge described Charles Bronson, now�s your chance. Bronson -
+ the serial hostage taker, not the movie star - has written a health and
+ fitness guide in which he shares some of the secrets behind his legendary
+ muscle power. 
+ 
+ Solitary Fitness - a title which bears testament to the fact that Bronson, 48,
+ has spent 24 of his 28 prison years in solitary confinement - explains how he
+ has turned himself into a lean, mean, fitness machine while living 23 hours a
+ day in a space just 12 feet by eight feet, on a diet of scrubs grub and at
+ virtually no cost. 
+ 
+ The book is aimed at those who want to get fabulously fit without spending a
+ fortune on gym memberships, protein supplements or designer trainers, and
+ starts with a fierce attack on some of the expensive myths churned out by the
+ exercise industry. 
+ 
+ "I pick up a fitness mag, I start to laugh and I wipe my arse with it," is the
+ opening paragraph penned by Bronson. "It�s a joke and a big con and they call
+ me a criminal!" You can�t help feeling he has a point. 
+ 
+ This is not the first book that Bronson has written from behind bars, having
+ already published Birdman Opens His Mind, which features drawings and poems
+ created by Bronson while in prison. And he is not the first prisoner to
+ discover creative expression while residing at Her Majesty�s pleasure. 
+ 
+ Jimmy Boyle, the Scots sculptor and novelist, discovered his artistic talents
+ when he was sent to Barlinnie Prison�s famous special unit, which aimed to
+ help inmates put their violent pasts behind them by teaching them how to
+ express their emotions artistically. Boyle was sentenced to life for the
+ murder of "Babs" Rooney in 1967. Once released, he moved to Edinburgh where he
+ has become a respected artist. His first novel, Hero of the Underworld, was
+ published in 1999 and his autobiography, A Sense of Freedom, was made into an
+ award-winning film. 
+ 
+ Hugh Collins was jailed for life in 1977 for the murder of William Mooney in
+ Glasgow, and in his first year in Barlinnie prison stabbed three prison
+ officers, earning him an extra seven-year sentence. But, after being
+ transferred to the same unit that Boyle attended, he learned to sculpt and
+ developed an interest in art. He later published Autobiography of a Murderer,
+ a frank account of Glasgow�s criminal culture in the 1960s, which received
+ critical praise. 
+ 
+ And Lord Archer doesn�t seem to have had trouble continuing to write the books
+ that have made him millions while in jail. He recently signed a three-book
+ deal with Macmillan publishers worth a reported �10 million, and is no doubt
+ scribbling away as we speak. 
+ 
+ So why is it that men like Collins, Bronson and Boyle, who can be so
+ destructive towards society on the outside, can become so creative once stuck
+ on the inside? Steve Richards, Bronson�s publisher, has published many books
+ about criminal figures and believes the roots of this phenomenon are both
+ pragmatic and profound. 
+ 
+ He says: "Prison is sometimes the first time some criminals will ever have
+ known a stable environment, and this can be the first time they have the
+ chance to focus on their creative skills. 
+ 
+ "It may also be the first time that they have really had the chance of an
+ education, if their early years have been hard. It could be the first time
+ anyone has offered them the chance to explore their creative talents." 
+ 
+ However, Richards believes the reasons are also deeper than that. He says:
+ "Once they are behind bars, the cold light of day hits them, and they examine
+ the very essence of who they are. 
+ 
+ "They ask themselves, am I a man who wants to be remembered for violence? Or
+ am I a man who can contribute to society, who can be remembered for something
+ good?" 
+ 
+ Bronson - who was born Michael Gordon Peterson, but changed his name to that
+ of the Hollywood star of the Death Wish films - has, so far, been remembered
+ mainly for things bad. He was originally jailed for seven years for armed
+ robbery in 1974, and has had a series of sentences added to his original term
+ over the years as a result of attacking people in prison. In 2000 he was
+ jailed for life after being convicted of holding a teacher hostage for nearly
+ two days during a jail siege. 
+ 
+ Standing five feet ten and a half inches tall and weighing 210lbs, he is
+ renowned for his strength. He has bent metal cell doors with his bare hands
+ and does up to 3,000 - yes, 3,000 - press-ups a day. As he puts it: "I can hit
+ a man 20 times in four seconds, I can push 132 press ups in 60 seconds." 
+ 
+ But judging by our current obsession with health and exercise, Solitary
+ Fitness might be the book which will see Bronson�s face sitting on every
+ coffee table in the land. He might be the man to give us the dream body which
+ so many so-called fitness gurus promise but fail to motivate us into. Because
+ Bronson has learned to use words as powerfully as he can use his fists. 
+ 
+ "All this crap about high-protein drinks, pills, diets, it�s just a load of
+ bollocks and a multi-million-pound racket," he writes, in what can only be
+ described as a refreshingly honest style. "We can all be fat lazy bastards,
+ it�s our choice, I�m sick of hearing and reading about excuses, if you stuff
+ your face with shit you become shit, that�s logical to me." 
+ 
+ As motivational mantras go, that might be just the kick up the, er, backside
+ we all needed. 
+ 
+ 
+ Solitary Fitness by Charles Bronson is published by Mirage Publishing and will
+ be available in bookstores from October at �7.99
+
+
+------------------------ Yahoo! Groups Sponsor ---------------------~-->
+4 DVDs Free +s&p Join Now
+http://us.click.yahoo.com/pt6YBB/NXiEAA/mG3HAA/7gSolB/TM
+---------------------------------------------------------------------~->
+
+To unsubscribe from this group, send an email to:
+forteana-unsubscribe@egroups.com
+
+ 
+
+Your use of Yahoo! Groups is subject to http://docs.yahoo.com/info/terms/ 
+
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam1
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam1 b/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam1
new file mode 100644
index 0000000..8bad787
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam1
@@ -0,0 +1,108 @@
+From ilug-admin@linux.ie  Tue Aug  6 11:51:02 2002
+Return-Path: <il...@linux.ie>
+Delivered-To: yyyy@localhost.netnoteinc.com
+Received: from localhost (localhost [127.0.0.1])
+	by phobos.labs.netnoteinc.com (Postfix) with ESMTP id 9E1F5441DD
+	for <jm...@localhost>; Tue,  6 Aug 2002 06:48:09 -0400 (EDT)
+Received: from phobos [127.0.0.1]
+	by localhost with IMAP (fetchmail-5.9.0)
+	for jm@localhost (single-drop); Tue, 06 Aug 2002 11:48:09 +0100 (IST)
+Received: from lugh.tuatha.org (root@lugh.tuatha.org [194.125.145.45]) by
+    dogma.slashnull.org (8.11.6/8.11.6) with ESMTP id g72LqWv13294 for
+    <jm...@jmason.org>; Fri, 2 Aug 2002 22:52:32 +0100
+Received: from lugh (root@localhost [127.0.0.1]) by lugh.tuatha.org
+    (8.9.3/8.9.3) with ESMTP id WAA31224; Fri, 2 Aug 2002 22:50:17 +0100
+Received: from bettyjagessar.com (w142.z064000057.nyc-ny.dsl.cnc.net
+    [64.0.57.142]) by lugh.tuatha.org (8.9.3/8.9.3) with ESMTP id WAA31201 for
+    <il...@linux.ie>; Fri, 2 Aug 2002 22:50:11 +0100
+X-Authentication-Warning: lugh.tuatha.org: Host w142.z064000057.nyc-ny.dsl.cnc.net
+    [64.0.57.142] claimed to be bettyjagessar.com
+Received: from 64.0.57.142 [202.63.165.34] by bettyjagessar.com
+    (SMTPD32-7.06 EVAL) id A42A7FC01F2; Fri, 02 Aug 2002 02:18:18 -0400
+Message-Id: <10...@0.57.142>
+Date: Fri, 02 Aug 2002 23:37:59 0530
+To: ilug@linux.ie
+From: "Start Now" <st...@hotmail.com>
+MIME-Version: 1.0
+Content-Type: text/plain; charset="US-ASCII"; format=flowed
+Subject: [ILUG] STOP THE MLM INSANITY
+Sender: ilug-admin@linux.ie
+Errors-To: ilug-admin@linux.ie
+X-Mailman-Version: 1.1
+Precedence: bulk
+List-Id: Irish Linux Users' Group <ilug.linux.ie>
+X-Beenthere: ilug@linux.ie
+
+Greetings!
+
+You are receiving this letter because you have expressed an interest in 
+receiving information about online business opportunities. If this is 
+erroneous then please accept my most sincere apology. This is a one-time 
+mailing, so no removal is necessary.
+
+If you've been burned, betrayed, and back-stabbed by multi-level marketing, 
+MLM, then please read this letter. It could be the most important one that 
+has ever landed in your Inbox.
+
+MULTI-LEVEL MARKETING IS A HUGE MISTAKE FOR MOST PEOPLE
+
+MLM has failed to deliver on its promises for the past 50 years. The pursuit 
+of the "MLM Dream" has cost hundreds of thousands of people their friends, 
+their fortunes and their sacred honor. The fact is that MLM is fatally 
+flawed, meaning that it CANNOT work for most people.
+
+The companies and the few who earn the big money in MLM are NOT going to 
+tell you the real story. FINALLY, there is someone who has the courage to 
+cut through the hype and lies and tell the TRUTH about MLM.
+
+HERE'S GOOD NEWS
+
+There IS an alternative to MLM that WORKS, and works BIG! If you haven't yet 
+abandoned your dreams, then you need to see this. Earning the kind of income 
+you've dreamed about is easier than you think!
+
+With your permission, I'd like to send you a brief letter that will tell you 
+WHY MLM doesn't work for most people and will then introduce you to 
+something so new and refreshing that you'll wonder why you haven't heard of 
+this before.
+
+I promise that there will be NO unwanted follow up, NO sales pitch, no one 
+will call you, and your email address will only be used to send you the 
+information. Period.
+
+To receive this free, life-changing information, simply click Reply, type 
+"Send Info" in the Subject box and hit Send. I'll get the information to you 
+within 24 hours. Just look for the words MLM WALL OF SHAME in your Inbox.
+
+Cordially,
+
+Siddhi
+
+P.S. Someone recently sent the letter to me and it has been the most 
+eye-opening, financially beneficial information I have ever received. I 
+honestly believe that you will feel the same way once you've read it. And 
+it's FREE!
+
+
+------------------------------------------------------------
+This email is NEVER sent unsolicited.  THIS IS NOT "SPAM". You are receiving 
+this email because you EXPLICITLY signed yourself up to our list with our 
+online signup form or through use of our FFA Links Page and E-MailDOM 
+systems, which have EXPLICIT terms of use which state that through its use 
+you agree to receive our emailings.  You may also be a member of a Altra 
+Computer Systems list or one of many numerous FREE Marketing Services and as 
+such you agreed when you signed up for such list that you would also be 
+receiving this emailing.
+Due to the above, this email message cannot be considered unsolicitated, or 
+spam.
+-----------------------------------------------------------
+
+
+
+
+-- 
+Irish Linux Users' Group: ilug@linux.ie
+http://www.linux.ie/mailman/listinfo/ilug for (un)subscription information.
+List maintainer: listmaster@linux.ie
+
+

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam2
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam2 b/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam2
new file mode 100644
index 0000000..88a809e
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam2
@@ -0,0 +1,186 @@
+From lmrn@mailexcite.com  Mon Jun 24 17:03:24 2002
+Return-Path: merchantsworld2001@juno.com
+Delivery-Date: Mon May 13 04:46:13 2002
+Received: from mandark.labs.netnoteinc.com ([213.105.180.140]) by
+    dogma.slashnull.org (8.11.6/8.11.6) with ESMTP id g4D3kCe15097 for
+    <jm...@jmason.org>; Mon, 13 May 2002 04:46:12 +0100
+Received: from 203.129.205.5.205.129.203.in-addr.arpa ([203.129.205.5]) by
+    mandark.labs.netnoteinc.com (8.11.2/8.11.2) with SMTP id g4D3k2D12605 for
+    <jm...@netnoteinc.com>; Mon, 13 May 2002 04:46:04 +0100
+Received: from html (unverified [207.95.174.49]) by
+    203.129.205.5.205.129.203.in-addr.arpa (EMWAC SMTPRS 0.83) with SMTP id
+    <B0...@203.129.205.5.205.129.203.in-addr.arpa>; Mon, 13 May 2002
+    09:04:46 +0530
+Message-Id: <B0...@203.129.205.5.205.129.203.in-addr.arpa>
+From: lmrn@mailexcite.com
+To: ranmoore@cybertime.net
+Subject: Real Protection, Stun Guns!  Free Shipping! Time:2:01:35 PM
+Date: Mon, 28 Jul 1980 14:01:35
+MIME-Version: 1.0
+X-Keywords: 
+Content-Type: text/html; charset="DEFAULT"
+
+<html>
+<body>
+<center>
+<h3>
+<font color="blue">
+<b>
+The Need For Safety Is Real In 2002, You Might Only Get One Chance - Be Ready!
+<p>
+Free Shipping & Handling Within The (USA) If You Order Before May 25, 2002! 
+<p>
+3 Day Super Sale, Now Until May 7, 2002!  Save Up To $30.00 On Some Items!
+
+</b>
+</font>
+</h3>
+</center>
+<p>
+IT'S GETTING TO BE SPRING AGAIN, PROTECT YOURSELF AS YOU WALK,<br>
+JOG AND EXERCISE OUTSIDE.  ALSO PROTECT YOUR LOVED ONES AS<br>
+THEY RETURN HOME FROM COLLEGE!<br>
+<p>
+*     LEGAL PROTECTION FOR COLLEGE STUDENTS!<br>
+*     GREAT UP'COMING OUTDOOR PROTECTION GIFTS!<br>
+*     THERE IS NOTHING WORTH MORE PROTECTING THAN LIFE!<br>
+*     OUR STUN DEVICES & PEPPER PRODUCTS ARE LEGAL PROTECTION!
+<p>
+<b>
+<font color="red">
+JOIN THE WAR ON CRIME!
+</b>
+</font>
+<p>
+
+STUN GUNS AND BATONS 
+<p>
+EFFECTIVE - SAFE - NONLETHAL
+<p>
+PROTECT YOUR LOVED ONES AND YOURSELF
+<p>
+No matter who you are, no matter what City or Town you live in,<br>
+if you live in America, you will be touched by crime.
+<p>
+You hear about it on TV.  You read about it in the newspaper.<br>
+It's no secret that crime is a major problem in the U.S. today.<br>
+Criminals are finding it easier to commit crimes all the time.
+<p>
+Weapons are readily available.  Our cities' police forces have<br>
+more work than they can handle.  Even if these criminal are<br>
+caught, they won't be spending long in our nation's overcrowded<br>
+jails.  And while lawmakers are well aware of the crime problem,<br>
+they don't seem to have any effective answers.
+<p>
+Our Email Address:  <a
+href="mailto:Merchants4all@aol.com">Merchants4all@aol.com</a>
+<p>
+INTERESTED:
+<p>
+You will be protecting yourself within 7 days!  Don't Wait,<br>
+visit our web page below, and join The War On Crime!
+<p>
+*****************<br>
+<a
+href="http://www.geocities.com/realprotection_20022003/">http://www.geocities.com/realprotection_20022003/</a><br>
+*****************
+<p>
+Well, there is an effective answer.  Take responsibility for<br>
+your own security.  Our site has a variety of quality personal<br>
+security products.  Visit our site, choose the personal security<br>
+products that are right for you.  Use them, and join the war on
+crime!
+<p>
+FREE PEPPER SPRAY WITH ANY STUN UNIT PURCHASE.<br>
+(A Value of $15.95)
+<p>
+We Ship Orders Within 5 To 7 Days, To Every State In The U.S.A.<br>
+by UPS, FEDEX, or U.S. POSTAL SERVICE.  Visa, MasterCard, American<br>
+Express & Debt Card Gladly Accepted.
+<p>
+Ask yourself this question, if you don't help your loved ones,
+who will?
+<p>
+INTERESTED:
+<p>
+*****************<br>
+<a
+href="http://www.geocities.com/realprotection_20022003/">http://www.geocities.com/realprotection_20022003/</a><br>
+*****************
+<p>
+___The Stun Monster 625,000 Volts ($86.95)<br>
+___The Z-Force Slim Style 300,000 Volts ($64.95)<br>
+___The StunMaster 300,000 Volts Straight ($59.95)<br>
+___The StunMaster 300,000 Volts Curb ($59.95)<br>
+___The StunMaster 200,000 Volts Straight ($49.95)<br>
+___The StunMaster 200,000 Volts Curb ($49.95)<br>
+___The StunBaton 500,000 Volts ($89.95)<br>
+___The StunBaton 300,000 Volts ($79.95)<br>
+___Pen Knife (One $12.50, Two Or More $9.00)<br>
+___Wildfire Pepper Spray  (One $15.95, Two Or More $11.75)
+<p>
+___Add $5.75 For Shipping & Handling Charge.
+<p>
+
+To Order by postal mail, please send to the below address.<br>
+Make payable to Mega Safety Technology.
+<p>
+Mega Safety Technology<br>
+3215 Merrimac Ave.<br>
+Dayton, Ohio  45405<br>
+Our Email Address:  <a
+href="mailto:Merchants4all@aol.com">Merchants4all@aol.com</a>
+<p>
+Order by 24 Hour Fax!!!  775-257-6657.
+<p>
+*****<br>
+<b><font color="red">Important Credit Card Information! Please Read Below!</b></font>
+ <br><br>
+*     Credit Card Address, City, State and Zip Code, must match
+      billing address to be processed. 
+<br><br>
+
+CHECK____  MONEYORDER____  VISA____ MASTERCARD____ AmericanExpress___
+Debt Card___
+<br><br>
+Name_______________________________________________________<br>
+(As it appears on Check or Credit Card)
+<br><br>
+Address____________________________________________________<br>
+(As it appears on Check or Credit Card)
+<br><br>
+___________________________________________________<br>
+City,State,Zip(As it appears on Check or Credit Card)
+<br><br>
+___________________________________________________<br>
+Country
+<br><br>
+___________________________________________________<br>
+(Credit Card Number)
+<br><br>
+Expiration Month_____  Year_____
+<br><br>
+___________________________________________________<br>
+Authorized Signature
+<br><br>
+<b>
+*****IMPORTANT NOTE*****
+</b>
+<br><br>
+If Shipping Address Is Different From The Billing Address Above,
+Please Fill Out Information Below.
+<br><br>
+Shipping Name______________________________________________
+<br><br>
+Shipping Address___________________________________________
+<br><br>
+___________________________________________________________<br>
+Shipping City,State,Zip
+<br><br>
+___________________________________________________________<br>
+Country
+<br><br>
+___________________________________________________________<br>
+Email Address & Phone Number(Please Write Neat)
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/james-project/blob/1fd63a7f/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam3
----------------------------------------------------------------------
diff --git a/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam3 b/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam3
new file mode 100644
index 0000000..e828804
--- /dev/null
+++ b/third-party/spamassassin/src/test/resources/spamassassin_db/spam/spam3
@@ -0,0 +1,211 @@
+From amknight@mailexcite.com  Mon Jun 24 17:03:49 2002
+Return-Path: merchantsworld2001@juno.com
+Delivery-Date: Wed May 15 08:58:23 2002
+Received: from mandark.labs.netnoteinc.com ([213.105.180.140]) by
+    dogma.slashnull.org (8.11.6/8.11.6) with ESMTP id g4F7wIe23864 for
+    <jm...@jmason.org>; Wed, 15 May 2002 08:58:18 +0100
+Received: from webcust2.hightowertech.com (webcust2.hightowertech.com
+    [216.41.166.100]) by mandark.labs.netnoteinc.com (8.11.2/8.11.2) with
+    ESMTP id g4F7wGD24120 for <jm...@netnoteinc.com>; Wed, 15 May 2002 08:58:17
+    +0100
+Received: from html ([206.216.197.214]) by webcust2.hightowertech.com with
+    Microsoft SMTPSVC(5.5.1877.197.19); Wed, 15 May 2002 00:55:53 -0700
+From: amknight@mailexcite.com
+To: cbmark@cbmark.com
+Subject: New Improved Fat Burners, Now With TV Fat Absorbers! Time:6:25:49 PM
+Date: Wed, 30 Jul 1980 18:25:49
+MIME-Version: 1.0
+Message-Id: <08...@webcust2.hightowertech.com>
+X-Keywords: 
+Content-Type: text/html; charset="DEFAULT"
+
+<html>
+<body>
+<center>
+<b>
+<font color="blue">
+*****Bonus Fat Absorbers As Seen On TV, Included Free With Purchase Of 2 Or More Bottle, $24.95 Value*****
+</font>
+<br>
+<br>
+***TAKE $10.00 OFF 2 & 3 MONTH SUPPLY ORDERS, $5.00 OFF 1 MONTH SUPPLY!
+***AND STILL GET YOUR BONUS!  PRICE WILL BE DEDUCTED DURING PROCESSING.
+<br>
+<br>
+***FAT ABSORBERS ARE GREAT FOR THOSE WHO WANT TO LOSE WEIGHT,  BUT CAN'T STAY ON A DIET***
+<br>
+<br>
+***OFFER GOOD UNTIL MAY 27, 2002!  FOREIGN ORDERS INCLUDED!
+<br>
+<br>
+
+<font color="blue">
+
+LOSE 30 POUNDS  IN 30 DAYS... GUARANTEED!!!
+<br>
+<br>
+
+All Natural Weight-Loss Program, Speeds Up The Metabolism Safely
+Rated #1 In Both Categories of SAFETY & EFFECTIVENESS In<br>
+(THE United States Today)
+<br><br>
+WE'LL HELP YOU GET THINNER!
+WE'RE GOING TO HELP YOU LOOK GOOD, FEEL GOOD AND TAKE CONTROL IN
+2002
+<br>
+<br>
+</b>
+</font color="blue">
+</center>
+
+Why Use Our Amazing Weight Loss Capsules?
+<br><br>
+*  They act like a natural magnet to attract fat.<br>
+*  Stimulates the body's natural metabolism. <br>
+*  Controls appetite naturally and makes it easier to
+   eat the right foods consistently.<br>
+*  Reduces craving for sweets.<br>
+*  Aids in the absorption of fat and in overall digestion.<br>
+*  Inhibits bad cholesterol and boosts good cholesterol.<br>
+*  Aids in the process of weight loss and long-term weight management.<br>
+*  Completely safe, UltraTrim New Century contains no banned
+   substances and has no known side effects.<br>
+<br>
+What Makes UltraTrim New Century Unique?
+<br><br>
+A scientifically designed combination of natural ingredients that
+provide long-term weight management in a safe and effective manner.
+<br><br>
+*****<br>
+Receive A Bonus Supply Of Ultra Trim New Century & A Bottle Of Fat Absorbers Listed Above, 
+With Every Order Of 2 Or More Bottles. Offer Good Until May. 27, 2002! <br>
+*****
+<br><br>
+WE GLADLY SHIP TO ALL FOREIGN COUNTRIES! 
+<br><br>
+You will be losing by tomorrow!  Don't Wait, visit our web
+page below, and order now!
+<br><br>
+Email Address:   <a
+href="mailto:ultratrimnow2001@aol.com">ultratrimnow2001@aol.com</a>
+<br><br>
+Order by 24 Hour Fax!!!  775-257-6657.<br>
+<br>
+*****************<br>
+<a
+href="http://www.geocities.com/ultra_weightloss_2002/">http://www.geocities.com/ultra_weightloss_2002/</a><br>
+*****************
+<br><br>
+This is the easiest, fastest, and most effective way to lose both
+pounds and inches permanently!!!  This weight loss program is
+designed specifically to "boost" weight-loss efforts by assisting
+body metabolism, and helping the body's ability to manage weight.
+A powerful, safe, 30 Day Program.  This is one program you won't
+feel starved on.  Complete program for one amazing low price!
+Program includes: <b>BONUS AMAZING FAT ABSORBER CAPSULES, 30 DAY -
+WEIGHT
+REDUCTION PLAN, PROGRESS REPORT!</b>
+<br><br>
+SPECIAL BONUS..."FAT ABSORBERS", AS SEEN ON TV
+With every order...AMAZING MELT AWAY FAT ABSORBER CAPSULES with
+directions ( Absolutely Free ) ...With these capsules
+you can eat what you enjoy, without the worry of fat in your diet.
+2 to 3 capsules 15 minutes before eating or snack, and the fat will be
+absorbed and passed through the body without the digestion of fat into
+the body. 
+<br><br>
+You will be losing by tomorrow!  Don't Wait, visit our web
+page below, and order now!
+<br><br>
+Email Address:  <a href="mailto:ultratrimnow2001@aol.com">ultratrimnow2001@aol.com</a>
+<br><br>
+
+Order by 24 Hour Fax!!!  775-257-6657.<br>
+<br>
+*****************<br>
+<a
+href="http://www.geocities.com/ultra_weightloss_2002/">http://www.geocities.com/ultra_weightloss_2002/</a><br>
+*****************
+<br><br>
+___1 Month Supply $32.95 plus $4.75 S & H, 100 Amazing MegaTrim
+     Capsules.
+<br><br>
+___2 Month Supply $54.95 plus $4.75 S & H, 200 Amazing MegaTrim
+     Capsules.  (A $10.95 Savings, Free Bottle)!
+<br><br>
+___3 Month Supply $69.95,  Plus $4.75 S & H, 300 Amazing MegaTrim
+     Capsules.  (A $28.90 Savings, Free Bottle)!
+<br><br>
+To Order by postal mail, please send to the below address.
+Make payable to UltraTrim 2002.
+<br><br>
+Ultra Trim 2002<br>
+4132 Pompton Ct.<br>
+Dayton, Ohio  45405<br>
+(937) 567-9807<br>
+<br>
+Order by 24 Hour Voice/Fax!!!  775-257-6657.<br>
+<br>
+*****<br>
+<b><font color="red">Important Credit Card Information! Please Read Below!</b></font>
+ <br><br>
+*     Credit Card Address, City, State and Zip Code, must match
+      billing address to be processed. 
+<br><br>
+
+___Check<br>
+___MoneyOrder<br>
+___Visa<br>
+___MasterCard<br>
+___AmericanExpress<br>
+___Debt Card
+<br><br>
+Name_______________________________________________________<br>
+(As it appears on Check or Credit Card)
+<br><br>
+Address____________________________________________________<br>
+(As it appears on Check or Credit Card)
+<br><br>
+___________________________________________________<br>
+City,State,Zip(As it appears on Check or Credit Card)
+<br><br>
+___________________________________________________<br>
+Country
+<br><br>
+___________________________________________________<br>
+(Credit Card Number)
+<br><br>
+Expiration Month_____  Year_____
+<br><br>
+___________________________________________________<br>
+Authorized Signature
+<br><br>
+<b>
+*****IMPORTANT NOTE*****
+</b>
+<br><br>
+If Shipping Address Is Different From The Billing Address Above,
+Please Fill Out Information Below.
+<br><br>
+Shipping Name______________________________________________
+<br><br>
+Shipping Address___________________________________________
+<br><br>
+___________________________________________________________<br>
+Shipping City,State,Zip
+<br><br>
+___________________________________________________________<br>
+Country
+<br><br>
+___________________________________________________________<br>
+Email Address & Phone Number(Please Write Neat)
+<br>
+<br>
+<center>
+<a
+href="mailto:ultratrim2002dontsend@yahoo.com">To Be Removed From Our Mail List, Click Here And Put The Word Remove In The Subject Line.</a>
+</center>
+<br>
+<br>
+</body>
+</html>


---------------------------------------------------------------------
To unsubscribe, e-mail: server-dev-unsubscribe@james.apache.org
For additional commands, e-mail: server-dev-help@james.apache.org