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 2017/12/21 17:27:45 UTC

[2/7] qpid-broker-j git commit: QPID-6933: [System Tests] Move JMS specific parts of PropertyValueTest to new suite. Protocol specific parts already moved to protocol suites

QPID-6933: [System Tests] Move JMS specific parts of PropertyValueTest to new suite.  Protocol specific parts already moved to protocol suites


Project: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/commit/a28be4b5
Tree: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/tree/a28be4b5
Diff: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/diff/a28be4b5

Branch: refs/heads/master
Commit: a28be4b508c330165a13c46295886260c5f2d471
Parents: 9b0a837
Author: Keith Wall <kw...@apache.org>
Authored: Thu Dec 21 10:53:46 2017 +0000
Committer: Keith Wall <kw...@apache.org>
Committed: Thu Dec 21 11:28:56 2017 +0000

----------------------------------------------------------------------
 .../message/JMSHeadersAndPropertiesTest.java    |  51 +-
 .../qpid/test/unit/basic/PropertyValueTest.java | 511 -------------------
 test-profiles/CPPExcludes                       |   7 -
 test-profiles/Java010Excludes                   |   3 -
 test-profiles/Java10Excludes                    |   5 -
 test-profiles/JavaPre010Excludes                |   3 -
 6 files changed, 44 insertions(+), 536 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a28be4b5/systests/qpid-systests-jms_1.1/src/test/java/org/apache/qpid/systests/jms_1_1/message/JMSHeadersAndPropertiesTest.java
----------------------------------------------------------------------
diff --git a/systests/qpid-systests-jms_1.1/src/test/java/org/apache/qpid/systests/jms_1_1/message/JMSHeadersAndPropertiesTest.java b/systests/qpid-systests-jms_1.1/src/test/java/org/apache/qpid/systests/jms_1_1/message/JMSHeadersAndPropertiesTest.java
index 2068b96..a753281 100644
--- a/systests/qpid-systests-jms_1.1/src/test/java/org/apache/qpid/systests/jms_1_1/message/JMSHeadersAndPropertiesTest.java
+++ b/systests/qpid-systests-jms_1.1/src/test/java/org/apache/qpid/systests/jms_1_1/message/JMSHeadersAndPropertiesTest.java
@@ -51,7 +51,7 @@ public class JMSHeadersAndPropertiesTest extends JmsTestBase
 {
 
     @Test
-    public void testResentJMSMessageGetsReplacementJMSMessageID() throws Exception
+    public void resentJMSMessageGetsReplacementJMSMessageID() throws Exception
     {
         Queue queue = createQueue(getTestName());
         Connection connection = getConnection();
@@ -85,7 +85,7 @@ public class JMSHeadersAndPropertiesTest extends JmsTestBase
     }
 
     @Test
-    public void JMSRedelivered() throws Exception
+    public void redelivered() throws Exception
     {
         Queue queue = createQueue(getTestName());
         Connection connection = getConnectionBuilder().setPrefetch(1).build();
@@ -126,7 +126,7 @@ public class JMSHeadersAndPropertiesTest extends JmsTestBase
     }
 
     @Test
-    public void testJMSHeaders() throws Exception
+    public void headers() throws Exception
     {
         final Queue queue = createQueue(getTestName());
         final Destination replyTo = createQueue(getTestName() + "_replyTo");
@@ -184,9 +184,8 @@ public class JMSHeadersAndPropertiesTest extends JmsTestBase
         }
     }
 
-
     @Test
-    public void testJMSXGroupIDAndJMSXGroupSeq() throws Exception
+    public void groupIDAndGroupSeq() throws Exception
     {
         final Connection connection = getConnection();
         try
@@ -220,13 +219,52 @@ public class JMSHeadersAndPropertiesTest extends JmsTestBase
     }
 
     @Test
+    public void propertyValues() throws Exception
+    {
+        Queue queue = createQueue(getTestName());
+        Connection connection = getConnection();
+        try
+        {
+            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
+            MessageProducer producer = session.createProducer(queue);
+            Message message = session.createMessage();
+
+            message.setBooleanProperty("boolean", true);
+            message.setByteProperty("byte", Byte.MAX_VALUE);
+            message.setShortProperty("short", Short.MAX_VALUE);
+            message.setIntProperty("int", Integer.MAX_VALUE);
+            message.setFloatProperty("float", Float.MAX_VALUE);
+            message.setDoubleProperty("double", Double.MAX_VALUE);
+
+            producer.send(message);
+
+            final MessageConsumer consumer = session.createConsumer(queue);
+            connection.start();
+
+            final Message receivedMessage = consumer.receive(getReceiveTimeout());
+            assertNotNull(receivedMessage);
+
+            assertEquals("Unexpected boolean property value", Boolean.TRUE, message.getBooleanProperty("boolean"));
+            assertEquals("Unexpected byte property value", Byte.MAX_VALUE, message.getByteProperty("byte"));
+            assertEquals("Unexpected short property value", Short.MAX_VALUE, message.getShortProperty("short"));
+            assertEquals("Unexpected int property value", Integer.MAX_VALUE, message.getIntProperty("int"));
+            assertEquals("Unexpected float property value", Float.MAX_VALUE, message.getFloatProperty("float"), 0f);
+            assertEquals("Unexpected double property value", Double.MAX_VALUE, message.getDoubleProperty("double"), 0d);
+        }
+        finally
+        {
+            connection.close();
+        }
+    }
+
+    @Test
     public void unsupportedObjectPropertyValue() throws Exception
     {
         Queue queue = createQueue(getTestName());
         Connection connection = getConnection();
         try
         {
-            Session session = connection.createSession(true, Session.SESSION_TRANSACTED);
+            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
             MessageProducer producer = session.createProducer(queue);
             Message message = session.createMessage();
             try
@@ -240,7 +278,6 @@ public class JMSHeadersAndPropertiesTest extends JmsTestBase
             String validValue = "validValue";
             message.setObjectProperty("validObject", validValue);
             producer.send(message);
-            session.commit();
 
             final MessageConsumer consumer = session.createConsumer(queue);
             connection.start();

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a28be4b5/systests/src/test/java/org/apache/qpid/test/unit/basic/PropertyValueTest.java
----------------------------------------------------------------------
diff --git a/systests/src/test/java/org/apache/qpid/test/unit/basic/PropertyValueTest.java b/systests/src/test/java/org/apache/qpid/test/unit/basic/PropertyValueTest.java
deleted file mode 100644
index 50bb87e..0000000
--- a/systests/src/test/java/org/apache/qpid/test/unit/basic/PropertyValueTest.java
+++ /dev/null
@@ -1,511 +0,0 @@
-/*
- *
- * 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.test.unit.basic;
-
-import java.lang.reflect.InvocationTargetException;
-import java.lang.reflect.Method;
-import java.net.URISyntaxException;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-
-import javax.jms.Connection;
-import javax.jms.Destination;
-import javax.jms.JMSException;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageFormatException;
-import javax.jms.MessageListener;
-import javax.jms.MessageProducer;
-import javax.jms.Queue;
-import javax.jms.Session;
-import javax.jms.TextMessage;
-
-import com.google.common.base.Strings;
-import org.junit.Assert;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import org.apache.qpid.client.AMQConnection;
-import org.apache.qpid.test.utils.QpidBrokerTestCase;
-
-public class PropertyValueTest extends QpidBrokerTestCase implements MessageListener
-{
-    private static final Logger LOGGER = LoggerFactory.getLogger(PropertyValueTest.class);
-
-    private Connection _connection;
-    private Destination _destination;
-    private Session _session;
-    private final List<TextMessage> received = new ArrayList<>();
-    private final List<String> messages = new ArrayList<String>();
-    private Map<String, Destination> _replyToDestinations;
-    private int _count = 1;
-
-    @Override
-    protected void setUp() throws Exception
-    {
-        _replyToDestinations = new HashMap<String, Destination>();
-        super.setUp();
-    }
-
-    @Override
-    protected void tearDown() throws Exception
-    {
-        super.tearDown();
-    }
-
-    private void init(Connection connection) throws Exception
-    {
-        _connection = connection;
-        _session = connection.createSession(true, Session.SESSION_TRANSACTED);
-        _destination = createTestQueue(_session);
-
-        // set up a slow consumer
-        connection.start();
-        _session.createConsumer(_destination).setMessageListener(this);
-    }
-
-    private Message getTestMessage() throws Exception
-    {
-        Connection conn = getConnection();
-        Session ssn = conn.createSession(false, Session.AUTO_ACKNOWLEDGE);
-        return ssn.createTextMessage();
-    }
-
-    public void testGetNonexistent() throws Exception
-    {
-        Message m = getTestMessage();
-        String s = m.getStringProperty("nonexistent");
-        assertNull(s);
-    }
-
-    private static final String[] NAMES = {
-        "setBooleanProperty", "setByteProperty", "setShortProperty",
-        "setIntProperty", "setLongProperty", "setFloatProperty",
-        "setDoubleProperty", "setObjectProperty"
-    };
-
-    private static final Class[] TYPES = {
-        boolean.class, byte.class, short.class, int.class, long.class,
-        float.class, double.class, Object.class
-    };
-
-    private static final Object[] VALUES = {
-        true, (byte) 0, (short) 0, 0, (long) 0, (float) 0, (double) 0,
-        new Object()
-    };
-
-    public void testSetEmptyPropertyName() throws Exception
-    {
-        Message m = getTestMessage();
-
-        for (int i = 0; i < NAMES.length; i++)
-        {
-            Method meth = m.getClass().getMethod(NAMES[i], String.class, TYPES[i]);
-            try
-            {
-                meth.invoke(m, "", VALUES[i]);
-                fail("expected illegal argument exception");
-            }
-            catch (InvocationTargetException e)
-            {
-                assertEquals(e.getCause().getClass(), IllegalArgumentException.class);
-            }
-        }
-    }
-
-    public void testSetDisallowedClass() throws Exception
-    {
-        Message m = getTestMessage();
-        try
-        {
-            m.setObjectProperty("foo", new Object());
-            fail("expected a MessageFormatException");
-        }
-        catch (MessageFormatException e)
-        {
-            // pass
-        }
-    }
-
-    public void testOnce()
-    {
-        runBatch(1);
-    }
-
-    public void test50()
-    {
-        runBatch(50);
-    }
-
-
-    /**
-     * This fails because of QPID-6793
-     */
-    /*
-    public void testLargeHeader_010_HeaderLargerThan16Bit() throws Exception
-    {
-        _connection = (AMQConnection) getConnection();
-        int maximumFrameSize = (int) _connection.getMaximumFrameSize();
-        String propertyName = "string";
-        String propertyValue = generateLongString(1<<16);
-        sendReceiveMessageWithHeader(_connection, propertyName, propertyValue);
-    }
-    */
-
-    /**
-     * Test QPID-6786
-     */
-    public void testLargeHeader_010_HeadersFillContentHeaderFrame() throws Exception
-    {
-        _connection = getConnection();
-        int maximumFrameSize = (int) ((AMQConnection)_connection).getMaximumFrameSize();
-        Map<String, String> headerProperties = new HashMap<>();
-        int headerPropertySize = ((1<<16) - 1);
-        int i = 0;
-        do
-        {
-            String propertyName = "string_" + i;
-            String propertyValue = generateLongString((1<<16) - 1);
-            headerProperties.put(propertyName, propertyValue);
-            ++i;
-        }
-        while (headerProperties.size() * headerPropertySize < 2 * maximumFrameSize);
-
-        _connection.start();
-        Session session = _connection.createSession(true, Session.SESSION_TRANSACTED);
-
-        Destination destination = session.createQueue(getTestQueueName());
-
-        Message message = session.createMessage();
-        for (Map.Entry<String, String> propertyEntry : headerProperties.entrySet())
-        {
-            message.setStringProperty(propertyEntry.getKey(), propertyEntry.getValue());
-        }
-
-        MessageConsumer consumer = session.createConsumer(destination);
-
-        MessageProducer producer = session.createProducer(destination);
-        producer.setDisableMessageID(true);
-        producer.setDisableMessageTimestamp(true);
-        producer.send(message);
-        session.commit();
-
-        Message receivedMessage = consumer.receive(1000);
-        assertNotNull("Message not received", receivedMessage);
-        for (Map.Entry<String, String> propertyEntry : headerProperties.entrySet())
-        {
-            assertEquals("Message has unexpected property value",
-                         propertyEntry.getValue(),
-                         receivedMessage.getStringProperty(propertyEntry.getKey()));
-        }
-        session.commit();
-
-    }
-
-    public void testLargeHeader_08091_HeadersFillContentHeaderFrame() throws Exception
-    {
-        _connection =  getConnection();
-        int maximumFrameSize = (int) ((AMQConnection)_connection).getMaximumFrameSize();
-        String propertyName = "string";
-        int overhead = calculateOverHead_08091_FrameWithHeader(propertyName);
-
-        String propertyValue = generateLongString(maximumFrameSize - overhead);
-        sendReceiveMessageWithHeader(_connection, propertyName, propertyValue);
-    }
-
-    public void testOverlyLargeHeaderRejected_08091() throws Exception
-    {
-        _connection = (AMQConnection) getConnection();
-        _session = _connection.createSession(true, Session.SESSION_TRANSACTED);
-        MessageProducer producer = _session.createProducer(_session.createQueue(getTestQueueName()));
-
-        int maximumFrameSize = (int) ((AMQConnection)_connection).getMaximumFrameSize();
-        String propertyName = "string";
-        int overhead = calculateOverHead_08091_FrameWithHeader(propertyName);
-
-        String propertyValue = generateLongString(maximumFrameSize - overhead + 1);
-        try
-        {
-            Message m = _session.createMessage();
-            m.setStringProperty(propertyName, propertyValue);
-            producer.send(m);
-            fail("Exception not thrown");
-        }
-        catch (JMSException je)
-        {
-            assertTrue("Unexpected message " + je.getMessage(), je.getMessage().contains("Unable to send message as the headers are too large"));
-            // PASS
-        }
-    }
-
-
-    private int calculateOverHead_08091_FrameWithHeader(final String propertyName)
-    {
-        int frame = 1 + 2 + 4 + 1;
-        int body = 2 + 2 + 8 + 2;
-        int properties = GUEST_USERNAME.length() + 1  // Username + length
-                         + 1 // DeliveryMode byte
-                         + 1 // Priority byte
-                         + "application/octet-stream".length() + 1 // Encoding + length
-                         + 4  // Headers field table
-                         + "JMS_QPID_DESTTYPE".length() + 1 + 1 + 4
-                         + propertyName.length() + 1 + 1 + 4;
-        return frame + body + properties;
-    }
-
-    private String generateLongString(final int count)
-    {
-        String pattern = "abcde";
-        String str = Strings.repeat(pattern, count / pattern.length()) + pattern.substring(0, count % pattern.length());
-        assertEquals(count, str.length());
-        return str;
-    }
-
-    private void sendReceiveMessageWithHeader(Connection connection,
-                                              final String propName, final String propValue) throws Exception
-    {
-        connection.start();
-        Session session = connection.createSession(true, Session.SESSION_TRANSACTED);
-
-        Destination destination = session.createQueue(getTestQueueName());
-
-        Message message = session.createMessage();
-        message.setStringProperty(propName, propValue);
-
-        MessageConsumer consumer = session.createConsumer(destination);
-
-        MessageProducer producer = session.createProducer(destination);
-        producer.setDisableMessageID(true);
-        producer.setDisableMessageTimestamp(true);
-        producer.send(message);
-        session.commit();
-
-        Message receivedMessage = consumer.receive(1000);
-        assertNotNull("Message not received", receivedMessage);
-        assertEquals("Message has unexpected property value", propValue, receivedMessage.getStringProperty(propName));
-        session.commit();
-    }
-
-    private void runBatch(int runSize)
-    {
-        try
-        {
-            int run = 0;
-            while (run < runSize)
-            {
-                LOGGER.error("Run Number:" + run++);
-                try
-                {
-                    init(getConnection());
-                }
-                catch (Exception e)
-                {
-                    LOGGER.error("exception:", e);
-                    fail("Unable to initialise connection: " + e);
-                }
-
-                int count = _count;
-                send(count, run);
-                waitFor(count);
-                check();
-                LOGGER.info("Completed without failure");
-
-                _connection.close();
-
-                LOGGER.error("End Run Number:" + (run - 1));
-            }
-        }
-        catch (Exception e)
-        {
-            LOGGER.error(e.getMessage(), e);
-        }
-    }
-
-    void send( int count, final int iteration) throws JMSException
-    {
-        // create a publisher
-        MessageProducer producer = _session.createProducer(_destination);
-        for (int i = 0; i < count; i++)
-        {
-            String text = "Message " + iteration;
-            messages.add(text);
-            Message m = _session.createTextMessage(text);
-
-            m.setBooleanProperty("Bool", true);
-
-            m.setByteProperty("Byte", (byte) Byte.MAX_VALUE);
-            m.setDoubleProperty("Double", (double) Double.MAX_VALUE);
-            m.setFloatProperty("Float", (float) Float.MAX_VALUE);
-            m.setIntProperty("Int", (int) Integer.MAX_VALUE);
-
-            m.setJMSCorrelationID("Correlation");
-            // fixme the m.setJMSMessage has no effect
-            producer.setPriority(8);
-            m.setJMSPriority(3);
-
-            // Queue
-            Queue q;
-
-            if ((i / 2) == 0)
-            {
-                q = _session.createTemporaryQueue();
-            }
-            else
-            {
-                q = _session.createQueue("TestReply");
-            }
-
-            m.setJMSReplyTo(q);
-
-            m.setStringProperty("ReplyToIndex", String.valueOf(i));
-            _replyToDestinations.put(String.valueOf(i), q);
-
-            LOGGER.debug("Message:" + m);
-
-            m.setJMSType("Test");
-            m.setLongProperty("UnsignedInt", (long) 4294967295L);
-            m.setLongProperty("Long", (long) Long.MAX_VALUE);
-
-            m.setShortProperty("Short", (short) Short.MAX_VALUE);
-            m.setStringProperty("String", "Test");
-
-            LOGGER.debug("Sending Msg:" + m);
-            producer.send(m);
-            _session.commit();
-        }
-    }
-
-    void waitFor(int count) throws Exception
-    {
-        synchronized (received)
-        {
-            while (received.size() < count)
-            {
-                received.wait();
-            }
-        }
-        _session.commit();
-    }
-
-    void check() throws JMSException, URISyntaxException
-    {
-        List<String> actual = new ArrayList<>();
-        for (TextMessage m : received)
-        {
-            getLogger().debug("Checking : message : {} text payload: {}", m, m.getText());
-            actual.add(m.getText());
-
-            // Check Properties
-
-            Assert.assertEquals("Check Boolean properties are correctly transported", true, m.getBooleanProperty("Bool"));
-            Assert.assertEquals("Check Byte properties are correctly transported", Byte.MAX_VALUE,
-                m.getByteProperty("Byte"));
-            Assert.assertEquals("Check Double properties are correctly transported", Double.MAX_VALUE,
-                m.getDoubleProperty("Double"), 0d);
-            Assert.assertEquals("Check Float properties are correctly transported", Float.MAX_VALUE,
-                m.getFloatProperty("Float"), 0f);
-            Assert.assertEquals("Check Int properties are correctly transported", Integer.MAX_VALUE,
-                m.getIntProperty("Int"));
-            Assert.assertEquals("Check CorrelationID properties are correctly transported", "Correlation",
-                m.getJMSCorrelationID());
-            Assert.assertEquals("Check Priority properties are correctly transported", 8, m.getJMSPriority());
-
-            // Queue
-            String replyToIndex = m.getStringProperty("ReplyToIndex");
-            Assert.assertEquals("Check ReplyTo properties are correctly transported :" + replyToIndex + " : " + _replyToDestinations, _replyToDestinations.get(replyToIndex), m.getJMSReplyTo());
-
-            Assert.assertEquals("Check Type properties are correctly transported", "Test", m.getJMSType());
-
-            Assert.assertEquals("Check Short properties are correctly transported", (short) Short.MAX_VALUE,
-                m.getShortProperty("Short"));
-            Assert.assertEquals("Check UnsignedInt properties are correctly transported", (long) 4294967295L,
-                m.getLongProperty("UnsignedInt"));
-            Assert.assertEquals("Check Long properties are correctly transported", (long) Long.MAX_VALUE,
-                m.getLongProperty("Long"));
-            Assert.assertEquals("Check String properties are correctly transported", "Test", m.getStringProperty("String"));
-
-            //JMSXUserID
-            if (m.getStringProperty("JMSXUserID") != null)
-            {
-                Assert.assertEquals("Check 'JMSXUserID' is supported ", QpidBrokerTestCase.GUEST_USERNAME,
-                                    m.getStringProperty("JMSXUserID"));
-            }
-        }
-
-        received.clear();
-
-        assertEqual(messages.iterator(), actual.iterator());
-
-        messages.clear();
-    }
-
-    private static void assertEqual(Iterator expected, Iterator actual)
-    {
-        List<String> errors = new ArrayList<String>();
-        while (expected.hasNext() && actual.hasNext())
-        {
-            try
-            {
-                assertEqual(expected.next(), actual.next());
-            }
-            catch (Exception e)
-            {
-                errors.add(e.getMessage());
-            }
-        }
-        while (expected.hasNext())
-        {
-            errors.add("Expected " + expected.next() + " but no more actual values.");
-        }
-        while (actual.hasNext())
-        {
-            errors.add("Found " + actual.next() + " but no more expected values.");
-        }
-
-        if (!errors.isEmpty())
-        {
-            throw new RuntimeException(errors.toString());
-        }
-    }
-
-    private static void assertEqual(Object expected, Object actual)
-    {
-        if (!expected.equals(actual))
-        {
-            throw new RuntimeException("Expected '" + expected + "' found '" + actual + "'");
-        }
-    }
-
-    @Override
-    public void onMessage(Message message)
-    {
-        synchronized (received)
-        {
-            received.add((TextMessage) message);
-            received.notify();
-        }
-    }
-
-
-}

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a28be4b5/test-profiles/CPPExcludes
----------------------------------------------------------------------
diff --git a/test-profiles/CPPExcludes b/test-profiles/CPPExcludes
index d34a834..2860246 100755
--- a/test-profiles/CPPExcludes
+++ b/test-profiles/CPPExcludes
@@ -194,13 +194,6 @@ org.apache.qpid.server.virtualhostnode.berkeleydb.*
 // Qpid Broker-J Derby Tests
 org.apache.qpid.server.store.derby.*
 
-// These tests are 0-8..0-91 specific
-org.apache.qpid.test.unit.basic.PropertyValueTest#testLargeHeader_08091_HeadersFillContentHeaderFrame
-org.apache.qpid.test.unit.basic.PropertyValueTest#testOverlyLargeHeaderRejected_08091
-
-// QPID-6786 Sending headers larger than [first] transfer/frame size (which is outside the spec) isn't supported against the C++ broker
-org.apache.qpid.test.unit.basic.PropertyValueTest#testLargeHeader_010_HeadersFillContentHeaderFrame
-
 # QPID-7156: Test requires a Broker with a virtualhost
 org.apache.qpid.test.unit.client.connection.BrokerClosesClientConnectionTest#testClientCloseOnVirtualHostStop
 

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a28be4b5/test-profiles/Java010Excludes
----------------------------------------------------------------------
diff --git a/test-profiles/Java010Excludes b/test-profiles/Java010Excludes
index ecd85a8..a7d30cf 100755
--- a/test-profiles/Java010Excludes
+++ b/test-profiles/Java010Excludes
@@ -67,9 +67,6 @@ org.apache.qpid.client.prefetch.PrefetchBehaviourTest#testPrefetchWindowExpandsO
 org.apache.qpid.client.failover.FailoverBehaviourTest#testConnectionCloseInterruptsFailover
 org.apache.qpid.client.failover.AddressBasedFailoverBehaviourTest#testConnectionCloseInterruptsFailover
 
-org.apache.qpid.test.unit.basic.PropertyValueTest#testLargeHeader_08091_HeadersFillContentHeaderFrame
-org.apache.qpid.test.unit.basic.PropertyValueTest#testOverlyLargeHeaderRejected_08091
-
 // There is no way in the 0-10 client to cause a send to fail when the message does not reach any queue
 org.apache.qpid.server.queue.NodeAutoCreationPolicyTest#testSendingToNonMatchingQueuePatternBURL
 

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a28be4b5/test-profiles/Java10Excludes
----------------------------------------------------------------------
diff --git a/test-profiles/Java10Excludes b/test-profiles/Java10Excludes
index 81005c2..08bed84 100644
--- a/test-profiles/Java10Excludes
+++ b/test-profiles/Java10Excludes
@@ -82,11 +82,6 @@ org.apache.qpid.client.session.ExchangeDeleteTest#*
 org.apache.qpid.client.session.QueueDeclareTest#*
 org.apache.qpid.client.session.QueueDeleteTest#*
 
-// The tests are Protocol version specific constraints on total header property size
-org.apache.qpid.test.unit.basic.PropertyValueTest#testOverlyLargeHeaderRejected_08091
-org.apache.qpid.test.unit.basic.PropertyValueTest#testLargeHeader_08091_HeadersFillContentHeaderFrame
-org.apache.qpid.test.unit.basic.PropertyValueTest#testLargeHeader_010_HeadersFillContentHeaderFrame
-
 // This test concerns 0-8/0-10 bytes limiting flow control
 org.apache.qpid.test.client.ConsumerFlowControlTest#*
 

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a28be4b5/test-profiles/JavaPre010Excludes
----------------------------------------------------------------------
diff --git a/test-profiles/JavaPre010Excludes b/test-profiles/JavaPre010Excludes
index 17fe64b..d1883a9 100644
--- a/test-profiles/JavaPre010Excludes
+++ b/test-profiles/JavaPre010Excludes
@@ -61,9 +61,6 @@ org.apache.qpid.client.prefetch.PrefetchBehaviourTest#testConnectionStop
 // QPID-3396
 org.apache.qpid.test.unit.client.connection.ConnectionTest#testExceptionWhenUserPassIsRequired
 
-// Testing of large 0-10 headers (QPID-6786)
-org.apache.qpid.test.unit.basic.PropertyValueTest#testLargeHeader_010_HeadersFillContentHeaderFrame
-
 # Exclude the JMS 2.0 test suite
 org.apache.qpid.systests.jms_2_0.*
 


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