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 no...@apache.org on 2010/01/22 11:29:28 UTC

svn commit: r902049 [2/2] - in /james/server/trunk: imapserver-function/src/main/java/org/apache/james/imapserver/ mina-socket-library/src/main/java/org/apache/james/socket/mina/ pop3server-function/ pop3server-function/src/main/java/org/apache/james/p...

Modified: james/server/trunk/smtpserver-function/src/test/java/org/apache/james/smtpserver/AsyncSMTPServerTest.java
URL: http://svn.apache.org/viewvc/james/server/trunk/smtpserver-function/src/test/java/org/apache/james/smtpserver/AsyncSMTPServerTest.java?rev=902049&r1=902048&r2=902049&view=diff
==============================================================================
--- james/server/trunk/smtpserver-function/src/test/java/org/apache/james/smtpserver/AsyncSMTPServerTest.java (original)
+++ james/server/trunk/smtpserver-function/src/test/java/org/apache/james/smtpserver/AsyncSMTPServerTest.java Fri Jan 22 10:29:27 2010
@@ -19,19 +19,155 @@
 
 package org.apache.james.smtpserver;
 
+import java.io.BufferedReader;
+import java.io.ByteArrayOutputStream;
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.io.OutputStream;
+import java.io.Writer;
+import java.net.InetAddress;
+import java.net.Socket;
+import java.net.UnknownHostException;
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.Iterator;
+import java.util.List;
+
+import javax.mail.MessagingException;
+import javax.mail.internet.MimeMessage;
+
+import junit.framework.TestCase;
+
+import org.apache.avalon.cornerstone.services.datasources.DataSourceSelector;
+import org.apache.avalon.cornerstone.services.store.Store;
+import org.apache.avalon.framework.container.ContainerUtil;
 import org.apache.commons.logging.impl.SimpleLog;
+import org.apache.commons.net.smtp.SMTPClient;
+import org.apache.commons.net.smtp.SMTPReply;
+import org.apache.james.api.dnsservice.DNSService;
 import org.apache.james.api.kernel.mock.FakeLoader;
+import org.apache.james.api.user.UsersRepository;
+import org.apache.james.api.vut.VirtualUserTableStore;
+import org.apache.james.services.FileSystem;
+import org.apache.james.services.MailServer;
 import org.apache.james.smtpserver.integration.SMTPServerDNSServiceAdapter;
 import org.apache.james.smtpserver.mina.AsyncSMTPServer;
+import org.apache.james.test.mock.DummyDataSourceSelector;
+import org.apache.james.test.mock.DummyVirtualUserTableStore;
+import org.apache.james.test.mock.avalon.MockSocketManager;
+import org.apache.james.test.mock.avalon.MockStore;
+import org.apache.james.test.mock.avalon.MockThreadManager;
+import org.apache.james.test.mock.james.MockFileSystem;
+import org.apache.james.test.mock.james.MockMailServer;
+import org.apache.james.test.util.Util;
+import org.apache.james.userrepository.MockUsersRepository;
+import org.apache.james.util.codec.Base64;
+import org.apache.mailet.HostAddress;
+import org.apache.mailet.Mail;
+import org.apache.mailet.MailAddress;
+
+public class AsyncSMTPServerTest extends TestCase {
+
+    final class AlterableDNSServer implements DNSService {
+
+        private InetAddress localhostByName = null;
+
+        public Collection<String> findMXRecords(String hostname) {
+            List<String> res = new ArrayList<String>();
+            if (hostname == null) {
+                return res;
+            }
+            ;
+            if ("james.apache.org".equals(hostname)) {
+                res.add("nagoya.apache.org");
+            }
+            return res;
+        }
+
+        public Iterator<HostAddress> getSMTPHostAddresses(String domainName) {
+            throw new UnsupportedOperationException("Unimplemented mock service");
+        }
+
+        public InetAddress[] getAllByName(String host) throws UnknownHostException {
+            return new InetAddress[] { getByName(host) };
+        }
+
+        public InetAddress getByName(String host) throws UnknownHostException {
+            if (getLocalhostByName() != null) {
+                if ("127.0.0.1".equals(host))
+                    return getLocalhostByName();
+            }
+
+            if ("1.0.0.127.bl.spamcop.net.".equals(host)) {
+                return InetAddress.getByName("localhost");
+            }
+
+            if ("james.apache.org".equals(host)) {
+                return InetAddress.getByName("james.apache.org");
+            }
 
-public class AsyncSMTPServerTest extends SMTPServerTest {
+            if ("abgsfe3rsf.de".equals(host)) {
+                throw new UnknownHostException();
+            }
 
+            if ("128.0.0.1".equals(host) || "192.168.0.1".equals(host) || "127.0.0.1".equals(host) || "127.0.0.0".equals(host) || "255.0.0.0".equals(host) || "255.255.255.255".equals(host)) {
+                return InetAddress.getByName(host);
+            }
+
+            throw new UnsupportedOperationException("getByName not implemented in mock for host: " + host);
+            // return InetAddress.getByName(host);
+        }
+
+        public Collection<String> findTXTRecords(String hostname) {
+            List<String> res = new ArrayList<String>();
+            if (hostname == null) {
+                return res;
+            }
+            ;
+            if ("2.0.0.127.bl.spamcop.net.".equals(hostname)) {
+                res.add("Blocked - see http://www.spamcop.net/bl.shtml?127.0.0.2");
+            }
+            return res;
+        }
+
+        public InetAddress getLocalhostByName() {
+            return localhostByName;
+        }
+
+        public void setLocalhostByName(InetAddress localhostByName) {
+            this.localhostByName = localhostByName;
+        }
+
+        public String getHostName(InetAddress addr) {
+            return addr.getHostName();
+        }
+
+        public InetAddress getLocalHost() throws UnknownHostException {
+            return InetAddress.getLocalHost();
+        }
+    }
+
+    protected final int m_smtpListenerPort;
+    protected MockMailServer m_mailServer;
     private AsyncSMTPServer m_smtpServer;
+    protected SMTPTestConfiguration m_testConfiguration;
+    protected MockUsersRepository m_usersRepository = new MockUsersRepository();
+    protected FakeLoader m_serviceManager;
+    protected AlterableDNSServer m_dnsServer;
+    protected MockSocketManager socketManager;
+    protected MockThreadManager threadManager;
+    protected MockStore store;
+    protected MockFileSystem fileSystem;
+    protected SMTPServerDNSServiceAdapter dnsAdapter;
+
+    public AsyncSMTPServerTest() {
+        super("AsyncSMTPServerTest");
+        m_smtpListenerPort = Util.getNonPrivilegedPort();
+    }
 
     protected void setUp() throws Exception {
-        m_serviceManager = setUpServiceManager();
+        setUpFakeLoader();
 
-        
         m_smtpServer = new AsyncSMTPServer();
         m_smtpServer.setDNSService(m_dnsServer);
         m_smtpServer.setFileSystem(fileSystem);
@@ -45,21 +181,1234 @@
         testConfiguration.init();
         m_smtpServer.configure(testConfiguration);
         m_smtpServer.init();
-        m_mailServer.setMaxMessageSizeBytes(m_testConfiguration.getMaxMessageSize()*1024);
+        m_mailServer.setMaxMessageSizeBytes(m_testConfiguration.getMaxMessageSize() * 1024);
+    }
+
+    protected void tearDown() throws Exception {
+        ContainerUtil.dispose(m_mailServer);
+        super.tearDown();
     }
 
-    protected FakeLoader setUpServiceManager() throws Exception {
-        super.setUpServiceManager();
+    public void verifyLastMail(String sender, String recipient, MimeMessage msg) throws IOException, MessagingException {
+        Mail mailData = m_mailServer.getLastMail();
+        assertNotNull("mail received by mail server", mailData);
+
+        if (sender == null && recipient == null && msg == null)
+            fail("no verification can be done with all arguments null");
+
+        if (sender != null)
+            assertEquals("sender verfication", sender, mailData.getSender().toString());
+        if (recipient != null)
+            assertTrue("recipient verfication", mailData.getRecipients().contains(new MailAddress(recipient)));
+        if (msg != null) {
+            ByteArrayOutputStream bo1 = new ByteArrayOutputStream();
+            msg.writeTo(bo1);
+            ByteArrayOutputStream bo2 = new ByteArrayOutputStream();
+            mailData.getMessage().writeTo(bo2);
+            assertEquals(bo1.toString(), bo2.toString());
+            assertEquals("message verification", msg, mailData.getMessage());
+        }
+    }
+
+    protected void setUpFakeLoader() throws Exception {
+        m_serviceManager = new FakeLoader();
+        m_mailServer = new MockMailServer(new MockUsersRepository());
+        m_serviceManager.put(MailServer.ROLE, m_mailServer);
+        m_serviceManager.put(UsersRepository.ROLE, m_usersRepository);
+
+        m_dnsServer = new AlterableDNSServer();
+        m_serviceManager.put(DNSService.ROLE, m_dnsServer);
+
+        store = new MockStore();
+        m_serviceManager.put(Store.ROLE, store);
+        fileSystem = new MockFileSystem();
+
+        m_serviceManager.put(FileSystem.ROLE, fileSystem);
+
+        dnsAdapter = new SMTPServerDNSServiceAdapter();
+        dnsAdapter.setDNSService(m_dnsServer);
+        m_serviceManager.put("org.apache.james.smtpserver.protocol.DNSService", dnsAdapter);
+        m_serviceManager.put(VirtualUserTableStore.ROLE, new DummyVirtualUserTableStore());
+        m_serviceManager.put(DataSourceSelector.ROLE, new DummyDataSourceSelector());
         SMTPServerDNSServiceAdapter dnsAdapter = new SMTPServerDNSServiceAdapter();
         dnsAdapter.setDNSService(m_dnsServer);
         m_serviceManager.put("org.apache.james.smtpserver.protocol.DNSService", dnsAdapter);
-        return m_serviceManager;
     }
-    
+
+    public void testSimpleMailSendWithEHLO() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol.sendCommand("EHLO " + InetAddress.getLocalHost());
+        String[] capabilityRes = smtpProtocol.getReplyStrings();
+
+        List<String> capabilitieslist = new ArrayList<String>();
+        for (int i = 1; i < capabilityRes.length; i++) {
+            capabilitieslist.add(capabilityRes[i].substring(4));
+        }
+
+        assertEquals("capabilities", 3, capabilitieslist.size());
+        assertTrue("capabilities present PIPELINING", capabilitieslist.contains("PIPELINING"));
+        assertTrue("capabilities present ENHANCEDSTATUSCODES", capabilitieslist.contains("ENHANCEDSTATUSCODES"));
+        assertTrue("capabilities present 8BITMIME", capabilitieslist.contains("8BITMIME"));
+
+        smtpProtocol.setSender("mail@localhost");
+        smtpProtocol.addRecipient("mail@localhost");
+
+        smtpProtocol.sendShortMessageData("Subject: test\r\n\r\nBody\r\n\r\n.\r\n");
+        smtpProtocol.quit();
+        smtpProtocol.disconnect();
+
+        // mail was propagated by SMTPServer
+        assertNotNull("mail received by mail server", m_mailServer.getLastMail());
+    }
+
+    public void testStartTLSInEHLO() throws Exception {
+        m_testConfiguration.setStartTLS();
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol.sendCommand("EHLO " + InetAddress.getLocalHost());
+        String[] capabilityRes = smtpProtocol.getReplyStrings();
+
+        List<String> capabilitieslist = new ArrayList<String>();
+        for (int i = 1; i < capabilityRes.length; i++) {
+            capabilitieslist.add(capabilityRes[i].substring(4));
+        }
+
+        assertEquals("capabilities", 4, capabilitieslist.size());
+        assertTrue("capabilities present PIPELINING", capabilitieslist.contains("PIPELINING"));
+        assertTrue("capabilities present ENHANCEDSTATUSCODES", capabilitieslist.contains("ENHANCEDSTATUSCODES"));
+        assertTrue("capabilities present 8BITMIME", capabilitieslist.contains("8BITMIME"));
+        assertTrue("capabilities present STARTTLS", capabilitieslist.contains("STARTTLS"));
+
+        smtpProtocol.quit();
+        smtpProtocol.disconnect();
+
+    }
+
+    /**
+     * TODO: Understand why this fails!
+     * 
+     * public void testEmptyMessage() throws Exception {
+     * finishSetUp(m_testConfiguration);
+     * 
+     * SMTPClient smtp = new SMTPClient(); smtp.connect("127.0.0.1",
+     * m_smtpListenerPort);
+     * 
+     * // no message there, yet assertNull("no mail received by mail server",
+     * m_mailServer.getLastMail());
+     * 
+     * smtp.helo(InetAddress.getLocalHost().toString());
+     * 
+     * smtp.setSender("mail@localhost");
+     * 
+     * smtp.addRecipient("mail@localhost");
+     * 
+     * smtp.sendShortMessageData("");
+     * 
+     * smtp.quit();
+     * 
+     * smtp.disconnect();
+     * 
+     * // mail was propagated by SMTPServer
+     * assertNotNull("mail received by mail server",
+     * m_mailServer.getLastMail());
+     * 
+     * // added to check a NPE in the test (JAMES-474) due to MockMailServer //
+     * not cloning the message (added a MimeMessageCopyOnWriteProxy there)
+     * System.gc();
+     * 
+     * int size = m_mailServer.getLastMail().getMessage().getSize();
+     * 
+     * assertEquals(size, 2); }
+     */
+
+    public void testSimpleMailSendWithHELO() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol.helo(InetAddress.getLocalHost().toString());
+
+        smtpProtocol.setSender("mail@localhost");
+
+        smtpProtocol.addRecipient("mail@localhost");
+
+        smtpProtocol.sendShortMessageData("Subject: test mail\r\n\r\nTest body testSimpleMailSendWithHELO\r\n.\r\n");
+
+        smtpProtocol.quit();
+        smtpProtocol.disconnect();
+
+        // mail was propagated by SMTPServer
+        assertNotNull("mail received by mail server", m_mailServer.getLastMail());
+    }
+
+    public void testTwoSimultaneousMails() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+        SMTPClient smtpProtocol2 = new SMTPClient();
+        smtpProtocol2.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+        assertTrue("second connection taken", smtpProtocol2.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+        smtpProtocol2.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@localhost";
+        String recipient1 = "mail_recipient1@localhost";
+        smtpProtocol1.setSender(sender1);
+        smtpProtocol1.addRecipient(recipient1);
+
+        String sender2 = "mail_sender2@localhost";
+        String recipient2 = "mail_recipient2@localhost";
+        smtpProtocol2.setSender(sender2);
+        smtpProtocol2.addRecipient(recipient2);
+
+        smtpProtocol1.sendShortMessageData("Subject: test\r\n\r\nTest body testTwoSimultaneousMails1\r\n.\r\n");
+        verifyLastMail(sender1, recipient1, null);
+
+        smtpProtocol2.sendShortMessageData("Subject: test\r\n\r\nTest body testTwoSimultaneousMails2\r\n.\r\n");
+        verifyLastMail(sender2, recipient2, null);
+
+        smtpProtocol1.quit();
+        smtpProtocol2.quit();
+
+        smtpProtocol1.disconnect();
+        smtpProtocol2.disconnect();
+    }
+
+    public void testTwoMailsInSequence() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@localhost";
+        String recipient1 = "mail_recipient1@localhost";
+        smtpProtocol1.setSender(sender1);
+        smtpProtocol1.addRecipient(recipient1);
+
+        smtpProtocol1.sendShortMessageData("Subject: test\r\n\r\nTest body testTwoMailsInSequence1\r\n");
+        verifyLastMail(sender1, recipient1, null);
+
+        String sender2 = "mail_sender2@localhost";
+        String recipient2 = "mail_recipient2@localhost";
+        smtpProtocol1.setSender(sender2);
+        smtpProtocol1.addRecipient(recipient2);
+
+        smtpProtocol1.sendShortMessageData("Subject: test2\r\n\r\nTest body2 testTwoMailsInSequence2\r\n");
+        verifyLastMail(sender2, recipient2, null);
+
+        smtpProtocol1.quit();
+        smtpProtocol1.disconnect();
+    }
+
+    public void testHeloResolv() throws Exception {
+        m_testConfiguration.setHeloResolv();
+        m_testConfiguration.setAuthorizedAddresses("192.168.0.1");
+        finishSetUp(m_testConfiguration);
+
+        doTestHeloEhloResolv("helo");
+    }
+
+    private void doTestHeloEhloResolv(String heloCommand) throws IOException {
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        String fictionalDomain = "abgsfe3rsf.de";
+        String existingDomain = "james.apache.org";
+        String mail = "sender@james.apache.org";
+        String rcpt = "rcpt@localhost";
+
+        smtpProtocol.sendCommand(heloCommand, fictionalDomain);
+        smtpProtocol.setSender(mail);
+        smtpProtocol.addRecipient(rcpt);
+
+        // this should give a 501 code cause the helo/ehlo could not resolved
+        assertEquals("expected error: " + heloCommand + " could not resolved", 501, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendCommand(heloCommand, existingDomain);
+        smtpProtocol.setSender(mail);
+        smtpProtocol.addRecipient(rcpt);
+
+        if (smtpProtocol.getReplyCode() == 501) {
+            fail(existingDomain + " domain currently cannot be resolved (check your DNS/internet connection/proxy settings to make test pass)");
+        }
+        // helo/ehlo is resolvable. so this should give a 250 code
+        assertEquals(heloCommand + " accepted", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.quit();
+    }
+
+    public void testHeloResolvDefault() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol1.helo("abgsfe3rsf.de");
+        // helo should not be checked. so this should give a 250 code
+        assertEquals("Helo accepted", 250, smtpProtocol1.getReplyCode());
+
+        smtpProtocol1.quit();
+    }
+
+    public void testReverseEqualsHelo() throws Exception {
+        m_testConfiguration.setReverseEqualsHelo();
+        m_testConfiguration.setAuthorizedAddresses("192.168.0.1");
+        // temporary alter the loopback resolution
+        try {
+            m_dnsServer.setLocalhostByName(InetAddress.getByName("james.apache.org"));
+        } catch (UnknownHostException e) {
+            fail("james.apache.org currently cannot be resolved (check your DNS/internet connection/proxy settings to make test pass)");
+        }
+        try {
+            finishSetUp(m_testConfiguration);
+
+            SMTPClient smtpProtocol1 = new SMTPClient();
+            smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+            assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+            // no message there, yet
+            assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+            String helo1 = "abgsfe3rsf.de";
+            String helo2 = "james.apache.org";
+            String mail = "sender";
+            String rcpt = "recipient";
+
+            smtpProtocol1.sendCommand("helo", helo1);
+            smtpProtocol1.setSender(mail);
+            smtpProtocol1.addRecipient(rcpt);
+
+            // this should give a 501 code cause the helo not equal reverse of
+            // ip
+            assertEquals("expected error: helo not equals reverse of ip", 501, smtpProtocol1.getReplyCode());
+
+            smtpProtocol1.sendCommand("helo", helo2);
+            smtpProtocol1.setSender(mail);
+            smtpProtocol1.addRecipient(rcpt);
+
+            // helo is resolvable. so this should give a 250 code
+            assertEquals("Helo accepted", 250, smtpProtocol1.getReplyCode());
+
+            smtpProtocol1.quit();
+        } finally {
+            m_dnsServer.setLocalhostByName(null);
+        }
+    }
+
+    public void testSenderDomainResolv() throws Exception {
+        m_testConfiguration.setSenderDomainResolv();
+        m_testConfiguration.setAuthorizedAddresses("192.168.0.1/32");
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@xfwrqqfgfe.de";
+
+        smtpProtocol1.setSender(sender1);
+        assertEquals("expected 501 error", 501, smtpProtocol1.getReplyCode());
+
+        smtpProtocol1.addRecipient("test@localhost");
+        assertEquals("Recipient not accepted cause no valid sender", 503, smtpProtocol1.getReplyCode());
+        smtpProtocol1.quit();
+
+    }
+
+    public void testSenderDomainResolvDefault() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@xfwrqqfgfe.de";
+
+        smtpProtocol1.setSender(sender1);
+
+        smtpProtocol1.quit();
+    }
+
+    public void testSenderDomainResolvRelayClientDefault() throws Exception {
+        m_testConfiguration.setSenderDomainResolv();
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@xfwrqqfgfe.de";
+
+        // Both mail shold
+        smtpProtocol1.setSender(sender1);
+
+        smtpProtocol1.quit();
+
+    }
+
+    public void testSenderDomainResolvRelayClient() throws Exception {
+        m_testConfiguration.setSenderDomainResolv();
+        m_testConfiguration.setCheckAuthNetworks(true);
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@xfwrqqfgfe.de";
+        String sender2 = "mail_sender2@james.apache.org";
+
+        smtpProtocol1.setSender(sender1);
+        assertEquals("expected 501 error", 501, smtpProtocol1.getReplyCode());
+
+        smtpProtocol1.setSender(sender2);
+
+        smtpProtocol1.quit();
+
+    }
+
+    public void testMaxRcpt() throws Exception {
+        m_testConfiguration.setMaxRcpt(1);
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@james.apache.org";
+        String rcpt1 = "test@localhost";
+        String rcpt2 = "test2@localhost";
+
+        smtpProtocol1.setSender(sender1);
+        smtpProtocol1.addRecipient(rcpt1);
+
+        smtpProtocol1.addRecipient(rcpt2);
+        assertEquals("expected 452 error", 452, smtpProtocol1.getReplyCode());
+
+        smtpProtocol1.sendShortMessageData("Subject: test\r\n\r\nTest body testMaxRcpt1\r\n");
+
+        // After the data is send the rcpt count is set back to 0.. So a new
+        // mail with rcpt should be accepted
+
+        smtpProtocol1.setSender(sender1);
+
+        smtpProtocol1.addRecipient(rcpt1);
+
+        smtpProtocol1.sendShortMessageData("Subject: test\r\n\r\nTest body testMaxRcpt2\r\n");
+
+        smtpProtocol1.quit();
+
+    }
+
+    public void testMaxRcptDefault() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        String sender1 = "mail_sender1@james.apache.org";
+        String rcpt1 = "test@localhost";
+
+        smtpProtocol1.setSender(sender1);
+
+        smtpProtocol1.addRecipient(rcpt1);
+
+        smtpProtocol1.sendShortMessageData("Subject: test\r\n\r\nTest body testMaxRcptDefault\r\n");
+
+        smtpProtocol1.quit();
+    }
+
+    public void testEhloResolv() throws Exception {
+        m_testConfiguration.setEhloResolv();
+        m_testConfiguration.setAuthorizedAddresses("192.168.0.1");
+        finishSetUp(m_testConfiguration);
+
+        doTestHeloEhloResolv("ehlo");
+    }
+
+    public void testEhloResolvDefault() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol1.sendCommand("ehlo", "abgsfe3rsf.de");
+        // ehlo should not be checked. so this should give a 250 code
+        assertEquals("ehlo accepted", 250, smtpProtocol1.getReplyCode());
+
+        smtpProtocol1.quit();
+    }
+
+    public void testEhloResolvIgnoreClientDisabled() throws Exception {
+        m_testConfiguration.setEhloResolv();
+        m_testConfiguration.setCheckAuthNetworks(true);
+        finishSetUp(m_testConfiguration);
+
+        doTestHeloEhloResolv("ehlo");
+    }
+
+    public void testReverseEqualsEhlo() throws Exception {
+        m_testConfiguration.setReverseEqualsEhlo();
+        m_testConfiguration.setAuthorizedAddresses("192.168.0.1");
+        // temporary alter the loopback resolution
+        InetAddress jamesDomain = null;
+        try {
+            jamesDomain = m_dnsServer.getByName("james.apache.org");
+        } catch (UnknownHostException e) {
+            fail("james.apache.org currently cannot be resolved (check your DNS/internet connection/proxy settings to make test pass)");
+        }
+        m_dnsServer.setLocalhostByName(jamesDomain);
+        try {
+            finishSetUp(m_testConfiguration);
+
+            SMTPClient smtpProtocol1 = new SMTPClient();
+            smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+            assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+            // no message there, yet
+            assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+            String ehlo1 = "abgsfe3rsf.de";
+            String ehlo2 = "james.apache.org";
+            String mail = "sender";
+            String rcpt = "recipient";
+
+            smtpProtocol1.sendCommand("ehlo", ehlo1);
+            smtpProtocol1.setSender(mail);
+            smtpProtocol1.addRecipient(rcpt);
+
+            // this should give a 501 code cause the ehlo not equals reverse of
+            // ip
+            assertEquals("expected error: ehlo not equals reverse of ip", 501, smtpProtocol1.getReplyCode());
+
+            smtpProtocol1.sendCommand("ehlo", ehlo2);
+            smtpProtocol1.setSender(mail);
+            smtpProtocol1.addRecipient(rcpt);
+
+            // ehlo is resolvable. so this should give a 250 code
+            assertEquals("ehlo accepted", 250, smtpProtocol1.getReplyCode());
+
+            smtpProtocol1.quit();
+        } finally {
+            m_dnsServer.setLocalhostByName(null);
+        }
+    }
+
+    public void testHeloEnforcement() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        String sender1 = "mail_sender1@localhost";
+        smtpProtocol1.setSender(sender1);
+        assertEquals("expected 503 error", 503, smtpProtocol1.getReplyCode());
+
+        smtpProtocol1.helo(InetAddress.getLocalHost().toString());
+
+        smtpProtocol1.setSender(sender1);
+
+        smtpProtocol1.quit();
+    }
+
+    public void testHeloEnforcementDisabled() throws Exception {
+        m_testConfiguration.setHeloEhloEnforcement(false);
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol1 = new SMTPClient();
+        smtpProtocol1.connect("127.0.0.1", m_smtpListenerPort);
+
+        assertTrue("first connection taken", smtpProtocol1.isConnected());
+
+        // no message there, yet
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+
+        String sender1 = "mail_sender1@localhost";
+
+        smtpProtocol1.setSender(sender1);
+
+        smtpProtocol1.quit();
+    }
+
+    public void testAuthCancel() throws Exception {
+        m_testConfiguration.setAuthorizedAddresses("127.0.0.1/8");
+        m_testConfiguration.setAuthorizingAnnounce();
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo", InetAddress.getLocalHost().toString());
+
+        smtpProtocol.sendCommand("AUTH PLAIN");
+
+        assertEquals("start auth.", 334, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendCommand("*");
+
+        assertEquals("cancel auth.", 501, smtpProtocol.getReplyCode());
+
+        smtpProtocol.quit();
+
+    }
+
+    // Test for JAMES-939
+    public void testAuth() throws Exception {
+        m_testConfiguration.setAuthorizedAddresses("128.0.0.1/8");
+        m_testConfiguration.setAuthorizingAnnounce();
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo", InetAddress.getLocalHost().toString());
+        String[] capabilityRes = smtpProtocol.getReplyStrings();
+
+        List<String> capabilitieslist = new ArrayList<String>();
+        for (int i = 1; i < capabilityRes.length; i++) {
+            capabilitieslist.add(capabilityRes[i].substring(4));
+        }
+
+        assertTrue("anouncing auth required", capabilitieslist.contains("AUTH LOGIN PLAIN"));
+        // is this required or just for compatibility?
+        // assertTrue("anouncing auth required",
+        // capabilitieslist.contains("AUTH=LOGIN PLAIN"));
+
+        String userName = "test_user_smtp";
+        String noexistUserName = "noexist_test_user_smtp";
+        String sender = "test_user_smtp@localhost";
+        smtpProtocol.sendCommand("AUTH FOO", null);
+        assertEquals("expected error: unrecognized authentication type", 504, smtpProtocol.getReplyCode());
+
+        smtpProtocol.setSender(sender);
+
+        smtpProtocol.addRecipient("mail@sample.com");
+        assertEquals("expected 530 error", 530, smtpProtocol.getReplyCode());
+
+        assertFalse("user not existing", m_usersRepository.contains(noexistUserName));
+
+        smtpProtocol.sendCommand("AUTH PLAIN");
+        smtpProtocol.sendCommand(Base64.encodeAsString("\0" + noexistUserName + "\0pwd\0"));
+        // smtpProtocol.sendCommand(noexistUserName+"pwd".toCharArray());
+        assertEquals("expected error", 535, smtpProtocol.getReplyCode());
+
+        m_usersRepository.addUser(userName, "pwd");
+
+        smtpProtocol.sendCommand("AUTH PLAIN");
+        smtpProtocol.sendCommand(Base64.encodeAsString("\0" + userName + "\0wrongpwd\0"));
+        assertEquals("expected error", 535, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendCommand("AUTH PLAIN");
+        smtpProtocol.sendCommand(Base64.encodeAsString("\0" + userName + "\0pwd\0"));
+        assertEquals("authenticated", 235, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendCommand("AUTH PLAIN");
+        assertEquals("expected error: User has previously authenticated.", 503, smtpProtocol.getReplyCode());
+
+        smtpProtocol.addRecipient("mail@sample.com");
+        smtpProtocol.sendShortMessageData("Subject: test\r\n\r\nTest body testAuth\r\n");
+
+        smtpProtocol.quit();
+
+        // mail was propagated by SMTPServer
+        assertNotNull("mail received by mail server", m_mailServer.getLastMail());
+    }
+
+    public void testAuthWithEmptySender() throws Exception {
+        m_testConfiguration.setAuthorizedAddresses("128.0.0.1/8");
+        m_testConfiguration.setAuthorizingAnnounce();
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo " + InetAddress.getLocalHost());
+
+        String userName = "test_user_smtp";
+        m_usersRepository.addUser(userName, "pwd");
+
+        smtpProtocol.setSender("");
+
+        smtpProtocol.sendCommand("AUTH PLAIN");
+        smtpProtocol.sendCommand(Base64.encodeAsString("\0" + userName + "\0pwd\0"));
+        assertEquals("authenticated", 235, smtpProtocol.getReplyCode());
+
+        smtpProtocol.addRecipient("mail@sample.com");
+        assertEquals("expected error", 503, smtpProtocol.getReplyCode());
+
+        smtpProtocol.quit();
+    }
+
+    public void testNoRecepientSpecified() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo " + InetAddress.getLocalHost());
+
+        smtpProtocol.setSender("mail@sample.com");
+
+        // left out for test smtpProtocol.rcpt(new Address("mail@localhost"));
+
+        smtpProtocol.sendShortMessageData("Subject: test\r\n\r\nTest body testNoRecepientSpecified\r\n");
+        assertTrue("sending succeeded without recepient", SMTPReply.isNegativePermanent(smtpProtocol.getReplyCode()));
+
+        smtpProtocol.quit();
+
+        // mail was propagated by SMTPServer
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+    }
+
+    public void testMultipleMailsAndRset() throws Exception {
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo " + InetAddress.getLocalHost());
+
+        smtpProtocol.setSender("mail@sample.com");
+
+        smtpProtocol.reset();
+
+        smtpProtocol.setSender("mail@sample.com");
+
+        smtpProtocol.quit();
+
+        // mail was propagated by SMTPServer
+        assertNull("no mail received by mail server", m_mailServer.getLastMail());
+    }
+
+    public void testRelayingDenied() throws Exception {
+        m_testConfiguration.setAuthorizedAddresses("128.0.0.1/8");
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo " + InetAddress.getLocalHost());
+
+        smtpProtocol.setSender("mail@sample.com");
+
+        smtpProtocol.addRecipient("maila@sample.com");
+        assertEquals("expected 550 error", 550, smtpProtocol.getReplyCode());
+    }
+
+    public void testHandleAnnouncedMessageSizeLimitExceeded() throws Exception {
+        m_testConfiguration.setMaxMessageSize(1); // set message limit to 1kb
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo " + InetAddress.getLocalHost());
+
+        smtpProtocol.sendCommand("MAIL FROM:<ma...@localhost> SIZE=1025", null);
+        assertEquals("expected error: max msg size exceeded", 552, smtpProtocol.getReplyCode());
+
+        smtpProtocol.addRecipient("mail@localhost");
+        assertEquals("expected error", 503, smtpProtocol.getReplyCode());
+    }
+
+    public void testHandleMessageSizeLimitExceeded() throws Exception {
+        m_testConfiguration.setMaxMessageSize(1); // set message limit to 1kb
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo " + InetAddress.getLocalHost());
+
+        smtpProtocol.setSender("mail@localhost");
+        smtpProtocol.addRecipient("mail@localhost");
+
+        Writer wr = smtpProtocol.sendMessageData();
+        // create Body with more than 1kb . 502
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100\r\n");
+        // second line
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("123456781012345678201\r\n"); // 521 + CRLF = 523 + 502 => 1025
+        wr.close();
+
+        assertFalse(smtpProtocol.completePendingCommand());
+
+        assertEquals("expected 552 error", 552, smtpProtocol.getReplyCode());
+
+    }
+
+    public void testHandleMessageSizeLimitRespected() throws Exception {
+        m_testConfiguration.setMaxMessageSize(1); // set message limit to 1kb
+        finishSetUp(m_testConfiguration);
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo " + InetAddress.getLocalHost());
+
+        smtpProtocol.setSender("mail@localhost");
+        smtpProtocol.addRecipient("mail@localhost");
+
+        Writer wr = smtpProtocol.sendMessageData();
+        // create Body with less than 1kb
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012345678301234567840123456785012345678601234567870123456788012345678901234567100");
+        wr.write("1234567810123456782012\r\n"); // 1022 + CRLF = 1024
+        wr.close();
+
+        assertTrue(smtpProtocol.completePendingCommand());
+
+        assertEquals("expected 250 ok", 250, smtpProtocol.getReplyCode());
+
+    }
+
+    /*
+     * What we want to see is that for a given connection limit and a given
+     * backlog, that connection limit requests are handled, and that up to the
+     * backlog number of connections are queued. More connections than that
+     * should error out until space opens up in the queue.
+     * 
+     * For example:
+     * 
+     * # telnet localhost <m_smtpListenPort> Trying 127.0.0.1... telnet: Unable
+     * to connect to remote host: Connection refused
+     * 
+     * is the immediate response if the backlog is full.
+     */
+
+    /*
+     * TODO: Rewrite the test to work with ConnectionFilter
+     * 
     public void testConnectionLimitExceeded() throws Exception {
-        // Disable superclass test because this doesn't work with MINA yet.
-        // TODO try to understand and fix it.
+        final int acceptLimit = 1;
+        final int backlog = 1;
+
+        m_testConfiguration.setConnectionLimit(acceptLimit); // allow no more
+                                                             // than
+                                                             // <acceptLimit>
+                                                             // connection(s) in
+                                                             // the service
+        m_testConfiguration.setConnectionBacklog(backlog); // allow <backlog>
+                                                           // additional
+                                                           // connection(s) in
+                                                           // the queue
+        finishSetUp(m_testConfiguration);
+
+        final SMTPClient[] client = new SMTPClient[acceptLimit];
+        for (int i = 0; i < client.length; i++) {
+            client[i] = new SMTPClient(); // should connect to worker
+            try {
+                client[i].connect("127.0.0.1", m_smtpListenerPort);
+            } catch (Exception _) {
+            }
+            assertTrue("client #" + (i + 1) + " established", client[i].isConnected());
+        }
+
+        // Cannot use SMTPClient. It appears that even though the
+        // client's socket is established, since the client won't be
+        // able to connect to the protocol handler, the connect call
+        // hangs.
+
+        // Different TCP/IP stacks may provide a "grace" margin above
+        // and beyond the specified backlog. So we won't try to be
+        // precise. Instead we will compute some upper limit, loop
+        // until we get a connection error (or hit the limit), and
+        // then test for the expected behavior.
+        //
+        // See: http://www.phrack.org/archives/48/P48-13
+        final Socket connection[] = new Socket[Math.max(((backlog * 3) / 2) + 1, backlog + 3)];
+
+        final java.net.SocketAddress server = new java.net.InetSocketAddress("localhost", m_smtpListenerPort);
+
+        for (int i = 0; i < connection.length; i++) {
+            connection[i] = new Socket();
+            try {
+                connection[i].connect(server, 1000);
+            } catch (Exception _) {
+                assertTrue("Accepted connections " + i + " did not meet or exceed backlog of " + backlog + ".", i >= backlog);
+                connection[i] = null; // didn't open, so don't try to close
+                                      // later
+                break; // OK to fail, since we've at least reached the backlog
+            }
+            assertTrue("connection #" + (i + 1) + " established", connection[i].isConnected());
+        }
+
+        try {
+            final Socket shouldFail = new Socket();
+            shouldFail.connect(server, 1000);
+            fail("connection # " + (client.length + connection.length + 1) + " did not fail.");
+        } catch (Exception _) {
+        }
+
+        client[0].quit();
+        client[0].disconnect();
+
+        Thread.sleep(100);
+
+        // now should be able to connect (backlog)
+        try {
+            final Socket shouldWork = new Socket();
+            shouldWork.connect(server, 1000);
+            assertTrue("Additional connection established after close.", shouldWork.isConnected());
+            shouldWork.close();
+        } catch (Exception e) {
+            fail("Could not establish additional connection after close." + e.getMessage());
+        }
+
+        // close the pending connections first, so that the server doesn't see
+        // them
+        for (int i = 0; i < connection.length; i++)
+            if (connection[i] != null)
+                connection[i].close();
+
+        // close the remaining clients
+        for (int i = 1; i < client.length; i++) {
+            client[i].quit();
+            client[i].disconnect();
+        }
+    }
+    */
+    // Check if auth users get not rejected cause rbl. See JAMES-566
+    public void testDNSRBLNotRejectAuthUser() throws Exception {
+        m_testConfiguration.setAuthorizedAddresses("192.168.0.1/32");
+        m_testConfiguration.setAuthorizingAnnounce();
+        m_testConfiguration.useRBL(true);
+        finishSetUp(m_testConfiguration);
+
+        m_dnsServer.setLocalhostByName(InetAddress.getByName("127.0.0.1"));
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo", InetAddress.getLocalHost().toString());
+        String[] capabilityRes = smtpProtocol.getReplyStrings();
+
+        List<String> capabilitieslist = new ArrayList<String>();
+        for (int i = 1; i < capabilityRes.length; i++) {
+            capabilitieslist.add(capabilityRes[i].substring(4));
+        }
+
+        assertTrue("anouncing auth required", capabilitieslist.contains("AUTH LOGIN PLAIN"));
+        // is this required or just for compatibility? assertTrue("anouncing
+        // auth required", capabilitieslist.contains("AUTH=LOGIN PLAIN"));
+
+        String userName = "test_user_smtp";
+        String sender = "test_user_smtp@localhost";
+
+        smtpProtocol.setSender(sender);
+
+        m_usersRepository.addUser(userName, "pwd");
+
+        smtpProtocol.sendCommand("AUTH PLAIN");
+        smtpProtocol.sendCommand(Base64.encodeAsString("\0" + userName + "\0pwd\0"));
+        assertEquals("authenticated", 235, smtpProtocol.getReplyCode());
+
+        smtpProtocol.addRecipient("mail@sample.com");
+        assertEquals("authenticated.. not reject", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendShortMessageData("Subject: test\r\n\r\nTest body testDNSRBLNotRejectAuthUser\r\n");
+
+        smtpProtocol.quit();
+
+        // mail was propagated by SMTPServer
+        assertNotNull("mail received by mail server", m_mailServer.getLastMail());
     }
-   
-    	
+
+    public void testDNSRBLRejectWorks() throws Exception {
+        m_testConfiguration.setAuthorizedAddresses("192.168.0.1/32");
+        m_testConfiguration.useRBL(true);
+        finishSetUp(m_testConfiguration);
+
+        m_dnsServer.setLocalhostByName(InetAddress.getByName("127.0.0.1"));
+
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo", InetAddress.getLocalHost().toString());
+
+        String sender = "test_user_smtp@localhost";
+
+        smtpProtocol.setSender(sender);
+
+        smtpProtocol.addRecipient("mail@sample.com");
+        assertEquals("reject", 550, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendShortMessageData("Subject: test\r\n\r\nTest body testDNSRBLRejectWorks\r\n");
+
+        smtpProtocol.quit();
+
+        // mail was rejected by SMTPServer
+        assertNull("mail reject by mail server", m_mailServer.getLastMail());
+    }
+
+    public void testAddressBracketsEnforcementDisabled() throws Exception {
+        m_testConfiguration.setAddressBracketsEnforcement(false);
+        finishSetUp(m_testConfiguration);
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo", InetAddress.getLocalHost().toString());
+
+        smtpProtocol.sendCommand("mail from:", "test@localhost");
+        assertEquals("accept", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendCommand("rcpt to:", "mail@sample.com");
+        assertEquals("accept", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.quit();
+
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo", InetAddress.getLocalHost().toString());
+
+        smtpProtocol.sendCommand("mail from:", "<te...@localhost>");
+        assertEquals("accept", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendCommand("rcpt to:", "<ma...@sample.com>");
+        assertEquals("accept", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.quit();
+    }
+
+    public void testAddressBracketsEnforcementEnabled() throws Exception {
+        finishSetUp(m_testConfiguration);
+        SMTPClient smtpProtocol = new SMTPClient();
+        smtpProtocol.connect("127.0.0.1", m_smtpListenerPort);
+
+        smtpProtocol.sendCommand("ehlo", InetAddress.getLocalHost().toString());
+
+        smtpProtocol.sendCommand("mail from:", "test@localhost");
+        assertEquals("reject", 501, smtpProtocol.getReplyCode());
+        smtpProtocol.sendCommand("mail from:", "<te...@localhost>");
+        assertEquals("accept", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.sendCommand("rcpt to:", "mail@sample.com");
+        assertEquals("reject", 501, smtpProtocol.getReplyCode());
+        smtpProtocol.sendCommand("rcpt to:", "<ma...@sample.com>");
+        assertEquals("accept", 250, smtpProtocol.getReplyCode());
+
+        smtpProtocol.quit();
+    }
+
+    // See http://www.ietf.org/rfc/rfc2920.txt 4: Examples
+    public void testPipelining() throws Exception {
+        StringBuffer buf = new StringBuffer();
+        finishSetUp(m_testConfiguration);
+        Socket client = new Socket("127.0.0.1", m_smtpListenerPort);
+
+        buf.append("HELO TEST");
+        buf.append("\r\n");
+        buf.append("MAIL FROM: <te...@localhost>");
+        buf.append("\r\n");
+        buf.append("RCPT TO: <te...@localhost>");
+        buf.append("\r\n");
+        buf.append("DATA");
+        buf.append("\r\n");
+        buf.append("Subject: test");
+        buf.append("\r\n");
+        ;
+        buf.append("\r\n");
+        buf.append("content");
+        buf.append("\r\n");
+        buf.append(".");
+        buf.append("\r\n");
+        buf.append("quit");
+        buf.append("\r\n");
+
+        OutputStream out = client.getOutputStream();
+
+        out.write(buf.toString().getBytes());
+        out.flush();
+
+        BufferedReader in = new BufferedReader(new InputStreamReader(client.getInputStream()));
+
+        assertEquals("Connection made", 220, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("HELO accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("MAIL FROM accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("RCPT TO accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("DATA accepted", 354, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("Message accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        in.close();
+        out.close();
+        client.close();
+    }
+
+    // See http://www.ietf.org/rfc/rfc2920.txt 4: Examples
+    public void testRejectAllRCPTPipelining() throws Exception {
+        StringBuffer buf = new StringBuffer();
+        m_testConfiguration.setAuthorizedAddresses("");
+        finishSetUp(m_testConfiguration);
+        Socket client = new Socket("127.0.0.1", m_smtpListenerPort);
+
+        buf.append("HELO TEST");
+        buf.append("\r\n");
+        buf.append("MAIL FROM: <te...@localhost>");
+        buf.append("\r\n");
+        buf.append("RCPT TO: <te...@invalid>");
+        buf.append("\r\n");
+        buf.append("RCPT TO: <te...@invalid>");
+        buf.append("\r\n");
+        buf.append("DATA");
+        buf.append("\r\n");
+        buf.append("Subject: test");
+        buf.append("\r\n");
+        ;
+        buf.append("\r\n");
+        buf.append("content");
+        buf.append("\r\n");
+        buf.append(".");
+        buf.append("\r\n");
+        buf.append("quit");
+        buf.append("\r\n");
+
+        OutputStream out = client.getOutputStream();
+
+        out.write(buf.toString().getBytes());
+        out.flush();
+
+        BufferedReader in = new BufferedReader(new InputStreamReader(client.getInputStream()));
+
+        assertEquals("Connection made", 220, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("HELO accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("MAIL FROM accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("RCPT TO rejected", 550, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("RCPT TO rejected", 550, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("DATA not accepted", 503, Integer.parseInt(in.readLine().split(" ")[0]));
+        in.close();
+        out.close();
+        client.close();
+    }
+
+    public void testRejectOneRCPTPipelining() throws Exception {
+        StringBuffer buf = new StringBuffer();
+        m_testConfiguration.setAuthorizedAddresses("");
+        finishSetUp(m_testConfiguration);
+        Socket client = new Socket("127.0.0.1", m_smtpListenerPort);
+
+        buf.append("HELO TEST");
+        buf.append("\r\n");
+        buf.append("MAIL FROM: <te...@localhost>");
+        buf.append("\r\n");
+        buf.append("RCPT TO: <te...@invalid>");
+        buf.append("\r\n");
+        buf.append("RCPT TO: <te...@localhost>");
+        buf.append("\r\n");
+        buf.append("DATA");
+        buf.append("\r\n");
+        buf.append("Subject: test");
+        buf.append("\r\n");
+        ;
+        buf.append("\r\n");
+        buf.append("content");
+        buf.append("\r\n");
+        buf.append(".");
+        buf.append("\r\n");
+        buf.append("quit");
+        buf.append("\r\n");
+
+        OutputStream out = client.getOutputStream();
+
+        out.write(buf.toString().getBytes());
+        out.flush();
+
+        BufferedReader in = new BufferedReader(new InputStreamReader(client.getInputStream()));
+
+        assertEquals("Connection made", 220, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("HELO accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("MAIL FROM accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("RCPT TO rejected", 550, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("RCPT accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("DATA accepted", 354, Integer.parseInt(in.readLine().split(" ")[0]));
+        assertEquals("Message accepted", 250, Integer.parseInt(in.readLine().split(" ")[0]));
+        in.close();
+        out.close();
+        client.close();
+    }
+
 }

Modified: james/server/trunk/spring-deployment/src/main/config/james/spring-beans.xml
URL: http://svn.apache.org/viewvc/james/server/trunk/spring-deployment/src/main/config/james/spring-beans.xml?rev=902049&r1=902048&r2=902049&view=diff
==============================================================================
--- james/server/trunk/spring-deployment/src/main/config/james/spring-beans.xml (original)
+++ james/server/trunk/spring-deployment/src/main/config/james/spring-beans.xml Fri Jan 22 10:29:27 2010
@@ -89,17 +89,9 @@
 		<property name="order" value="1" />
 		<property name="mappings">
 			<map>
-				<entry key="pop3server.protocolserver" value="pop3server" />
-				<entry key="pop3server.protocolhandlerfactory" value="pop3server" />
-				<entry key="smtpserver.protocolserver" value="smtpserver" />
-				<entry key="smtpserver.protocolhandlerfactory" value="smtpserver" />
 				<entry key="nntpserver.protocolserver" value="nntpserver" />
 				<entry key="nntpserver.protocolhandlerfactory" value="nntpserver" />
-				<entry key="imapserver.protocolserver" value="imapserver" />
-				<entry key="imapserver.protocolhandlerfactory" value="imapserver" />
 				<entry key="mailboxmanager" value="imapserver" />				
-				<entry key="remotemanager.protocolserver" value="remotemanager" />
-				<entry key="remotemanager.protocolhandlerfactory" value="remotemanager" />
 			</map>
 		</property>
 	</bean>
@@ -115,16 +107,8 @@
 		<property name="order" value="0" />
 		<property name="mappings">
 			<map>
-				<entry key="pop3server.protocolserver" value="pop3server" />
-				<entry key="pop3server.protocolhandlerfactory" value="pop3server" />
-				<entry key="smtpserver.protocolserver" value="smtpserver" />
-				<entry key="smtpserver.protocolhandlerfactory" value="smtpserver" />
 				<entry key="nntpserver.protocolserver" value="nntpserver" />
 				<entry key="nntpserver.protocolhandlerfactory" value="nntpserver" />
-				<entry key="imapserver.protocolserver" value="imapserver" />
-				<entry key="imapserver.protocolhandlerfactory" value="imapserver" />
-				<entry key="remotemanager.protocolserver" value="remotemanager" />
-				<entry key="remotemanager.protocolhandlerfactory" value="remotemanager" />
 			</map>
 		</property>
 	</bean>
@@ -169,62 +153,19 @@
 	<bean id="bayesiananalyzermanagement"
 		class="org.apache.james.management.impl.BayesianAnalyzerManagement" />
 
-	<!-- RemoteManager Beans-->
-	<bean id="remotemanager.protocolhandlerfactory"
-		class="org.apache.james.remotemanager.RemoteManagerProtocolHandlerFactory" />
-
-	<bean id="remotemanager.protocolserver" class="org.apache.james.socket.AvalonProtocolServer">
-		<property name="protocolHandlerFactory" ref="remotemanager.protocolhandlerfactory" />
-	</bean>
-
-	<bean id="remotemanager" class="org.apache.james.remotemanager.RemoteManagerMBeanImpl">
-		<property name="protocolServer" ref="remotemanager.protocolserver" />
-	</bean>
-
 	<!-- Async RemoteManager -->
-	<!-- enable this to use the MINA based RemoteManager Server which uses NIO -->
-	<!--
 	<bean id="remotemanager" class="org.apache.james.remotemanager.mina.AsyncRemoteManager" />
-	-->
 	
 	<!-- The User Management block  -->
 	<bean id="usermanagement" class="org.apache.james.impl.user.UserManagement" />
 
-	<!-- POP3 Server Beans-->
-	<bean id="pop3server.protocolhandlerfactory"
-		class="org.apache.james.pop3server.POP3ServerProtocolServerHandlerFactory" />
-
-	<bean id="pop3server.protocolserver" class="org.apache.james.socket.AvalonProtocolServer">
-		<property name="protocolHandlerFactory" ref="pop3server.protocolhandlerfactory" />
-	</bean>
-
-	<bean id="pop3server" class="org.apache.james.pop3server.POP3ServerMBeanImpl">
-		<property name="protocolServer" ref="pop3server.protocolserver" />
-	</bean>
 	
 	<!-- Async POP3 Server -->
-	<!-- enable this to use the MINA based POP3 Server which uses NIO -->
-	<!--
     <bean id="pop3server"  class="org.apache.james.pop3server.mina.AsyncPOP3Server" />
-	-->
 	
 	
-	<!-- SMTP Server Beans-->
-	<bean id="smtpserver.protocolhandlerfactory" class="org.apache.james.smtpserver.SMTPServerProtocolHandlerFactory" />
-
-	<bean id="smtpserver.protocolserver" class="org.apache.james.socket.AvalonProtocolServer">
-		<property name="protocolHandlerFactory" ref="smtpserver.protocolhandlerfactory" />
-	</bean>
-	
-	<bean id="smtpserver" class="org.apache.james.smtpserver.SMTPServerMBeanImpl">
-		<property name="protocolServer" ref="smtpserver.protocolserver" />
-	</bean>
-
 	<!-- Async SMTP Server -->
-	<!-- enable this to use the MINA based SMTP Server which uses NIO -->
-	<!--
 	<bean id="smtpserver" class="org.apache.james.smtpserver.mina.AsyncSMTPServer" />
-	-->
 
 	<bean id="org.apache.james.smtpserver.protocol.DNSService" class="org.apache.james.smtpserver.integration.SMTPServerDNSServiceAdapter" />
 
@@ -305,23 +246,13 @@
 	<!--
 	<bean id="domainlist" class="org.apache.james.vut.XMLVirtualUserTable"/>
 	-->
-	<!--  
-    <bean id="imapserver" name="org.apache.jsieve.mailet.Poster" class="org.apache.james.imapserver.mina.AsyncImapServer">
-		<property name="imapDecoder" ref="imapDecoder"/>
-		<property name="imapEncoder" ref="imapEncoder"/>	
-	</bean>
-	-->
 
 	<!-- IMAP server Beans -->
-	<bean id="imapserver.protocolhandlerfactory" name="org.apache.jsieve.mailet.Poster" class="org.apache.james.imapserver.ImapServerProtocolHandlerFactory">
+    <bean id="imapserver" name="org.apache.jsieve.mailet.Poster" class="org.apache.james.imapserver.mina.AsyncImapServer">
 		<property name="imapDecoder" ref="imapDecoder"/>
 		<property name="imapEncoder" ref="imapEncoder"/>	
 	</bean>
 
-	<bean id="imapserver.protocolserver" class="org.apache.james.socket.AvalonProtocolServer">
-		<property name="protocolHandlerFactory" ref="imapserver.protocolhandlerfactory" />
-	</bean>
-		
 	<bean id="imapProcessor" class="org.apache.james.imap.processor.main.DefaultImapProcessorFactory" factory-method="createDefaultProcessor">
       	<constructor-arg ref="mailboxmanager"/>
     </bean>



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