You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ai...@apache.org on 2008/10/15 16:50:27 UTC

svn commit: r704932 - /incubator/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/ResetMessageListenerTest.java

Author: aidan
Date: Wed Oct 15 07:50:27 2008
New Revision: 704932

URL: http://svn.apache.org/viewvc?rev=704932&view=rev
Log:
QPID-1320: Yank out random, badly written 08 test. Use correct one instead.

Modified:
    incubator/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/ResetMessageListenerTest.java

Modified: incubator/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/ResetMessageListenerTest.java
URL: http://svn.apache.org/viewvc/incubator/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/ResetMessageListenerTest.java?rev=704932&r1=704931&r2=704932&view=diff
==============================================================================
--- incubator/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/ResetMessageListenerTest.java (original)
+++ incubator/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/ResetMessageListenerTest.java Wed Oct 15 07:50:27 2008
@@ -55,19 +55,14 @@
     Context _context;
 
     private static final int MSG_COUNT = 6;
-    private int receivedCount1ML1 = 0;
-    private int receivedCount1ML2 = 0;
-    private int receivedCount2 = 0;
+    private int receivedCount = 0;
     private Connection _clientConnection, _producerConnection;
     private MessageConsumer _consumer1;
-    private MessageConsumer _consumer2;
     MessageProducer _producer;
     Session _clientSession, _producerSession;
 
     private final CountDownLatch _allFirstMessagesSent = new CountDownLatch(2); // all messages Sent Lock
     private final CountDownLatch _allSecondMessagesSent = new CountDownLatch(2); // all messages Sent Lock
-    private final CountDownLatch _allFirstMessagesSent010 = new CountDownLatch(MSG_COUNT); // all messages Sent Lock
-	private final CountDownLatch _allSecondMessagesSent010 = new CountDownLatch(MSG_COUNT); // all messages Sent Lock
     
     private String oldImmediatePrefetch;
 
@@ -88,9 +83,6 @@
 
         _consumer1 = _clientSession.createConsumer(queue);
 
-        // Create Client 2 on same session
-        _consumer2 = _clientSession.createConsumer(queue);
-
         // Create Producer
         _producerConnection = getConnection("guest", "guest");
 
@@ -107,7 +99,6 @@
             m.setText("Message " + msg);
             _producer.send(m);
         }
-
     }
 
     protected void tearDown() throws Exception
@@ -126,257 +117,121 @@
     {
 
         _logger.info("Test Start");
-        if (isBroker08())
+
+        try
         {
-            // Set default Message Listener
-            try
+            _consumer1.setMessageListener(new MessageListener()
             {
-                _consumer1.setMessageListener(new MessageListener()
+                public void onMessage(Message message)
                 {
-                    public void onMessage(Message message)
-                    {
-                        _logger.info("Client 1 ML 1 Received Message(" + receivedCount1ML1 + "):" + message);
+                    _logger.info("Received Message(" + receivedCount + "):" + message);
 
-                        receivedCount1ML1++;
-                        if (receivedCount1ML1 == (MSG_COUNT / 2))
-                        {
-                            _allFirstMessagesSent.countDown();
-                        }
-                    }
-                });
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Error Setting Default ML on consumer1");
-            }
-
-            try
-            {
-                _consumer2.setMessageListener(new MessageListener()
-                {
-                    public void onMessage(Message message)
+                    try
                     {
-                        _logger.info("Client 2 Received Message(" + receivedCount2 + "):" + message);
-
-                        receivedCount2++;
-                        if (receivedCount2 == (MSG_COUNT / 2))
+                        if (message.getStringProperty("rank").equals("first"))
                         {
-                            _logger.info("Client 2 received all its messages1");
                             _allFirstMessagesSent.countDown();
                         }
-
-                        if (receivedCount2 == MSG_COUNT)
-                        {
-                            _logger.info("Client 2 received all its messages2");
-                            _allSecondMessagesSent.countDown();
-                        }
                     }
-                });
-
-                _clientConnection.start();
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Error Setting Default ML on consumer2");
-
-            }
-
-            try
-            {
-                _allFirstMessagesSent.await(1000, TimeUnit.MILLISECONDS);
-                _logger.info("Received first batch of messages");
-            }
-            catch (InterruptedException e)
-            {
-                // do nothing
-            }
-
-            try
-            {
-                _clientConnection.stop();
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Error stopping connection");
-            }
-
-            _logger.info("Reset Message Listener to better listener while connection stopped, will restart session");
-            try
-            {
-                _consumer1.setMessageListener(new MessageListener()
-                {
-                    public void onMessage(Message message)
+                    catch (JMSException e)
                     {
-                        _logger.info("Client 1 ML2 Received Message(" + receivedCount1ML1 + "):" + message);
-
-                        receivedCount1ML2++;
-                        if (receivedCount1ML2 == (MSG_COUNT / 2))
-                        {
-                            _allSecondMessagesSent.countDown();
-                        }
+                        e.printStackTrace();
+                        fail("error receiving message");
                     }
-                });
-
-                _clientConnection.start();
-            }
-            catch (javax.jms.IllegalStateException e)
-            {
-                _logger.error("Connection not stopped while setting ML", e);
-                fail("Unable to change message listener:" + e.getCause());
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Error Setting Better ML on consumer1", e);
-            }
-
-            try
-            {
-                _logger.info("Send additional messages");
-
-                for (int msg = 0; msg < MSG_COUNT; msg++)
-                {
-                    _producer.send(_producerSession.createTextMessage("Message " + msg));
                 }
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Unable to send additional messages", e);
-            }
-
-            _logger.info("Waiting upto 2 seconds for messages");
+            });
+        }
+        catch (JMSException e)
+        {
+            _logger.error("Error Setting Default ML on consumer1");
+        }
+        try
+        {
+            _allFirstMessagesSent.await(1000, TimeUnit.MILLISECONDS);
+            _logger.info("Received first batch of messages");
+        }
+        catch (InterruptedException e)
+        {
+            // do nothing
+        }
 
-            try
-            {
-            _allSecondMessagesSent.await(5000, TimeUnit.MILLISECONDS);
-            }
-            catch (InterruptedException e)
-            {
-                // do nothing
-            }
-            assertEquals("First batch of messages not received correctly", 0, _allFirstMessagesSent.getCount());
-            assertEquals("Second batch of messages not received correctly", 0, _allSecondMessagesSent.getCount());
-            assertEquals("Client 1 ML1 didn't get all messages", MSG_COUNT / 2, receivedCount1ML1);
-            assertEquals("Client 2 didn't get all messages", MSG_COUNT, receivedCount2);
-            assertEquals("Client 1 ML2 didn't get all messages", MSG_COUNT / 2, receivedCount1ML2);
+        try
+        {
+            _clientConnection.stop();
         }
-        else
+        catch (JMSException e)
         {
-            try
+            _logger.error("Error stopping connection");
+        }
+
+        _logger.info("Reset Message Listener ");
+        try
+        {
+            _consumer1.setMessageListener(new MessageListener()
             {
-                 _consumer2.close();
-                _consumer1.setMessageListener(new MessageListener()
+                public void onMessage(Message message)
                 {
-                    public void onMessage(Message message)
-                    {
-                        _logger.info("Received Message(" + receivedCount1ML1 + "):" + message);
+                    _logger.info("Received Message(" + receivedCount + "):" + message);
 
-                        try
+                    try
+                    {
+                        if (message.getStringProperty("rank").equals("first"))
                         {
-                            if (message.getStringProperty("rank").equals("first"))
-                            {
-                                _allFirstMessagesSent010.countDown();
-                            }
+                            _allFirstMessagesSent.countDown();
                         }
-                        catch (JMSException e)
+                        else
                         {
-                            e.printStackTrace();
-                            fail("error receiving message");
+                            _allSecondMessagesSent.countDown();
                         }
                     }
-                });
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Error Setting Default ML on consumer1");
-            }
-            try
-            {
-                _allFirstMessagesSent.await(1000, TimeUnit.MILLISECONDS);
-                _logger.info("Received first batch of messages");
-            }
-            catch (InterruptedException e)
-            {
-                // do nothing
-            }
-
-            try
-            {
-                _clientConnection.stop();
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Error stopping connection");
-            }
-
-            _logger.info("Reset Message Listener ");
-            try
-            {
-                _consumer1.setMessageListener(new MessageListener()
-                {
-                    public void onMessage(Message message)
+                    catch (JMSException e)
                     {
-                        _logger.info("Received Message(" + receivedCount1ML1 + "):" + message);
-
-                        try
-                        {
-                            if (message.getStringProperty("rank").equals("first"))
-                            {
-                                _allFirstMessagesSent010.countDown();
-                            }
-                            else
-                            {
-                                _allSecondMessagesSent010.countDown();
-                            }
-                        }
-                        catch (JMSException e)
-                        {
-                            e.printStackTrace();
-                            fail("error receiving message");
-                        }
+                        e.printStackTrace();
+                        fail("error receiving message");
                     }
-                });
+                }
+            });
 
-                _clientConnection.start();
-            }
-            catch (javax.jms.IllegalStateException e)
-            {
-                _logger.error("Connection not stopped while setting ML", e);
-                fail("Unable to change message listener:" + e.getCause());
-            }
-            catch (JMSException e)
-            {
-                _logger.error("Error Setting Better ML on consumer1", e);
-            }
+            _clientConnection.start();
+        }
+        catch (javax.jms.IllegalStateException e)
+        {
+            _logger.error("Connection not stopped while setting ML", e);
+            fail("Unable to change message listener:" + e.getCause());
+        }
+        catch (JMSException e)
+        {
+            _logger.error("Error Setting Better ML on consumer1", e);
+        }
 
-            try
-            {
-                _logger.info("Send additional messages");
-                TextMessage m = _producerSession.createTextMessage();
-                m.setStringProperty("rank", "second");
-                for (int msg = 0; msg < MSG_COUNT; msg++)
-                {
-                    m.setText("Message " + msg);
-                    _producer.send(m);
-                }
-            }
-            catch (JMSException e)
+        try
+        {
+            _logger.info("Send additional messages");
+            TextMessage m = _producerSession.createTextMessage();
+            m.setStringProperty("rank", "second");
+            for (int msg = 0; msg < MSG_COUNT; msg++)
             {
-                _logger.error("Unable to send additional messages", e);
+                m.setText("Message " + msg);
+                _producer.send(m);
             }
+        }
+        catch (JMSException e)
+        {
+            _logger.error("Unable to send additional messages", e);
+        }
 
-            _logger.info("Waiting upto 2 seconds for messages");
+        _logger.info("Waiting upto 2 seconds for messages");
 
-            try
-            {
-                _allSecondMessagesSent.await(1000, TimeUnit.MILLISECONDS);
-            }
-            catch (InterruptedException e)
-            {
-                // do nothing
-            }
-            assertEquals("First batch of messages not received correctly", 0, _allFirstMessagesSent010.getCount());
-            assertEquals("Second batch of messages not received correctly", 0, _allSecondMessagesSent010.getCount());                  
+        try
+        {
+            _allSecondMessagesSent.await(1000, TimeUnit.MILLISECONDS);
+        }
+        catch (InterruptedException e)
+        {
+            // do nothing
         }
+        assertEquals("First batch of messages not received correctly", 0, _allFirstMessagesSent.getCount());
+        assertEquals("Second batch of messages not received correctly", 0, _allSecondMessagesSent.getCount());                  
     }
 
     public static junit.framework.Test suite()