You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ta...@apache.org on 2015/10/08 18:52:46 UTC

[2/3] qpid-jms git commit: NO-JIRA Fix and update javadocs

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/PropertyUtil.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/PropertyUtil.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/PropertyUtil.java
index 1f061c4..35f1cf3 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/PropertyUtil.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/PropertyUtil.java
@@ -52,7 +52,7 @@ public class PropertyUtil {
      * @return a new URI that matches the original one but has its query options replaced with
      *         the given ones.
      *
-     * @throws URISyntaxException
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static URI replaceQuery(URI originalURI, Map<String, String> params) throws URISyntaxException {
         String s = createQueryString(params);
@@ -71,7 +71,8 @@ public class PropertyUtil {
      *        The new URI query string that should be appended to the given URI.
      *
      * @return a new URI that is a combination of the original URI and the given query string.
-     * @throws URISyntaxException
+     *
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static URI replaceQuery(URI uri, String query) throws URISyntaxException {
         String schemeSpecificPart = uri.getRawSchemeSpecificPart();
@@ -97,7 +98,8 @@ public class PropertyUtil {
      *        The source URI whose existing query is replaced with the newly supplied one.
      *
      * @return a new URI that is a combination of the original URI and the given query string.
-     * @throws URISyntaxException
+     *
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static URI eraseQuery(URI uri) throws URISyntaxException {
         return replaceQuery(uri, (String) null);
@@ -112,7 +114,7 @@ public class PropertyUtil {
      *
      * @return a URI formatted query string.
      *
-     * @throws URISyntaxException
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static String createQueryString(Map<String, ? extends Object> options) throws URISyntaxException {
         try {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/ThreadPoolUtils.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/ThreadPoolUtils.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/ThreadPoolUtils.java
index acf823d..47e1a56 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/ThreadPoolUtils.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/ThreadPoolUtils.java
@@ -36,6 +36,9 @@ public final class ThreadPoolUtils {
     /**
      * Shutdown the given executor service only (ie not graceful shutdown).
      *
+     * @param executorService
+     *        The ExecutorService that is being shutdown.
+     *
      * @see java.util.concurrent.ExecutorService#shutdown()
      */
     public static void shutdown(ExecutorService executorService) {
@@ -47,7 +50,9 @@ public final class ThreadPoolUtils {
      *
      * @param executorService
      *        the executor service to shutdown now
+     *
      * @return list of tasks that never commenced execution
+     *
      * @see java.util.concurrent.ExecutorService#shutdownNow()
      */
     public static List<Runnable> shutdownNow(ExecutorService executorService) {
@@ -77,6 +82,9 @@ public final class ThreadPoolUtils {
      * This implementation invokes the
      * {@link #shutdownGraceful(java.util.concurrent.ExecutorService, long)} with a timeout
      * value of {@link #DEFAULT_SHUTDOWN_AWAIT_TERMINATION} millis.
+     *
+     * @param executorService
+     *        The ExecutorService that is being shutdown.
      */
     public static void shutdownGraceful(ExecutorService executorService) {
         doShutdown(executorService, DEFAULT_SHUTDOWN_AWAIT_TERMINATION);

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/URISupport.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/URISupport.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/URISupport.java
index 1335398..959f4f0 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/URISupport.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/URISupport.java
@@ -110,7 +110,8 @@ public class URISupport {
      *        The target URI that should be parsed.
      *
      * @return a new CompsiteData instance representing the parsed composite URI.
-     * @throws URISyntaxException
+     *
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static CompositeData parseComposite(URI uri) throws URISyntaxException {
 
@@ -336,7 +337,8 @@ public class URISupport {
      *        The URI whose query value is to be removed.
      *
      * @return a new URI that does not contain a query value.
-     * @throws URISyntaxException
+     *
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static URI removeQuery(URI uri) throws URISyntaxException {
         return PropertyUtil.replaceQuery(uri, (String) null);
@@ -353,7 +355,8 @@ public class URISupport {
      *        The URI whose query should be extracted and processed.
      *
      * @return A Mapping of the URI options.
-     * @throws URISyntaxException
+     *
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static Map<String, String> parseParameters(URI uri) throws URISyntaxException {
         if (!isCompositeURI(uri)) {
@@ -389,7 +392,8 @@ public class URISupport {
      *        The Key / Value mapping that will be transformed into a URI query string.
      *
      * @return A new URI value that combines the given URI and the constructed query string.
-     * @throws URISyntaxException
+     *
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static URI applyParameters(URI uri, Map<String, String> queryParameters) throws URISyntaxException {
         return applyParameters(uri, queryParameters, "");
@@ -410,7 +414,8 @@ public class URISupport {
      *        key.
      *
      * @return A new URI value that combines the given URI and the constructed query string.
-     * @throws URISyntaxException
+     *
+     * @throws URISyntaxException if the given URI is invalid.
      */
     public static URI applyParameters(URI uri, Map<String, String> queryParameters, String optionPrefix) throws URISyntaxException {
         if (queryParameters != null && !queryParameters.isEmpty()) {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsConnectionFactoryTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsConnectionFactoryTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsConnectionFactoryTest.java
index 75317cb..5238933 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsConnectionFactoryTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsConnectionFactoryTest.java
@@ -319,6 +319,8 @@ public class JmsConnectionFactoryTest extends QpidJmsTestCase {
      * The prefetch policy is maintained in a child-object, which we extract the properties from
      * when serializing the factory. Ensure this functions by doing a round trip on a factory
      * configured with some new prefetch configuration via the URI.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSerializeThenDeserializeMaintainsPrefetchPolicy() throws Exception {
@@ -348,6 +350,8 @@ public class JmsConnectionFactoryTest extends QpidJmsTestCase {
      * The redelivery policy is maintained in a child-object, which we extract the properties from
      * when serializing the factory. Ensure this functions by doing a round trip on a factory
      * configured with some new redelivery configuration via the URI.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSerializeThenDeserializeMaintainsRedeliveryPolicy() throws Exception {
@@ -405,6 +409,8 @@ public class JmsConnectionFactoryTest extends QpidJmsTestCase {
     /**
      * Verify that the 'global' exception listener set on the connection factory
      * is ignored when the factory gets serialized.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSerializeThenDeserializeIgnoresGlobalExceptionListener() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsQueueConnectionTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsQueueConnectionTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsQueueConnectionTest.java
index 64a2b08..a218ce2 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsQueueConnectionTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/JmsQueueConnectionTest.java
@@ -61,9 +61,11 @@ public class JmsQueueConnectionTest extends JmsConnectionTestSupport {
      * (see JMS 1.1 specs, table 4-1).
      *
      * @since JMS 1.1
+     *
+     * @throws JMSException if an error occurs during the test.
      */
     @Test(timeout = 30000, expected=IllegalStateException.class)
-    public void testCreateDurableConnectionConsumerOnQueueConnection() throws JMSException{
+    public void testCreateDurableConnectionConsumerOnQueueConnection() throws JMSException {
         queueConnection.createDurableConnectionConsumer(new JmsTopic(), "subscriptionName", "", (ServerSessionPool)null, 1);
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/BytesMessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/BytesMessageIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/BytesMessageIntegrationTest.java
index aa62f50..5df5e93 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/BytesMessageIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/BytesMessageIntegrationTest.java
@@ -157,6 +157,8 @@ public class BytesMessageIntegrationTest extends QpidJmsTestCase {
      * gives the expected data values when read, and when reset and left mid-stream before being
      * resent that it results in the expected AMQP data body section and properties content type
      * being received by the test peer.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceiveBytesMessageAndResendAfterResetAndPartialRead() throws Exception {
@@ -265,6 +267,8 @@ public class BytesMessageIntegrationTest extends QpidJmsTestCase {
      * expected data values when read, and when sent to the test peer it results in an
      * AMQP message containing a data body section and content type of
      * {@link AmqpMessageSupport#OCTET_STREAM_CONTENT_TYPE}
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceiveBytesMessageWithAmqpValueAndResendResultsInData() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ConsumerIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ConsumerIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ConsumerIntegrationTest.java
index 3df5b3a..e4d1869 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ConsumerIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ConsumerIntegrationTest.java
@@ -135,6 +135,8 @@ public class ConsumerIntegrationTest extends QpidJmsTestCase {
     /**
      * Test that a message is received when calling receive with a timeout
      * of 0, which means wait indefinitely.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceiveMessageWithReceiveZeroTimeout() throws Exception {
@@ -164,6 +166,8 @@ public class ConsumerIntegrationTest extends QpidJmsTestCase {
 
     /**
      * Test that an Ack is not dropped when RTE is thrown from onMessage
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testRuntimeExceptionInOnMessageReleasesInAutoAckMode() throws Exception {
@@ -197,6 +201,8 @@ public class ConsumerIntegrationTest extends QpidJmsTestCase {
 
     /**
      * Test that an Ack is not dropped when RTE is thrown from onMessage
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testRuntimeExceptionInOnMessageReleasesInDupsOkAckMode() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ForeignMessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ForeignMessageIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ForeignMessageIntegrationTest.java
index 3543fc3..41e069a 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ForeignMessageIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ForeignMessageIntegrationTest.java
@@ -19,8 +19,8 @@
 package org.apache.qpid.jms.integration;
 
 import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.nullValue;
 import static org.hamcrest.Matchers.notNullValue;
+import static org.hamcrest.Matchers.nullValue;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.assertNull;
@@ -117,6 +117,8 @@ public class ForeignMessageIntegrationTest extends QpidJmsTestCase {
      * Test that after sending a message with the disableMessageID hint set, which already had
      * a JMSMessageID value, that the message object then has a null JMSMessageID value, and no
      * message-id field value was set.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendForeignMessageWithDisableMessageIDHintAndExistingMessageID() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MapMessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MapMessageIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MapMessageIntegrationTest.java
index 0ac384c..8141751 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MapMessageIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MapMessageIntegrationTest.java
@@ -57,6 +57,8 @@ public class MapMessageIntegrationTest extends QpidJmsTestCase {
      * Test that a message received from the test peer with an AmqpValue section containing
      * a map which holds entries of the various supported entry types is returned as a
      * {@link MapMessage}, and verify the values can all be retrieved as expected.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceiveBasicMapMessage() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
index bd991c1..101a637 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/MessageIntegrationTest.java
@@ -332,6 +332,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the lack of a 'to' in the Properties section of the incoming message (e.g
      * one sent by a non-JMS client) is handled by making the JMSDestination method simply
      * return the Queue Destination used to create the consumer that received the message.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromQueueWithoutToResultsInUseOfConsumerDestinationQueue() throws Exception {
@@ -342,6 +344,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the lack of a 'to' in the Properties section of the incoming message (e.g
      * one sent by a non-JMS client) is handled by making the JMSDestination method simply
      * return the Topic Destination used to create the consumer that received the message.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromQueueWithoutToResultsInUseOfConsumerDestinationTopic() throws Exception {
@@ -397,6 +401,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that lack of the reply-to set on a message results in it returning null for JMSReplyTo
      * and not the consumer destination as happens for JMSDestination.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromQueueWithNoReplyToReturnsNull() throws Exception {
@@ -432,6 +438,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with a 'topic prefix' set on it strips the
      * prefix from the content of the to/reply-to fields for incoming messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithTopicDestinationsOnConnectionWithTopicPrefix() throws Exception {
@@ -455,6 +463,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the a connection with a 'topic prefix' set on it strips the
      * prefix from the content of the to/reply-to fields for incoming messages
      * if they don't have the 'destination type annotation' set.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithNoTypeAnnotationAndTopicDestinationsOnConnectionWithTopicPrefix() throws Exception {
@@ -477,6 +487,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with a 'queue prefix' set on it strips the
      * prefix from the content of the to/reply-to fields for incoming messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithQueueDestinationsOnConnectionWithQueuePrefix() throws Exception {
@@ -500,6 +512,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the a connection with a 'queue prefix' set on it strips the
      * prefix from the content of the to/reply-to fields for incoming messages
      * if they don't have the 'destination type annotation' set.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithNoTypeAnnotationAndQueueDestinationsOnConnectionWithQueuePrefix() throws Exception {
@@ -522,6 +536,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that a connection with a 'prefixes' set on its does not alter the
      * address for a temporary queue in the to/reply-to fields for incoming messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithTemporaryQueueDestinationsOnConnectionWithPrefixes() throws Exception {
@@ -544,6 +560,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that a connection with a 'prefixes' set on its does not alter the
      * address for a temporary queue in the to/reply-to fields for incoming messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithTemporaryTopicDestinationsOnConnectionWithPrefixes() throws Exception {
@@ -671,6 +689,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with a 'topic prefix' set on it adds the
      * prefix to the content of the to/reply-to fields for outgoing messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendMessageWithTopicDestinationsOnConnectionWithTopicPrefix() throws Exception {
@@ -686,6 +706,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with a 'queue prefix' set on it adds the
      * prefix to the content of the to/reply-to fields for outgoing messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendMessageWithQueueDestinationsOnConnectionWithQueuePrefix() throws Exception {
@@ -701,6 +723,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with 'destination prefixes' set on it does not add
      * the prefix to the content of the to/reply-to fields for TemporaryQueues.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendMessageWithTemporaryQueueDestinationsOnConnectionWithDestinationPrefixes() throws Exception {
@@ -716,6 +740,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with 'destination prefixes' set on it does not add
      * the prefix to the content of the to/reply-to fields for TemporaryTopics.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendMessageWithTemporaryTopicDestinationsOnConnectionWithDestinationPrefixes() throws Exception {
@@ -807,6 +833,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that a connection with 'prefixes' set on it via broker-provided connection properties
      * strips the prefix from the to/reply-to fields for incoming messages with Topic destinations.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithTopicDestinationsOnConnectionWithBrokerDefinedPrefixProperties() throws Exception {
@@ -829,6 +857,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that a connection with 'prefixes' set on it via broker-provided connection properties
      * strips the prefix from the to/reply-to fields for incoming messages with Queue destinations.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithQueueDestinationsOnConnectionWithBrokerDefinedPrefixProperties() throws Exception {
@@ -936,6 +966,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with a 'queue prefix' set on it via broker-provided connection
      * properties adds the prefix to the content of the to/reply-to fields for outgoing messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendMessageWithQueueDestinationsOnConnectionWithBrokerDefinedPrefixProperties() throws Exception {
@@ -951,6 +983,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the a connection with a 'topic prefix' set on it via broker-provided connection
      * properties adds the prefix to the content of the to/reply-to fields for outgoing messages.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendMessageWithTopicDestinationsOnConnectionWithBrokerDefinedPrefixProperties() throws Exception {
@@ -1033,6 +1067,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * or {@link AmqpMessageSupport#LEGACY_REPLY_TO_TYPE_MSG_ANNOTATION_SYMBOL_NAME}) set
      * on a message to indicate type of its 'reply-to' address results in it
      * being classed as the same type as the consumer destination.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromTopicWithReplyToWithoutTypeAnnotationResultsInUseOfConsumerDestinationType() throws Exception {
@@ -1074,6 +1110,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the {@link AmqpDestinationHelper#JMS_DEST_TYPE_MSG_ANNOTATION_SYMBOL_NAME} is set as a byte on
      * a sent message to indicate its 'to' address represents a Topic JMSDestination.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSentMessageContainsToTypeAnnotationByte() throws Exception {
@@ -1111,6 +1149,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that the {@link AmqpDestinationHelper#JMS_REPLY_TO_TYPE_MSG_ANNOTATION_SYMBOL_NAME} is set as a byte on
      * a sent message to indicate its 'reply-to' address represents a Topic JMSDestination.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSentMessageContainsReplyToTypeAnnotationByte() throws Exception {
@@ -1156,6 +1196,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the {@link AmqpMessageSupport#LEGACY_TO_TYPE_MSG_ANNOTATION_SYMBOL_NAME} set on a message to
      * indicate its 'to' address represents a Topic results in the JMSDestination object being a
      * Topic. Ensure the consumers destination is not used by consuming from a Queue.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromQueueWithToLegacyTypeAnnotationForTopic() throws Exception {
@@ -1198,6 +1240,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that the {@link AmqpMessageSupport#LEGACY_REPLY_TO_TYPE_MSG_ANNOTATION_SYMBOL_NAME} set on a message to
      * indicate its 'reply-to' address represents a Topic results in the JMSReplyTo object being a
      * Topic. Ensure the consumers destination is not used by consuming from a Queue.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromQueueWithLegacyReplyToTypeAnnotationForTopic() throws Exception {
@@ -1241,6 +1285,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that lack of the absolute-expiry-time and ttl fields on a message results
      * in it returning 0 for for JMSExpiration
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromQueueWithNoAbsoluteExpiryOrTtlReturnsJMSExpirationZero() throws Exception {
@@ -1274,6 +1320,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that setting a non-zero value in the absolute-expiry-time field on a
      * message results in it returning this value for JMSExpiration
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageFromQueueWithAbsoluteExpiryReturnsJMSExpirationNonZero() throws Exception {
@@ -1339,6 +1387,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that receiving a message with a string typed message-id results in returning the
      * expected value for JMSMessageId where the JMS "ID:" prefix has been added.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithStringMessageIdReturnsExpectedJMSMessageID() throws Exception {
@@ -1348,6 +1398,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that receiving a message with a UUID typed message-id results in returning the
      * expected value for JMSMessageId where the JMS "ID:" prefix has been added to the UUID.tostring()
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithUUIDMessageIdReturnsExpectedJMSMessageID() throws Exception {
@@ -1357,6 +1409,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that receiving a message with a ulong typed message-id results in returning the
      * expected value for JMSMessageId where the JMS "ID:" prefix has been added to the UnsignedLong.tostring()
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithUnsignedLongMessageIdReturnsExpectedJMSMessageID() throws Exception {
@@ -1366,6 +1420,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that receiving a message with a binary typed message-id results in returning the
      * expected value for JMSMessageId where the JMS "ID:" prefix has been added to the hex representation of the binary.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithBinaryMessageIdReturnsExpectedJMSMessageID() throws Exception {
@@ -1405,6 +1461,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that receiving a message with a string typed correlation-id results in returning the
      * expected value for JMSCorrelationID where the JMS "ID:" prefix has been added.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithStringCorrelationIdReturnsExpectedJMSCorrelationID() throws Exception {
@@ -1415,6 +1473,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that receiving a message with a string typed correlation-id, which is indicated to be an
      * application-specific value, results in returning the expected value for JMSCorrelationID
      * where the JMS "ID:" prefix has NOT been added.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithAppSpecificStringCorrelationIdReturnsExpectedJMSCorrelationID() throws Exception {
@@ -1424,6 +1484,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that receiving a message with a UUID typed correlation-id results in returning the
      * expected value for JMSCorrelationID where the JMS "ID:" prefix has been added to the UUID.tostring()
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithUUIDCorrelationIdReturnsExpectedJMSCorrelationID() throws Exception {
@@ -1433,6 +1495,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
     /**
      * Tests that receiving a message with a UUID typed correlation-id results in returning the
      * expected value for JMSCorrelationID where the JMS "ID:" prefix has been added to the UUID.tostring()
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithLongCorrelationIdReturnsExpectedJMSCorrelationID() throws Exception {
@@ -1484,6 +1548,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * message-id results in an AMQP message with the expected encoding of the correlation-id,
      * where the type is uuid, the "ID:" prefix of the JMSCorrelationID value is (obviously) not present, and there is
      * no presence of the message annotation to indicate an app-specific correlation-id.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSentMessageWithUUIDCorrelationId() throws Exception {
@@ -1497,6 +1563,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * message-id results in an AMQP message with the expected encoding of the correlation-id,
      * where the type is binary, the "ID:" prefix of the JMSCorrelationID value is (obviously) not present, and there is
      * no presence of the message annotation to indicate an app-specific correlation-id.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSentMessageWithBinaryCorrelationId() throws Exception
@@ -1511,6 +1579,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * message-id results in an AMQP message with the expected encoding of the correlation-id,
      * where the type is ulong, the "ID:" prefix of the JMSCorrelationID value is (obviously) not present, and there is
      * no presence of the message annotation to indicate an app-specific correlation-id.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSentMessageWithUlongCorrelationId() throws Exception {
@@ -1524,6 +1594,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * message-id results in an AMQP message with the expected encoding of the correlation-id,
      * where the "ID:" prefix of the JMSCorrelationID value is not present, and there is
      * no presence of the message annotation to indicate an app-specific correlation-id.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSentMessageWithStringCorrelationId() throws Exception {
@@ -1536,6 +1608,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that sending a message with a string typed correlation-id value which is a
      * app-specific results in an AMQP message with the expected encoding of the correlation-id,
      * and the presence of the message annotation to indicate an app-specific correlation-id.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSentMessageWithAppSpecificStringCorrelationId() throws Exception {
@@ -1590,6 +1664,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that receiving a message with a string typed message-id, and then sending a message which
      * uses the result of calling getJMSMessageID as the value for setJMSCorrelationId results in
      * transmission of the expected AMQP message content.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithStringMessageIdAndSendValueAsCorrelationId() throws Exception {
@@ -1600,6 +1676,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that receiving a message with a UUID typed message-id, and then sending a message which
      * uses the result of calling getJMSMessageID as the value for setJMSCorrelationId results in
      * transmission of the expected AMQP message content.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithUUIDMessageIdAndSendValueAsCorrelationId() throws Exception {
@@ -1610,6 +1688,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that receiving a message with a ulong typed message-id, and then sending a message which
      * uses the result of calling getJMSMessageID as the value for setJMSCorrelationId results in
      * transmission of the expected AMQP message content.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithUlongMessageIdAndSendValueAsCorrelationId() throws Exception {
@@ -1620,6 +1700,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that receiving a message with a binary typed message-id, and then sending a message which
      * uses the result of calling getJMSMessageID as the value for setJMSCorrelationId results in
      * transmission of the expected AMQP message content.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithBinaryMessageIdAndSendValueAsCorrelationId() throws Exception {
@@ -1691,6 +1773,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that when receiving a message with the group-id, reply-to-group-id, and group-sequence
      * fields of the AMQP properties section set, that the expected JMSX or JMS_AMQP properties
      * are present, and the expected values are returned when retrieved from the JMS message.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceivedMessageWithGroupRelatedPropertiesSet() throws Exception {
@@ -1766,6 +1850,8 @@ public class MessageIntegrationTest extends QpidJmsTestCase
      * Tests that when sending a message with the JMSXGroupID, JMSXGroupSeq, and JMS_AMQP_REPLY_TO_GROUP_ID
      * properties of the JMS message set, that the expected values are included in the fields of
      * the AMQP message emitted.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendMessageWithGroupRelatedPropertiesSet() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ProducerIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ProducerIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ProducerIntegrationTest.java
index 1cc54b3..2dd723b 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ProducerIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/ProducerIntegrationTest.java
@@ -194,6 +194,8 @@ public class ProducerIntegrationTest extends QpidJmsTestCase {
     /**
      * Test that when a message is sent the JMSDestination header is set to
      * the Destination used by the producer.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendingMessageSetsJMSDestination() throws Exception {
@@ -273,6 +275,8 @@ public class ProducerIntegrationTest extends QpidJmsTestCase {
     /**
      * Test that after sending a message with the disableMessageTimestamp hint set, the
      * message object has a 0 JMSTimestamp value, and no creation-time field value was set.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendingMessageWithDisableMessageTimestampHint() throws Exception {
@@ -415,6 +419,8 @@ public class ProducerIntegrationTest extends QpidJmsTestCase {
     /**
      * Test that when a message is sent with default priority of 4, the emitted AMQP message has no value in the header
      * priority field, since the default for that field is already 4.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testDefaultPriorityProducesMessagesWithoutPriorityField() throws Exception {
@@ -451,6 +457,8 @@ public class ProducerIntegrationTest extends QpidJmsTestCase {
     /**
      * Test that when a message is sent with a non-default priority, the emitted AMQP message has that value in the
      * header priority field, and the JMS message has had JMSPriority set.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testNonDefaultPriorityProducesMessagesWithPriorityFieldAndSetsJMSPriority() throws Exception {
@@ -489,6 +497,8 @@ public class ProducerIntegrationTest extends QpidJmsTestCase {
     /**
      * Test that upon sending a message, the sender sets the JMSMessageID on the Message object,
      * and that the value is included in the AMQP message sent by the client.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendingMessageSetsJMSMessageID() throws Exception {
@@ -635,6 +645,8 @@ public class ProducerIntegrationTest extends QpidJmsTestCase {
     /**
      * Test that after sending a message with the disableMessageID hint set, the message
      * object has a null JMSMessageID value, and no message-id field value was set.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendingMessageWithDisableMessageIDHint() throws Exception {
@@ -645,6 +657,8 @@ public class ProducerIntegrationTest extends QpidJmsTestCase {
      * Test that after sending a message with the disableMessageID hint set, which already had
      * a JMSMessageID value, that the message object then has a null JMSMessageID value, and no
      * message-id field value was set.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testSendingMessageWithDisableMessageIDHintAndExistingMessageID() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SaslIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SaslIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SaslIntegrationTest.java
index c41416b..c51b8f3 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SaslIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/SaslIntegrationTest.java
@@ -134,6 +134,8 @@ public class SaslIntegrationTest extends QpidJmsTestCase {
     /**
      * Add a small delay after the SASL process fails, test peer will throw if
      * any unexpected frames arrive, such as erroneous open+close.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testWaitForUnexpectedFramesAfterSaslFailure() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/StreamMessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/StreamMessageIntegrationTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/StreamMessageIntegrationTest.java
index ef1c89d..2ac37ac 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/StreamMessageIntegrationTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/integration/StreamMessageIntegrationTest.java
@@ -57,6 +57,8 @@ public class StreamMessageIntegrationTest extends QpidJmsTestCase {
      * Test that a message received from the test peer with an AmqpValue section containing
      * a list which holds entries of the various supported entry types is returned as a
      * {@link StreamMessage}, and verify the values can all be retrieved as expected.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(timeout = 20000)
     public void testReceiveBasicMapMessage() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsBytesMessageTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsBytesMessageTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsBytesMessageTest.java
index df71e28..b2aa7b2 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsBytesMessageTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsBytesMessageTest.java
@@ -58,6 +58,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that calling {@link BytesMessage#getBodyLength()} on a new message which has been
      * populated and {@link BytesMessage#reset()} causes the length to be reported correctly.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testResetOnNewlyPopulatedBytesMessageUpdatesBodyLength() throws Exception {
@@ -71,6 +73,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that attempting to call {@link BytesMessage#getBodyLength()} on a new message causes
      * a {@link MessageNotReadableException} to be thrown due to being write-only.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected = MessageNotReadableException.class)
     public void testGetBodyLengthOnNewMessageThrowsMessageNotReadableException() throws Exception {
@@ -109,6 +113,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that attempting to write bytes to a received message (without calling {@link BytesMessage#clearBody()} first)
      * causes a {@link MessageNotWriteableException} to be thrown due to being read-only.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected = MessageNotWriteableException.class)
     public void testReceivedBytesMessageThrowsMessageNotWriteableExceptionOnWriteBytes() throws Exception {
@@ -123,6 +129,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that attempting to read bytes from a new message (without calling {@link BytesMessage#reset()} first) causes a
      * {@link MessageNotReadableException} to be thrown due to being write-only.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected = MessageNotReadableException.class)
     public void testNewBytesMessageThrowsMessageNotReadableOnReadBytes() throws Exception {
@@ -134,6 +142,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that calling {@link BytesMessage#clearBody()} causes a received
      * message to become writable
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testClearBodyOnReceivedBytesMessageMakesMessageWritable() throws Exception {
@@ -150,6 +160,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that calling {@link BytesMessage#clearBody()} of a received message
      * causes the facade input stream to be empty and body length to return 0.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testClearBodyOnReceivedBytesMessageClearsFacadeInputStream() throws Exception {
@@ -169,6 +181,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that attempting to call {@link BytesMessage#getBodyLength()} on a received message after calling
      * {@link BytesMessage#clearBody()} causes {@link MessageNotReadableException} to be thrown due to being write-only.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testGetBodyLengthOnClearedReceivedMessageThrowsMessageNotReadableException() throws Exception {
@@ -191,6 +205,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that calling {@link BytesMessage#reset()} causes a write-only
      * message to become read-only
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testResetOnReceivedBytesMessageResetsMarker() throws Exception {
@@ -217,6 +233,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that calling {@link BytesMessage#reset()} on a new message which has been populated
      * causes the marker to be reset and makes the message read-only
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testResetOnNewlyPopulatedBytesMessageResetsMarkerAndMakesReadable() throws Exception {
@@ -239,6 +257,8 @@ public class JmsBytesMessageTest {
     /**
      * Verify that nothing is read when {@link BytesMessage#readBytes(byte[])} is
      * called with a zero length destination array.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testReadBytesWithZeroLengthDestination() throws Exception {
@@ -250,6 +270,8 @@ public class JmsBytesMessageTest {
     /**
      * Verify that when {@link BytesMessage#readBytes(byte[], int)} is called
      * with a negative length that an {@link IndexOutOfBoundsException} is thrown.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected=IndexOutOfBoundsException.class)
     public void testReadBytesWithNegativeLengthThrowsIOOBE() throws Exception
@@ -263,6 +285,8 @@ public class JmsBytesMessageTest {
      * Verify that when {@link BytesMessage#readBytes(byte[], int)} is called
      * with a length that is greater than the size of the provided array,
      * an {@link IndexOutOfBoundsException} is thrown.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected=IndexOutOfBoundsException.class)
     public void testReadBytesWithLengthGreatThanArraySizeThrowsIOOBE() throws Exception {
@@ -274,6 +298,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that writing a null using {@link BytesMessage#writeObject(Object)}
      * results in a NPE being thrown.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected=NullPointerException.class)
     public void testWriteObjectWithNullThrowsNPE() throws Exception {
@@ -284,6 +310,8 @@ public class JmsBytesMessageTest {
     /**
      * Test that writing a null using {@link BytesMessage#writeObject(Object)}
      * results in an {@link MessageFormatException} being thrown.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected=MessageFormatException.class)
     public void testWriteObjectWithIllegalTypeThrowsMFE() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMapMessageTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMapMessageTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMapMessageTest.java
index bbfc983..58a0ee9 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMapMessageTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMapMessageTest.java
@@ -63,6 +63,8 @@ public class JmsMapMessageTest {
     /**
      * Test that we are able to retrieve the names and values of map entries on a received
      * message
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testGetMapNamesUsingReceivedMessageReturnsExpectedEnumeration() throws Exception {
@@ -89,6 +91,8 @@ public class JmsMapMessageTest {
     /**
      * Test that we enforce the requirement that map message key names not be null or the empty
      * string.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetObjectWithNullOrEmptyKeyNameThrowsIAE() throws Exception {
@@ -111,6 +115,8 @@ public class JmsMapMessageTest {
     /**
      * Test that we are not able to write to a received message without calling
      * {@link JmsMapMessage#clearBody()}
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testReceivedMessageIsReadOnlyAndThrowsMNWE() throws Exception {
@@ -130,6 +136,8 @@ public class JmsMapMessageTest {
 
     /**
      * Test that calling {@link JmsMapMessage#clearBody()} makes a received message writable
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testClearBodyMakesReceivedMessageWritable() throws Exception {
@@ -149,6 +157,8 @@ public class JmsMapMessageTest {
     /**
      * Test that calling {@link JmsMapMessage#clearBody()} clears the underlying message body
      * map.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testClearBodyClearsUnderlyingMessageMap() throws Exception {
@@ -169,6 +179,8 @@ public class JmsMapMessageTest {
      * fashion as <primitive>.valueOf(String).
      *
      * Test that this is the case.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testGetMissingMapEntryResultsInExpectedBehaviour() throws Exception {
@@ -201,6 +213,8 @@ public class JmsMapMessageTest {
     /**
      * Test that the {@link JmsMapMessage#setObject(String, Object)} method rejects Objects of
      * unexpected types
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected=MessageFormatException.class)
     public void testSetObjectWithIllegalTypeThrowsMFE() throws Exception {
@@ -288,6 +302,8 @@ public class JmsMapMessageTest {
     /**
      * Set a String, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetStringGetLegal() throws Exception {
@@ -335,6 +351,8 @@ public class JmsMapMessageTest {
     /**
      * Set a String, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetStringGetIllegal() throws Exception {
@@ -354,6 +372,8 @@ public class JmsMapMessageTest {
     /**
      * Set a boolean, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetBooleanGetLegal() throws Exception {
@@ -376,6 +396,8 @@ public class JmsMapMessageTest {
     /**
      * Set a boolean, then retrieve it as all of the illegal type combinations to verify it
      * fails as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetBooleanGetIllegal() throws Exception {
@@ -401,6 +423,8 @@ public class JmsMapMessageTest {
     /**
      * Set a byte, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetByteGetLegalProperty() throws Exception {
@@ -421,6 +445,8 @@ public class JmsMapMessageTest {
     /**
      * Set a byte, then retrieve it as all of the illegal type combinations to verify it is
      * fails as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetByteGetIllegal() throws Exception {
@@ -443,6 +469,8 @@ public class JmsMapMessageTest {
     /**
      * Set a short, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetShortGetLegal() throws Exception {
@@ -462,6 +490,8 @@ public class JmsMapMessageTest {
     /**
      * Set a short, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetShortGetIllegal() throws Exception {
@@ -485,6 +515,8 @@ public class JmsMapMessageTest {
     /**
      * Set an int, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetIntGetLegal() throws Exception {
@@ -503,6 +535,8 @@ public class JmsMapMessageTest {
     /**
      * Set an int, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetIntGetIllegal() throws Exception {
@@ -527,6 +561,8 @@ public class JmsMapMessageTest {
     /**
      * Set a long, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetLongGetLegal() throws Exception {
@@ -544,6 +580,8 @@ public class JmsMapMessageTest {
     /**
      * Set an long, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetLongGetIllegal() throws Exception {
@@ -569,6 +607,8 @@ public class JmsMapMessageTest {
     /**
      * Set a float, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetFloatGetLegal() throws Exception {
@@ -587,6 +627,8 @@ public class JmsMapMessageTest {
     /**
      * Set a float, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetFloatGetIllegal() throws Exception {
@@ -611,6 +653,8 @@ public class JmsMapMessageTest {
     /**
      * Set a double, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetDoubleGetLegal() throws Exception {
@@ -628,6 +672,8 @@ public class JmsMapMessageTest {
     /**
      * Set a double, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetDoubleGetIllegal() throws Exception {
@@ -653,6 +699,8 @@ public class JmsMapMessageTest {
     /**
      * Set a char, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetCharGetLegal() throws Exception {
@@ -670,6 +718,8 @@ public class JmsMapMessageTest {
     /**
      * Set a char, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetCharGetIllegal() throws Exception {
@@ -695,6 +745,8 @@ public class JmsMapMessageTest {
     /**
      * Set bytes, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetBytesGetLegal() throws Exception {
@@ -710,6 +762,8 @@ public class JmsMapMessageTest {
     /**
      * Set bytes, then retrieve it as all of the illegal type combinations to verify it fails as
      * expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetBytesGetIllegal() throws Exception {
@@ -773,6 +827,8 @@ public class JmsMapMessageTest {
     /**
      * Verify that setting bytes takes a copy of the array. Set bytes, then modify them, then
      * retrieve the map entry and verify the two differ.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetBytesTakesSnapshot() throws Exception {
@@ -797,6 +853,8 @@ public class JmsMapMessageTest {
     /**
      * Verify that getting bytes returns a copy of the array. Set bytes, then get them, modify
      * the retrieved value, then get them again and verify the two differ.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testGetBytesReturnsSnapshot() throws Exception {
@@ -825,6 +883,8 @@ public class JmsMapMessageTest {
     /**
      * Verify that setting bytes takes a copy of the array. Set bytes, then modify them, then
      * retrieve the map entry and verify the two differ.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetBytesWithOffsetAndLength() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMessageTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMessageTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMessageTest.java
index 2726810..4aaf1e5 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMessageTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsMessageTest.java
@@ -1169,6 +1169,8 @@ public class JmsMessageTest {
      * When a property is not set, the behaviour of JMS specifies that it is equivalent to a null value,
      * and the primitive property accessors should behave in the same fashion as <primitive>.valueOf(String).
      * Test that this is the case.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testGetMissingPrimitivePropertyResultsInExpectedBehaviour() throws Exception {
@@ -1206,6 +1208,8 @@ public class JmsMessageTest {
      * {@link Character#isJavaLetter(char)} is true, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * beginning with a non-letter character.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNonLetterAsFirstCharacterThrowsIAE() throws Exception {
@@ -1223,6 +1227,8 @@ public class JmsMessageTest {
      * for which {@link Character#isJavaLetterOrDigit(char)} is true, as
      * described in {@link javax.jms.Message}. Verify an IAE is thrown if
      * setting a property continuing with a non-letter-or-digit character.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNonLetterOrDigitCharacterThrowsIAE() throws Exception {
@@ -1259,6 +1265,8 @@ public class JmsMessageTest {
      * Property 'identifiers' (i.e. names) are not allowed to be NULL, TRUE, or
      * FALSE, as described in {@link javax.jms.Message}. Verify an IAE is thrown
      * if setting a property with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameNULL() throws Exception {
@@ -1274,6 +1282,8 @@ public class JmsMessageTest {
      * Property 'identifiers' (i.e. names) are not allowed to be NULL, TRUE, or
      * FALSE, as described in {@link javax.jms.Message}. Verify an IAE is thrown
      * if setting a property with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameTRUE() throws Exception {
@@ -1289,6 +1299,8 @@ public class JmsMessageTest {
      * Property 'identifiers' (i.e. names) are not allowed to be NULL, TRUE, or
      * FALSE, as described in {@link javax.jms.Message}. Verify an IAE is thrown
      * if setting a property with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameFALSE() throws Exception {
@@ -1305,6 +1317,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameNOT() throws Exception {
@@ -1321,6 +1335,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameAND() throws Exception {
@@ -1337,6 +1353,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameOR() throws Exception {
@@ -1353,6 +1371,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameBETWEEN() throws Exception {
@@ -1369,6 +1389,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameLIKE() throws Exception {
@@ -1385,6 +1407,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameIN() throws Exception {
@@ -1401,6 +1425,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameIS() throws Exception {
@@ -1417,6 +1443,8 @@ public class JmsMessageTest {
      * BETWEEN, LIKE, IN, IS, or ESCAPE, as described in
      * {@link javax.jms.Message}. Verify an IAE is thrown if setting a property
      * with these values.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetPropertyWithNameESCAPE() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsObjectMessageTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsObjectMessageTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsObjectMessageTest.java
index 720aaaa..f116396 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsObjectMessageTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsObjectMessageTest.java
@@ -52,6 +52,8 @@ public class JmsObjectMessageTest {
     /**
      * Test that attempting to write bytes to a received message (without calling {@link ObjectMessage#clearBody()} first)
      * causes a {@link MessageNotWriteableException} to be thrown due to being read-only.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testReceivedObjectMessageThrowsMessageNotWriteableExceptionOnSetObject() throws Exception {
@@ -71,6 +73,8 @@ public class JmsObjectMessageTest {
 
     /**
      * Test that calling {@link ObjectMessage#toString()} returns a meaningful value
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testToString() throws Exception {
@@ -86,6 +90,8 @@ public class JmsObjectMessageTest {
     /**
      * Test that calling {@link ObjectMessage#clearBody()} causes a received
      * message to become writable
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testClearBodyOnReceivedObjectMessageMakesMessageWritable() throws Exception {
@@ -103,6 +109,8 @@ public class JmsObjectMessageTest {
     /**
      * Test that calling {@link ObjectMessage#clearBody()} of a received message
      * causes the body of the underlying message facade to be emptied.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testClearBodyOnReceivedObjectMessageClearsUnderlyingMessageBody() throws Exception {
@@ -125,6 +133,8 @@ public class JmsObjectMessageTest {
     /**
      * Test that setting an object on a new message and later getting the value, returns an
      * equal but different object that does not pick up intermediate changes to the set object.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetThenGetObjectReturnsSnapshot() throws Exception
@@ -162,6 +172,8 @@ public class JmsObjectMessageTest {
     /**
      * Test that setting an object on a new message which contains non-serializable content results
      * in an {@link MessageFormatException} being thrown due to failure to encode the object.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetObjectWithNonSerializableThrowsJMSMFE() throws Exception {
@@ -179,17 +191,16 @@ public class JmsObjectMessageTest {
         }
     }
 
-    //Test class
-    private static class NotSerializable
-    {
-        public NotSerializable()
-        {
-        }
+    // Test class
+    private static class NotSerializable {
+        public NotSerializable() {}
     }
 
     /**
      * Test that failure during deserialization of an object in a message results
      * in an {@link MessageFormatException} being throw.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test(expected=MessageFormatException.class)
     public void testGetObjectWithFailedDeserialisationThrowsJMSMFE() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsStreamMessageTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsStreamMessageTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsStreamMessageTest.java
index f1c9efe..40849e9 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsStreamMessageTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/message/JmsStreamMessageTest.java
@@ -107,6 +107,8 @@ public class JmsStreamMessageTest {
      *
      * Write bytes, then deliberately try to retrieve them as illegal types, then check they can
      * be successfully read.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testIllegalTypeConvesionFailureDoesNotIncrementPosition1() throws Exception {
@@ -142,6 +144,8 @@ public class JmsStreamMessageTest {
      *
      * Write String, then deliberately try illegal retrieval as bytes, then check it can be
      * successfully read.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testIllegalTypeConvesionFailureDoesNotIncrementPosition2() throws Exception {
@@ -164,6 +168,8 @@ public class JmsStreamMessageTest {
      * Test that this is the case, and in doing show demonstrate that primitive type conversion
      * failure does not increment the stream position, as shown by not hitting the end of the
      * stream unexpectedly.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testNullStreamEntryResultsInExpectedBehaviour() throws Exception {
@@ -199,7 +205,6 @@ public class JmsStreamMessageTest {
         streamMessage.reset(); // need to reset as read was a success
     }
 
-
     @Test
     public void testClearBodyAppliesCorrectState() throws JMSException {
         JmsStreamMessage streamMessage = factory.createStreamMessage();
@@ -300,6 +305,8 @@ public class JmsStreamMessageTest {
 
     /**
      * Write bytes, then retrieve them as all of the legal type combinations
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteBytesReadLegal() throws Exception {
@@ -320,6 +327,8 @@ public class JmsStreamMessageTest {
     /**
      * Write bytes, then retrieve them as all of the illegal type combinations to verify it
      * fails as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteBytesReadIllegal() throws Exception {
@@ -470,6 +479,8 @@ public class JmsStreamMessageTest {
      *
      * Test that these restrictions are met, and don't interfere with completing the readBytes
      * usage.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testReadObjectAfterPartialReadBytesThrowsMFE() throws Exception {
@@ -506,6 +517,8 @@ public class JmsStreamMessageTest {
     /**
      * Verify that setting bytes takes a copy of the array. Set bytes subset, then retrieve the
      * entry and verify the are different arrays and the subsets are equal.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteBytesWithOffsetAndLength() throws Exception {
@@ -547,6 +560,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a boolean, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteBooleanReadLegal() throws Exception {
@@ -564,6 +579,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a boolean, then retrieve it as all of the illegal type combinations to verify it
      * fails as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetBooleanGetIllegal() throws Exception {
@@ -601,6 +618,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a string, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteStringReadLegal() throws Exception {
@@ -647,6 +666,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a string, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteStringReadIllegal() throws Exception {
@@ -693,6 +714,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a byte, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteByteReadLegal() throws Exception {
@@ -713,6 +736,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a byte, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteByteReadIllegal() throws Exception {
@@ -747,6 +772,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a short, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteShortReadLegal() throws Exception {
@@ -766,6 +793,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a short, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteShortReadIllegal() throws Exception {
@@ -801,6 +830,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a char, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteCharReadLegal() throws Exception {
@@ -818,6 +849,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a char, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteCharReadIllegal() throws Exception {
@@ -855,6 +888,8 @@ public class JmsStreamMessageTest {
     /**
      * Set an int, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteIntReadLegal() throws Exception {
@@ -873,6 +908,8 @@ public class JmsStreamMessageTest {
     /**
      * Set an int, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteIntReadIllegal() throws Exception {
@@ -909,6 +946,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a long, then retrieve it as all of the legal type combinations to verify it is parsed
      * correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteLongReadLegal() throws Exception {
@@ -926,6 +965,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a long, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteLongReadIllegal() throws Exception {
@@ -963,6 +1004,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a float, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteFloatReadLegal() throws Exception {
@@ -981,6 +1024,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a float, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteFloatReadIllegal() throws Exception {
@@ -1017,6 +1062,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a double, then retrieve it as all of the legal type combinations to verify it is
      * parsed correctly
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteDoubleReadLegal() throws Exception {
@@ -1034,6 +1081,8 @@ public class JmsStreamMessageTest {
     /**
      * Set a double, then retrieve it as all of the illegal type combinations to verify it fails
      * as expected
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testWriteDoubleReadIllegal() throws Exception {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/test/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsBytesMessageFacadeTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/test/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsBytesMessageFacadeTest.java b/qpid-jms-client/src/test/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsBytesMessageFacadeTest.java
index 67d8af3..ce7cf4d 100644
--- a/qpid-jms-client/src/test/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsBytesMessageFacadeTest.java
+++ b/qpid-jms-client/src/test/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsBytesMessageFacadeTest.java
@@ -137,6 +137,8 @@ public class AmqpJmsBytesMessageFacadeTest extends AmqpJmsMessageTypesTestCase {
     /**
      * Test that copying a new messages which has been written to creates the
      * non-empty data section of the underlying message.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testCopyOnPopulatedNewMessageCreatesDataSection() throws Exception {
@@ -159,6 +161,8 @@ public class AmqpJmsBytesMessageFacadeTest extends AmqpJmsMessageTypesTestCase {
     /**
      * Test that copying a new messages which has not been written to creates the
      * (empty) data section of the underlying message on the copy.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testCopyOfNewMessageDoesNotCreateDataSection() throws Exception {
@@ -399,6 +403,8 @@ public class AmqpJmsBytesMessageFacadeTest extends AmqpJmsMessageTypesTestCase {
     /**
      * Test that setting bytes on a received message results in the expected content in the body section
      * of the underlying message and returned by a new InputStream requested from the message.
+     *
+     * @throws Exception if an error occurs during the test.
      */
     @Test
     public void testSetGetBodyOnReceivedMessage() throws Exception {


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