You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ro...@apache.org on 2014/08/08 18:39:34 UTC

svn commit: r1616823 [2/3] - in /qpid/branches/0.30/qpid/java: amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/ bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/ bdbstore/src/main/java/org/apache/qpid/server/store/berk...

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java Fri Aug  8 16:39:32 2014
@@ -77,23 +77,24 @@ import java.util.concurrent.TimeUnit;
  * event on to more specific handlers for the type. In this sense, it channels the richer event model of AMQP,
  * expressed in terms of methods and so on, through the cruder, general purpose event model of MINA, expressed in
  * terms of "message received" and so on.
- *
- * <p/>There is a 1:1 mapping between an AMQProtocolHandler and an {@link AMQConnection}. The connection class is
+ * <p>
+ * There is a 1:1 mapping between an AMQProtocolHandler and an {@link AMQConnection}. The connection class is
  * exposed to the end user of the AMQP client API, and also implements the JMS Connection API, so provides the public
  * API calls through which an individual connection can be manipulated. This protocol handler talks to the network
  * through MINA, in a behind the scenes role; it is not an exposed part of the client API.
- *
- * <p/>There is a 1:many mapping between an AMQProtocolHandler and a set of {@link AMQSession}s. At the MINA level,
+ * <p>
+ * There is a 1:many mapping between an AMQProtocolHandler and a set of {@link AMQSession}s. At the MINA level,
  * there is one session per connection. At the AMQP level there can be many channels which are also called sessions in
  * JMS parlance. The {@link AMQSession}s are managed through an {@link AMQProtocolSession} instance. The protocol
  * session is similar to the MINA per-connection session, except that it can span the lifecycle of multiple MINA sessions
  * in the event of failover. See below for more information about this.
- *
- * <p/>Mina provides a session container that can be used to store/retrieve arbitrary objects as String named
+ * <p>
+ * Mina provides a session container that can be used to store/retrieve arbitrary objects as String named
  * attributes. A more convenient, type-safe, container for session data is provided in the form of
  * {@link AMQProtocolSession}.
  *
- * <p/>A common way to use MINA is to have a single instance of the event handler, and for MINA to pass in its session
+ * <p>
+ * A common way to use MINA is to have a single instance of the event handler, and for MINA to pass in its session
  * object with every event, and for per-connection data to be held in the MINA session (perhaps using a type-safe wrapper
  * as described above). This event handler is different, because dealing with failover complicates things. To the
  * end client of an AMQConnection, a failed over connection is still handled through the same connection instance, but
@@ -101,19 +102,13 @@ import java.util.concurrent.TimeUnit;
  * be used to track the state of the fail-over process, because it is destroyed and a new one is created, as the old
  * connection is shutdown and a new one created. For this reason, an AMQProtocolHandler is created per AMQConnection
  * and the protocol session data is held outside of the MINA IOSession.
- *
- * <p/>This handler is responsible for setting up the filter chain to filter all events for this handler through.
+ * <p>
+ * This handler is responsible for setting up the filter chain to filter all events for this handler through.
  * The filter chain is set up as a stack of event handers that perform the following functions (working upwards from
  * the network traffic at the bottom), handing off incoming events to an asynchronous thread pool to do the work,
  * optionally handling secure sockets encoding/decoding, encoding/decoding the AMQP format itself.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Maintain fail-over state.
- * <tr><td>
- * </table>
- *
- * @todo Use a single handler instance, by shifting everything to do with the 'protocol session' state, including
+ * <p>
+ * TODO  Use a single handler instance, by shifting everything to do with the 'protocol session' state, including
  * failover state, into AMQProtocolSession, and tracking that from AMQConnection? The lifecycles of
  * AMQProtocolSesssion and AMQConnection will be the same, so if there is high cohesion between them, they could
  * be merged, although there is sense in keeping the session model separate. Will clarify things by having data
@@ -203,8 +198,8 @@ public class AMQProtocolHandler implemen
      * where the connection died, an attempt to failover automatically to a new connection may be started. The failover
      * process will be started, provided that it is the clients policy to allow failover, and provided that a failover
      * has not already been started or failed.
-     *
-     * @todo Clarify: presumably exceptionCaught is called when the client is sending during a connection failure and
+     * <p>
+     * TODO  Clarify: presumably exceptionCaught is called when the client is sending during a connection failure and
      * not otherwise? The above comment doesn't make that clear.
      */
     public void closed()
@@ -396,7 +391,7 @@ public class AMQProtocolHandler implemen
      * protocol level waits.
      *
      * This will would normally be used to notify all Frame Listeners that Failover is about to occur and they should
-     * stop waiting and relinquish the Failover lock {@see FailoverHandler}.
+     * stop waiting and relinquish the Failover lock. See {@link FailoverHandler}.
      *
      * Once the {@link FailoverHandler} has re-established the connection then the listeners will be able to re-attempt
      * their protocol request and so listen again for the correct frame.
@@ -727,8 +722,8 @@ public class AMQProtocolHandler implemen
 
     /**
      * Closes the connection.
-     *
-     * <p/>If a failover exception occurs whilst closing the connection it is ignored, as the connection is closed
+     * <p>
+     * If a failover exception occurs whilst closing the connection it is ignored, as the connection is closed
      * anyway.
      *
      * @param timeout The timeout to wait for an acknowledgment to the close request.

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java Fri Aug  8 16:39:32 2014
@@ -55,8 +55,9 @@ import java.util.concurrent.ConcurrentHa
 import java.util.concurrent.ConcurrentMap;
 
 /**
- * Wrapper for protocol session that provides type-safe access to session attributes. <p/> The underlying protocol
- * session is still available but clients should not use it to obtain session attributes.
+ * Wrapper for protocol session that provides type-safe access to session attributes.
+ * <p>
+ * The underlying protocol session is still available but clients should not use it to obtain session attributes.
  */
 public class AMQProtocolSession implements AMQVersionAwareProtocolSession
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/BlockingMethodFrameListener.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/BlockingMethodFrameListener.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/BlockingMethodFrameListener.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/BlockingMethodFrameListener.java Fri Aug  8 16:39:32 2014
@@ -32,31 +32,24 @@ import org.apache.qpid.protocol.AMQMetho
  * incoming methods to a method listener implemented as a sub-class of this and hands off the processed method or
  * error to a consumer. The producer of the event does not have to wait for the consumer to take the event, so this
  * differs from a 'rendezvous' in that sense.
- *
- * <p/>BlockingMethodFrameListeners are used to coordinate waiting for replies to method calls that expect a response.
+ * <p>
+ * BlockingMethodFrameListeners are used to coordinate waiting for replies to method calls that expect a response.
  * They are always used in a 'one-shot' manner, that is, to recieve just one response. Usually the caller has to register
  * them as method listeners with an event dispatcher and remember to de-register them (in a finally block) once they
  * have been completed.
- *
- * <p/>The {@link #processMethod} must return <tt>true</tt> on any incoming method that it handles. This indicates to
+ * <p>
+ * The {@link #processMethod} must return <tt>true</tt> on any incoming method that it handles. This indicates to
  * this listeners that the method it is waiting for has arrived. Incoming methods are also filtered by channel prior to
  * being passed to the {@link #processMethod} method, so responses are only received for a particular channel. The
  * channel id must be passed to the constructor.
- *
- * <p/>Errors from the producer are rethrown to the consumer.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Accept notification of AMQP method events. <td> {@link AMQMethodEvent}
- * <tr><td> Delegate handling of the method to another method listener. <td> {@link AMQMethodBody}
- * <tr><td> Block until a method is handled by the delegated to handler.
- * <tr><td> Propagate the most recent exception to the consumer.
- * </table>
- *
- * @todo Might be neater if this method listener simply wrapped another that provided the method handling using a
+ * <p>
+ * Errors from the producer are rethrown to the consumer.
+ * <p>
+ * TODO  Might be neater if this method listener simply wrapped another that provided the method handling using a
  * methodRecevied method. The processMethod takes an additional channelId, however none of the implementations
  * seem to use it. So wrapping the listeners is possible.
- * @todo If the retrotranslator can handle it, could use a SynchronousQueue to implement this rendezvous. Need to
+ * <p>
+ * TODO  If the retrotranslator can handle it, could use a SynchronousQueue to implement this rendezvous. Need to
  * check that SynchronousQueue has a non-blocking put method available.
  */
 public abstract class BlockingMethodFrameListener extends BlockingWaiter<AMQMethodEvent> implements AMQMethodListener

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/CallbackHandlerRegistry.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/CallbackHandlerRegistry.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/CallbackHandlerRegistry.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/CallbackHandlerRegistry.java Fri Aug  8 16:39:32 2014
@@ -44,23 +44,17 @@ import java.util.TreeMap;
  * authentication. It is capable of reading its configuration from a properties file containing call back handler
  * implementing class names for different SASL mechanism names. Instantiating this registry also has the effect of
  * configuring and registering the SASL client factory implementations using {@link DynamicSaslRegistrar}.
- *
- * <p/>The callback configuration should be specified in a properties file, refered to by the System property
+ * <p>
+ * The callback configuration should be specified in a properties file, refered to by the System property
  * "amp.callbackhandler.properties". The format of the properties file is:
- *
- * <p/><pre>
+ * <p>
+ * <pre>
  * CallbackHanlder.n.mechanism=fully.qualified.class.name where n is an ordinal
  * </pre>
- *
- * <p/>Where mechanism is an IANA-registered mechanism name and the fully qualified class name refers to a
+ * <p>
+ * Where mechanism is an IANA-registered mechanism name and the fully qualified class name refers to a
  * class that implements org.apache.qpid.client.security.AMQCallbackHanlder and provides a call back handler for the
  * specified mechanism.
- *
- * <p><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Parse callback properties.
- * <tr><td> Provide mapping from SASL mechanisms to callback implementations.
- * </table>
  */
 public class CallbackHandlerRegistry
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/DynamicSaslRegistrar.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/DynamicSaslRegistrar.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/DynamicSaslRegistrar.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/DynamicSaslRegistrar.java Fri Aug  8 16:39:32 2014
@@ -40,19 +40,16 @@ import java.util.TreeMap;
  * DynamicSaslRegistrar provides a collection of helper methods for reading a configuration file that contains a mapping
  * from SASL mechanism names to implementing client factory class names and registering a security provider with the
  * Java runtime system, that uses the configured client factory implementations.
- *
- * <p/>The sasl configuration should be specified in a properties file, refered to by the System property
+ * <p>
+ * The sasl configuration should be specified in a properties file, refered to by the System property
  * "amp.dynamicsaslregistrar.properties". The format of the properties file is:
- *
- * <p/><pre>
+ * <p>
+ * <pre>
  * mechanism=fully.qualified.class.name
  * </pre>
- *
- * <p/>Where mechanism is an IANA-registered mechanism name and the fully qualified class name refers to a class that
+ * <p>
+ * Where mechanism is an IANA-registered mechanism name and the fully qualified class name refers to a class that
  * implements javax.security.sasl.SaslClientFactory and provides the specified mechanism.
- *
- * <p><table id="crc"><caption>CRC Card</caption> <tr><th> Responsibilities <th> Collaborations <tr><td> Parse SASL
- * mechanism properties. <tr><td> Create and register security provider for SASL mechanisms. </table>
  */
 public class DynamicSaslRegistrar
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/AMQStateManager.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/AMQStateManager.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/AMQStateManager.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/AMQStateManager.java Fri Aug  8 16:39:32 2014
@@ -34,18 +34,20 @@ import java.util.Set;
 import java.util.concurrent.CopyOnWriteArrayList;
 
 /**
- * The state manager is responsible for managing the state of the protocol session. <p/>
+ * The state manager is responsible for managing the state of the protocol session.
+ * <p>
  * For each {@link org.apache.qpid.client.protocol.AMQProtocolHandler} there is a separate state manager.
- *
+ * <p>
  * The AMQStateManager is now attached to the {@link org.apache.qpid.client.protocol.AMQProtocolHandler} and that is the sole point of reference so that
  * As the {@link AMQProtocolSession} changes due to failover the AMQStateManager need not be copied around.
- *
+ * <p>
  * The StateManager works by any component can wait for a state change to occur by using the following sequence.
- *
- * <li>StateWaiter waiter = stateManager.createWaiter(Set<AMQState> states);
+ * <ul>
+ * <li>{@literal StateWaiter waiter = stateManager.createWaiter(Set<AMQState> states); }
  * <li> // Perform action that will cause state change
  * <li>waiter.await();
- *
+ * </ul>
+ * <p>
  * The two step process is required as there is an inherit race condition between starting a process that will cause
  * the state to change and then attempting to wait for that change. The interest in the change must be first set up so
  * that any asynchronous errors that occur can be delivered to the correct waiters.

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/StateWaiter.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/StateWaiter.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/StateWaiter.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/StateWaiter.java Fri Aug  8 16:39:32 2014
@@ -93,8 +93,8 @@ public class StateWaiter extends Blockin
 
     /**
      * Await for the required State to be achieved.
-     *
-     * <b>It is the responsibility of this class to remove the waiter from the StateManager
+     * <p>
+     * It is the responsibility of this class to remove the waiter from the StateManager
      *
      * @param timeout The time in milliseconds to wait for any of the states to be achieved.
      * @return The achieved state that was requested.

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/url/URLParser_0_10.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/url/URLParser_0_10.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/url/URLParser_0_10.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/url/URLParser_0_10.java Fri Aug  8 16:39:32 2014
@@ -25,30 +25,32 @@ import java.util.ArrayList;
 import java.util.List;
 
 /**
- * The format Qpid URL is based on the AMQP one.
- * The grammar is as follows:
- * <p> qpid_url          = "qpid:" [client_props "@"] port_addr_list ["/" future-parameters]
- * <p> port_addr_list 	 = [port_addr ","]* port_addr
- * <p> port_addr         = tcp_port_addr | tls_prot_addr | future_prot_addr
- * <p> tcp_port_addr     = tcp_id tcp_addr
- * <p> tcp_id            = "tcp:" | ""
- * <p> tcp_addr          = host [":" port]
- * <p> host              = <as per http://www.apps.ietf.org/>
- * <p> port              = number
- * <p> tls_prot_addr     = tls_id tls_addr
- * <p> tls_id            = "tls:" | ""
- * <p> tls_addr          = host [":" port]
- * <p> future_prot_addr  = future_prot_id future_prot_addr
- * <p> future_prot_id    = <placeholder, must end in ":". Example "sctp:">
- * <p> future_prot_addr  = <placeholder, protocl-specific address>
- * <p> future_parameters = <placeholder, not used in failover addresses>
- * <p> client_props      = [client_prop ";"]*  client_prop
- * <p> client_prop       = prop "=" val
- * <p> prop              = chars as per <as per http://www.apps.ietf.org/>
- * <p> val               = valid as per <as per http://www.apps.ietf.org/>
- * <p/>
- * Ex: qpid:virtualhost=tcp:host-foo,test,client_id=foo@tcp:myhost.com:5672,virtualhost=prod;
- * keystore=/opt/keystore@client_id2@tls:mysecurehost.com:5672
+ * The format Qpid URL is based on the AMQP one. The grammar is as follows:
+ * <p>
+ * <p>{@literal qpid_url          = "qpid:" [client_props "@"] port_addr_list ["/" future-parameters] }
+ * <p>{@literal port_addr_list 	 = [port_addr ","]* port_addr }
+ * <p>{@literal port_addr         = tcp_port_addr | tls_prot_addr | future_prot_addr }
+ * <p>{@literal tcp_port_addr     = tcp_id tcp_addr }
+ * <p>{@literal tcp_id            = "tcp:" | "" }
+ * <p>{@literal tcp_addr          = host [":" port] }
+ * <p>{@literal host              = <as per http://www.apps.ietf.org/> }
+ * <p>{@literal port              = number }
+ * <p>{@literal tls_prot_addr     = tls_id tls_addr }
+ * <p>{@literal tls_id            = "tls:" | "" }
+ * <p>{@literal tls_addr          = host [":" port] }
+ * <p>{@literal future_prot_addr  = future_prot_id future_prot_addr }
+ * <p>{@literal future_prot_id    = <placeholder, must end in ":". Example "sctp:"> }
+ * <p>{@literal future_prot_addr  = <placeholder, protocl-specific address> }
+ * <p>{@literal future_parameters = <placeholder, not used in failover addresses> }
+ * <p>{@literal client_props      = [client_prop ";"]*  client_prop }
+ * <p>{@literal client_prop       = prop "=" val }
+ * <p>{@literal prop              = chars as per <as per http://www.apps.ietf.org/> }
+ * <p>{@literal val               = valid as per <as per http://www.apps.ietf.org/> }
+ * <p>
+ * Ex:
+ * <p>
+ * {@literal qpid:virtualhost=tcp:host-foo,test,client_id=foo@tcp:myhost.com:5672,virtualhost=prod;
+ * keystore=/opt/keystore@client_id2@tls:mysecurehost.com:5672 }
  */
 public class URLParser_0_10
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/BlockingWaiter.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/BlockingWaiter.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/BlockingWaiter.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/BlockingWaiter.java Fri Aug  8 16:39:32 2014
@@ -37,29 +37,22 @@ import java.util.concurrent.locks.Reentr
  * incoming Objects to a listener implemented as a sub-class of this and hands off the process or
  * error to a consumer. The producer of the event does not have to wait for the consumer to take the event, so this
  * differs from a 'rendezvous' in that sense.
- *
- * <p/>BlockingWaiters are used to coordinate when waiting for an an event that expect a response.
+ * <p>
+ * BlockingWaiters are used to coordinate when waiting for an an event that expect a response.
  * They are always used in a 'one-shot' manner, that is, to receive just one response. Usually the caller has to register
  * them as method listeners with an event dispatcher and remember to de-register them (in a finally block) once they
  * have been completed.
- *
- * <p/>The {@link #process} must return <tt>true</tt> on any incoming method that it handles. This indicates to
+ * <p>
+ * The {@link #process} must return <tt>true</tt> on any incoming method that it handles. This indicates to
  * this listeners that the object just processed ends the waiting process.
- *
- * <p/>Errors from the producer are rethrown to the consumer.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations </td>
- * <tr><td> Accept generic objects as events for processing via {@link #process}. <td>
- * <tr><td> Delegate handling and understanding of the object to a concrete implementation. <td>
- * <tr><td> Block until {@link #process} determines that waiting is no longer required <td>
- * <tr><td> Propagate the most recent exception to the consumer.<td>
- * </table>
- *
- * @todo Interruption is caught but not handled. This could be allowed to fall through. This might actually be useful
+ * <p>
+ * Errors from the producer are rethrown to the consumer.
+ * <p>
+ * TODO  Interruption is caught but not handled. This could be allowed to fall through. This might actually be useful
  * for fail-over where a thread is blocking when failure happens, it could be interrupted to abandon or retry
  * when this happens. At the very least, restore the interrupted status flag.
- * @todo If the retrotranslator can handle it, could use a SynchronousQueue to implement this rendezvous. Need to
+ * <p>
+ * TODO  If the retrotranslator can handle it, could use a SynchronousQueue to implement this rendezvous. Need to
  * check that SynchronousQueue has a non-blocking put method available.
  */
 public abstract class BlockingWaiter<T>

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/FlowControllingBlockingQueue.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/FlowControllingBlockingQueue.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/FlowControllingBlockingQueue.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/FlowControllingBlockingQueue.java Fri Aug  8 16:39:32 2014
@@ -30,10 +30,12 @@ import java.util.concurrent.ConcurrentLi
 /**
  * A blocking queue that emits events above a user specified threshold allowing the caller to take action (e.g. flow
  * control) to try to prevent the queue growing (much) further. The underlying queue itself is not bounded therefore the
- * caller is not obliged to react to the events. <p/> This implementation is <b>only</b> safe where we have a single
+ * caller is not obliged to react to the events.
+ * <p>
+ * This implementation is <b>only</b> safe where we have a single
  * thread adding items and a single (different) thread removing items.
- *
- * @todo Make this implement java.util.Queue and hide the implementation. Then different queue types can be substituted.
+ * <p>
+ * TODO  Make this implement java.util.Queue and hide the implementation. Then different queue types can be substituted.
  */
 public class FlowControllingBlockingQueue
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jms/ConnectionURL.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jms/ConnectionURL.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jms/ConnectionURL.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jms/ConnectionURL.java Fri Aug  8 16:39:32 2014
@@ -25,9 +25,9 @@ import org.apache.qpid.framing.AMQShortS
 
 /**
  Connection URL format
- amqp://[user:pass@][clientid]/virtualhost?brokerlist='tcp://host:port?option=\'value\'&option=\'value\';tcp://host:port/virtualpath?option=\'value\''&failover='method?option=\'value\'&option='value''"
+ {@literal amqp://[user:pass@][clientid]/virtualhost?brokerlist='tcp://host:port?option=\'value\'&option=\'value\';tcp://host:port/virtualpath?option=\'value\''&failover='method?option=\'value\'&option='value''" }
  Options are of course optional except for requiring a single broker in the broker list.
- The option seperator is defined to be either '&' or ','
+ The option seperator is defined to be either {@literal '&' or ','}
   */
 public interface ConnectionURL
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/NameParserImpl.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/NameParserImpl.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/NameParserImpl.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/NameParserImpl.java Fri Aug  8 16:39:32 2014
@@ -25,7 +25,7 @@ import javax.naming.NamingException;
 
 /**
  * A default implementation of {@link NameParser}
- * <p/>
+ * <p>
  * Based on class from ActiveMQ.
  */
 public class NameParserImpl implements NameParser

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/ReadOnlyContext.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/ReadOnlyContext.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/ReadOnlyContext.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/ReadOnlyContext.java Fri Aug  8 16:39:32 2014
@@ -44,13 +44,13 @@ import java.util.Map;
 /**
  * Based on class from ActiveMQ.
  * A read-only Context
- * <p/>
+ * <p>
  * This version assumes it and all its subcontext are read-only and any attempt
  * to modify (e.g. through bind) will result in an OperationNotSupportedException.
  * Each Context in the tree builds a cache of the entries in all sub-contexts
  * to optimise the performance of lookup.
- * </p>
- * <p>This implementation is intended to optimise the performance of lookup(String)
+ * <p>
+ * This implementation is intended to optimise the performance of lookup(String)
  * to about the level of a HashMap get. It has been observed that the scheme
  * resolution phase performed by the JVM takes considerably longer, so for
  * optimum performance lookups should be coded like:</p>
@@ -147,11 +147,6 @@ public class ReadOnlyContext implements 
      * to bind the remaining name.  It returns a map containing all the bindings from the next context, plus
      * the context it just created (if it in fact created it). (the names are suitably extended by the segment
      * originally lopped off).
-     *
-     * @param name
-     * @param value
-     * @return
-     * @throws javax.naming.NamingException
      */
     protected Map internalBind(String name, Object value) throws NamingException
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelClosedException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelClosedException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelClosedException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelClosedException.java Fri Aug  8 16:39:32 2014
@@ -24,13 +24,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQChannelClosedException indicates that an operation cannot be performed becauase a channel has been closed.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents a failed operation on a closed channel.
- * </table>
- *
- * @todo Does this duplicate AMQChannelException?
  */
 public class AMQChannelClosedException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java Fri Aug  8 16:39:32 2014
@@ -28,13 +28,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQChannelException indicates that an error that requires the channel to be closed has occurred.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents an error that rquires the channel to be closed.
- * </table>
- *
- * @todo Does this duplicate AMQChannelClosedException?
  */
 public class AMQChannelException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionClosedException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionClosedException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionClosedException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionClosedException.java Fri Aug  8 16:39:32 2014
@@ -25,15 +25,8 @@ import org.apache.qpid.protocol.AMQConst
 /**
  * AMQConnectionClosedException indicates that a connection has been closed.
  *
- * <p/>This exception is really used as an event, in order that the method handler that raises it creates an event
+ * <p>This exception is really used as an event, in order that the method handler that raises it creates an event
  * which is propagated to the io handler, in order to notify it of the connection closure.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents a the closure of a connection.
- * </table>
- *
- * @todo Should review where exceptions-as-events
  */
 public class AMQConnectionClosedException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java Fri Aug  8 16:39:32 2014
@@ -29,13 +29,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQConnectionException indicates that an error that requires the channel to be closed has occurred.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents an error that rquires the channel to be closed.
- * </table>
- *
- * @todo Does this duplicate AMQChannelClosedException?
  */
 public class AMQConnectionException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionFailureException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionFailureException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionFailureException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionFailureException.java Fri Aug  8 16:39:32 2014
@@ -26,13 +26,6 @@ import java.util.Collection;
 
 /**
  * AMQConnectionFailureException indicates that a connection to a broker could not be formed.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents failure to connect to a broker.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
  */
 public class AMQConnectionFailureException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQDisconnectedException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQDisconnectedException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQDisconnectedException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQDisconnectedException.java Fri Aug  8 16:39:32 2014
@@ -22,13 +22,6 @@ package org.apache.qpid;
 
 /**
  * AMQDisconnectedException indicates that a broker disconnected without failover.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents disconnection without failover by the broker.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
  */
 public class AMQDisconnectedException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java Fri Aug  8 16:39:32 2014
@@ -26,14 +26,6 @@ import org.apache.qpid.protocol.AMQConst
 /**
  * AMQException forms the root exception of all exceptions relating to the AMQ protocol. It provides space to associate
  * a required AMQ error code with the exception, which is a numeric value, with a meaning defined by the protocol.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents an exception condition associated with an AMQ protocol status code.
- * </table>
- *
- * @todo This exception class is also used as a generic exception throughout Qpid code. This usage may not be strictly
- *       correct if this is to signify a protocol exception. Should review.
  */
 public class AMQException extends Exception
 {
@@ -117,9 +109,9 @@ public class AMQException extends Except
      * Rethrown this exception as a new exception.
      *
      * Attempt to create a new exception of the same class if they have the default constructor of:
-     * {AMQConstant.class, String.class, Throwable.class}
-     * <p>
-     * Individual subclasses may override as requried to create a new instance.
+     * {AMQConstant.class, String.class, Throwable.class}.
+     *
+     * @return cloned exception
      */
     public AMQException cloneForCurrentThread()
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidArgumentException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidArgumentException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidArgumentException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidArgumentException.java Fri Aug  8 16:39:32 2014
@@ -24,11 +24,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQInvalidArgumentException indicates that an invalid argument has been passed to an AMQP method.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents an error due to an invalid argument being passed to an AMQP method.
- * </table>
  */
 public class AMQInvalidArgumentException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidRoutingKeyException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidRoutingKeyException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidRoutingKeyException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidRoutingKeyException.java Fri Aug  8 16:39:32 2014
@@ -24,11 +24,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQInvalidRoutingKeyException indicates an error with a routing key having an invalid format.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents a format error in a routing key.
- * </table>
  */
 public class AMQInvalidRoutingKeyException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQPInvalidClassException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQPInvalidClassException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQPInvalidClassException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQPInvalidClassException.java Fri Aug  8 16:39:32 2014
@@ -23,12 +23,7 @@ package org.apache.qpid;
 /**
  * AMQPInvalidClassException indicates an error when trying to store an illegally typed argument in a field table.
  *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents illegal argument type for field table values.
- * </table>
- *
- * @todo Could just re-use an exising exception like IllegalArgumentException or ClassCastException.
+ * <p>TODO Could just re-use an exising exception like IllegalArgumentException or ClassCastException.
  */
 public class AMQPInvalidClassException extends RuntimeException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQTimeoutException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQTimeoutException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQTimeoutException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQTimeoutException.java Fri Aug  8 16:39:32 2014
@@ -24,11 +24,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQTimeoutException indicates that an expected response from a broker took too long.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Indicates that an expected response from a broker took too long.
- * </table>
  */
 public class AMQTimeoutException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUndeliveredException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUndeliveredException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUndeliveredException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUndeliveredException.java Fri Aug  8 16:39:32 2014
@@ -24,11 +24,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQUndeliveredException indicates that a message, marked immediate or mandatory, could not be delivered.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents failure to delivery a message that must be delivered.
- * </table>
  */
 public class AMQUndeliveredException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUnresolvedAddressException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUnresolvedAddressException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUnresolvedAddressException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUnresolvedAddressException.java Fri Aug  8 16:39:32 2014
@@ -22,15 +22,10 @@ package org.apache.qpid;
 
 /**
  * AMQUnresolvedAddressException indicates failure to resolve a socket address.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents failre to resolve a socket address.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
- *
- * @todo Why replace java.nio.UnresolvedAddressException with this? This is checked, which may explain why, but it
+ * <p>
+ * TODO Not an AMQP exception as no status code.
+ * <p>
+ * TODO Why replace java.nio.UnresolvedAddressException with this? This is checked, which may explain why, but it
  *       doesn't wrap the underlying exception.
  */
 public class AMQUnresolvedAddressException extends AMQException

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/api/Message.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/api/Message.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/api/Message.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/api/Message.java Fri Aug  8 16:39:32 2014
@@ -47,6 +47,7 @@ public interface Message
 	 * <li> To Socket (Stream)
 	 * </ul>
 	 * @param src - the data to append
+	 * @throws IOException if there is an issue appending the data
 	 */
 	public void appendData(byte[] src) throws IOException;
 
@@ -63,6 +64,7 @@ public interface Message
      * <li> To Socket (Stream)
      * </ul>
      * @param src - the data to append
+     * @throws IOException if there is an issue appending the data
      */
     public void appendData(ByteBuffer src) throws IOException;
 
@@ -78,6 +80,7 @@ public interface Message
 	 * <li> From Socket as and when it gets streamed
 	 * </ul>
 	 * @param target  The target byte[] which the data gets copied to
+     * @throws IOException if there is an issue reading the data
 	 */
     public void readData(byte[] target) throws IOException;
 
@@ -94,7 +97,7 @@ public interface Message
      * </ul>
      *
      * @return A ByteBuffer containing data
-     * @throws IOException
+     * @throws IOException if there is an issue reading the data
      */
     public ByteBuffer readData() throws IOException;
 

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java Fri Aug  8 16:39:32 2014
@@ -25,11 +25,6 @@ import org.apache.qpid.protocol.AMQVersi
 /**
  * AMQCodecFactory is a Mina codec factory. It supplies the encoders and decoders need to read and write the bytes to
  * the wire.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations.
- * <tr><td> Supply the protocol decoder. <td> {@link AMQDecoder}
- * </table>
  */
 public class AMQCodecFactory
 {
@@ -44,6 +39,7 @@ public class AMQCodecFactory
      *
      * @param expectProtocolInitiation <tt>true</tt> if the first frame received is going to be a protocol initiation
      *                                 frame, <tt>false</tt> if it is going to be a standard AMQ data block.
+     * @param session protocol session (connection)
      */
     public AMQCodecFactory(boolean expectProtocolInitiation, AMQVersionAwareProtocolSession session)
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java Fri Aug  8 16:39:32 2014
@@ -46,17 +46,11 @@ import java.util.ListIterator;
  * protocol initiation decoder. It is a cumulative decoder, which means that it can accumulate data to decode in the
  * buffer until there is enough data to decode.
  *
- * <p/>One instance of this class is created per session, so any changes or configuration done at run time to the
+ * <p>One instance of this class is created per session, so any changes or configuration done at run time to the
  * decoder will only affect decoding of the protocol session data to which is it bound.
  *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Delegate protocol initiation to its decoder. <td> {@link ProtocolInitiation.Decoder}
- * <tr><td> Delegate AMQP data to its decoder. <td> {@link AMQDataBlockDecoder}
- * <tr><td> Accept notification that protocol initiation has completed.
- * </table>
- *
- * @todo If protocol initiation decoder not needed, then don't create it. Probably not a big deal, but it adds to the
+ * <p>
+ * TODO If protocol initiation decoder not needed, then don't create it. Probably not a big deal, but it adds to the
  *       per-session overhead.
  */
 public class AMQDecoder
@@ -78,6 +72,7 @@ public class AMQDecoder
      * Creates a new AMQP decoder.
      *
      * @param expectProtocolInitiation <tt>true</tt> if this decoder needs to handle protocol initiation.
+     * @param session protocol session (connection)
      */
     public AMQDecoder(boolean expectProtocolInitiation, AMQVersionAwareProtocolSession session)
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/AMQPFilterTypes.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/AMQPFilterTypes.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/AMQPFilterTypes.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/AMQPFilterTypes.java Fri Aug  8 16:39:32 2014
@@ -24,11 +24,6 @@ import org.apache.qpid.framing.AMQShortS
 
 /**
  * Specifies the different filter types for consumers that filter their messages.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent different consumer filter types.
- * </table>
  */
 public enum AMQPFilterTypes
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/QpidProperties.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/QpidProperties.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/QpidProperties.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/QpidProperties.java Fri Aug  8 16:39:32 2014
@@ -35,17 +35,13 @@ import java.util.Properties;
  * idea behind this, is that every build has these values incorporated directly into its jar file, so that code in the
  * wild can be identified, should its origination be forgotten.
  *
- * <p/>To get the build version of any Qpid code call the {@link #main} method. This version string is usually also
+ * <p>To get the build version of any Qpid code call the {@link #main} method. This version string is usually also
  * printed to the console on broker start up.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><td>Load build versioning information into the runtime, for code identification purposes.
- * </table>
- *
- * @todo Code to locate/load/log properties can be factored into a reusable properties utils class. Avoid having this
+ * <p>
+ * TODO  Code to locate/load/log properties can be factored into a reusable properties utils class. Avoid having this
  *       same snippet of loading code scattered in many places.
- *
- * @todo Could also add a build number property for a sequential build number assigned by an automated build system, for
+ * <p>
+ * TODO  Could also add a build number property for a sequential build number assigned by an automated build system, for
  *       build reproducability purposes.
  */
 public class QpidProperties

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyException.java Fri Aug  8 16:39:32 2014
@@ -26,12 +26,8 @@ import org.apache.qpid.AMQException;
  * Indicates a failure to parse a property expansion. See {@link PropertyUtils} for the code that does property
  * expansions.
  *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaboration
- * <tr><td> Represent failure to expand a property name into a value.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
+ * <p>
+ * TODO Not an AMQP exception as no status code.
  */
 public class PropertyException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyUtils.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyUtils.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyUtils.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyUtils.java Fri Aug  8 16:39:32 2014
@@ -26,15 +26,11 @@ import java.util.Iterator;
 /**
  * PropertyUtils provides helper methods for dealing with Java properties.
  *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Expand system properties into strings with named expansions.
- * </table>
- *
- * @todo Make the lookup method generic by passing in the properties to use for the expansion, rather than hard coding
+ * <p>
+ * TODO  Make the lookup method generic by passing in the properties to use for the expansion, rather than hard coding
  *       as system properties. The expansion code has greater potential for re-use that way.
- *
- * @todo Some more property related code could be added to this utils class, which might more appropriately reside under
+ * <p>
+ * TODO  Some more property related code could be added to this utils class, which might more appropriately reside under
  *       org.apache.qpid.util. For example standardised code to load properties from a resource name, currently found in
  *       QpidProperties and possibly other places could be moved here.
  */

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/dtx/XidImpl.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/dtx/XidImpl.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/dtx/XidImpl.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/dtx/XidImpl.java Fri Aug  8 16:39:32 2014
@@ -99,14 +99,14 @@ public class XidImpl implements Xid
      * +---+---+---+---+---+---+---+-  -+---+---+-  -+---+
      * 0               4   5   6           6+g         6+g+b
      * format_id: an implementation specific format identifier
-     * <p/>
+     * <p>
      * gtrid_length: how many bytes of this form the transaction id
-     * <p/>
+     * <p>
      * bqual_length: how many bytes of this form the branch id
-     * <p/>
+     * <p>
      * data: a sequence of octets of at most 128 bytes containing the txn id and the
      * branch id
-     * <p/>
+     * <p>
      * Note - The sum of the two lengths must equal the length of the data field.
      *
      * @param xid an XID STring Form
@@ -239,14 +239,14 @@ public class XidImpl implements Xid
      * +---+---+---+---+---+---+---+-  -+---+---+-  -+---+
      * 0               4   5   6           6+g         6+g+b
      * format_id: an implementation specific format identifier
-     * <p/>
+     * <p>
      * gtrid_length: how many bytes of this form the transaction id
-     * <p/>
+     * <p>
      * bqual_length: how many bytes of this form the branch id
-     * <p/>
+     * <p>
      * data: a sequence of octets of at most 128 bytes containing the txn id and the
      * branch id
-     * <p/>
+     * <p>
      * Note - The sum of the two lengths must equal the length of the data field.
      *
      * @param xid an Xid to convert.

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java Fri Aug  8 16:39:32 2014
@@ -20,19 +20,12 @@
  */
 package org.apache.qpid.exchange;
 
-import org.apache.qpid.framing.AMQShortString;
-
 /**
  * Defines the names of the standard AMQP exchanges that every AMQP broker should provide. These exchange names
  * and type are given in the specification.
  *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Defines the standard AMQP exchange names.
- * <tr><td> Defines the standard AMQP exchange types.
- * </table>
- *
- * @todo A type safe enum, might be more appropriate for the exchange types.
+ * <p>
+ * TODO A type safe enum, might be more appropriate for the exchange types.
  */
 public class ExchangeDefaults
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java Fri Aug  8 16:39:32 2014
@@ -30,10 +30,6 @@ public abstract class ArithmeticExpressi
     protected static final int LONG = 2;
     protected static final int DOUBLE = 3;
 
-    /**
-     * @param left
-     * @param right
-     */
     public ArithmeticExpression(Expression left, Expression right)
     {
         super(left, right);
@@ -262,11 +258,6 @@ public abstract class ArithmeticExpressi
         return evaluate(lvalue, rvalue);
     }
 
-    /**
-     * @param lvalue
-     * @param rvalue
-     * @return
-     */
     protected abstract Object evaluate(Object lvalue, Object rvalue);
 
 }

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java Fri Aug  8 16:39:32 2014
@@ -83,7 +83,7 @@ public abstract class BinaryExpression i
      * Returns the symbol that represents this binary expression.  For example, addition is
      * represented by "+"
      *
-     * @return
+     * @return the expression symbol
      */
     public abstract String getExpressionSymbol();
 

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java Fri Aug  8 16:39:32 2014
@@ -28,7 +28,7 @@ public interface BooleanExpression exten
 {
 
     /**
-     * @param message
+     * @param message message to match
      * @return true if the expression evaluates to Boolean.TRUE.
      */
     public boolean matches(FilterableMessage message);

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java Fri Aug  8 16:39:32 2014
@@ -74,9 +74,6 @@ public abstract class ComparisonExpressi
 
         private Pattern likePattern;
 
-        /**
-         * @param right
-         */
         public LikeExpression(Expression right, String like, int escape)
         {
             super(right);
@@ -316,9 +313,9 @@ public abstract class ComparisonExpressi
     }
 
     /**
-     * Only Numeric expressions can be used in >, >=, < or <= expressions.s
+     * Only Numeric expressions can be used in {@literal >, >=, < or <=} expressions.
      *
-     * @param expr
+     * @param expr expression to check
      */
     public static void checkLessThanOperand(Expression expr)
     {
@@ -341,10 +338,10 @@ public abstract class ComparisonExpressi
     }
 
     /**
-     * Validates that the expression can be used in == or <> expression.
+     * Validates that the expression can be used in {@literal == or <>} expression.
      * Cannot not be NULL TRUE or FALSE literals.
      *
-     * @param expr
+     * @param expr expression to check
      */
     public static void checkEqualOperand(Expression expr)
     {
@@ -374,10 +371,6 @@ public abstract class ComparisonExpressi
         }
     }
 
-    /**
-     * @param left
-     * @param right
-     */
     public ComparisonExpression(Expression left, Expression right)
     {
         super(left, right);

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java Fri Aug  8 16:39:32 2014
@@ -181,8 +181,8 @@ public class ConstantExpression implemen
      * Encodes the value of string so that it looks like it would look like
      * when it was provided in a selector.
      *
-     * @param s
-     * @return
+     * @param s string to encode
+     * @return encoded string
      */
     public static String encodeString(String s)
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java Fri Aug  8 16:39:32 2014
@@ -27,6 +27,7 @@ public interface Expression
 {
 
     /**
+     * @param message message to evaluate
      * @return the value of this expression
      */
     public Object evaluate(FilterableMessage message);

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java Fri Aug  8 16:39:32 2014
@@ -36,10 +36,6 @@ public abstract class LogicExpression ex
         return new AndExpression(lvalue, rvalue);
     }
 
-    /**
-     * @param left
-     * @param right
-     */
     public LogicExpression(BooleanExpression left, BooleanExpression right)
     {
         super(left, right);

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlock.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlock.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlock.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlock.java Fri Aug  8 16:39:32 2014
@@ -39,7 +39,8 @@ public abstract class AMQDataBlock imple
 
     /**
      * Writes the datablock to the specified buffer.
-     * @param buffer
+     * @param buffer the buffer to write to
+     * @throws IOException if there is a problem writing the output
      */
     public abstract void writePayload(DataOutput buffer) throws IOException;
 

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrameDecodingException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrameDecodingException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrameDecodingException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrameDecodingException.java Fri Aug  8 16:39:32 2014
@@ -26,11 +26,6 @@ import org.apache.qpid.protocol.AMQConst
 /**
  * AMQFrameDecodingException indicates that an AMQP frame cannot be decoded because it does not have the correct
  * format as defined by the protocol.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents a format error in a protocol frame.
- * </table>
  */
 public class AMQFrameDecodingException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java Fri Aug  8 16:39:32 2014
@@ -32,9 +32,12 @@ public interface AMQMethodBody extends A
 {
     public static final byte TYPE = 1;
 
-    /** AMQP version */
+    /** AMQP major version 
+     * @return the major version*/
     public byte getMajor();
 
+    /** AMQP minor version 
+     * @return the minor version*/
     public byte getMinor();
 
 

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java Fri Aug  8 16:39:32 2014
@@ -46,7 +46,9 @@ public abstract class AMQMethodBodyImpl 
     }
 
 
-    /** unsigned short */
+    /** unsigned short
+     *
+     * @return body size*/
     abstract protected int getBodySize();
 
 

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolClassException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolClassException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolClassException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolClassException.java Fri Aug  8 16:39:32 2014
@@ -22,13 +22,8 @@ package org.apache.qpid.framing;
 
 /**
  * AMQProtocolInstanceException indicates that the protocol class is incorrect in a header.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent incorrect protocol class in frame header.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
+ * <p>
+ * TODO Not an AMQP exception as no status code.
  */
 public class AMQProtocolClassException extends AMQProtocolHeaderException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolHeaderException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolHeaderException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolHeaderException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolHeaderException.java Fri Aug  8 16:39:32 2014
@@ -24,13 +24,8 @@ import org.apache.qpid.AMQException;
 
 /**
  * AMQProtocolHeaderException indicates a format error in an AMQP frame header.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent format error in frame header.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
+ * <p>
+ * TODO Not an AMQP exception as no status code.
  */
 public class AMQProtocolHeaderException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolInstanceException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolInstanceException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolInstanceException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolInstanceException.java Fri Aug  8 16:39:32 2014
@@ -22,13 +22,8 @@ package org.apache.qpid.framing;
 
 /**
  * AMQProtocolInstanceException indicates that the protocol instance is incorrect in a header.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent incorrect protocol instance in frame header.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
+ * <p>
+ * TODO Not an AMQP exception as no status code.
  */
 public class AMQProtocolInstanceException extends AMQProtocolHeaderException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolVersionException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolVersionException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolVersionException.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolVersionException.java Fri Aug  8 16:39:32 2014
@@ -22,13 +22,8 @@ package org.apache.qpid.framing;
 
 /**
  * AMQProtocolInstanceException indicates that the client and server differ on expected protocol version  in a header.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent incorrect protocol version in frame header.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
+ * <p>
+ * TODO Not an AMQP exception as no status code.
  */
 public class AMQProtocolVersionException extends AMQProtocolHeaderException
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQType.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQType.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQType.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQType.java Fri Aug  8 16:39:32 2014
@@ -30,16 +30,6 @@ import java.util.Collection;
  * AMQType is a type that represents the different possible AMQP field table types. It provides operations for each
  * of the types to perform tasks such as calculating the size of an instance of the type, converting types between AMQP
  * and Java native types, and reading and writing instances of AMQP types in binary formats to and from byte buffers.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Get the equivalent one byte identifier for a type.
- * <tr><td> Calculate the size of an instance of an AMQP parameter type. <td> {@link EncodingUtils}
- * <tr><td> Convert an instance of an AMQP parameter into a compatable Java object tagged with its AMQP type.
- *     <td> {@link AMQTypedValue}
- * <tr><td> Write an instance of an AMQP parameter type to a byte buffer. <td> {@link EncodingUtils}
- * <tr><td> Read an instance of an AMQP parameter from a byte buffer. <td> {@link EncodingUtils}
- * </table>
  */
 public enum AMQType
 {
@@ -827,6 +817,7 @@ public enum AMQType
      *
      * @param value  An instance of the type.
      * @param buffer The byte buffer to write it to.
+     * @throws IOException if there is a problem writing to the buffer
      */
     public void writeToBuffer(Object value, DataOutput buffer) throws IOException
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java Fri Aug  8 16:39:32 2014
@@ -33,15 +33,6 @@ import java.util.Map;
  * value. It provides the ability to read and write fully typed parameters to and from byte buffers. It also provides
  * the ability to create such parameters from Java native value and a type tag or to extract the native value and type
  * from one.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Create a fully typed AMQP value from a native type and a type tag. <td> {@link AMQType}
- * <tr><td> Create a fully typed AMQP value from a binary representation in a byte buffer. <td> {@link AMQType}
- * <tr><td> Write a fully typed AMQP value to a binary representation in a byte buffer. <td> {@link AMQType}
- * <tr><td> Extract the type from a fully typed AMQP value.
- * <tr><td> Extract the value from a fully typed AMQP value.
- * </table>
  */
 public abstract class AMQTypedValue
 {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java Fri Aug  8 16:39:32 2014
@@ -76,11 +76,14 @@ public class ContentHeaderBody implement
     }
 
     /**
-     * Helper method that is used currently by the persistence layer (by BDB at the moment).
-     * @param buffer
-     * @param size
-     * @return
-     * @throws AMQFrameDecodingException
+     * Helper method that is used currently by the persistence layer.
+     * @param buffer buffer to decode
+     * @param size size of the body
+     *
+     * @return the decoded header body
+     * @throws AMQFrameDecodingException if there is a decoding issue
+     * @throws AMQProtocolVersionException if there is a version issue
+     * @throws IOException if there is an IO issue
      */
     public static ContentHeaderBody createFromBuffer(DataInputStream buffer, long size)
         throws AMQFrameDecodingException, AMQProtocolVersionException, IOException
@@ -152,7 +155,9 @@ public class ContentHeaderBody implement
         return weight;
     }
 
-    /** unsigned long but java can't handle that anyway when allocating byte array */
+    /** unsigned long but java can't handle that anyway when allocating byte array
+     *
+     * @return the body size */
     public long getBodySize()
     {
         return bodySize;

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java Fri Aug  8 16:39:32 2014
@@ -594,9 +594,9 @@ public class EncodingUtils
 
     /**
      * This is used for writing longstrs.
-     *
-     * @param buffer
-     * @param data
+     * @param buffer buffer to write to
+     * @param data data to write
+     * @throws IOException if there is an issue writing the output
      */
     public static void writeLongstr(DataOutput buffer, byte[] data) throws IOException
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java Fri Aug  8 16:39:32 2014
@@ -73,7 +73,8 @@ public class FieldTable
      * Construct a new field table.
      *
      * @param buffer the buffer from which to read data. The length byte must be read already
-     * @param length the length of the field table. Must be > 0.
+     * @param length the length of the field table. Must be great than 0.
+     * @throws IOException if there is an issue reading the buffer
      */
     public FieldTable(DataInput buffer, long length) throws IOException
     {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java Fri Aug  8 16:39:32 2014
@@ -137,6 +137,7 @@ public class ProtocolInitiation extends 
          * @param in input buffer
          * @return true if we have enough data to decode the PI frame fully, false if more
          * data is required
+         * @throws IOException if there is an issue reading the input
          */
         public boolean decodable(MarkableDataInput in) throws IOException
         {

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/pool/ReferenceCountingExecutorService.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/pool/ReferenceCountingExecutorService.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/pool/ReferenceCountingExecutorService.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/pool/ReferenceCountingExecutorService.java Fri Aug  8 16:39:32 2014
@@ -33,28 +33,19 @@ import java.util.concurrent.TimeUnit;
  * the references taken, instantiating the service on the first reference, and shutting it down when the last
  * reference is released.
  *
- * <p/>It is important to ensure that an executor service is correctly shut down as failing to do so prevents the JVM
+ * <p>It is important to ensure that an executor service is correctly shut down as failing to do so prevents the JVM
  * from terminating due to the existence of non-daemon threads.
  *
- * <p/><table id="crc><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Provide a shared executor service. <td> {@link Executors}
- * <tr><td> Shutdown the executor service when not needed. <td> {@link ExecutorService}
- * <tr><td> Track references to the executor service.
- * <tr><td> Provide configuration of the executor service.
- * </table>
- *
- * @todo Might be more elegant to make this actually implement ExecutorService, providing better hiding of the
+ * <p>
+ * TODO  Might be more elegant to make this actually implement ExecutorService, providing better hiding of the
  *       implementation details. Also this class introduces a pattern (albeit specific to this usage) that could be
  *       generalized to reference count anything. That is, on first instance call a create method, on release of last
  *       instance call a destroy method. This could definitely be abstracted out as a re-usable piece of code; a
  *       reference counting factory. It could then be re-used to do reference counting in other places (such as
  *       messages). Countable objects have a simple create/destroy life cycle, capturable by an interface that the
  *       ref counting factory can call to manage the lifecycle.
- *
- * @todo {@link #_poolSize} should be static?
- *
- * @todo The {@link #getPool()} method breaks the encapsulation of the reference counter. Generally when getPool is used
+ * <p>
+ * TODO  The {@link #getPool()} method breaks the encapsulation of the reference counter. Generally when getPool is used
  *       further checks are applied to ensure that the executor service has not been shutdown. This passes responsibility
  *       for managing the lifecycle of the reference counted object onto the caller rather than neatly encapsulating it
  *       here. Could think about adding more state to the lifecycle, to mark ref counted objects as invalid, and have an

Modified: qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQConstant.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQConstant.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQConstant.java (original)
+++ qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQConstant.java Fri Aug  8 16:39:32 2014
@@ -28,20 +28,14 @@ import java.util.Map;
 /**
  * Defines constants for AMQP codes and also acts as a factory for creating such constants from the raw codes. Each
  * constant also defines a short human readable description of the constant.
- *
- * @todo Why would a constant be defined that is not in the map? Seems more natural that getConstant should raise an
+ * <p>
+ * TODO  Why would a constant be defined that is not in the map? Seems more natural that getConstant should raise an
  *       exception for an unknown constant. Or else provide an explanation of why this is so. Also, there is no way for
  *       callers to determine the unknown status of a code except by comparing its name to "unknown code", which would
  *       seem to render this scheme a little bit pointless?
- *
- * @todo Java has a nice enum construct for doing this sort of thing. Maybe this is done in the old style for Java 1.4
+ * <p>
+ * TODO  Java has a nice enum construct for doing this sort of thing. Maybe this is done in the old style for Java 1.4
  *       backward compatability? Now that is handled through retrotranslater it may be time to use enum.
- *
- * <p/><tabld id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Define the set of AMQP status codes.
- * <tr><td> Provide a factory to lookup constants by their code.
- * <tr><td>
  */
 public final class AMQConstant
 {



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