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:47 UTC

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

NO-JIRA Fix and update javadocs 

Project: http://git-wip-us.apache.org/repos/asf/qpid-jms/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-jms/commit/197d1227
Tree: http://git-wip-us.apache.org/repos/asf/qpid-jms/tree/197d1227
Diff: http://git-wip-us.apache.org/repos/asf/qpid-jms/diff/197d1227

Branch: refs/heads/master
Commit: 197d1227320270acb8b9786d86c914bcdce9b2e9
Parents: 7bdd536
Author: Timothy Bish <ta...@gmail.com>
Authored: Thu Oct 8 12:52:29 2015 -0400
Committer: Timothy Bish <ta...@gmail.com>
Committed: Thu Oct 8 12:52:29 2015 -0400

----------------------------------------------------------------------
 .../java/org/apache/qpid/jms/JmsConnection.java | 91 +------------------
 .../apache/qpid/jms/JmsConnectionFactory.java   | 41 +--------
 .../qpid/jms/JmsDurableTopicSubscriber.java     | 11 ---
 .../org/apache/qpid/jms/JmsMessageConsumer.java | 37 +-------
 .../org/apache/qpid/jms/JmsMessageProducer.java | 96 +-------------------
 .../org/apache/qpid/jms/JmsQueueReceiver.java   |  2 -
 .../org/apache/qpid/jms/JmsQueueSender.java     | 18 ----
 .../org/apache/qpid/jms/JmsQueueSession.java    | 58 ++----------
 .../java/org/apache/qpid/jms/JmsSession.java    | 93 +++----------------
 .../org/apache/qpid/jms/JmsTopicPublisher.java  | 24 -----
 .../org/apache/qpid/jms/JmsTopicSession.java    | 46 +---------
 .../org/apache/qpid/jms/JmsTopicSubscriber.java | 26 +-----
 .../apache/qpid/jms/JmsTransactionContext.java  |  9 ++
 .../qpid/jms/jndi/JNDIReferenceFactory.java     | 17 +++-
 .../org/apache/qpid/jms/jndi/JNDIStorable.java  |  7 +-
 .../org/apache/qpid/jms/message/JmsMessage.java |  3 +-
 .../jms/message/JmsMessageTransformation.java   | 15 +--
 .../jms/message/facade/JmsMapMessageFacade.java |  3 +
 .../jms/message/facade/JmsMessageFacade.java    |  7 ++
 .../org/apache/qpid/jms/provider/Provider.java  |  3 +-
 .../provider/ProviderRedirectedException.java   |  3 -
 .../qpid/jms/provider/ProviderWrapper.java      |  2 +
 .../qpid/jms/provider/WrappedAsyncResult.java   |  3 +
 .../jms/provider/amqp/AmqpAbstractResource.java |  3 +
 .../qpid/jms/provider/amqp/AmqpConsumer.java    |  6 ++
 .../provider/amqp/AmqpSaslAuthenticator.java    |  6 +-
 .../amqp/builders/AmqpResourceBuilder.java      |  5 +
 .../amqp/message/AmqpDestinationHelper.java     | 12 +++
 .../amqp/message/AmqpJmsMessageFacade.java      |  5 +-
 .../AmqpJmsMessagePropertyIntercepter.java      |  3 +
 .../jms/provider/failover/FailoverProvider.java |  3 -
 .../qpid/jms/transports/TransportSupport.java   |  2 +
 .../org/apache/qpid/jms/util/FactoryFinder.java |  4 +
 .../org/apache/qpid/jms/util/IdGenerator.java   | 12 ++-
 .../apache/qpid/jms/util/InetAddressUtil.java   |  4 +-
 .../java/org/apache/qpid/jms/util/LRUCache.java | 12 ++-
 .../org/apache/qpid/jms/util/MessageQueue.java  |  3 +
 .../org/apache/qpid/jms/util/PropertyUtil.java  | 10 +-
 .../apache/qpid/jms/util/ThreadPoolUtils.java   |  8 ++
 .../org/apache/qpid/jms/util/URISupport.java    | 15 ++-
 .../qpid/jms/JmsConnectionFactoryTest.java      |  6 ++
 .../apache/qpid/jms/JmsQueueConnectionTest.java |  4 +-
 .../BytesMessageIntegrationTest.java            |  4 +
 .../integration/ConsumerIntegrationTest.java    |  6 ++
 .../ForeignMessageIntegrationTest.java          |  4 +-
 .../integration/MapMessageIntegrationTest.java  |  2 +
 .../jms/integration/MessageIntegrationTest.java | 86 ++++++++++++++++++
 .../integration/ProducerIntegrationTest.java    | 14 +++
 .../jms/integration/SaslIntegrationTest.java    |  2 +
 .../StreamMessageIntegrationTest.java           |  2 +
 .../qpid/jms/message/JmsBytesMessageTest.java   | 28 ++++++
 .../qpid/jms/message/JmsMapMessageTest.java     | 60 ++++++++++++
 .../apache/qpid/jms/message/JmsMessageTest.java | 28 ++++++
 .../qpid/jms/message/JmsObjectMessageTest.java  | 23 +++--
 .../qpid/jms/message/JmsStreamMessageTest.java  | 51 ++++++++++-
 .../message/AmqpJmsBytesMessageFacadeTest.java  |  6 ++
 .../amqp/message/AmqpJmsMessageBuilderTest.java | 46 ++++++++++
 .../amqp/message/AmqpJmsMessageFacadeTest.java  | 14 +++
 .../message/AmqpJmsObjectMessageFacadeTest.java | 28 ++++--
 .../amqp/message/AmqpMessageIdHelperTest.java   | 24 ++++-
 .../qpid/jms/selector/SelectorParserTest.java   |  3 +-
 .../qpid/jms/session/JmsQueueSessionTest.java   |  8 ++
 .../qpid/jms/session/JmsTopicSessionTest.java   |  6 ++
 .../qpid/jms/test/testpeer/TestAmqpPeer.java    |  3 +
 .../sections/AbstractMessageSectionMatcher.java |  4 +
 .../provider/discovery/DiscoveryProvider.java   |  2 +
 .../qpid/jms/consumer/JmsAutoAckTest.java       |  5 +-
 .../qpid/jms/consumer/JmsClientAckTest.java     |  2 +-
 .../apache/qpid/jms/consumer/JmsDupsOkTest.java |  5 +-
 .../jms/consumer/JmsMessageConsumerTest.java    |  2 +-
 70 files changed, 623 insertions(+), 583 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnection.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnection.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnection.java
index ac02544..5e83302 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnection.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnection.java
@@ -141,10 +141,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         this.connectionInfo = new JmsConnectionInfo(new JmsConnectionId(connectionId));
     }
 
-    /**
-     * @throws JMSException
-     * @see javax.jms.Connection#close()
-     */
     @Override
     public void close() throws JMSException {
         boolean interrupted = Thread.interrupted();
@@ -244,13 +240,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         connected.set(false);
     }
 
-    /**
-     * @param transacted
-     * @param acknowledgeMode
-     * @return Session
-     * @throws JMSException
-     * @see javax.jms.Connection#createSession(boolean, int)
-     */
     @Override
     public Session createSession(boolean transacted, int acknowledgeMode) throws JMSException {
         checkClosedOrFailed();
@@ -264,31 +253,18 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         return result;
     }
 
-    /**
-     * @return clientId
-     * @see javax.jms.Connection#getClientID()
-     */
     @Override
     public synchronized String getClientID() throws JMSException {
         checkClosedOrFailed();
         return this.connectionInfo.getClientId();
     }
 
-    /**
-     * @return connectionInfoData
-     * @see javax.jms.Connection#getMetaData()
-     */
     @Override
     public ConnectionMetaData getMetaData() throws JMSException {
         checkClosedOrFailed();
         return JmsConnectionMetaData.INSTANCE;
     }
 
-    /**
-     * @param clientID
-     * @throws JMSException
-     * @see javax.jms.Connection#setClientID(java.lang.String)
-     */
     @Override
     public synchronized void setClientID(String clientID) throws JMSException {
         checkClosedOrFailed();
@@ -311,10 +287,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         connect();
     }
 
-    /**
-     * @throws JMSException
-     * @see javax.jms.Connection#start()
-     */
     @Override
     public void start() throws JMSException {
         checkClosedOrFailed();
@@ -330,16 +302,15 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         }
     }
 
-    /**
-     * @throws JMSException
-     * @see javax.jms.Connection#stop()
-     */
     @Override
     public void stop() throws JMSException {
         doStop(true);
     }
 
     /**
+     * Performs the actual connection stop with the option to disable the close check in cases
+     * where we don't want an exception.
+     *
      * @see #stop()
      * @param checkClosed <tt>true</tt> to check for already closed and throw
      *                    {@link java.lang.IllegalStateException} if already closed,
@@ -359,18 +330,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         }
     }
 
-    /**
-     * @param topic
-     * @param subscriptionName
-     * @param messageSelector
-     * @param sessionPool
-     * @param maxMessages
-     * @return ConnectionConsumer
-     * @throws JMSException
-     *
-     * @see javax.jms.Connection#createDurableConnectionConsumer(javax.jms.Topic,
-     *      java.lang.String, java.lang.String, javax.jms.ServerSessionPool, int)
-     */
     @Override
     public ConnectionConsumer createDurableConnectionConsumer(Topic topic, String subscriptionName,
                                                               String messageSelector, ServerSessionPool sessionPool, int maxMessages) throws JMSException {
@@ -379,16 +338,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         throw new JMSException("Not supported");
     }
 
-    /**
-     * @param destination
-     * @param messageSelector
-     * @param sessionPool
-     * @param maxMessages
-     * @return ConnectionConsumer
-     * @throws JMSException
-     * @see javax.jms.Connection#createConnectionConsumer(javax.jms.Destination,
-     *      java.lang.String, javax.jms.ServerSessionPool, int)
-     */
     @Override
     public ConnectionConsumer createConnectionConsumer(Destination destination, String messageSelector,
                                                        ServerSessionPool sessionPool, int maxMessages) throws JMSException {
@@ -397,16 +346,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         throw new JMSException("Not supported");
     }
 
-    /**
-     * @param topic
-     * @param messageSelector
-     * @param sessionPool
-     * @param maxMessages
-     * @return ConnectionConsumer
-     * @throws JMSException
-     * @see javax.jms.TopicConnection#createConnectionConsumer(javax.jms.Topic,
-     *      java.lang.String, javax.jms.ServerSessionPool, int)
-     */
     @Override
     public ConnectionConsumer createConnectionConsumer(Topic topic, String messageSelector,
                                                        ServerSessionPool sessionPool, int maxMessages) throws JMSException {
@@ -415,16 +354,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         throw new JMSException("Not supported");
     }
 
-    /**
-     * @param queue
-     * @param messageSelector
-     * @param sessionPool
-     * @param maxMessages
-     * @return ConnectionConsumer
-     * @throws JMSException
-     * @see javax.jms.QueueConnection#createConnectionConsumer(javax.jms.Queue,
-     *      java.lang.String, javax.jms.ServerSessionPool, int)
-     */
     @Override
     public ConnectionConsumer createConnectionConsumer(Queue queue, String messageSelector,
                                                        ServerSessionPool sessionPool, int maxMessages) throws JMSException {
@@ -433,13 +362,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         throw new JMSException("Not supported");
     }
 
-    /**
-     * @param transacted
-     * @param acknowledgeMode
-     * @return TopicSession
-     * @throws JMSException
-     * @see javax.jms.TopicConnection#createTopicSession(boolean, int)
-     */
     @Override
     public TopicSession createTopicSession(boolean transacted, int acknowledgeMode) throws JMSException {
         checkClosedOrFailed();
@@ -453,13 +375,6 @@ public class JmsConnection implements Connection, TopicConnection, QueueConnecti
         return result;
     }
 
-    /**
-     * @param transacted
-     * @param acknowledgeMode
-     * @return QueueSession
-     * @throws JMSException
-     * @see javax.jms.QueueConnection#createQueueSession(boolean, int)
-     */
     @Override
     public QueueSession createQueueSession(boolean transacted, int acknowledgeMode) throws JMSException {
         checkClosedOrFailed();

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnectionFactory.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnectionFactory.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnectionFactory.java
index 2067e17..3b90b18 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnectionFactory.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsConnectionFactory.java
@@ -132,24 +132,11 @@ public class JmsConnectionFactory extends JNDIStorable implements ConnectionFact
         }
     }
 
-    /**
-     * @return a TopicConnection
-     * @throws JMSException
-     * @see javax.jms.TopicConnectionFactory#createTopicConnection()
-     */
     @Override
     public TopicConnection createTopicConnection() throws JMSException {
         return createTopicConnection(getUsername(), getPassword());
     }
 
-    /**
-     * @param username
-     * @param password
-     * @return a TopicConnection
-     * @throws JMSException
-     * @see javax.jms.TopicConnectionFactory#createTopicConnection(java.lang.String,
-     *      java.lang.String)
-     */
     @Override
     public TopicConnection createTopicConnection(String username, String password) throws JMSException {
         try {
@@ -162,23 +149,11 @@ public class JmsConnectionFactory extends JNDIStorable implements ConnectionFact
         }
     }
 
-    /**
-     * @return a Connection
-     * @throws JMSException
-     * @see javax.jms.ConnectionFactory#createConnection()
-     */
     @Override
     public Connection createConnection() throws JMSException {
         return createConnection(getUsername(), getPassword());
     }
 
-    /**
-     * @param username
-     * @param password
-     * @return Connection
-     * @throws JMSException
-     * @see javax.jms.ConnectionFactory#createConnection(java.lang.String, java.lang.String)
-     */
     @Override
     public Connection createConnection(String username, String password) throws JMSException {
         try {
@@ -191,24 +166,11 @@ public class JmsConnectionFactory extends JNDIStorable implements ConnectionFact
         }
     }
 
-    /**
-     * @return a QueueConnection
-     * @throws JMSException
-     * @see javax.jms.QueueConnectionFactory#createQueueConnection()
-     */
     @Override
     public QueueConnection createQueueConnection() throws JMSException {
         return createQueueConnection(getUsername(), getPassword());
     }
 
-    /**
-     * @param username
-     * @param password
-     * @return a QueueConnection
-     * @throws JMSException
-     * @see javax.jms.QueueConnectionFactory#createQueueConnection(java.lang.String,
-     *      java.lang.String)
-     */
     @Override
     public QueueConnection createQueueConnection(String username, String password) throws JMSException {
         try {
@@ -574,6 +536,9 @@ public class JmsConnectionFactory extends JNDIStorable implements ConnectionFact
      * It is possible to set the clientID on the Connection itself immediately after
      * creation if no value has been set via the factory that created it, which will
      * allow the factory to create multiple open connections at a time.
+     *
+     * @param clientID
+     *      The clientID to assign when creating a new connection.
      */
     public void setClientID(String clientID) {
         this.clientID = clientID;

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsDurableTopicSubscriber.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsDurableTopicSubscriber.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsDurableTopicSubscriber.java
index b7ae1b9..3a45736 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsDurableTopicSubscriber.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsDurableTopicSubscriber.java
@@ -25,17 +25,6 @@ import org.apache.qpid.jms.meta.JmsConsumerId;
  */
 public class JmsDurableTopicSubscriber extends JmsTopicSubscriber {
 
-    /**
-     * Creates a durable TopicSubscriber
-     *
-     * @param id
-     * @param s
-     * @param destination
-     * @param name
-     * @param noLocal
-     * @param selector
-     * @throws JMSException
-     */
     public JmsDurableTopicSubscriber(JmsConsumerId id, JmsSession s, JmsDestination destination, String name, boolean noLocal, String selector) throws JMSException {
         super(id, s, destination, name, noLocal, selector);
     }

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageConsumer.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageConsumer.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageConsumer.java
index 80ae995..e90c6c8 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageConsumer.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageConsumer.java
@@ -139,10 +139,6 @@ public class JmsMessageConsumer implements MessageConsumer, JmsMessageAvailableC
         }
     }
 
-    /**
-     * @throws JMSException
-     * @see javax.jms.MessageConsumer#close()
-     */
     @Override
     public void close() throws JMSException {
         if (!closed.get()) {
@@ -187,7 +183,7 @@ public class JmsMessageConsumer implements MessageConsumer, JmsMessageAvailableC
      * to be sent to the remote peer.  This is most commonly needed when the parent
      * Session is closing.
      *
-     * @throws JMSException
+     * @throws JMSException if an error occurs during shutdown.
      */
     protected void shutdown() throws JMSException {
         shutdown(null);
@@ -201,22 +197,11 @@ public class JmsMessageConsumer implements MessageConsumer, JmsMessageAvailableC
         }
     }
 
-    /**
-     * @return a Message or null if closed during the operation
-     * @throws JMSException
-     * @see javax.jms.MessageConsumer#receive()
-     */
     @Override
     public Message receive() throws JMSException {
         return receive(0);
     }
 
-    /**
-     * @param timeout
-     * @return a Message or null
-     * @throws JMSException
-     * @see javax.jms.MessageConsumer#receive(long)
-     */
     @Override
     public Message receive(long timeout) throws JMSException {
         checkClosed();
@@ -230,11 +215,6 @@ public class JmsMessageConsumer implements MessageConsumer, JmsMessageAvailableC
         return copy(ackFromReceive(dequeue(timeout, connection.isReceiveLocalOnly())));
     }
 
-    /**
-     * @return a Message or null
-     * @throws JMSException
-     * @see javax.jms.MessageConsumer#receiveNoWait()
-     */
     @Override
     public Message receiveNoWait() throws JMSException {
         checkClosed();
@@ -253,10 +233,13 @@ public class JmsMessageConsumer implements MessageConsumer, JmsMessageAvailableC
      *
      * This method may consume messages that are expired or exceed a configured
      * delivery count value but will continue to wait for the configured timeout.
+     *
      * @param localCheckOnly
      *          if false, try pulling a message if a >= 0 timeout expires with no message arriving
-     * @throws JMSException
+     *
      * @return null if we timeout or if the consumer is closed concurrently.
+     *
+     * @throws JMSException if an error occurs during the dequeue.
      */
     private JmsInboundMessageDispatch dequeue(long timeout, boolean localCheckOnly) throws JMSException {
         boolean pullConsumer = isPullConsumer();
@@ -577,11 +560,6 @@ public class JmsMessageConsumer implements MessageConsumer, JmsMessageAvailableC
         return this.messageListener;
     }
 
-    /**
-     * @param listener
-     * @throws JMSException
-     * @see javax.jms.MessageConsumer#setMessageListener(javax.jms.MessageListener)
-     */
     @Override
     public void setMessageListener(MessageListener listener) throws JMSException {
         checkClosed();
@@ -593,11 +571,6 @@ public class JmsMessageConsumer implements MessageConsumer, JmsMessageAvailableC
         drainMessageQueueToListener();
     }
 
-    /**
-     * @return the Message Selector
-     * @throws JMSException
-     * @see javax.jms.MessageConsumer#getMessageSelector()
-     */
     @Override
     public String getMessageSelector() throws JMSException {
         checkClosed();

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageProducer.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageProducer.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageProducer.java
index 71752f1..a830760 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageProducer.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsMessageProducer.java
@@ -60,13 +60,6 @@ public class JmsMessageProducer implements MessageProducer {
         session.getConnection().createResource(producerInfo);
     }
 
-    /**
-     * Close the producer
-     *
-     * @throws JMSException
-     *
-     * @see javax.jms.MessageProducer#close()
-     */
     @Override
     public void close() throws JMSException {
         if (!closed.get()) {
@@ -78,7 +71,7 @@ public class JmsMessageProducer implements MessageProducer {
      * Called to initiate shutdown of Producer resources and request that the remote
      * peer remove the registered producer.
      *
-     * @throws JMSException
+     * @throws JMSException if an internal error occurs during the close operation.
      */
     protected void doClose() throws JMSException {
         shutdown();
@@ -90,7 +83,7 @@ public class JmsMessageProducer implements MessageProducer {
      * to be sent to the remote peer.  This is most commonly needed when the parent
      * Session is closing.
      *
-     * @throws JMSException
+     * @throws JMSException if an internal error occurs during the shutdown operation.
      */
     protected void shutdown() throws JMSException {
         shutdown(null);
@@ -103,90 +96,47 @@ public class JmsMessageProducer implements MessageProducer {
         }
     }
 
-    /**
-     * @return the delivery mode
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#getDeliveryMode()
-     */
     @Override
     public int getDeliveryMode() throws JMSException {
         checkClosed();
         return this.deliveryMode;
     }
 
-    /**
-     * @return the destination
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#getDestination()
-     */
     @Override
     public Destination getDestination() throws JMSException {
         checkClosed();
         return this.producerInfo.getDestination();
     }
 
-    /**
-     * @return true if disableIds is set
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#getDisableMessageID()
-     */
     @Override
     public boolean getDisableMessageID() throws JMSException {
         checkClosed();
         return this.disableMessageId;
     }
 
-    /**
-     * @return true if disable timestamp is set
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#getDisableMessageTimestamp()
-     */
     @Override
     public boolean getDisableMessageTimestamp() throws JMSException {
         checkClosed();
         return this.disableTimestamp;
     }
 
-    /**
-     * @return the priority
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#getPriority()
-     */
     @Override
     public int getPriority() throws JMSException {
         checkClosed();
         return this.priority;
     }
 
-    /**
-     * @return timeToLive
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#getTimeToLive()
-     */
     @Override
     public long getTimeToLive() throws JMSException {
         checkClosed();
         return this.timeToLive;
     }
 
-    /**
-     * @param message
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#send(javax.jms.Message)
-     */
     @Override
     public void send(Message message) throws JMSException {
         send(message, this.deliveryMode, this.priority, this.timeToLive);
     }
 
-    /**
-     * @param message
-     * @param deliveryMode
-     * @param priority
-     * @param timeToLive
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#send(javax.jms.Message, int, int, long)
-     */
     @Override
     public void send(Message message, int deliveryMode, int priority, long timeToLive) throws JMSException {
         checkClosed();
@@ -198,28 +148,11 @@ public class JmsMessageProducer implements MessageProducer {
         sendMessage(producerInfo.getDestination(), message, deliveryMode, priority, timeToLive);
     }
 
-    /**
-     * @param destination
-     * @param message
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#send(javax.jms.Destination,
-     *      javax.jms.Message)
-     */
     @Override
     public void send(Destination destination, Message message) throws JMSException {
         send(destination, message, this.deliveryMode, this.priority, this.timeToLive);
     }
 
-    /**
-     * @param destination
-     * @param message
-     * @param deliveryMode
-     * @param priority
-     * @param timeToLive
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#send(javax.jms.Destination,
-     *      javax.jms.Message, int, int, long)
-     */
     @Override
     public void send(Destination destination, Message message, int deliveryMode, int priority, long timeToLive) throws JMSException {
         checkClosed();
@@ -239,55 +172,30 @@ public class JmsMessageProducer implements MessageProducer {
         this.session.send(this, destination, message, deliveryMode, priority, timeToLive, disableMessageId, disableTimestamp);
     }
 
-    /**
-     * @param deliveryMode
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#setDeliveryMode(int)
-     */
     @Override
     public void setDeliveryMode(int deliveryMode) throws JMSException {
         checkClosed();
         this.deliveryMode = deliveryMode;
     }
 
-    /**
-     * @param value
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#setDisableMessageID(boolean)
-     */
     @Override
     public void setDisableMessageID(boolean value) throws JMSException {
         checkClosed();
         this.disableMessageId = value;
     }
 
-    /**
-     * @param value
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#setDisableMessageTimestamp(boolean)
-     */
     @Override
     public void setDisableMessageTimestamp(boolean value) throws JMSException {
         checkClosed();
         this.disableTimestamp = value;
     }
 
-    /**
-     * @param defaultPriority
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#setPriority(int)
-     */
     @Override
     public void setPriority(int defaultPriority) throws JMSException {
         checkClosed();
         this.priority = defaultPriority;
     }
 
-    /**
-     * @param timeToLive
-     * @throws JMSException
-     * @see javax.jms.MessageProducer#setTimeToLive(long)
-     */
     @Override
     public void setTimeToLive(long timeToLive) throws JMSException {
         checkClosed();

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueReceiver.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueReceiver.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueReceiver.java
index aa1da65..59c0b0b 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueReceiver.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueReceiver.java
@@ -47,8 +47,6 @@ public class JmsQueueReceiver extends JmsMessageConsumer implements QueueReceive
     }
 
     /**
-     * @return the Queue
-     * @throws IllegalStateException
      * @see javax.jms.QueueReceiver#getQueue()
      */
     @Override

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSender.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSender.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSender.java
index c2276c8..11b65f0 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSender.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSender.java
@@ -29,20 +29,11 @@ import org.apache.qpid.jms.meta.JmsProducerId;
  */
 public class JmsQueueSender extends JmsMessageProducer implements QueueSender {
 
-    /**
-     * Constructor
-     *
-     * @param id
-     * @param session
-     * @param destination
-     */
     protected JmsQueueSender(JmsProducerId id, JmsSession session, JmsDestination destination) throws JMSException {
         super(id, session, destination);
     }
 
     /**
-     * @return the Queue
-     * @throws IllegalStateException
      * @see javax.jms.QueueSender#getQueue()
      */
     @Override
@@ -52,9 +43,6 @@ public class JmsQueueSender extends JmsMessageProducer implements QueueSender {
     }
 
     /**
-     * @param queue
-     * @param message
-     * @throws JMSException
      * @see javax.jms.QueueSender#send(javax.jms.Queue, javax.jms.Message)
      */
     @Override
@@ -63,12 +51,6 @@ public class JmsQueueSender extends JmsMessageProducer implements QueueSender {
     }
 
     /**
-     * @param queue
-     * @param message
-     * @param deliveryMode
-     * @param priority
-     * @param timeToLive
-     * @throws JMSException
      * @see javax.jms.QueueSender#send(javax.jms.Queue, javax.jms.Message, int, int, long)
      */
     @Override

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSession.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSession.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSession.java
index ed7ad1d..c7063a1 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSession.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsQueueSession.java
@@ -37,6 +37,9 @@ public class JmsQueueSession extends JmsSession {
         super(connection, sessionId, acknowledgementMode);
     }
 
+    /**
+     * @see javax.jms.Session#createConsumer(javax.jms.Destination)
+     */
     @Override
     public MessageConsumer createConsumer(Destination destination) throws JMSException {
         if (destination instanceof Topic) {
@@ -46,12 +49,7 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param destination
-     * @param messageSelector
-     * @return the MessageConsumer
-     * @throws JMSException
-     * @see javax.jms.Session#createConsumer(javax.jms.Destination,
-     *      java.lang.String)
+     * @see javax.jms.Session#createConsumer(javax.jms.Destination, java.lang.String)
      */
     @Override
     public MessageConsumer createConsumer(Destination destination, String messageSelector) throws JMSException {
@@ -62,13 +60,7 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param destination
-     * @param messageSelector
-     * @param noLocal
-     * @return the MessageConsumer
-     * @throws JMSException
-     * @see javax.jms.Session#createConsumer(javax.jms.Destination,
-     *      java.lang.String, boolean)
+     * @see javax.jms.Session#createConsumer(javax.jms.Destination, java.lang.String, boolean)
      */
     @Override
     public MessageConsumer createConsumer(Destination destination, String messageSelector, boolean noLocal) throws JMSException {
@@ -79,12 +71,7 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param topic
-     * @param name
-     * @return the durable TopicSubscriber
-     * @throws JMSException
-     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic,
-     *      java.lang.String)
+     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic, java.lang.String)
      */
     @Override
     public TopicSubscriber createDurableSubscriber(Topic topic, String name) throws JMSException {
@@ -92,14 +79,7 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param topic
-     * @param name
-     * @param messageSelector
-     * @param noLocal
-     * @return the durable TopicSubscriber
-     * @throws JMSException
-     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic,
-     *      java.lang.String, java.lang.String, boolean)
+     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic, java.lang.String, java.lang.String, boolean)
      */
     @Override
     public TopicSubscriber createDurableSubscriber(Topic topic, String name, String messageSelector, boolean noLocal) throws JMSException {
@@ -107,9 +87,6 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param destination
-     * @return the MessageProducer
-     * @throws JMSException
      * @see javax.jms.Session#createProducer(javax.jms.Destination)
      */
     @Override
@@ -121,8 +98,6 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @return the TemporaryTopic object
-     * @throws JMSException
      * @see javax.jms.Session#createTemporaryTopic()
      */
     @Override
@@ -131,9 +106,6 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param topicName
-     * @return the Topic object
-     * @throws JMSException
      * @see javax.jms.Session#createTopic(java.lang.String)
      */
     @Override
@@ -142,8 +114,6 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param name
-     * @throws JMSException
      * @see javax.jms.Session#unsubscribe(java.lang.String)
      */
     @Override
@@ -152,9 +122,6 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param topic
-     * @return  the TopicPublisher
-     * @throws JMSException
      * @see javax.jms.TopicSession#createPublisher(javax.jms.Topic)
      */
     @Override
@@ -163,9 +130,6 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param topic
-     * @return the TopicSubscriber
-     * @throws JMSException
      * @see javax.jms.TopicSession#createSubscriber(javax.jms.Topic)
      */
     @Override
@@ -174,13 +138,7 @@ public class JmsQueueSession extends JmsSession {
     }
 
     /**
-     * @param topic
-     * @param messageSelector
-     * @param noLocal
-     * @return the TopicSubscriber
-     * @throws JMSException
-     * @see javax.jms.TopicSession#createSubscriber(javax.jms.Topic,
-     *      java.lang.String, boolean)
+     * @see javax.jms.TopicSession#createSubscriber(javax.jms.Topic, java.lang.String, boolean)
      */
     @Override
     public TopicSubscriber createSubscriber(Topic topic, String messageSelector, boolean noLocal) throws JMSException {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsSession.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsSession.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsSession.java
index a6765a0..fd35190 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsSession.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsSession.java
@@ -221,7 +221,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
      * Shutdown the Session and release all resources.  Once completed the Session can
      * request that the Provider destroy the Session and it's child resources.
      *
-     * @throws JMSException
+     * @throws JMSException if an internal error occurs during the close operation.
      */
     protected void doClose() throws JMSException {
         boolean interrupted = Thread.interrupted();
@@ -306,9 +306,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     //////////////////////////////////////////////////////////////////////////
 
     /**
-     * @param destination
-     * @return a MessageConsumer
-     * @throws JMSException
      * @see javax.jms.Session#createConsumer(javax.jms.Destination)
      */
     @Override
@@ -317,12 +314,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param destination
-     * @param messageSelector
-     * @return MessageConsumer
-     * @throws JMSException
-     * @see javax.jms.Session#createConsumer(javax.jms.Destination,
-     *      java.lang.String)
+     * @see javax.jms.Session#createConsumer(javax.jms.Destination, java.lang.String)
      */
     @Override
     public MessageConsumer createConsumer(Destination destination, String messageSelector) throws JMSException {
@@ -330,13 +322,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param destination
-     * @param messageSelector
-     * @param noLocal
-     * @return the MessageConsumer
-     * @throws JMSException
-     * @see javax.jms.Session#createConsumer(javax.jms.Destination,
-     *      java.lang.String, boolean)
+     * @see javax.jms.Session#createConsumer(javax.jms.Destination, java.lang.String, boolean)
      */
     @Override
     public MessageConsumer createConsumer(Destination destination, String messageSelector, boolean noLocal) throws JMSException {
@@ -350,9 +336,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param queue
-     * @return QueueRecevier
-     * @throws JMSException
      * @see javax.jms.QueueSession#createReceiver(javax.jms.Queue)
      */
     @Override
@@ -366,12 +349,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param queue
-     * @param messageSelector
-     * @return QueueReceiver
-     * @throws JMSException
-     * @see javax.jms.QueueSession#createReceiver(javax.jms.Queue,
-     *      java.lang.String)
+     * @see javax.jms.QueueSession#createReceiver(javax.jms.Queue, java.lang.String)
      */
     @Override
     public QueueReceiver createReceiver(Queue queue, String messageSelector) throws JMSException {
@@ -385,9 +363,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param destination
-     * @return QueueBrowser
-     * @throws JMSException
      * @see javax.jms.Session#createBrowser(javax.jms.Queue)
      */
     @Override
@@ -396,10 +371,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param destination
-     * @param messageSelector
-     * @return QueueBrowser
-     * @throws JMSException
      * @see javax.jms.Session#createBrowser(javax.jms.Queue, java.lang.String)
      */
     @Override
@@ -413,9 +384,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param topic
-     * @return TopicSubscriber
-     * @throws JMSException
      * @see javax.jms.TopicSession#createSubscriber(javax.jms.Topic)
      */
     @Override
@@ -424,13 +392,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param topic
-     * @param messageSelector
-     * @param noLocal
-     * @return TopicSubscriber
-     * @throws JMSException
-     * @see javax.jms.TopicSession#createSubscriber(javax.jms.Topic,
-     *      java.lang.String, boolean)
+     * @see javax.jms.TopicSession#createSubscriber(javax.jms.Topic, java.lang.String, boolean)
      */
     @Override
     public TopicSubscriber createSubscriber(Topic topic, String messageSelector, boolean noLocal) throws JMSException {
@@ -444,12 +406,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param topic
-     * @param name
-     * @return a TopicSubscriber
-     * @throws JMSException
-     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic,
-     *      java.lang.String)
+     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic, java.lang.String)
      */
     @Override
     public TopicSubscriber createDurableSubscriber(Topic topic, String name) throws JMSException {
@@ -457,14 +414,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param topic
-     * @param name
-     * @param messageSelector
-     * @param noLocal
-     * @return TopicSubscriber
-     * @throws JMSException
-     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic,
-     *      java.lang.String, java.lang.String, boolean)
+     * @see javax.jms.Session#createDurableSubscriber(javax.jms.Topic, java.lang.String, java.lang.String, boolean)
      */
     @Override
     public TopicSubscriber createDurableSubscriber(Topic topic, String name, String messageSelector, boolean noLocal) throws JMSException {
@@ -485,8 +435,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param name
-     * @throws JMSException
      * @see javax.jms.Session#unsubscribe(java.lang.String)
      */
     @Override
@@ -500,9 +448,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     //////////////////////////////////////////////////////////////////////////
 
     /**
-     * @param destination
-     * @return MessageProducer
-     * @throws JMSException
      * @see javax.jms.Session#createProducer(javax.jms.Destination)
      */
     @Override
@@ -515,9 +460,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param queue
-     * @return QueueSender
-     * @throws JMSException
      * @see javax.jms.QueueSession#createSender(javax.jms.Queue)
      */
     @Override
@@ -530,9 +472,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param topic
-     * @return TopicPublisher
-     * @throws JMSException
      * @see javax.jms.TopicSession#createPublisher(javax.jms.Topic)
      */
     @Override
@@ -601,9 +540,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     //////////////////////////////////////////////////////////////////////////
 
     /**
-     * @param queueName
-     * @return Queue
-     * @throws JMSException
      * @see javax.jms.Session#createQueue(java.lang.String)
      */
     @Override
@@ -613,9 +549,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @param topicName
-     * @return Topic
-     * @throws JMSException
      * @see javax.jms.Session#createTopic(java.lang.String)
      */
     @Override
@@ -625,8 +558,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @return TemporaryQueue
-     * @throws JMSException
      * @see javax.jms.Session#createTemporaryQueue()
      */
     @Override
@@ -636,8 +567,6 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     }
 
     /**
-     * @return TemporaryTopic
-     * @throws JMSException
      * @see javax.jms.Session#createTemporaryTopic()
      */
     @Override
@@ -779,7 +708,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     /**
      * Checks whether the session uses transactions.
      *
-     * @return true - if the session uses transactions.
+     * @return true if the session uses transactions.
      */
     public boolean isTransacted() {
         return acknowledgementMode == Session.SESSION_TRANSACTED;
@@ -788,7 +717,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     /**
      * Checks whether the session used client acknowledgment.
      *
-     * @return true - if the session uses client acknowledgment.
+     * @return true if the session uses client acknowledgment.
      */
     public boolean isClientAcknowledge() {
         return acknowledgementMode == Session.CLIENT_ACKNOWLEDGE;
@@ -797,7 +726,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     /**
      * Checks whether the session used auto acknowledgment.
      *
-     * @return true - if the session uses client acknowledgment.
+     * @return true if the session uses client acknowledgment.
      */
     public boolean isAutoAcknowledge() {
         return acknowledgementMode == Session.AUTO_ACKNOWLEDGE;
@@ -806,7 +735,7 @@ public class JmsSession implements Session, QueueSession, TopicSession, JmsMessa
     /**
      * Checks whether the session used dup ok acknowledgment.
      *
-     * @return true - if the session uses client acknowledgment.
+     * @return true if the session uses client acknowledgment.
      */
     public boolean isDupsOkAcknowledge() {
         return acknowledgementMode == Session.DUPS_OK_ACKNOWLEDGE;

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicPublisher.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicPublisher.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicPublisher.java
index a68ff00..2aba406 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicPublisher.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicPublisher.java
@@ -29,19 +29,11 @@ import org.apache.qpid.jms.meta.JmsProducerId;
  */
 public class JmsTopicPublisher extends JmsMessageProducer implements TopicPublisher {
 
-    /**
-     * Constructor
-     *
-     * @param session
-     * @param destination
-     */
     protected JmsTopicPublisher(JmsProducerId id, JmsSession session, JmsDestination destination) throws JMSException {
         super(id, session, destination);
     }
 
     /**
-     * @return the Topic
-     * @throws IllegalStateException
      * @see javax.jms.TopicPublisher#getTopic()
      */
     @Override
@@ -51,8 +43,6 @@ public class JmsTopicPublisher extends JmsMessageProducer implements TopicPublis
     }
 
     /**
-     * @param message
-     * @throws JMSException
      * @see javax.jms.TopicPublisher#publish(javax.jms.Message)
      */
     @Override
@@ -61,9 +51,6 @@ public class JmsTopicPublisher extends JmsMessageProducer implements TopicPublis
     }
 
     /**
-     * @param topic
-     * @param message
-     * @throws JMSException
      * @see javax.jms.TopicPublisher#publish(javax.jms.Topic, javax.jms.Message)
      */
     @Override
@@ -72,11 +59,6 @@ public class JmsTopicPublisher extends JmsMessageProducer implements TopicPublis
     }
 
     /**
-     * @param message
-     * @param deliveryMode
-     * @param priority
-     * @param timeToLive
-     * @throws JMSException
      * @see javax.jms.TopicPublisher#publish(javax.jms.Message, int, int, long)
      */
     @Override
@@ -85,12 +67,6 @@ public class JmsTopicPublisher extends JmsMessageProducer implements TopicPublis
     }
 
     /**
-     * @param topic
-     * @param message
-     * @param deliveryMode
-     * @param priority
-     * @param timeToLive
-     * @throws JMSException
      * @see javax.jms.TopicPublisher#publish(javax.jms.Topic, javax.jms.Message, int, int, long)
      */
     @Override

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSession.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSession.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSession.java
index 7b90b2f..b9d3505 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSession.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSession.java
@@ -39,9 +39,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param queue
-     * @return the QueueBrowser
-     * @throws JMSException
      * @see javax.jms.Session#createBrowser(javax.jms.Queue)
      */
     @Override
@@ -50,10 +47,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param queue
-     * @param messageSelector
-     * @return the QueueBrowser
-     * @throws JMSException
      * @see javax.jms.Session#createBrowser(javax.jms.Queue, java.lang.String)
      */
     @Override
@@ -62,9 +55,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param destination
-     * @return the MessageConsumer
-     * @throws JMSException
      * @see javax.jms.Session#createConsumer(javax.jms.Destination)
      */
     @Override
@@ -76,12 +66,7 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param destination
-     * @param messageSelector
-     * @return the MessageConsumer
-     * @throws JMSException
-     * @see javax.jms.Session#createConsumer(javax.jms.Destination,
-     *      java.lang.String)
+     * @see javax.jms.Session#createConsumer(javax.jms.Destination, java.lang.String)
      */
     @Override
     public MessageConsumer createConsumer(Destination destination, String messageSelector) throws JMSException {
@@ -92,13 +77,7 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param destination
-     * @param messageSelector
-     * @param noLocal
-     * @return the MessageConsumer
-     * @throws JMSException
-     * @see javax.jms.Session#createConsumer(javax.jms.Destination,
-     *      java.lang.String)
+     * @see javax.jms.Session#createConsumer(javax.jms.Destination, java.lang.String)
      */
     @Override
     public MessageConsumer createConsumer(Destination destination, String messageSelector, boolean noLocal) throws JMSException {
@@ -109,9 +88,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param destination
-     * @return the MessageProducer
-     * @throws JMSException
      * @see javax.jms.Session#createProducer(javax.jms.Destination)
      */
     @Override
@@ -123,9 +99,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param queueName
-     * @return the Queue object
-     * @throws JMSException
      * @see javax.jms.Session#createQueue(java.lang.String)
      */
     @Override
@@ -134,8 +107,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @return the TemporaryQueue object
-     * @throws JMSException
      * @see javax.jms.Session#createTemporaryQueue()
      */
     @Override
@@ -144,9 +115,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param queue
-     * @return the QueueReceiver
-     * @throws JMSException
      * @see javax.jms.QueueSession#createReceiver(javax.jms.Queue)
      */
     @Override
@@ -155,12 +123,7 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param queue
-     * @param messageSelector
-     * @return the QueueReceiver
-     * @throws JMSException
-     * @see javax.jms.QueueSession#createReceiver(javax.jms.Queue,
-     *      java.lang.String)
+     * @see javax.jms.QueueSession#createReceiver(javax.jms.Queue, java.lang.String)
      */
     @Override
     public QueueReceiver createReceiver(Queue queue, String messageSelector) throws JMSException {
@@ -168,9 +131,6 @@ public class JmsTopicSession extends JmsSession {
     }
 
     /**
-     * @param queue
-     * @return the QueueSender
-     * @throws JMSException
      * @see javax.jms.QueueSession#createSender(javax.jms.Queue)
      */
     @Override

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSubscriber.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSubscriber.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSubscriber.java
index efcd731..73fadf0 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSubscriber.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTopicSubscriber.java
@@ -28,38 +28,15 @@ import org.apache.qpid.jms.meta.JmsConsumerId;
  */
 public class JmsTopicSubscriber extends JmsMessageConsumer implements TopicSubscriber {
 
-    /**
-     * Creates a non-durable TopicSubscriber
-     *
-     * @param id
-     * @param s
-     * @param destination
-     * @param noLocal
-     * @param selector
-     * @throws JMSException
-     */
     JmsTopicSubscriber(JmsConsumerId id, JmsSession s, JmsDestination destination, boolean noLocal, String selector) throws JMSException {
         super(id, s, destination, selector, noLocal);
     }
 
-    /**
-     * Creates a TopicSubscriber that is durable.
-     *
-     * @param id
-     * @param s
-     * @param destination
-     * @param name
-     * @param noLocal
-     * @param selector
-     * @throws JMSException
-     */
     JmsTopicSubscriber(JmsConsumerId id, JmsSession s, JmsDestination destination, String name, boolean noLocal, String selector) throws JMSException {
         super(id, s, destination, name, selector, noLocal);
     }
 
     /**
-     * @return the Topic
-     * @throws IllegalStateException
      * @see javax.jms.TopicSubscriber#getTopic()
      */
     @Override
@@ -68,6 +45,9 @@ public class JmsTopicSubscriber extends JmsMessageConsumer implements TopicSubsc
         return (Topic) this.getDestination();
     }
 
+    /**
+     * @see javax.jms.TopicSubscriber#getNoLocal()
+     */
     @Override
     public boolean getNoLocal() throws JMSException {
         checkClosed();

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTransactionContext.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTransactionContext.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTransactionContext.java
index d83c92e..be487e1 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTransactionContext.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/JmsTransactionContext.java
@@ -130,12 +130,21 @@ public interface JmsTransactionContext {
      */
     boolean isInTransaction();
 
+    /**
+     * Signals that the connection that was previously established has been lost and the
+     * listener should alter its state to reflect the fact that there is no active connection.
+     */
     void onConnectionInterrupted();
 
     /**
      * Called when the connection to the remote peer has been lost and then a new
      * connection established.  The context should perform any necessary processing
      * recover and reset its internal state.
+     *
+     * @param provider
+     *      A reference to the provider that manages the new connection.
+     *
+     * @throws Exception if an error occurs while rebuilding against the new provider.
      */
     void onConnectionRecovery(Provider provider) throws Exception;
 

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIReferenceFactory.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIReferenceFactory.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIReferenceFactory.java
index 5d0d04a..693e2e1 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIReferenceFactory.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIReferenceFactory.java
@@ -53,8 +53,7 @@ public class JNDIReferenceFactory implements ObjectFactory {
      * @return the instance built from the Reference object
      *
      * @throws Exception
-     *         if building the instance from Reference fails (usually class not
-     *         found)
+     *         if building the instance from Reference fails (usually class not found)
      */
     @Override
     public Object getObjectInstance(Object object, Name name, Context nameCtx, Hashtable<?, ?> environment)
@@ -83,9 +82,13 @@ public class JNDIReferenceFactory implements ObjectFactory {
      * Create a Reference instance from a JNDIStorable object
      *
      * @param instanceClassName
+     *      The name of the class that is being created.
      * @param po
+     *      The properties object to use when configuring the new instance.
+     *
      * @return Reference
-     * @throws NamingException
+     *
+     * @throws NamingException if an error occurs while creating the new instance.
      */
     public static Reference createReference(String instanceClassName, JNDIStorable po) throws NamingException {
         Reference result = new Reference(instanceClassName, JNDIReferenceFactory.class.getName(), null);
@@ -105,9 +108,13 @@ public class JNDIReferenceFactory implements ObjectFactory {
      * Retrieve the class loader for a named class
      *
      * @param thisObj
+     *      Local object to use when doing the lookup.
      * @param className
-     * @return the class
-     * @throws ClassNotFoundException
+     *      The name of the class being loaded.
+     *
+     * @return the class that was requested.
+     *
+     * @throws ClassNotFoundException if a matching class cannot be created.
      */
     public static Class<?> loadClass(Object thisObj, String className) throws ClassNotFoundException {
         // try local ClassLoader first.

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIStorable.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIStorable.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIStorable.java
index 8753fcc..20edd95 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIStorable.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/jndi/JNDIStorable.java
@@ -53,6 +53,8 @@ public abstract class JNDIStorable implements Referenceable, Externalizable {
      * set the properties for this instance as retrieved from JNDI
      *
      * @param props
+     *      The properties to apply to this instance.
+     *
      * @return a new, unmodifiable, map containing any unused properties, or empty if none were.
      */
     public synchronized Map<String, String> setProperties(Map<String, String> props) {
@@ -83,9 +85,6 @@ public abstract class JNDIStorable implements Referenceable, Externalizable {
     }
 
     /**
-     * @param in
-     * @throws IOException
-     * @throws ClassNotFoundException
      * @see java.io.Externalizable#readExternal(java.io.ObjectInput)
      */
     @SuppressWarnings("unchecked")
@@ -98,8 +97,6 @@ public abstract class JNDIStorable implements Referenceable, Externalizable {
     }
 
     /**
-     * @param out
-     * @throws IOException
      * @see java.io.Externalizable#writeExternal(java.io.ObjectOutput)
      */
     @Override

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessage.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessage.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessage.java
index af58312..4fb1df9 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessage.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessage.java
@@ -286,7 +286,8 @@ public class JmsMessage implements javax.jms.Message {
      * properties
      *
      * @return Enumeration of all property names on this message
-     * @throws JMSException
+     *
+     * @throws JMSException if an error occurs while reading the properties from the Message.
      */
     public Enumeration<?> getAllPropertyNames() throws JMSException {
         Set<String> result = new HashSet<String>();

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessageTransformation.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessageTransformation.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessageTransformation.java
index 1beae38..4563f85 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessageTransformation.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/JmsMessageTransformation.java
@@ -51,13 +51,14 @@ public final class JmsMessageTransformation {
     /**
      * Creates a an available JMS message from another provider.
      *
+     * @param connection
+     *      The Connection instance that is requesting the transformation.
      * @param destination
-     *        - Destination to be converted into Jms's implementation.
-     * @return JmsDestination - Jms's implementation of the
-     *         destination.
-     * @throws JMSException
-     * @throws JMSException
-     *         if an error occurs
+     *      Destination to be converted into Jms's implementation.
+     *
+     * @return JmsDestination - Jms's implementation of the destination.
+     *
+     * @throws JMSException if an error occurs during the transformation.
      */
     public static JmsDestination transformDestination(JmsConnection connection, Destination destination) throws JMSException {
         JmsDestination result = null;
@@ -178,6 +179,8 @@ public final class JmsMessageTransformation {
      * specific to the foreign message may be lost if not returned directly via
      * the <code>propertyNames</code> method.
      *
+     * @param connection
+     *        The Connection instance that is requesting the transformation.
      * @param source
      *        the message to take the properties from
      * @param target

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMapMessageFacade.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMapMessageFacade.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMapMessageFacade.java
index a062984..d9650ab 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMapMessageFacade.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMapMessageFacade.java
@@ -45,6 +45,9 @@ public interface JmsMapMessageFacade extends JmsMessageFacade {
     /**
      * Determines whether an item exists in this Map based message.
      *
+     * @param key
+     *      The entry key that is being searched for.
+     *
      * @return true if the item exists in the Map, false otherwise.
      */
     boolean itemExists(String key);

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMessageFacade.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMessageFacade.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMessageFacade.java
index aead344..15bde3c 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMessageFacade.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/message/facade/JmsMessageFacade.java
@@ -48,6 +48,9 @@ public interface JmsMessageFacade {
     public Set<String> getPropertyNames() throws JMSException;
 
     /**
+     * @param key
+     *      The property name that is being searched for.
+     *
      * @return true if the given property exists within the message.
      *
      * @throws JMSException if an error occurs while accessing the Message properties.
@@ -60,6 +63,8 @@ public interface JmsMessageFacade {
      * @param key
      *        the key used to access the given property.
      *
+     * @return the object that is stored under the given key or null if none found.
+     *
      * @throws JMSException if an error occurs while accessing the Message properties.
      */
     Object getProperty(String key) throws JMSException;
@@ -116,6 +121,8 @@ public interface JmsMessageFacade {
      * Create a new instance and perform a deep copy of this object's
      * contents.
      *
+     * @return a copy of this JmsMessageFacade instance.
+     *
      * @throws JMSException if an error occurs while copying the message.
      */
     JmsMessageFacade copy() throws JMSException;

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/Provider.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/Provider.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/Provider.java
index ea82390..ad5993f 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/Provider.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/Provider.java
@@ -288,7 +288,8 @@ public interface Provider {
      *   {@literal timeout > 0} then it should remain open for timeout amount of time.
      *
      * The timeout value when positive is given in milliseconds.
-     *
+     * @param consumerId
+     *        the ID of the Consumer instance that is attempt to pull a message from the remote.
      * @param timeout
      *        the amount of time to tell the remote peer to keep this pull request valid.
      * @param request

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderRedirectedException.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderRedirectedException.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderRedirectedException.java
index f521a38..667f96a 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderRedirectedException.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderRedirectedException.java
@@ -30,9 +30,6 @@ public class ProviderRedirectedException extends IOException {
     private final String networkHost;
     private final int port;
 
-    /**
-     * @param reason
-     */
     public ProviderRedirectedException(String reason, String hostname, String networkHost, int port) {
         super(reason);
 

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderWrapper.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderWrapper.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderWrapper.java
index c138b47..c053c22 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderWrapper.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/ProviderWrapper.java
@@ -36,6 +36,8 @@ import org.apache.qpid.jms.provider.ProviderConstants.ACK_TYPE;
  * This wrapper is meant primarily for Providers that are adding some additional feature
  * on-top of an existing provider such as a discovery based provider that only needs to
  * pass along discovered remote peer information.
+ *
+ * @param <E> the Type of the Provider instance being wrapped.
  */
 public class ProviderWrapper<E extends Provider> implements Provider, ProviderListener {
 

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/WrappedAsyncResult.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/WrappedAsyncResult.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/WrappedAsyncResult.java
index c487f48..83fcb4e 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/WrappedAsyncResult.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/WrappedAsyncResult.java
@@ -25,6 +25,9 @@ public abstract class WrappedAsyncResult implements AsyncResult {
 
     /**
      * Create a new WrappedAsyncResult for the target AsyncResult
+     *
+     * @param wrapped
+     *      The AsyncResult to be wrapped by this AsyncResult instance.
      */
     public WrappedAsyncResult(AsyncResult wrapped) {
         this.wrapped = wrapped;

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpAbstractResource.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpAbstractResource.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpAbstractResource.java
index 91d220a..5474d75 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpAbstractResource.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpAbstractResource.java
@@ -32,6 +32,9 @@ import org.slf4j.LoggerFactory;
  * This abstract class wraps up the basic state management bits so that the concrete
  * object don't have to reproduce it.  Provides hooks for the subclasses to initialize
  * and shutdown.
+ *
+ * @param <R> The JmsResource type that describe this resource.
+ * @param <E> The AMQP Endpoint that this resource encapsulates.
  */
 public abstract class AmqpAbstractResource<R extends JmsResource, E extends Endpoint> implements AmqpResource {
 

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConsumer.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConsumer.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConsumer.java
index 69ffcdf..d2df866 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConsumer.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpConsumer.java
@@ -79,6 +79,9 @@ public class AmqpConsumer extends AmqpAbstractResource<JmsConsumerInfo, Receiver
 
     /**
      * Starts the consumer by setting the link credit to the given prefetch value.
+     *
+     * @param request
+     *      The request that awaits completion of the consumer start.
      */
     public void start(AsyncResult request) {
         sendFlowIfNeeded();
@@ -87,6 +90,9 @@ public class AmqpConsumer extends AmqpAbstractResource<JmsConsumerInfo, Receiver
 
     /**
      * Stops the consumer, using all link credit and waiting for in-flight messages to arrive.
+     *
+     * @param request
+     *      The request that awaits completion of the consumer stop.
      */
     public void stop(AsyncResult request) {
         Receiver receiver = getEndpoint();

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpSaslAuthenticator.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpSaslAuthenticator.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpSaslAuthenticator.java
index 0376197..ee12f5f 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpSaslAuthenticator.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/AmqpSaslAuthenticator.java
@@ -36,7 +36,7 @@ public class AmqpSaslAuthenticator {
     private final Sasl sasl;
     private final JmsConnectionInfo info;
     private Mechanism mechanism;
-    private Principal localPrincipal;
+    private final Principal localPrincipal;
     private Set<String> mechanismsRestriction;
 
     /**
@@ -77,7 +77,9 @@ public class AmqpSaslAuthenticator {
      * successful authentication or a JMSSecurityException is thrown indicating that the
      * handshake failed.
      *
-     * @throws JMSSecurityException
+     * @return true if the SASL handshake completes successfully.
+     *
+     * @throws JMSSecurityException if a security violation is detected during the handshake.
      */
     public boolean authenticate() throws JMSSecurityException {
         switch (sasl.getState()) {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/builders/AmqpResourceBuilder.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/builders/AmqpResourceBuilder.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/builders/AmqpResourceBuilder.java
index 6a678ad..a6618e7 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/builders/AmqpResourceBuilder.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/builders/AmqpResourceBuilder.java
@@ -31,6 +31,11 @@ import org.slf4j.LoggerFactory;
 
 /**
  * Base for all AmqpResource builders.
+ *
+ * @param <TARGET> The Type of resource that will be created.
+ * @param <PARENT> The Type of this resource's parent.
+ * @param <INFO> The Type of JmsResource used to describe the target resource.
+ * @param <ENDPOINT> The AMQP Endpoint that the target resource encapsulates.
  */
 public abstract class AmqpResourceBuilder<TARGET extends AmqpResource, PARENT extends AmqpResourceParent, INFO extends JmsResource, ENDPOINT extends Endpoint> implements AmqpEventSink {
 

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpDestinationHelper.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpDestinationHelper.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpDestinationHelper.java
index 140616e..06ac95f 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpDestinationHelper.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpDestinationHelper.java
@@ -58,6 +58,13 @@ public class AmqpDestinationHelper {
      * If the address is null then the consumer destination is returned, unless
      * the useConsumerDestForTypeOnly flag is true, in which case null will be
      * returned.
+     *
+     * @param message
+     *      The message that holds the addressing information.
+     * @param consumerDestination
+     *      The destination that the consumer is subscribed to.
+     *
+     * @return a Destination object that describe the original address the message was sent to.
      */
     public JmsDestination getJmsDestination(AmqpJmsMessageFacade message, JmsDestination consumerDestination) {
         String to = message.getToAddress();
@@ -295,6 +302,11 @@ public class AmqpDestinationHelper {
     }
 
     /**
+     * Return the appropriate type capability to describe the given Destination.
+     *
+     * @param destination
+     *      The Destination to examine for the destination type capability.
+     *
      * @return the type capability, or null if the supplied destination is null or can't be classified
      */
     public Symbol toTypeCapability(JmsDestination destination) {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
index 07eed51..4aa31f3 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessageFacade.java
@@ -48,9 +48,6 @@ import org.apache.qpid.proton.amqp.messaging.MessageAnnotations;
 import org.apache.qpid.proton.amqp.messaging.Properties;
 import org.apache.qpid.proton.message.Message;
 
-/**
- *
- */
 public class AmqpJmsMessageFacade implements JmsMessageFacade {
 
     private static final int DEFAULT_PRIORITY = javax.jms.Message.DEFAULT_PRIORITY;
@@ -606,7 +603,7 @@ public class AmqpJmsMessageFacade implements JmsMessageFacade {
      * @param ttl
      *        the value to use, in range {@literal 0 <= x <= 2^32 - 1}
      *
-     * @throws MessageFormatException
+     * @throws MessageFormatException if the TTL value is not in the allowed range.
      */
     public void setAmqpTimeToLiveOverride(Long ttl) throws MessageFormatException {
         if (ttl != null) {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessagePropertyIntercepter.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessagePropertyIntercepter.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessagePropertyIntercepter.java
index 35c5af5..90b4854 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessagePropertyIntercepter.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/amqp/message/AmqpJmsMessagePropertyIntercepter.java
@@ -279,6 +279,9 @@ public class AmqpJmsMessagePropertyIntercepter {
      * manipulated by the receiver without impacting the facade, and an empty set
      * will be returned if there are no matching properties.
      *
+     * @param message
+     *      The message being enumerated.
+     *
      * @return a {@code Set<String>} containing the names of all intercepted properties with a value.
      */
     public static Set<String> getPropertyNames(AmqpJmsMessageFacade message) {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/failover/FailoverProvider.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/failover/FailoverProvider.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/failover/FailoverProvider.java
index d7fc1d3..6d73058 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/failover/FailoverProvider.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/provider/failover/FailoverProvider.java
@@ -1032,9 +1032,6 @@ public class FailoverProvider extends DefaultProviderListener implements Provide
      */
     protected abstract class CreateConnectionRequest extends FailoverRequest {
 
-        /**
-         * @param watcher
-         */
         public CreateConnectionRequest(AsyncResult watcher) {
             super(watcher);
         }

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/transports/TransportSupport.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/transports/TransportSupport.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/transports/TransportSupport.java
index 3c876c1..ca9220f 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/transports/TransportSupport.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/transports/TransportSupport.java
@@ -55,6 +55,8 @@ public class TransportSupport {
      * Creates a Netty SslHandler instance for use in Transports that require
      * an SSL encoder / decoder.
      *
+     * @param remote
+     *        The URI of the remote peer that the SslHandler will be used against.
      * @param options
      *        The SSL options object to build the SslHandler instance from.
      *

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/FactoryFinder.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/FactoryFinder.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/FactoryFinder.java
index de4a3ef..8d013dc 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/FactoryFinder.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/FactoryFinder.java
@@ -26,6 +26,8 @@ import java.util.concurrent.ConcurrentHashMap;
  * A Factory finding helper class used to locate objects that serve as Factories for
  * other Object types.  The search an instantiate mechanism is configurable so that
  * in a non-stand-alone environment such as OSGI the finder and be configured to work.
+ *
+ * @param <T> The type of the object Factory to locate.
  */
 public class FactoryFinder<T extends Object> {
 
@@ -68,6 +70,8 @@ public class FactoryFinder<T extends Object> {
     /**
      * Creates a new instance of the FactoryFinder using the given search path.
      *
+     * @param factoryType
+     *        The Class that defines what this finder is searching for.
      * @param path
      *        The path to use when searching for the factory definitions.
      */

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/IdGenerator.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/IdGenerator.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/IdGenerator.java
index 5d7453e..28beb9f 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/IdGenerator.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/IdGenerator.java
@@ -98,6 +98,9 @@ public class IdGenerator {
 
     /**
      * Construct an IdGenerator
+     *
+     * @param prefix
+     *      The prefix value that is applied to all generated IDs.
      */
     public IdGenerator(String prefix) {
         synchronized (UNIQUE_STUB) {
@@ -189,7 +192,9 @@ public class IdGenerator {
      * From a generated id - return the generator count
      *
      * @param id
-     * @return the count
+     *      The ID that will be parsed for a sequence number.
+     *
+     * @return the sequence value parsed from the given ID.
      */
     public static long getSequenceFromId(String id) {
         long result = -1;
@@ -207,8 +212,9 @@ public class IdGenerator {
     /**
      * Does a proper compare on the Id's
      *
-     * @param id1
-     * @param id2
+     * @param id1 the lhs of the comparison.
+     * @param id2 the rhs of the comparison.
+     *
      * @return 0 if equal else a positive if {@literal id1 > id2} ...
      */
     public static int compare(String id1, String id2) {

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/InetAddressUtil.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/InetAddressUtil.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/InetAddressUtil.java
index b97d665..c7f2324 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/InetAddressUtil.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/InetAddressUtil.java
@@ -36,7 +36,9 @@ public class InetAddressUtil {
      * from the exception, only then is the <tt>UnknownHostException</tt> thrown.
      *
      * @return The hostname
-     * @throws UnknownHostException
+     *
+     * @throws UnknownHostException if the given host cannot be looked up.
+     *
      * @see java.net.InetAddress#getLocalHost()
      * @see java.net.InetAddress#getHostName()
      */

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/LRUCache.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/LRUCache.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/LRUCache.java
index 76b130e..91ae967 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/LRUCache.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/LRUCache.java
@@ -22,8 +22,8 @@ import java.util.Map;
 /**
  * A Simple LRU Cache based on a LinkedHashMap.
  *
- * @param <K>
- * @param <V>
+ * @param <K> The type of the map key.
+ * @param <V> The type of the map value.
  */
 public class LRUCache<K, V> extends LinkedHashMap<K, V> {
 
@@ -41,6 +41,7 @@ public class LRUCache<K, V> extends LinkedHashMap<K, V> {
      * Constructs a LRUCache with a maximum capacity
      *
      * @param maximumCacheSize
+     *      The maximum number of elements to keep in the Cache before eviction starts.
      */
     public LRUCache(int maximumCacheSize) {
         this(0, maximumCacheSize, 0.75f, true);
@@ -50,9 +51,12 @@ public class LRUCache<K, V> extends LinkedHashMap<K, V> {
      * Constructs an empty <tt>LRUCache</tt> instance with the specified
      * initial capacity, maximumCacheSize,load factor and ordering mode.
      *
-     * @param initialCapacity the initial capacity.
+     * @param initialCapacity
+     *      The initial capacity.
      * @param maximumCacheSize
-     * @param loadFactor the load factor.
+     *      The maximum number of elements to keep in the Cache before eviction starts.
+     * @param loadFactor
+     *      The load factor to configure on the underlying map.
      * @param accessOrder the ordering mode - <tt>true</tt> for access-order,
      *                <tt>false</tt> for insertion-order.
      *

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/197d1227/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/MessageQueue.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/MessageQueue.java b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/MessageQueue.java
index bdd99d0..fd35a0a 100644
--- a/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/MessageQueue.java
+++ b/qpid-jms-client/src/main/java/org/apache/qpid/jms/util/MessageQueue.java
@@ -61,6 +61,9 @@ public interface MessageQueue {
      * blocks up to timeout amount of time. Expired messages will consumed by
      * this method.
      *
+     * @param timeout
+     *      The amount of time to wait for an entry to be added before returning null.
+     *
      * @return null if we timeout or if the consumer is closed.
      *
      * @throws InterruptedException if the wait is interrupted.


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