You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by or...@apache.org on 2019/07/03 12:24:41 UTC

[qpid-broker-j] branch 7.0.x updated (9f90e2f -> 1526831)

This is an automated email from the ASF dual-hosted git repository.

orudyy pushed a change to branch 7.0.x
in repository https://gitbox.apache.org/repos/asf/qpid-broker-j.git.


    from 9f90e2f  NO-JIRA: Add apache-rat excludes
     new c4e24d2  NO-JIRA: Remove mistakenly merged test classes and resource
     new 9a8a618  NO-JIRA : Update apache-rat plugin excludes in systests
     new 1526831  [maven-release-plugin] prepare release 7.0.8

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 apache-qpid-broker-j/pom.xml                       |   2 +-
 bdbstore/pom.xml                                   |   2 +-
 bdbstore/systests/pom.xml                          |   2 +-
 broker-codegen/pom.xml                             |   2 +-
 broker-core/pom.xml                                |   2 +-
 broker-plugins/access-control/pom.xml              |   2 +-
 broker-plugins/amqp-0-10-protocol/pom.xml          |   2 +-
 broker-plugins/amqp-0-8-protocol/pom.xml           |   2 +-
 broker-plugins/amqp-1-0-bdb-store/pom.xml          |   2 +-
 broker-plugins/amqp-1-0-jdbc-store/pom.xml         |   2 +-
 broker-plugins/amqp-1-0-protocol/pom.xml           |   2 +-
 broker-plugins/amqp-msg-conv-0-10-to-1-0/pom.xml   |   2 +-
 broker-plugins/amqp-msg-conv-0-8-to-0-10/pom.xml   |   2 +-
 broker-plugins/amqp-msg-conv-0-8-to-1-0/pom.xml    |   2 +-
 broker-plugins/derby-store/pom.xml                 |   2 +-
 broker-plugins/jdbc-provider-bone/pom.xml          |   2 +-
 broker-plugins/jdbc-store/pom.xml                  |   2 +-
 broker-plugins/logging-logback/pom.xml             |   2 +-
 broker-plugins/management-amqp/pom.xml             |   2 +-
 broker-plugins/management-http/pom.xml             |   2 +-
 broker-plugins/memory-store/pom.xml                |   2 +-
 broker-plugins/websocket/pom.xml                   |   2 +-
 broker/pom.xml                                     |   2 +-
 doc/java-broker/pom.xml                            |   2 +-
 doc/java-perftests/pom.xml                         |   2 +-
 doc/pom.xml                                        |   2 +-
 joramtests/pom.xml                                 |   2 +-
 perftests/pom.xml                                  |   2 +-
 perftests/visualisation-jfc/pom.xml                |   2 +-
 pom.xml                                            |   4 +-
 qpid-perftests-systests/pom.xml                    |   2 +-
 qpid-systests-parent/pom.xml                       |   4 +-
 qpid-test-utils/pom.xml                            |   2 +-
 systests/end-to-end-conversion-tests/pom.xml       |   2 +-
 systests/pom.xml                                   |   5 +-
 .../qpid/tests/protocol/v0_10/ProtocolTest.java    | 154 ---------------------
 .../qpid/tests/protocol/v0_8/ProtocolTest.java     | 154 ---------------------
 .../basic/MalformedMessageValidation.java          |  87 ------------
 systests/protocol-tests-amqp-1-0/pom.xml           |   2 +-
 systests/protocol-tests-core/pom.xml               |   2 +-
 .../src/main/resources/java_broker_keystore.jks    | Bin 4425 -> 0 bytes
 systests/qpid-systests-jms_2.0/pom.xml             |   2 +-
 systests/systests-utils/pom.xml                    |   2 +-
 tck/pom.xml                                        |   2 +-
 tools/pom.xml                                      |   2 +-
 45 files changed, 46 insertions(+), 438 deletions(-)
 delete mode 100644 systests/protocol-tests-amqp-0-10/src/test/java/org/apache/qpid/tests/protocol/v0_10/ProtocolTest.java
 delete mode 100644 systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/ProtocolTest.java
 delete mode 100644 systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/extension/basic/MalformedMessageValidation.java
 delete mode 100644 systests/qpid-systests-http-management/src/main/resources/java_broker_keystore.jks


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


[qpid-broker-j] 02/03: NO-JIRA : Update apache-rat plugin excludes in systests

Posted by or...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

orudyy pushed a commit to branch 7.0.x
in repository https://gitbox.apache.org/repos/asf/qpid-broker-j.git

commit 9a8a618e77665271dee8b8e81b9971f36338ce30
Author: Alex Rudyy <or...@apache.org>
AuthorDate: Wed Jul 3 12:34:06 2019 +0100

    NO-JIRA : Update apache-rat plugin excludes in systests
---
 systests/pom.xml | 3 +++
 1 file changed, 3 insertions(+)

diff --git a/systests/pom.xml b/systests/pom.xml
index 459c391..800ef4c 100644
--- a/systests/pom.xml
+++ b/systests/pom.xml
@@ -155,6 +155,9 @@
             <exclude>src/test/resources/org/apache/qpid/test/unit/message/**</exclude>
             <exclude>qpid-systests-jms_2.0/**</exclude>
             <exclude>protocol-tests-amqp-1-0/**</exclude>
+            <exclude>protocol-tests-core/**</exclude>
+            <exclude>end-to-end-conversion-tests/**</exclude>
+            <exclude>systests-utils/**</exclude>
           </excludes>
         </configuration>
       </plugin>


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


[qpid-broker-j] 01/03: NO-JIRA: Remove mistakenly merged test classes and resource

Posted by or...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

orudyy pushed a commit to branch 7.0.x
in repository https://gitbox.apache.org/repos/asf/qpid-broker-j.git

commit c4e24d209788a7f7961947007b6b75e7b4c8f822
Author: Alex Rudyy <or...@apache.org>
AuthorDate: Wed Jul 3 12:33:21 2019 +0100

    NO-JIRA: Remove mistakenly merged test classes and resource
---
 .../qpid/tests/protocol/v0_10/ProtocolTest.java    | 154 ---------------------
 .../qpid/tests/protocol/v0_8/ProtocolTest.java     | 154 ---------------------
 .../basic/MalformedMessageValidation.java          |  87 ------------
 .../src/main/resources/java_broker_keystore.jks    | Bin 4425 -> 0 bytes
 4 files changed, 395 deletions(-)

diff --git a/systests/protocol-tests-amqp-0-10/src/test/java/org/apache/qpid/tests/protocol/v0_10/ProtocolTest.java b/systests/protocol-tests-amqp-0-10/src/test/java/org/apache/qpid/tests/protocol/v0_10/ProtocolTest.java
deleted file mode 100644
index 35675e1..0000000
--- a/systests/protocol-tests-amqp-0-10/src/test/java/org/apache/qpid/tests/protocol/v0_10/ProtocolTest.java
+++ /dev/null
@@ -1,154 +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.tests.protocol.v0_10;
-
-import static org.hamcrest.CoreMatchers.instanceOf;
-import static org.hamcrest.CoreMatchers.is;
-import static org.hamcrest.CoreMatchers.notNullValue;
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.contains;
-import static org.junit.Assert.assertArrayEquals;
-
-import java.io.ByteArrayOutputStream;
-import java.io.DataOutputStream;
-import java.net.InetSocketAddress;
-import java.nio.charset.StandardCharsets;
-
-import org.hamcrest.core.IsEqual;
-import org.junit.Before;
-import org.junit.Test;
-
-import org.apache.qpid.server.protocol.v0_10.transport.ConnectionStart;
-import org.apache.qpid.tests.protocol.HeaderResponse;
-import org.apache.qpid.tests.protocol.Response;
-import org.apache.qpid.tests.protocol.SpecificationTest;
-import org.apache.qpid.tests.utils.BrokerAdmin;
-import org.apache.qpid.tests.utils.BrokerAdminUsingTestBase;
-
-public class ProtocolTest extends BrokerAdminUsingTestBase
-{
-    private static final String DEFAULT_LOCALE = "en_US";
-    private InetSocketAddress _brokerAddress;
-
-    @Before
-    public void setUp()
-    {
-        _brokerAddress = getBrokerAdmin().getBrokerAddress(BrokerAdmin.PortType.ANONYMOUS_AMQP);
-    }
-
-    @Test
-    @SpecificationTest(section = "4.3. Version Negotiation",
-            description = "When the client opens a new socket connection to an AMQP server,"
-                          + " it MUST send a protocol header with the client's preferred protocol version."
-                          + "If the requested protocol version is supported, the server MUST send its own protocol"
-                          + " header with the requested version to the socket, and then implement the protocol accordingly")
-    public void versionNegotiation() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-            final Interaction interaction = transport.newInteraction();
-            Response<?> response = interaction.negotiateProtocol().consumeResponse().getLatestResponse();
-            assertThat(response, is(instanceOf(HeaderResponse.class)));
-            assertThat(response.getBody(), is(IsEqual.equalTo(transport.getProtocolHeader())));
-
-            ConnectionStart connectionStart = interaction.consumeResponse().getLatestResponse(ConnectionStart.class);
-            assertThat(connectionStart.getMechanisms(), is(notNullValue()));
-            assertThat(connectionStart.getMechanisms(), contains(ConnectionInteraction.SASL_MECHANISM_ANONYMOUS));
-            assertThat(connectionStart.getLocales(), is(notNullValue()));
-            assertThat(connectionStart.getLocales(), contains(DEFAULT_LOCALE));
-        }
-    }
-
-    @Test
-    @SpecificationTest(section = "4.3. Version Negotiation",
-            description = "If the server can't parse the protocol header, the server MUST send a valid protocol "
-                          + "header with a supported protocol version and then close the socket.")
-    public void unrecognisedProtocolHeader() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-
-            final Interaction interaction = transport.newInteraction();
-
-            byte[] unknownHeader = "NOTANAMQPHEADER".getBytes(StandardCharsets.UTF_8);
-            byte[] expectedResponse = "AMQP\001\001\000\012".getBytes(StandardCharsets.UTF_8);
-            final byte[] response = interaction.protocolHeader(unknownHeader)
-                                               .negotiateProtocol()
-                                               .consumeResponse().getLatestResponse(byte[].class);
-            assertArrayEquals("Unexpected protocol header response", expectedResponse, response);
-            transport.assertNoMoreResponsesAndChannelClosed();
-        }
-    }
-
-    @Test
-    @SpecificationTest(section = "4.3. Version Negotiation",
-            description = "If the requested protocol version is not supported, the server MUST send a protocol "
-                          + "header with a supported protocol version and then close the socket.")
-    public void unrecognisedProtocolVersion() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-
-
-            final Interaction interaction = transport.newInteraction();
-
-            byte[] unknownAmqpVersion = "AMQP\001\001\000\013".getBytes(StandardCharsets.UTF_8);
-            byte[] expectedResponse = "AMQP\001\001\000\012".getBytes(StandardCharsets.UTF_8);
-            final byte[] response = interaction.protocolHeader(unknownAmqpVersion)
-                                               .negotiateProtocol()
-                                               .consumeResponse().getLatestResponse(byte[].class);
-            assertArrayEquals("Unexpected protocol header response", expectedResponse, response);
-            transport.assertNoMoreResponsesAndChannelClosed();
-        }
-    }
-
-    @Test
-    @SpecificationTest(section = "8. Domains", description = "valid values for the frame type indicator.")
-    public void invalidSegmentType() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-            final Interaction interaction = transport.newInteraction();
-
-            interaction.negotiateProtocol().consumeResponse()
-                       .consumeResponse(ConnectionStart.class);
-
-            try (ByteArrayOutputStream bos = new ByteArrayOutputStream();
-                 DataOutputStream dos = new DataOutputStream(bos))
-            {
-                dos.writeByte(0);   /* flags */
-                dos.writeByte(4);   /* segment type - undefined value in 0-10 */
-                dos.writeShort(12); /* size */
-                dos.writeByte(0);
-                dos.writeByte(0);   /* track */
-                dos.writeShort(0);  /* channel */
-                dos.writeByte(0);
-                dos.writeByte(0);
-                dos.writeByte(0);
-                dos.writeByte(0);
-
-                transport.sendBytes(bos.toByteArray());
-            }
-            transport.flush();
-            transport.assertNoMoreResponsesAndChannelClosed();
-        }
-    }
-}
diff --git a/systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/ProtocolTest.java b/systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/ProtocolTest.java
deleted file mode 100644
index 8475bb9..0000000
--- a/systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/ProtocolTest.java
+++ /dev/null
@@ -1,154 +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.tests.protocol.v0_8;
-
-import static org.hamcrest.CoreMatchers.equalTo;
-import static org.hamcrest.CoreMatchers.is;
-import static org.junit.Assert.assertArrayEquals;
-import static org.junit.Assume.assumeThat;
-
-import java.net.InetSocketAddress;
-import java.nio.charset.StandardCharsets;
-
-import org.junit.Before;
-import org.junit.Test;
-
-import org.apache.qpid.server.protocol.ProtocolVersion;
-import org.apache.qpid.server.protocol.v0_8.transport.AMQBody;
-import org.apache.qpid.server.protocol.v0_8.transport.AMQVersionAwareProtocolSession;
-import org.apache.qpid.server.protocol.v0_8.transport.ConnectionStartBody;
-import org.apache.qpid.server.transport.ByteBufferSender;
-import org.apache.qpid.tests.protocol.SpecificationTest;
-import org.apache.qpid.tests.utils.BrokerAdmin;
-import org.apache.qpid.tests.utils.BrokerAdminUsingTestBase;
-
-public class ProtocolTest extends BrokerAdminUsingTestBase
-{
-    private InetSocketAddress _brokerAddress;
-
-    @Before
-    public void setUp()
-    {
-        _brokerAddress = getBrokerAdmin().getBrokerAddress(BrokerAdmin.PortType.ANONYMOUS_AMQP);
-    }
-
-    @Test
-    @SpecificationTest(section = "4.2.2",
-            description = "If the server does not recognise the first 5 octets of data on the socket [...], it MUST "
-                          + "write a valid protocol header to the socket, [...] and then close the socket connection.")
-    public void unrecognisedProtocolHeader() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-            assumeThat(transport.getProtocolVersion(), is(equalTo(ProtocolVersion.v0_91)));
-
-            final Interaction interaction = transport.newInteraction();
-
-            byte[] unknownHeader = "NOTANAMQPHEADER".getBytes(StandardCharsets.UTF_8);
-            byte[] expectedResponse = "AMQP\000\000\011\001".getBytes(StandardCharsets.UTF_8);
-            final byte[] response = interaction.protocolHeader(unknownHeader)
-                                               .negotiateProtocol()
-                                               .consumeResponse().getLatestResponse(byte[].class);
-            assertArrayEquals("Unexpected protocol header response", expectedResponse, response);
-            transport.assertNoMoreResponsesAndChannelClosed();
-        }
-    }
-
-    @Test
-    @SpecificationTest(section = "4.2.2",
-            description = "If the server [...] does not support the specific protocol version that the client "
-                          + "requests, it MUST write a valid protocol header to the socket, [...] and then close "
-                          + "the socket connection.")
-    public void unrecognisedProtocolVersion() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-            assumeThat(transport.getProtocolVersion(), is(equalTo(ProtocolVersion.v0_91)));
-
-            final Interaction interaction = transport.newInteraction();
-
-            byte[] unknownAmqpVersion = "AMQP\000\000\010\002".getBytes(StandardCharsets.UTF_8);
-            byte[] expectedResponse = "AMQP\000\000\011\001".getBytes(StandardCharsets.UTF_8);
-            final byte[] response = interaction.protocolHeader(unknownAmqpVersion)
-                                               .negotiateProtocol()
-                                               .consumeResponse().getLatestResponse(byte[].class);
-            assertArrayEquals("Unexpected protocol header response", expectedResponse, response);
-            transport.assertNoMoreResponsesAndChannelClosed();
-        }
-    }
-
-    @Test
-    @SpecificationTest(section = "4.2.2", description = "The server either accepts [...] the protocol header")
-    public void validProtocolVersion() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-            final Interaction interaction = transport.newInteraction();
-
-            interaction.negotiateProtocol()
-                       .consumeResponse().getLatestResponse(ConnectionStartBody.class);
-
-        }
-    }
-
-    @Test
-    @SpecificationTest(section = "4.2.2",
-            description = "If a peer receives a frame with a type that is not one of these defined types, it MUST "
-                          + "treat this as a fatal protocol error and close the connection without sending any "
-                          + "further data on it")
-    public void unrecognisedFrameType() throws Exception
-    {
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-            final Interaction interaction = transport.newInteraction();
-
-            interaction.negotiateProtocol()
-                       .consumeResponse(ConnectionStartBody.class)
-                       .sendPerformative(new AMQBody()
-                       {
-                           @Override
-                           public byte getFrameType()
-                           {
-                               return (byte)5;  // Spec defines 1 - 4 only.
-                           }
-
-                           @Override
-                           public int getSize()
-                           {
-                               return 0;
-                           }
-
-                           @Override
-                           public long writePayload(final ByteBufferSender sender)
-                           {
-                               return 0;
-                           }
-
-                           @Override
-                           public void handle(final int channelId, final AMQVersionAwareProtocolSession session)
-                           {
-                               throw new UnsupportedOperationException();
-                           }
-                       }).sync();
-            transport.assertNoMoreResponsesAndChannelClosed();
-        }
-    }
-}
diff --git a/systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/extension/basic/MalformedMessageValidation.java b/systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/extension/basic/MalformedMessageValidation.java
deleted file mode 100644
index 6391081..0000000
--- a/systests/protocol-tests-amqp-0-8/src/test/java/org/apache/qpid/tests/protocol/v0_8/extension/basic/MalformedMessageValidation.java
+++ /dev/null
@@ -1,87 +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.tests.protocol.v0_8.extension.basic;
-
-import static org.apache.qpid.tests.utils.BrokerAdmin.KIND_BROKER_J;
-import static org.hamcrest.CoreMatchers.equalTo;
-import static org.hamcrest.CoreMatchers.is;
-import static org.hamcrest.MatcherAssert.assertThat;
-
-import java.net.InetSocketAddress;
-import java.nio.charset.StandardCharsets;
-
-import org.junit.Before;
-import org.junit.Test;
-
-import org.apache.qpid.server.bytebuffer.QpidByteBuffer;
-import org.apache.qpid.server.protocol.v0_8.FieldTable;
-import org.apache.qpid.server.protocol.v0_8.FieldTableFactory;
-import org.apache.qpid.server.protocol.v0_8.transport.ChannelOpenOkBody;
-import org.apache.qpid.server.protocol.v0_8.transport.ConnectionCloseBody;
-import org.apache.qpid.tests.protocol.v0_8.FrameTransport;
-import org.apache.qpid.tests.protocol.v0_8.Interaction;
-import org.apache.qpid.tests.utils.BrokerAdmin;
-import org.apache.qpid.tests.utils.BrokerAdminUsingTestBase;
-import org.apache.qpid.tests.utils.BrokerSpecific;
-import org.apache.qpid.tests.utils.ConfigItem;
-
-@BrokerSpecific(kind = KIND_BROKER_J)
-@ConfigItem(name = "qpid.connection.forceValidation", value = "true")
-public class MalformedMessageValidation extends BrokerAdminUsingTestBase
-{
-    private InetSocketAddress _brokerAddress;
-    private static final String CONTENT_TEXT = "Test";
-
-    @Before
-    public void setUp()
-    {
-        _brokerAddress = getBrokerAdmin().getBrokerAddress(BrokerAdmin.PortType.ANONYMOUS_AMQP);
-        getBrokerAdmin().createQueue(BrokerAdmin.TEST_QUEUE_NAME);
-    }
-
-    @Test
-    public void malformedHeaderValue() throws Exception
-    {
-        final FieldTable malformedHeader = createMalformedHeaders();
-        byte[] contentBytes = CONTENT_TEXT.getBytes(StandardCharsets.UTF_8);
-        try(FrameTransport transport = new FrameTransport(_brokerAddress).connect())
-        {
-            final Interaction interaction = transport.newInteraction();
-            interaction.openAnonymousConnection()
-                       .channel().open().consumeResponse(ChannelOpenOkBody.class)
-                       .basic().publishExchange("")
-                       .publishRoutingKey(BrokerAdmin.TEST_QUEUE_NAME)
-                       .contentHeaderPropertiesHeaders(malformedHeader)
-                       .content(contentBytes)
-                       .publishMessage()
-                       .consumeResponse(ConnectionCloseBody.class);
-        }
-        assertThat(getBrokerAdmin().getQueueDepthMessages(BrokerAdmin.TEST_QUEUE_NAME), is(equalTo(0)));
-    }
-
-    private static FieldTable createMalformedHeaders()
-    {
-        final QpidByteBuffer buf = QpidByteBuffer.allocate(1);
-        buf.put((byte) -1);
-        buf.flip();
-        return FieldTableFactory.createFieldTable(buf);
-    }
-}
diff --git a/systests/qpid-systests-http-management/src/main/resources/java_broker_keystore.jks b/systests/qpid-systests-http-management/src/main/resources/java_broker_keystore.jks
deleted file mode 100644
index b45991f..0000000
Binary files a/systests/qpid-systests-http-management/src/main/resources/java_broker_keystore.jks and /dev/null differ


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


[qpid-broker-j] 03/03: [maven-release-plugin] prepare release 7.0.8

Posted by or...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

orudyy pushed a commit to branch 7.0.x
in repository https://gitbox.apache.org/repos/asf/qpid-broker-j.git

commit 15268316699dd8c7ef0ff9740dbf8ce145f06593
Author: Alex Rudyy <or...@apache.org>
AuthorDate: Wed Jul 3 13:24:37 2019 +0100

    [maven-release-plugin] prepare release 7.0.8
---
 apache-qpid-broker-j/pom.xml                     | 2 +-
 bdbstore/pom.xml                                 | 2 +-
 bdbstore/systests/pom.xml                        | 2 +-
 broker-codegen/pom.xml                           | 2 +-
 broker-core/pom.xml                              | 2 +-
 broker-plugins/access-control/pom.xml            | 2 +-
 broker-plugins/amqp-0-10-protocol/pom.xml        | 2 +-
 broker-plugins/amqp-0-8-protocol/pom.xml         | 2 +-
 broker-plugins/amqp-1-0-bdb-store/pom.xml        | 2 +-
 broker-plugins/amqp-1-0-jdbc-store/pom.xml       | 2 +-
 broker-plugins/amqp-1-0-protocol/pom.xml         | 2 +-
 broker-plugins/amqp-msg-conv-0-10-to-1-0/pom.xml | 2 +-
 broker-plugins/amqp-msg-conv-0-8-to-0-10/pom.xml | 2 +-
 broker-plugins/amqp-msg-conv-0-8-to-1-0/pom.xml  | 2 +-
 broker-plugins/derby-store/pom.xml               | 2 +-
 broker-plugins/jdbc-provider-bone/pom.xml        | 2 +-
 broker-plugins/jdbc-store/pom.xml                | 2 +-
 broker-plugins/logging-logback/pom.xml           | 2 +-
 broker-plugins/management-amqp/pom.xml           | 2 +-
 broker-plugins/management-http/pom.xml           | 2 +-
 broker-plugins/memory-store/pom.xml              | 2 +-
 broker-plugins/websocket/pom.xml                 | 2 +-
 broker/pom.xml                                   | 2 +-
 doc/java-broker/pom.xml                          | 2 +-
 doc/java-perftests/pom.xml                       | 2 +-
 doc/pom.xml                                      | 2 +-
 joramtests/pom.xml                               | 2 +-
 perftests/pom.xml                                | 2 +-
 perftests/visualisation-jfc/pom.xml              | 2 +-
 pom.xml                                          | 4 ++--
 qpid-perftests-systests/pom.xml                  | 2 +-
 qpid-systests-parent/pom.xml                     | 4 ++--
 qpid-test-utils/pom.xml                          | 2 +-
 systests/end-to-end-conversion-tests/pom.xml     | 2 +-
 systests/pom.xml                                 | 2 +-
 systests/protocol-tests-amqp-1-0/pom.xml         | 2 +-
 systests/protocol-tests-core/pom.xml             | 2 +-
 systests/qpid-systests-jms_2.0/pom.xml           | 2 +-
 systests/systests-utils/pom.xml                  | 2 +-
 tck/pom.xml                                      | 2 +-
 tools/pom.xml                                    | 2 +-
 41 files changed, 43 insertions(+), 43 deletions(-)

diff --git a/apache-qpid-broker-j/pom.xml b/apache-qpid-broker-j/pom.xml
index e63d444..71de3b3 100644
--- a/apache-qpid-broker-j/pom.xml
+++ b/apache-qpid-broker-j/pom.xml
@@ -18,7 +18,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
 
diff --git a/bdbstore/pom.xml b/bdbstore/pom.xml
index e85dba5..d00a7b0 100644
--- a/bdbstore/pom.xml
+++ b/bdbstore/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-bdbstore</artifactId>
diff --git a/bdbstore/systests/pom.xml b/bdbstore/systests/pom.xml
index 0f6589d..e3b812a 100644
--- a/bdbstore/systests/pom.xml
+++ b/bdbstore/systests/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-systests-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../qpid-systests-parent/pom.xml</relativePath>
   </parent>
 
diff --git a/broker-codegen/pom.xml b/broker-codegen/pom.xml
index cd68068..4c0896b 100644
--- a/broker-codegen/pom.xml
+++ b/broker-codegen/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-broker-codegen</artifactId>
diff --git a/broker-core/pom.xml b/broker-core/pom.xml
index 3387998..7b92e3c 100644
--- a/broker-core/pom.xml
+++ b/broker-core/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-broker-core</artifactId>
diff --git a/broker-plugins/access-control/pom.xml b/broker-plugins/access-control/pom.xml
index beb724c..fc984d3 100644
--- a/broker-plugins/access-control/pom.xml
+++ b/broker-plugins/access-control/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/amqp-0-10-protocol/pom.xml b/broker-plugins/amqp-0-10-protocol/pom.xml
index 33260ac..c0ad6ae 100644
--- a/broker-plugins/amqp-0-10-protocol/pom.xml
+++ b/broker-plugins/amqp-0-10-protocol/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/amqp-0-8-protocol/pom.xml b/broker-plugins/amqp-0-8-protocol/pom.xml
index a8769fe..3a11845 100644
--- a/broker-plugins/amqp-0-8-protocol/pom.xml
+++ b/broker-plugins/amqp-0-8-protocol/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/amqp-1-0-bdb-store/pom.xml b/broker-plugins/amqp-1-0-bdb-store/pom.xml
index 564853b..ec874ce 100644
--- a/broker-plugins/amqp-1-0-bdb-store/pom.xml
+++ b/broker-plugins/amqp-1-0-bdb-store/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-broker-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../..</relativePath>
     </parent>
 
diff --git a/broker-plugins/amqp-1-0-jdbc-store/pom.xml b/broker-plugins/amqp-1-0-jdbc-store/pom.xml
index 9876c13..548940d 100644
--- a/broker-plugins/amqp-1-0-jdbc-store/pom.xml
+++ b/broker-plugins/amqp-1-0-jdbc-store/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-broker-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../..</relativePath>
     </parent>
 
diff --git a/broker-plugins/amqp-1-0-protocol/pom.xml b/broker-plugins/amqp-1-0-protocol/pom.xml
index 8bb1c3b..de8e42f 100644
--- a/broker-plugins/amqp-1-0-protocol/pom.xml
+++ b/broker-plugins/amqp-1-0-protocol/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/amqp-msg-conv-0-10-to-1-0/pom.xml b/broker-plugins/amqp-msg-conv-0-10-to-1-0/pom.xml
index 67872fe..b7e2b4e 100644
--- a/broker-plugins/amqp-msg-conv-0-10-to-1-0/pom.xml
+++ b/broker-plugins/amqp-msg-conv-0-10-to-1-0/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/amqp-msg-conv-0-8-to-0-10/pom.xml b/broker-plugins/amqp-msg-conv-0-8-to-0-10/pom.xml
index dbb30bc..d250158 100644
--- a/broker-plugins/amqp-msg-conv-0-8-to-0-10/pom.xml
+++ b/broker-plugins/amqp-msg-conv-0-8-to-0-10/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/amqp-msg-conv-0-8-to-1-0/pom.xml b/broker-plugins/amqp-msg-conv-0-8-to-1-0/pom.xml
index 426528b..632edd5 100644
--- a/broker-plugins/amqp-msg-conv-0-8-to-1-0/pom.xml
+++ b/broker-plugins/amqp-msg-conv-0-8-to-1-0/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/derby-store/pom.xml b/broker-plugins/derby-store/pom.xml
index ddfdbdc..7a5de0a 100644
--- a/broker-plugins/derby-store/pom.xml
+++ b/broker-plugins/derby-store/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/jdbc-provider-bone/pom.xml b/broker-plugins/jdbc-provider-bone/pom.xml
index f6bf5aa..656ac25 100644
--- a/broker-plugins/jdbc-provider-bone/pom.xml
+++ b/broker-plugins/jdbc-provider-bone/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/jdbc-store/pom.xml b/broker-plugins/jdbc-store/pom.xml
index dffe8f9..9045b39 100644
--- a/broker-plugins/jdbc-store/pom.xml
+++ b/broker-plugins/jdbc-store/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/logging-logback/pom.xml b/broker-plugins/logging-logback/pom.xml
index 47f6cfb..3bccc97 100644
--- a/broker-plugins/logging-logback/pom.xml
+++ b/broker-plugins/logging-logback/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/management-amqp/pom.xml b/broker-plugins/management-amqp/pom.xml
index 156363f..db3b495 100644
--- a/broker-plugins/management-amqp/pom.xml
+++ b/broker-plugins/management-amqp/pom.xml
@@ -21,7 +21,7 @@
     <parent>
         <artifactId>qpid-broker-parent</artifactId>
         <groupId>org.apache.qpid</groupId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../../pom.xml</relativePath>
     </parent>
 
diff --git a/broker-plugins/management-http/pom.xml b/broker-plugins/management-http/pom.xml
index 6290917..52dc051 100644
--- a/broker-plugins/management-http/pom.xml
+++ b/broker-plugins/management-http/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/memory-store/pom.xml b/broker-plugins/memory-store/pom.xml
index b884baf..fadede8 100644
--- a/broker-plugins/memory-store/pom.xml
+++ b/broker-plugins/memory-store/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/broker-plugins/websocket/pom.xml b/broker-plugins/websocket/pom.xml
index 332335d..5e775c0 100644
--- a/broker-plugins/websocket/pom.xml
+++ b/broker-plugins/websocket/pom.xml
@@ -21,7 +21,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-broker-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../../pom.xml</relativePath>
     </parent>
 
diff --git a/broker/pom.xml b/broker/pom.xml
index e66bf93..665398d 100644
--- a/broker/pom.xml
+++ b/broker/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-broker</artifactId>
diff --git a/doc/java-broker/pom.xml b/doc/java-broker/pom.xml
index 73039c3..a985778 100644
--- a/doc/java-broker/pom.xml
+++ b/doc/java-broker/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-java-doc</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
     </parent>
 
     <artifactId>qpid-java-doc-broker</artifactId>
diff --git a/doc/java-perftests/pom.xml b/doc/java-perftests/pom.xml
index 403095f..5457a2d 100644
--- a/doc/java-perftests/pom.xml
+++ b/doc/java-perftests/pom.xml
@@ -27,7 +27,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-java-doc</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
     </parent>
 
     <artifactId>qpid-java-doc-perftests</artifactId>
diff --git a/doc/pom.xml b/doc/pom.xml
index 4aa6224..3dfd61e 100644
--- a/doc/pom.xml
+++ b/doc/pom.xml
@@ -26,7 +26,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-broker-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
     </parent>
 
     <artifactId>qpid-java-doc</artifactId>
diff --git a/joramtests/pom.xml b/joramtests/pom.xml
index 77ee354..138f062 100644
--- a/joramtests/pom.xml
+++ b/joramtests/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>qpid-broker-parent</artifactId>
         <groupId>org.apache.qpid</groupId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
     </parent>
     <modelVersion>4.0.0</modelVersion>
 
diff --git a/perftests/pom.xml b/perftests/pom.xml
index d01b5d4..bc33696 100644
--- a/perftests/pom.xml
+++ b/perftests/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-perftests</artifactId>
diff --git a/perftests/visualisation-jfc/pom.xml b/perftests/visualisation-jfc/pom.xml
index e7f3c66..009c741 100644
--- a/perftests/visualisation-jfc/pom.xml
+++ b/perftests/visualisation-jfc/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../pom.xml</relativePath>
   </parent>
 
diff --git a/pom.xml b/pom.xml
index d759006..3118169 100644
--- a/pom.xml
+++ b/pom.xml
@@ -26,7 +26,7 @@
 
   <groupId>org.apache.qpid</groupId>
   <artifactId>qpid-broker-parent</artifactId>
-  <version>7.0.8-SNAPSHOT</version>
+  <version>7.0.8</version>
   <packaging>pom</packaging>
 
   <name>Apache Qpid Broker-J Parent</name>
@@ -65,7 +65,7 @@
     <connection>scm:git:https://gitbox.apache.org/repos/asf/qpid-broker-j.git</connection>
     <developerConnection>scm:git:https://gitbox.apache.org/repos/asf/qpid-broker-j.git</developerConnection>
     <url>https://gitbox.apache.org/repos/asf/qpid-broker-j.git</url>
-    <tag>7.0.x</tag>
+    <tag>7.0.8</tag>
   </scm>
 
   <distributionManagement>
diff --git a/qpid-perftests-systests/pom.xml b/qpid-perftests-systests/pom.xml
index a1ed412..701f2a1 100644
--- a/qpid-perftests-systests/pom.xml
+++ b/qpid-perftests-systests/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-systests-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../qpid-systests-parent/pom.xml</relativePath>
   </parent>
 
diff --git a/qpid-systests-parent/pom.xml b/qpid-systests-parent/pom.xml
index 2c5e32d..2d630f9 100644
--- a/qpid-systests-parent/pom.xml
+++ b/qpid-systests-parent/pom.xml
@@ -21,11 +21,11 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-systests-parent</artifactId>
-  <version>7.0.8-SNAPSHOT</version>
+  <version>7.0.8</version>
   <packaging>pom</packaging>
   <name>Apache Qpid Broker-J System Test Parent</name>
   <description>Parent POM for Qpid system testing modules</description>
diff --git a/qpid-test-utils/pom.xml b/qpid-test-utils/pom.xml
index 8d5ffc1..52d0889 100644
--- a/qpid-test-utils/pom.xml
+++ b/qpid-test-utils/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-test-utils</artifactId>
diff --git a/systests/end-to-end-conversion-tests/pom.xml b/systests/end-to-end-conversion-tests/pom.xml
index 7252d1a..ef063f1 100644
--- a/systests/end-to-end-conversion-tests/pom.xml
+++ b/systests/end-to-end-conversion-tests/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-systests-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../../qpid-systests-parent/pom.xml</relativePath>
     </parent>
 
diff --git a/systests/pom.xml b/systests/pom.xml
index 800ef4c..b5e8be1 100644
--- a/systests/pom.xml
+++ b/systests/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-systests-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../qpid-systests-parent/pom.xml</relativePath>
   </parent>
 
diff --git a/systests/protocol-tests-amqp-1-0/pom.xml b/systests/protocol-tests-amqp-1-0/pom.xml
index 8278cdc..f7ce3d5 100644
--- a/systests/protocol-tests-amqp-1-0/pom.xml
+++ b/systests/protocol-tests-amqp-1-0/pom.xml
@@ -19,7 +19,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-systests-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../../qpid-systests-parent/pom.xml</relativePath>
     </parent>
     <modelVersion>4.0.0</modelVersion>
diff --git a/systests/protocol-tests-core/pom.xml b/systests/protocol-tests-core/pom.xml
index 927d43c..8c8d52c 100644
--- a/systests/protocol-tests-core/pom.xml
+++ b/systests/protocol-tests-core/pom.xml
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-systests-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../../qpid-systests-parent/pom.xml</relativePath>
     </parent>
     <modelVersion>4.0.0</modelVersion>
diff --git a/systests/qpid-systests-jms_2.0/pom.xml b/systests/qpid-systests-jms_2.0/pom.xml
index adb911f..c2f874e 100644
--- a/systests/qpid-systests-jms_2.0/pom.xml
+++ b/systests/qpid-systests-jms_2.0/pom.xml
@@ -20,7 +20,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-systests-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
     <relativePath>../../qpid-systests-parent/pom.xml</relativePath>
   </parent>
 
diff --git a/systests/systests-utils/pom.xml b/systests/systests-utils/pom.xml
index 82a4cb4..a74fe1e 100644
--- a/systests/systests-utils/pom.xml
+++ b/systests/systests-utils/pom.xml
@@ -22,7 +22,7 @@
     <parent>
         <groupId>org.apache.qpid</groupId>
         <artifactId>qpid-systests-parent</artifactId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
         <relativePath>../../qpid-systests-parent/pom.xml</relativePath>
     </parent>
     <modelVersion>4.0.0</modelVersion>
diff --git a/tck/pom.xml b/tck/pom.xml
index b246aff..00885c8 100644
--- a/tck/pom.xml
+++ b/tck/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>qpid-broker-parent</artifactId>
         <groupId>org.apache.qpid</groupId>
-        <version>7.0.8-SNAPSHOT</version>
+        <version>7.0.8</version>
     </parent>
     <modelVersion>4.0.0</modelVersion>
 
diff --git a/tools/pom.xml b/tools/pom.xml
index f373ecb..8fe77ff 100644
--- a/tools/pom.xml
+++ b/tools/pom.xml
@@ -21,7 +21,7 @@
   <parent>
     <groupId>org.apache.qpid</groupId>
     <artifactId>qpid-broker-parent</artifactId>
-    <version>7.0.8-SNAPSHOT</version>
+    <version>7.0.8</version>
   </parent>
 
   <artifactId>qpid-tools</artifactId>


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