You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by kw...@apache.org on 2012/03/11 20:01:16 UTC

svn commit: r1299425 - in /qpid/trunk/qpid/java: systests/src/main/java/org/apache/qpid/client/ systests/src/main/java/org/apache/qpid/test/unit/basic/ test-profiles/

Author: kwall
Date: Sun Mar 11 19:01:15 2012
New Revision: 1299425

URL: http://svn.apache.org/viewvc?rev=1299425&view=rev
Log:
QPID-3894: MessageListener test improvments

Added:
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/AsynchMessageListenerTest.java
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SynchReceiveTest.java
Removed:
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/DispatcherTest.java
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/MessageListenerMultiConsumerImmediatePrefetch.java
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/MessageListenerMultiConsumerTest.java
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/MessageListenerTest.java
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/ResetMessageListenerTest.java
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/unit/basic/ReceiveTest.java
Modified:
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SessionCreateTest.java
    qpid/trunk/qpid/java/test-profiles/CPPExcludes
    qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes
    qpid/trunk/qpid/java/test-profiles/Java010Excludes
    qpid/trunk/qpid/java/test-profiles/JavaPre010Excludes

Added: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/AsynchMessageListenerTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/AsynchMessageListenerTest.java?rev=1299425&view=auto
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/AsynchMessageListenerTest.java (added)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/AsynchMessageListenerTest.java Sun Mar 11 19:01:15 2012
@@ -0,0 +1,362 @@
+/*
+ *  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.qpid.client;
+
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicInteger;
+
+import javax.jms.Connection;
+import javax.jms.ExceptionListener;
+import javax.jms.JMSException;
+import javax.jms.Message;
+import javax.jms.MessageConsumer;
+import javax.jms.MessageListener;
+import javax.jms.Queue;
+import javax.jms.Session;
+
+import org.apache.qpid.test.utils.QpidBrokerTestCase;
+import org.apache.qpid.util.LogMonitor;
+
+/**
+ * Tests the behaviour of JMS asynchronous message listeners as provided by
+ * {@link MessageListener#onMessage(Message)}.
+ *
+ */
+public class AsynchMessageListenerTest extends QpidBrokerTestCase
+{
+    private static final int MSG_COUNT = 10;
+    private static final long AWAIT_MESSAGE_TIMEOUT = 2000;
+    private static final long AWAIT_MESSAGE_TIMEOUT_NEGATIVE = 250;
+    private final String _testQueueName = getTestQueueName();
+    private Connection _consumerConnection;
+    private Session _consumerSession;
+    private MessageConsumer _consumer;
+    private Queue _queue;
+
+    protected void setUp() throws Exception
+    {
+        super.setUp();
+
+        _consumerConnection = getConnection();
+        _consumerConnection.start();
+        _consumerSession = _consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        _queue = _consumerSession.createQueue(_testQueueName);
+        _consumer = _consumerSession.createConsumer(_queue);
+
+        // Populate queue
+        Connection producerConnection = getConnection();
+        Session producerSession = producerConnection.createSession(true, Session.SESSION_TRANSACTED);
+        sendMessage(producerSession, _queue, MSG_COUNT);
+        producerConnection.close();
+
+    }
+
+    public void testMessageListener() throws Exception
+    {
+        CountingMessageListener countingMessageListener = new CountingMessageListener(MSG_COUNT);
+        _consumer.setMessageListener(countingMessageListener);
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        assertEquals("Unexpected number of outstanding messages", 0, countingMessageListener.getOutstandingCount());
+    }
+
+    public void testSynchronousReceiveFollowedByMessageListener() throws Exception
+    {
+        // Receive initial message synchronously
+        assertNotNull("Could not receive first message synchronously", _consumer.receive(AWAIT_MESSAGE_TIMEOUT) != null);
+        final int numberOfMessagesToReceiveByMessageListener = MSG_COUNT - 1;
+
+        // Consume remainder asynchronously
+        CountingMessageListener countingMessageListener = new CountingMessageListener(numberOfMessagesToReceiveByMessageListener);
+        _consumer.setMessageListener(countingMessageListener);
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        assertEquals("Unexpected number of outstanding messages", 0, countingMessageListener.getOutstandingCount());
+    }
+
+    public void testMessageListenerSetDisallowsSynchronousReceive() throws Exception
+    {
+        CountingMessageListener countingMessageListener = new CountingMessageListener(MSG_COUNT);
+        _consumer.setMessageListener(countingMessageListener);
+
+        try
+        {
+            _consumer.receive();
+            fail("Exception not thrown");
+        }
+        catch (JMSException e)
+        {
+            // PASS
+            assertEquals("A listener has already been set.", e.getMessage());
+        }
+    }
+
+
+    public void testConnectionStopThenStart() throws Exception
+    {
+        int messageToReceivedBeforeConnectionStop = 2;
+        CountingMessageListener countingMessageListener = new CountingMessageListener(MSG_COUNT, messageToReceivedBeforeConnectionStop);
+
+        // Consume at least two messages
+        _consumer.setMessageListener(countingMessageListener);
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        _consumerConnection.stop();
+
+        assertTrue("Too few messages received afer Connection#stop()", countingMessageListener.getReceivedCount() >= messageToReceivedBeforeConnectionStop);
+        countingMessageListener.resetLatch();
+
+        // Restart connection
+        _consumerConnection.start();
+
+        // Consume the remainder
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        assertEquals("Unexpected number of outstanding messages", 0, countingMessageListener.getOutstandingCount());
+    }
+
+    public void testConnectionStopAndMessageListenerChange() throws Exception
+    {
+        int messageToReceivedBeforeConnectionStop = 2;
+        CountingMessageListener countingMessageListener1 = new CountingMessageListener(MSG_COUNT, messageToReceivedBeforeConnectionStop);
+
+        // Consume remainder asynchronously
+        _consumer.setMessageListener(countingMessageListener1);
+        countingMessageListener1.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        _consumerConnection.stop();
+        assertTrue("Too few messages received afer Connection#stop()", countingMessageListener1.getReceivedCount() >= messageToReceivedBeforeConnectionStop);
+
+        CountingMessageListener countingMessageListener2 = new CountingMessageListener(countingMessageListener1.getOutstandingCount());
+
+        // Reset Message Listener
+        _consumer.setMessageListener(countingMessageListener2);
+
+        _consumerConnection.start();
+
+        // Consume the remainder
+        countingMessageListener2.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        assertEquals("Unexpected number of outstanding messages", 0, countingMessageListener2.getOutstandingCount());
+
+    }
+
+    public void testConnectionStopHaltsDeliveryToListener() throws Exception
+    {
+        int messageToReceivedBeforeConnectionStop = 2;
+        CountingMessageListener countingMessageListener = new CountingMessageListener(MSG_COUNT, messageToReceivedBeforeConnectionStop);
+
+        // Consume at least two messages
+        _consumer.setMessageListener(countingMessageListener);
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        _consumerConnection.stop();
+
+        // Connection should now be stopped and listener should receive no more
+        final int outstandingCountAtStop = countingMessageListener.getOutstandingCount();
+        countingMessageListener.resetLatch();
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT_NEGATIVE);
+
+        assertEquals("Unexpected number of outstanding messages", outstandingCountAtStop, countingMessageListener.getOutstandingCount());
+    }
+
+    public void testSessionCloseHaltsDelivery() throws Exception
+    {
+        int messageToReceivedBeforeConnectionStop = 2;
+        CountingMessageListener countingMessageListener = new CountingMessageListener(MSG_COUNT, messageToReceivedBeforeConnectionStop);
+
+        // Consume at least two messages
+        _consumer.setMessageListener(countingMessageListener);
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        _consumerSession.close();
+
+        // Once a session is closed, the listener should receive no more
+        final int outstandingCountAtClose = countingMessageListener.getOutstandingCount();
+        countingMessageListener.resetLatch();
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT_NEGATIVE);
+
+        assertEquals("Unexpected number of outstanding messages", outstandingCountAtClose, countingMessageListener.getOutstandingCount());
+    }
+
+    public void testImmediatePrefetchWithMessageListener() throws Exception
+    {
+        // Close connection provided by setup so we can set IMMEDIATE_PREFETCH
+        _consumerConnection.close();
+        setTestClientSystemProperty(AMQSession.IMMEDIATE_PREFETCH, "true");
+
+        _consumerConnection = getConnection();
+        _consumerConnection.start();
+        _consumerSession = _consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        _consumer = _consumerSession.createConsumer(_queue);
+        CountingMessageListener countingMessageListener = new CountingMessageListener(MSG_COUNT);
+        _consumer.setMessageListener(countingMessageListener);
+
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+
+        assertEquals("Unexpected number of messages received", MSG_COUNT, countingMessageListener.getReceivedCount());
+    }
+
+    public void testReceiveTwoConsumers() throws Exception
+    {
+        Session consumerSession2 = _consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        MessageConsumer _consumer2 = consumerSession2.createConsumer(_queue);
+
+        CountingMessageListener countingMessageListener = new CountingMessageListener(MSG_COUNT);
+        _consumer.setMessageListener(countingMessageListener);
+        _consumer2.setMessageListener(countingMessageListener);
+
+        countingMessageListener.awaitMessages(AWAIT_MESSAGE_TIMEOUT);
+        assertEquals("Unexpected number of messages received", MSG_COUNT, countingMessageListener.getReceivedCount());
+    }
+
+    /**
+     * Tests the case where the message listener throws an java.lang.Error.
+     * TODO - a useful test?.
+     */
+    public void testMessageListenerThrowsError() throws Exception
+    {
+        int expectedMessages = 1;  // The error will kill the dispatcher so only one message will be delivered.
+        final CountDownLatch awaitMessages = new CountDownLatch(expectedMessages);
+        final AtomicInteger receivedCount = new AtomicInteger(0);
+        final String javaLangErrorMessageText = "MessageListener failed with java.lang.Error";
+        CountingExceptionListener countingExceptionListener = new CountingExceptionListener();
+        _consumerConnection.setExceptionListener(countingExceptionListener);
+
+        _consumer.setMessageListener(new MessageListener()
+        {
+            @Override
+            public void onMessage(Message message)
+            {
+                try
+                {
+                    throw new Error(javaLangErrorMessageText);
+                }
+                finally
+                {
+                    receivedCount.incrementAndGet();
+                    awaitMessages.countDown();
+                }
+            }
+        });
+
+        awaitMessages.await(AWAIT_MESSAGE_TIMEOUT, TimeUnit.MILLISECONDS);
+
+        assertEquals("Unexpected number of messages received", expectedMessages, receivedCount.get());
+        assertEquals("onException should NOT have been called", 0, countingExceptionListener.getErrorCount());
+
+        // Check that Error has been written to the application log.
+
+        LogMonitor _monitor = new LogMonitor(_outputFile);
+        assertTrue("The expected message not written to log file.",
+                _monitor.waitForMessage(javaLangErrorMessageText, LOGMONITOR_TIMEOUT));
+
+        if (_consumerConnection != null)
+        {
+            try
+            {
+                _consumerConnection.close();
+            }
+            catch (JMSException e)
+            {
+                // Ignore connection close errors for this test.
+            }
+            finally
+            {
+                _consumerConnection = null;
+            }
+        }
+    }
+
+    private final class CountingExceptionListener implements ExceptionListener
+    {
+        private final AtomicInteger _errorCount = new AtomicInteger();
+
+        @Override
+        public void onException(JMSException arg0)
+        {
+            _errorCount.incrementAndGet();
+        }
+
+        public int getErrorCount()
+        {
+            return _errorCount.intValue();
+        }
+    }
+
+    private final class CountingMessageListener implements MessageListener
+    {
+        private volatile CountDownLatch _awaitMessages;
+        private final AtomicInteger _receivedCount;
+        private final AtomicInteger _outstandingMessageCount;
+
+        public CountingMessageListener(final int totalExpectedMessageCount)
+        {
+            this(totalExpectedMessageCount, totalExpectedMessageCount);
+        }
+
+
+        public CountingMessageListener(int totalExpectedMessageCount, int numberOfMessagesToAwait)
+        {
+            _receivedCount = new AtomicInteger(0);
+            _outstandingMessageCount = new AtomicInteger(totalExpectedMessageCount);
+            _awaitMessages = new CountDownLatch(numberOfMessagesToAwait);
+        }
+
+        public int getOutstandingCount()
+        {
+            return _outstandingMessageCount.get();
+        }
+
+        public int getReceivedCount()
+        {
+            return _receivedCount.get();
+        }
+
+        public void resetLatch()
+        {
+            _awaitMessages = new CountDownLatch(_outstandingMessageCount.get());
+        }
+
+        @Override
+        public void onMessage(Message message)
+        {
+            _receivedCount.incrementAndGet();
+            _outstandingMessageCount.decrementAndGet();
+            _awaitMessages.countDown();
+        }
+
+        public boolean awaitMessages(long timeout)
+        {
+            try
+            {
+                return _awaitMessages.await(timeout, TimeUnit.MILLISECONDS);
+            }
+            catch (InterruptedException e)
+            {
+                Thread.currentThread().interrupt();
+                return false;
+            }
+        }
+    }
+
+}

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SessionCreateTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SessionCreateTest.java?rev=1299425&r1=1299424&r2=1299425&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SessionCreateTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SessionCreateTest.java Sun Mar 11 19:01:15 2012
@@ -27,7 +27,6 @@ import org.apache.qpid.test.utils.QpidBr
 
 import javax.jms.Connection;
 import javax.jms.Session;
-import javax.naming.Context;
 
 
 /**
@@ -35,9 +34,7 @@ import javax.naming.Context;
  */
 public class SessionCreateTest extends QpidBrokerTestCase
 {
-    private static final Logger _logger = LoggerFactory.getLogger(MessageListenerTest.class);
-
-    private Context _context;
+    private static final Logger LOGGER = LoggerFactory.getLogger(SessionCreateTest.class);
 
     private Connection _clientConnection;
     protected int maxSessions = 65555;
@@ -54,7 +51,7 @@ public class SessionCreateTest extends Q
             Session sess = _clientConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
             assertNotNull(sess);
             sess.close();
-            System.out.println("created session: " + i); 
+            LOGGER.debug("created session: " + i);
         }
 
         _clientConnection.close();

Added: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SynchReceiveTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SynchReceiveTest.java?rev=1299425&view=auto
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SynchReceiveTest.java (added)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/client/SynchReceiveTest.java Sun Mar 11 19:01:15 2012
@@ -0,0 +1,133 @@
+/*
+ *  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.qpid.client;
+
+import javax.jms.Connection;
+import javax.jms.MessageConsumer;
+import javax.jms.Queue;
+import javax.jms.Session;
+
+import org.apache.qpid.configuration.ClientProperties;
+import org.apache.qpid.test.utils.QpidBrokerTestCase;
+
+public class SynchReceiveTest extends QpidBrokerTestCase
+{
+    private static final long AWAIT_MESSAGE_TIMEOUT = 2000;
+    private static final long AWAIT_MESSAGE_TIMEOUT_NEGATIVE = 250;
+    private static final int MSG_COUNT = 10;
+    private final String _testQueueName = getTestQueueName();
+    private Connection _consumerConnection;
+    private Session _consumerSession;
+    private MessageConsumer _consumer;
+    private Queue _queue;
+
+    protected void setUp() throws Exception
+    {
+        super.setUp();
+
+        _consumerConnection = getConnection();
+        _consumerConnection.start();
+        _consumerSession = _consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        _queue = _consumerSession.createQueue(_testQueueName);
+        _consumer = _consumerSession.createConsumer(_queue);
+
+        // Populate queue
+        Connection producerConnection = getConnection();
+        Session producerSession = producerConnection.createSession(true, Session.SESSION_TRANSACTED);
+        sendMessage(producerSession, _queue, MSG_COUNT);
+        producerConnection.close();
+    }
+
+    public void testReceiveWithTimeout() throws Exception
+    {
+        for (int msg = 0; msg < MSG_COUNT; msg++)
+        {
+            assertNotNull("Expected message number " + msg, _consumer.receive(AWAIT_MESSAGE_TIMEOUT));
+        }
+
+        assertNull("Received too many messages", _consumer.receive(500));
+    }
+
+    public void testReceiveNoWait() throws Exception
+    {
+        for (int msg = 0; msg < MSG_COUNT; msg++)
+        {
+            assertNotNull("Expected message number " + msg, _consumer.receiveNoWait());
+        }
+
+        assertNull("Received too many messages", _consumer.receive(500));
+    }
+
+    public void testTwoConsumersInterleaved() throws Exception
+    {
+        //create a new connection with prefetch set to 1
+        _consumerConnection.close();
+        setTestClientSystemProperty(ClientProperties.MAX_PREFETCH_PROP_NAME, new Integer(1).toString());
+
+        _consumerConnection = getConnection();
+        _consumerConnection.start();
+        Session consumerSession1 = _consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        MessageConsumer consumer1 = consumerSession1.createConsumer(_queue);
+
+        Session consumerSession2 = _consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        MessageConsumer consumer2 = consumerSession2.createConsumer(_queue);
+
+        final int maxLoops = MSG_COUNT * 2;
+        int msg = 0;
+        int loops = 0;
+        while(msg < MSG_COUNT && loops < maxLoops)
+        {
+            if (consumer1.receive(AWAIT_MESSAGE_TIMEOUT) != null)
+            {
+                msg++;
+            }
+
+            if (consumer2.receive(AWAIT_MESSAGE_TIMEOUT) != null)
+            {
+                msg++;
+            }
+
+            loops++;
+        }
+
+        assertEquals("Not all messages received.", MSG_COUNT, msg);
+        assertNull("Received too many messages", consumer1.receive(AWAIT_MESSAGE_TIMEOUT_NEGATIVE));
+        assertNull("Received too many messages", consumer2.receive(AWAIT_MESSAGE_TIMEOUT_NEGATIVE));
+    }
+
+    public void testIdleSecondConsumer() throws Exception
+    {
+        Session idleSession = _consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+        @SuppressWarnings("unused")
+        MessageConsumer idleConsumerOnSameQueue = idleSession.createConsumer(_queue);
+
+        // Since we don't call receive on the idle consumer, all messages will flow to other
+
+        for (int msg = 0; msg < MSG_COUNT; msg++)
+        {
+            assertNotNull("Expected message number " + msg, _consumer.receive(AWAIT_MESSAGE_TIMEOUT));
+        }
+
+        assertNull("Received too many messages", _consumer.receive(AWAIT_MESSAGE_TIMEOUT_NEGATIVE));
+    }
+
+
+}

Modified: qpid/trunk/qpid/java/test-profiles/CPPExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/CPPExcludes?rev=1299425&r1=1299424&r2=1299425&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/CPPExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/CPPExcludes Sun Mar 11 19:01:15 2012
@@ -24,7 +24,6 @@ org.apache.qpid.test.client.destination.
 org.apache.qpid.test.client.destination.AddressBasedDestinationTest#testDeleteOptions
 
 org.apache.qpid.test.unit.client.channelclose.ChannelCloseTest#*
-org.apache.qpid.client.ResetMessageListenerTest#*
 
 // Those tests are testing 0.8 specific semantics
 org.apache.qpid.test.client.ImmediateAndMandatoryPublishingTest#*
@@ -169,3 +168,6 @@ org.apache.qpid.server.message.MessagePr
 
 // passwd script is a Java Broker specific command line tool
 org.apache.qpid.scripts.QpidPasswdTest#*
+
+// QPID-3604: Immediate Prefetch no longer supported by 0-10
+org.apache.qpid.client.AsynchMessageListenerTest#testImmediatePrefetchWithMessageListener

Modified: qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes?rev=1299425&r1=1299424&r2=1299425&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/CPPPrefetchExcludes Sun Mar 11 19:01:15 2012
@@ -18,6 +18,6 @@
 //
 
 // those tests should be run with prefetch off
-org.apache.qpid.client.MessageListenerMultiConsumerTest#testRecieveC2Only
-org.apache.qpid.client.MessageListenerMultiConsumerTest#testRecieveBoth
+org.apache.qpid.client.SynchReceiveTest#testTwoConsumersInterleaved
+org.apache.qpid.client.SynchReceiveTest#testIdleSecondConsumer
 org.apache.qpid.test.unit.xa.TopicTest#testMigrateDurableSubscriber

Modified: qpid/trunk/qpid/java/test-profiles/Java010Excludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/Java010Excludes?rev=1299425&r1=1299424&r2=1299425&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/Java010Excludes (original)
+++ qpid/trunk/qpid/java/test-profiles/Java010Excludes Sun Mar 11 19:01:15 2012
@@ -54,3 +54,6 @@ org.apache.qpid.test.client.destination.
 org.apache.qpid.test.client.timeouts.SyncWaitTimeoutDelayTest#*
 org.apache.qpid.test.client.timeouts.SyncWaitDelayTest#*
 
+// QPID-3604: Immediate Prefetch no longer supported by 0-10
+org.apache.qpid.client.AsynchMessageListenerTest#testImmediatePrefetchWithMessageListener
+

Modified: qpid/trunk/qpid/java/test-profiles/JavaPre010Excludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/JavaPre010Excludes?rev=1299425&r1=1299424&r2=1299425&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/JavaPre010Excludes (original)
+++ qpid/trunk/qpid/java/test-profiles/JavaPre010Excludes Sun Mar 11 19:01:15 2012
@@ -36,7 +36,7 @@ org.apache.qpid.server.queue.AddressBase
 
 // Those tests are written against the 0.10 path
 org.apache.qpid.test.unit.message.UTF8Test#*
-org.apache.qpid.client.MessageListenerTest#testSynchronousReceiveNoWait
+org.apache.qpid.client.SynchReceiveTest#testReceiveNoWait
 
 // Tests 0.10 client feature
 org.apache.qpid.test.unit.client.connection.ConnectionTest#testUnsupportedSASLMechanism



---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org