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 [1/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...

Author: robbie
Date: Fri Aug  8 16:39:32 2014
New Revision: 1616823

URL: http://svn.apache.org/r1616823
Log:
QPID-5980: port javadoc fixups from trunk to the 0.30 branch

Modified:
    qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/NameParserImpl.java
    qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/ReadOnlyContext.java
    qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/BDBBackup.java
    qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom5To6.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/log4j/QpidCompositeRollingAppender.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/exchange/HeadersExchange.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/LogSubject.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/log4j/LoggingManagementFacade.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/message/MessageSource.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/registry/ApplicationRegistry.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/AuthorizationHolder.java
    qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/auth/manager/ldap/AbstractLDAPSSLSocketFactory.java
    qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/Action.java
    qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/RuleSet.java
    qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQNoMethodHandlerException.java
    qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java
    qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQAuthenticationException.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQConnection.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQNoConsumersException.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQNoRouteException.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSessionDirtyException.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQTopic.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageConsumer.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/Closeable.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/JMSAMQException.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/RejectBehaviour.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/XAResourceImpl.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverException.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverHandler.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverProtectedOperation.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverRetrySupport.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverState.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverSupport.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolHandler.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/AMQProtocolSession.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/protocol/BlockingMethodFrameListener.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/CallbackHandlerRegistry.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/security/DynamicSaslRegistrar.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/AMQStateManager.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/state/StateWaiter.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/url/URLParser_0_10.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/BlockingWaiter.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/util/FlowControllingBlockingQueue.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jms/ConnectionURL.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/NameParserImpl.java
    qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/jndi/ReadOnlyContext.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelClosedException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQChannelException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionClosedException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQConnectionFailureException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQDisconnectedException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidArgumentException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQInvalidRoutingKeyException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQPInvalidClassException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQTimeoutException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUndeliveredException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/AMQUnresolvedAddressException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/api/Message.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/AMQPFilterTypes.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/common/QpidProperties.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/configuration/PropertyUtils.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/dtx/XidImpl.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQDataBlock.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQFrameDecodingException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBody.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolClassException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolHeaderException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolInstanceException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQProtocolVersionException.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQType.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/pool/ReferenceCountingExecutorService.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQConstant.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQMethodEvent.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQMethodListener.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQProtocolWriter.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/AMQVersionAwareProtocolSession.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/protocol/ProtocolVersionAware.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/transport/Connection.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/transport/ConnectionSettings.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/transport/Session.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Decoder.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Encoder.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/transport/network/NetworkConnection.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/typedmessage/TypedBytesContentReader.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/util/CommandLineParser.java
    qpid/branches/0.30/qpid/java/common/src/main/java/org/apache/qpid/util/FileUtils.java
    qpid/branches/0.30/qpid/java/jca/src/main/java/org/apache/qpid/ra/QpidRASessionImpl.java
    qpid/branches/0.30/qpid/java/jca/src/main/java/org/apache/qpid/ra/inflow/QpidActivationSpec.java
    qpid/branches/0.30/qpid/java/management/common/src/main/java/org/apache/qpid/management/common/mbeans/ManagedExchange.java
    qpid/branches/0.30/qpid/java/management/example/src/main/java/org/apache/qpid/example/jmxexample/QueueInformation.java
    qpid/branches/0.30/qpid/java/perftests/src/main/java/org/apache/qpid/disttest/ConfigFileHelper.java
    qpid/branches/0.30/qpid/java/qpid-systests-parent/pom.xml
    qpid/branches/0.30/qpid/java/tools/src/main/java/org/apache/qpid/testkit/TestLauncher.java

Modified: qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/NameParserImpl.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/NameParserImpl.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/NameParserImpl.java (original)
+++ qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/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/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/ReadOnlyContext.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/ReadOnlyContext.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/ReadOnlyContext.java (original)
+++ qpid/branches/0.30/qpid/java/amqp-1-0-client-jms/src/main/java/org/apache/qpid/amqp_1_0/jms/jndi/ReadOnlyContext.java Fri Aug  8 16:39:32 2014
@@ -45,13 +45,13 @@ import javax.naming.spi.NamingManager;
 /**
  * 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>
@@ -148,11 +148,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/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/BDBBackup.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/BDBBackup.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/BDBBackup.java (original)
+++ qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/BDBBackup.java Fri Aug  8 16:39:32 2014
@@ -41,41 +41,38 @@ import java.util.Properties;
 
 /**
  * BDBBackup is a utility for taking hot backups of the current state of a BDB transaction log database.
- *
- * <p/>This utility makes the following assumptions/performs the following actions:
- *
- * <p/><ul> <li>The from and to directory locations will already exist. This scripts does not create them. <li>If this
+ * <p>
+ * This utility makes the following assumptions/performs the following actions:
+ * <p>
+ * <ul> <li>The from and to directory locations will already exist. This scripts does not create them. <li>If this
  * script fails to complete in one minute it will terminate. <li>This script always exits with code 1 on error, code 0
  * on success (standard unix convention). <li>This script will log out at info level, when it starts and ends and a list
  * of all files backed up. <li>This script logs all errors at error level. <li>This script does not perform regular
  * backups, wrap its calling script in a cron job or similar to do this. </ul>
- *
- * <p/>This utility is build around the BDB provided backup helper utility class, DbBackup. This utility class provides
+ * <p>
+ * This utility is build around the BDB provided backup helper utility class, DbBackup. This utility class provides
  * an ability to force BDB to stop writing to the current log file set, whilst the backup is taken, to ensure that a
  * consistent snapshot is acquired. Preventing BDB from writing to the current log file set, does not stop BDB from
  * continuing to run concurrently while the backup is running, it simply moves onto a new set of log files; this
  * provides a 'hot' backup facility.
- *
- * <p/>DbBackup can also help with incremental backups, by providing the number of the last log file backed up.
+ * <p>
+ * DbBackup can also help with incremental backups, by providing the number of the last log file backed up.
  * Subsequent backups can be taken, from later log files only. In a messaging application, messages are not expected to
  * be long-lived in most cases, so the log files will usually have been completely turned over between backups. This
  * utility does not support incremental backups for this reason.
- *
- * <p/>If the database is locked by BDB, as is required when using transactions, and therefore will always be the case
+ * <p>
+ * If the database is locked by BDB, as is required when using transactions, and therefore will always be the case
  * in Qpid, this utility cannot make use of the DbBackup utility in a seperate process. DbBackup, needs to ensure that
  * the BDB envinronment used to take the backup has exclusive write access to the log files. This utility can take a
  * backup as a standalone utility against log files, when a broker is not running, using the {@link #takeBackup(String,
  *String,com.sleepycat.je.Environment)} method.
- *
- * <p/>A seperate backup machanism is provided by the {@link #takeBackupNoLock(String,String)} method which can take a
+ * <p>
+ * A seperate backup machanism is provided by the {@link #takeBackupNoLock(String,String)} method which can take a
  * hot backup against a running broker. This works by finding out the set of files to copy, and then opening them all to
  * read, and repeating this process until a consistent set of open files is obtained. This is done to avoid the
  * situation where the BDB cleanup thread deletes a file, between the directory listing and opening of the file to copy.
  * All consistently opened files are copied. This is the default mechanism the the {@link #main} method of this utility
  * uses.
- *
- * <p/><table id="crc><caption>CRC Card</caption> <tr><th> Responsibilities <th> Collaborations <tr><td> Hot copy all
- * BDB log files from one directory to another. </table>
  */
 public class BDBBackup
 {
@@ -102,10 +99,10 @@ public class BDBBackup
     /**
      * Runs a backup of the BDB log files in a specified directory, copying the backed up files to another specified
      * directory.
-     *
-     * <p/>The following arguments must be specified:
-     *
-     * <p/><table><caption>Command Line</caption> <tr><th> Option <th> Comment <tr><td> -fromdir <td> The path to the
+     * <p>
+     * The following arguments must be specified:
+     * <table>
+     * <caption>Command Line</caption> <tr><th> Option <th> Comment <tr><td> -fromdir <td> The path to the
      * directory to back the bdb log file from. <tr><td> -todir   <td> The path to the directory to save the backed up
      * bdb log files to. </table>
      *

Modified: qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom5To6.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom5To6.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom5To6.java (original)
+++ qpid/branches/0.30/qpid/java/bdbstore/src/main/java/org/apache/qpid/server/store/berkeleydb/upgrade/UpgradeFrom5To6.java Fri Aug  8 16:39:32 2014
@@ -110,8 +110,8 @@ public class UpgradeFrom5To6 extends Abs
      *
      * Message content is moved from the database messageContentDb_v5 to
      * MESSAGE_CONTENT. The structure of the database changes from ( message-id:
-     * long, chunk-id: int ) -> ( size: int, byte[] data ) to ( message-id:
-     * long) -> ( byte[] data )
+     * long, chunk-id: int ) {@literal ->} ( size: int, byte[] data ) to ( message-id:
+     * long) {@literal ->} ( byte[] data )
      *
      * That is we keep only one record per message, which contains all the
      * message content

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/log4j/QpidCompositeRollingAppender.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/log4j/QpidCompositeRollingAppender.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/log4j/QpidCompositeRollingAppender.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/log4j/QpidCompositeRollingAppender.java Fri Aug  8 16:39:32 2014
@@ -51,7 +51,7 @@ import java.util.zip.GZIPOutputStream;
  * <p>A of few additional optional features have been added:<br> -- Attach date pattern for current log file (@see
  * staticLogFileName)<br> -- Backup number increments for newer files (@see countDirection)<br> -- Infinite number of
  * backups by file size (@see maxSizeRollBackups)<br> <br> <p>A few notes and warnings:  For large or infinite number of
- * backups countDirection > 0 is highly recommended, with staticLogFileName = false if time based rolling is also used
+ * backups countDirection {@literal >} 0 is highly recommended, with staticLogFileName = false if time based rolling is also used
  * -- this will reduce the number of file renamings to few or none.  Changing staticLogFileName or countDirection
  * without clearing the directory could have nasty side effects.  If Date/Time based rolling is enabled,
  * CompositeRollingAppender will attempt to roll existing files in the directory without a date/time tag based on the
@@ -358,9 +358,9 @@ public class QpidCompositeRollingAppende
     }
 
     /**
-     * By default newer files have lower numbers. (countDirection < 0) ie. log.1 is most recent, log.5 is the 5th
-     * backup, etc... countDirection > 0 does the opposite ie. log.1 is the first backup made, log.5 is the 5th backup
-     * made, etc. For infinite backups use countDirection > 0 to reduce rollOver costs.
+     * By default newer files have lower numbers. (countDirection {@literal <} 0) ie. log.1 is most recent, log.5 is the 5th
+     * backup, etc... countDirection {@literal >} 0 does the opposite ie. log.1 is the first backup made, log.5 is the 5th backup
+     * made, etc. For infinite backups use countDirection {@literal >} 0 to reduce rollOver costs.
      */
     public int getCountDirection()
     {
@@ -686,9 +686,9 @@ public class QpidCompositeRollingAppende
     /**
      * Implements roll overs base on file size.
      *
-     * <p>If the maximum number of size based backups is reached (<code>curSizeRollBackups == maxSizeRollBackups</code)
+     * <p>If the maximum number of size based backups is reached (<code>curSizeRollBackups {@literal ==} maxSizeRollBackups</code>)
      * then the oldest file is deleted -- it's index determined by the sign of countDirection.<br> If
-     * <code>countDirection</code> < 0, then files {<code>File.1</code>, ..., <code>File.curSizeRollBackups -1</code>}
+     * <code>countDirection</code> {@literal <} 0, then files {<code>File.1</code>, ..., <code>File.curSizeRollBackups -1</code>}
      * are renamed to {<code>File.2</code>, ..., <code>File.curSizeRollBackups</code>}.  Moreover, <code>File</code> is
      * renamed <code>File.1</code> and closed.<br>
      *
@@ -697,7 +697,7 @@ public class QpidCompositeRollingAppende
      * <p>If <code>maxSizeRollBackups</code> is equal to zero, then the <code>File</code> is truncated with no backup
      * files created.
      *
-     * <p>If <code>maxSizeRollBackups</code> < 0, then <code>File</code> is renamed if needed and no files are deleted.
+     * <p>If <code>maxSizeRollBackups</code> {@literal <} 0, then <code>File</code> is renamed if needed and no files are deleted.
      */
 
     // synchronization not necessary since doAppend is already synched

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/exchange/HeadersExchange.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/exchange/HeadersExchange.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/exchange/HeadersExchange.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/exchange/HeadersExchange.java Fri Aug  8 16:39:32 2014
@@ -45,7 +45,7 @@ import org.apache.qpid.server.virtualhos
  * An exchange that binds queues based on a set of required headers and header values
  * and routes messages to these queues by matching the headers of the message against
  * those with which the queues were bound.
- * <p/>
+ * <p>
  * <pre>
  * The Headers Exchange
  *

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/LogSubject.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/LogSubject.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/LogSubject.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/LogSubject.java Fri Aug  8 16:39:32 2014
@@ -30,7 +30,7 @@ public interface LogSubject 
     /**
      * Provides the log message as as String.
      *
-     * @returns String the display representation of this LogSubject
+     * @return String the display representation of this LogSubject
      */
     public String toLogString();
 }
\ No newline at end of file

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/log4j/LoggingManagementFacade.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/log4j/LoggingManagementFacade.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/log4j/LoggingManagementFacade.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/logging/log4j/LoggingManagementFacade.java Fri Aug  8 16:39:32 2014
@@ -122,11 +122,11 @@ public class LoggingManagementFacade
     /** The log4j XML configuration file DTD defines three possible element
      * combinations for specifying optional logger+level settings.
      * Must account for the following:
-     *
-     * <category name="x"> <priority value="y"/> </category>    OR
-     * <category name="x"> <level value="y"/> </category>    OR
-     * <logger name="x"> <level value="y"/> </logger>
-     *
+     * <p>
+     * {@literal <category name="x"> <priority value="y"/> </category>} OR
+     * {@literal <category name="x"> <level value="y"/> </category>} OR
+     * {@literal <logger name="x"> <level value="y"/> </logger>}
+     * <p>
      * Noting also that the level/priority child element is optional too,
      * and not the only possible child element.
      */
@@ -171,10 +171,10 @@ public class LoggingManagementFacade
      * The log4j XML configuration file DTD defines 2 possible element
      * combinations for specifying the optional root logger level settings
      * Must account for the following:
-     *
-     * <root> <priority value="y"/> </root>    OR
-     * <root> <level value="y"/> </root>
-     *
+     * <p>
+     * {@literal <root> <priority value="y"/> </root> } OR
+     * {@literal <root> <level value="y"/> </root>}
+     * <p>
      * Noting also that the level/priority child element is optional too,
      * and not the only possible child element.
      */

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/message/MessageSource.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/message/MessageSource.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/message/MessageSource.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/message/MessageSource.java Fri Aug  8 16:39:32 2014
@@ -54,13 +54,8 @@ public interface MessageSource extends T
     /**
      * ExistingExclusiveConsumer signals a failure to create a consumer, because an exclusive consumer
      * already exists.
-     *
-     * <p/><table id="crc"><caption>CRC Card</caption>
-     * <tr><th> Responsibilities <th> Collaborations
-     * <tr><td> Represent failure to create a consumer, because an exclusive consumer already exists.
-     * </table>
-     *     *
-     * @todo Move to top level, used outside this class.
+     * <p>
+     * TODO Move to top level, used outside this class.
      */
     static final class ExistingExclusiveConsumer extends Exception
     {
@@ -73,13 +68,8 @@ public interface MessageSource extends T
     /**
      * ExistingConsumerPreventsExclusive signals a failure to create an exclusive consumer, as a consumer
      * already exists.
-     *
-     * <p/><table id="crc"><caption>CRC Card</caption>
-     * <tr><th> Responsibilities <th> Collaborations
-     * <tr><td> Represent failure to create an exclusive consumer, as a consumer already exists.
-     * </table>
-     *     *
-     * @todo Move to top level, used outside this class.
+     * <p>
+     * TODO Move to top level, used outside this class.
      */
     static final class ExistingConsumerPreventsExclusive extends Exception
     {

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/registry/ApplicationRegistry.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/registry/ApplicationRegistry.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/registry/ApplicationRegistry.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/registry/ApplicationRegistry.java Fri Aug  8 16:39:32 2014
@@ -41,7 +41,7 @@ import org.apache.qpid.util.SystemUtils;
 /**
  * An abstract application registry that provides access to configuration information and handles the
  * construction and caching of configurable objects.
- * <p/>
+ * <p>
  * Subclasses should handle the construction of the "registered objects" such as the exchange registry.
  */
 public class ApplicationRegistry implements IApplicationRegistry

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/AuthorizationHolder.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/AuthorizationHolder.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/AuthorizationHolder.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/AuthorizationHolder.java Fri Aug  8 16:39:32 2014
@@ -32,7 +32,7 @@ public interface AuthorizationHolder
     /**
      * Returns the {@link Subject} of the authorized user.  This is guaranteed to
      * contain at least one {@link org.apache.qpid.server.security.auth.UsernamePrincipal}, representing the the identity
-     * used when the user logged on to the application, and zero or more {@link org.apache.qpid.server.security.auth.sasl.GroupPrincipal}
+     * used when the user logged on to the application, and zero or more {@link org.apache.qpid.server.security.group.GroupPrincipal}
      * representing the group(s) to which the user belongs.
      *
      * @return the Subject

Modified: qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/auth/manager/ldap/AbstractLDAPSSLSocketFactory.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/auth/manager/ldap/AbstractLDAPSSLSocketFactory.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/auth/manager/ldap/AbstractLDAPSSLSocketFactory.java (original)
+++ qpid/branches/0.30/qpid/java/broker-core/src/main/java/org/apache/qpid/server/security/auth/manager/ldap/AbstractLDAPSSLSocketFactory.java Fri Aug  8 16:39:32 2014
@@ -35,19 +35,16 @@ import javax.net.ssl.SSLSocketFactory;
  * <p>
  * Concrete implementations of this class are <b>generated dynamically</b> at runtime by
  * the {@link LDAPSSLSocketFactoryGenerator#createSubClass(String, SSLSocketFactory)} method.
- * </p>
  * <p>
  * Callers will create new instances of the concrete implementations by using the static
  * <code>#getDefault()</code> method. This will return an instance of the sub-class that is
  * associated with the {@link SSLSocketFactory}.
- * </p>
  * <p>
  * If callers are passing the sub-class to an API via class-name (i.e. String), the caller
  * <b>must</b> ensure that the context classloader of the thread to set to the classloader
  * of sub-class for the duration of the API call(s).
- * </p>
+ * <p>
  * For more details  see {@link LDAPSSLSocketFactoryGenerator}.
- * </p>
  */
 public abstract class AbstractLDAPSSLSocketFactory extends SSLSocketFactory
 {

Modified: qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/Action.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/Action.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/Action.java (original)
+++ qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/Action.java Fri Aug  8 16:39:32 2014
@@ -33,8 +33,8 @@ import org.apache.qpid.server.security.a
  *
  * An action consists of an {@link Operation} on an {@link ObjectType} with certain properties, stored in a {@link java.util.Map}.
  * The operation and object should be an allowable combination, based on the {@link ObjectType#isAllowed(Operation)}
- * method of the object, which is exposed as the {@link #isAllowed()} method here. The internal {@link #propertiesMatch(Map)}
- * and {@link #valueMatches(String, String)} methods are used to determine wildcarded matching of properties, with
+ * method of the object, which is exposed as the {@link #isAllowed()} method here. The internal #propertiesMatch(Map)
+ * and #valueMatches(String, String) methods are used to determine wildcarded matching of properties, with
  * the empty string or "*" matching all values, and "*" at the end of a rule value indicating prefix matching.
  * <p>
  * The {@link #matches(Action)} method is intended to be used when determining precedence of rules, and

Modified: qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/RuleSet.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/RuleSet.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/RuleSet.java (original)
+++ qpid/branches/0.30/qpid/java/broker-plugins/access-control/src/main/java/org/apache/qpid/server/security/access/config/RuleSet.java Fri Aug  8 16:39:32 2014
@@ -49,9 +49,6 @@ import org.apache.qpid.server.security.a
 
 /**
  * Models the rule configuration for the access control plugin.
- *
- * The access control rule definitions are loaded from an external configuration file, passed in as the
- * target to the {@link load(ConfigurationFile)} method. The file specified
  */
 public class RuleSet implements EventLoggerProvider
 {

Modified: qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQNoMethodHandlerException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQNoMethodHandlerException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQNoMethodHandlerException.java (original)
+++ qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/AMQNoMethodHandlerException.java Fri Aug  8 16:39:32 2014
@@ -27,14 +27,10 @@ import org.apache.qpid.protocol.AMQMetho
 /**
  * AMQNoMethodHandlerException represents the case where no method handler exists to handle an AQMP method.
  *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents failure to handle an AMQP method.
- * </table>
- *
- * @todo Not an AMQP exception as no status code.
- *
- * @todo Missing method handler. Unlikely to ever happen, and if it does its a coding error. Consider replacing with a
+ * <p>
+ * TODO  Not an AMQP exception as no status code.
+ * <p>
+ * TODO  Missing method handler. Unlikely to ever happen, and if it does its a coding error. Consider replacing with a
  *       Runtime.
  */
 public class AMQNoMethodHandlerException extends AMQException

Modified: qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java (original)
+++ qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/ConsumerTarget_0_8.java Fri Aug  8 16:39:32 2014
@@ -43,8 +43,10 @@ import java.util.concurrent.atomic.Atomi
 import java.util.concurrent.atomic.AtomicLong;
 
 /**
- * Encapsulation of a subscription to a queue. <p/> Ties together the protocol session of a subscriber, the consumer tag
- * that was given out by the broker and the channel id. <p/>
+ * Encapsulation of a subscription to a queue.
+ * <p>
+ * Ties together the protocol session of a subscriber, the consumer tag
+ * that was given out by the broker and the channel id.
  */
 public abstract class ConsumerTarget_0_8 extends AbstractConsumerTarget implements FlowCreditManager.FlowCreditManagerListener
 {
@@ -170,10 +172,8 @@ public abstract class ConsumerTarget_0_8
          * This method can be called by each of the publisher threads. As a result all changes to the channel object must be
          * thread safe.
          *
-         *
          * @param entry   The message to send
          * @param batch
-         * @throws org.apache.qpid.AMQException
          */
         @Override
         public void send(MessageInstance entry, boolean batch)
@@ -286,10 +286,8 @@ public abstract class ConsumerTarget_0_8
          * This method can be called by each of the publisher threads. As a result all changes to the channel object must be
          * thread safe.
          *
-         *
          * @param entry   The message to send
          * @param batch
-         * @throws org.apache.qpid.AMQException
          */
         @Override
         public void send(MessageInstance entry, boolean batch)

Modified: qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java (original)
+++ qpid/branches/0.30/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/state/AMQStateManager.java Fri Aug  8 16:39:32 2014
@@ -43,8 +43,9 @@ import org.apache.qpid.server.security.S
 import org.apache.qpid.server.util.ServerScopedRuntimeException;
 
 /**
- * The state manager is responsible for managing the state of the protocol session. <p/> For each AMQProtocolHandler
- * there is a separate state manager.
+ * The state manager is responsible for managing the state of the protocol session.
+ * <p>
+ * For each AMQProtocolHandler there is a separate state manager.
  */
 public class AMQStateManager implements AMQMethodListener
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQAuthenticationException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQAuthenticationException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQAuthenticationException.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQAuthenticationException.java Fri Aug  8 16:39:32 2014
@@ -25,13 +25,8 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQAuthenticationException represents all failures to authenticate access to a broker.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent failure to authenticate the client.
- * </table>
- *
- * @todo Will this alwyas have the same status code, NOT_ALLOWED 530? Might set this up to always use that code.
+ * <p>
+ * TODO Will this alwyas have the same status code, NOT_ALLOWED 530? Might set this up to always use that code.
  */
 public class AMQAuthenticationException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQConnection.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQConnection.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQConnection.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQConnection.java Fri Aug  8 16:39:32 2014
@@ -224,7 +224,7 @@ public class AMQConnection extends Close
     }
 
     /**
-     * @todo Some horrible stuff going on here with setting exceptions to be non-null to detect if an exception
+     * TODO Some horrible stuff going on here with setting exceptions to be non-null to detect if an exception
      * was thrown during the connection! Intention not clear. Use a flag anyway, not exceptions... Will fix soon.
      */
     public AMQConnection(ConnectionURL connectionURL) throws AMQException

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQNoConsumersException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQNoConsumersException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQNoConsumersException.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQNoConsumersException.java Fri Aug  8 16:39:32 2014
@@ -25,11 +25,6 @@ import org.apache.qpid.protocol.AMQConst
 
 /**
  * AMQNoConsumersException indicates failure to pass an immediate message to a consumer.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represents failure to pass an immediate message to a consumer.
- * <tr><td>
  */
 public class AMQNoConsumersException extends AMQUndeliveredException
 {

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

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSession.java Fri Aug  8 16:39:32 2014
@@ -79,20 +79,15 @@ import org.apache.qpid.thread.Threading;
 import org.apache.qpid.transport.SessionException;
 import org.apache.qpid.transport.TransportException;
 
-/**
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td>
- * </table>
- *
- * @todo Different FailoverSupport implementation are needed on the same method call, in different situations. For
+/*
+ * TODO  Different FailoverSupport implementation are needed on the same method call, in different situations. For
  * example, when failing-over and reestablishing the bindings, the bind cannot be interrupted by a second
  * fail-over, if it fails with an exception, the fail-over process should also fail. When binding outside of
  * the fail-over process, the retry handler could be used to automatically retry the operation once the connection
  * has been reestablished. All fail-over protected operations should be placed in private methods, with
  * FailoverSupport passed in by the caller to provide the correct support for the calling context. Sometimes the
  * fail-over process sets a nowait flag and uses an async method call instead.
- * @todo Two new objects created on every failover supported method call. Consider more efficient ways of doing this,
+ * TODO  Two new objects created on every failover supported method call. Consider more efficient ways of doing this,
  * after looking at worse bottlenecks first.
  */
 public abstract class AMQSession<C extends BasicMessageConsumer, P extends BasicMessageProducer> extends Closeable implements Session, QueueSession, TopicSession
@@ -613,14 +608,14 @@ public abstract class AMQSession<C exten
      * @param multiple    <tt>true</tt> to acknowledge all messages up to and including the one specified by the
      *                    delivery tag, <tt>false</tt> to just acknowledge that message.
      *
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     public abstract void acknowledgeMessage(long deliveryTag, boolean multiple);
 
     /**
      * Binds the named queue, with the specified routing key, to the named exchange.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param queueName    The name of the queue to bind.
      * @param routingKey   The routing key to bind the queue with.
@@ -628,8 +623,8 @@ public abstract class AMQSession<C exten
      * @param exchangeName The exchange to bind the queue on.
      *
      * @throws AMQException If the queue cannot be bound for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
-     * @todo Document the additional arguments that may be passed in the field table. Are these for headers exchanges?
+     * TODO  Be aware of possible changes to parameter order as versions change.
+     * TODO  Document the additional arguments that may be passed in the field table. Are these for headers exchanges?
      */
     public void bindQueue(final AMQShortString queueName, final AMQShortString routingKey, final FieldTable arguments,
                           final AMQShortString exchangeName, final AMQDestination destination) throws AMQException
@@ -666,18 +661,18 @@ public abstract class AMQSession<C exten
 
     /**
      * Closes the session.
-     *
-     * <p/>Note that this operation succeeds automatically if a fail-over interrupts the synchronous request to close
+     * <p>
+     * Note that this operation succeeds automatically if a fail-over interrupts the synchronous request to close
      * the channel. This is because the channel is marked as closed before the request to close it is made, so the
      * fail-over should not re-open it.
      *
      * @param timeout The timeout in milliseconds to wait for the session close acknowledgement from the broker.
      *
      * @throws JMSException If the JMS provider fails to close the session due to some internal error.
-     * @todo Be aware of possible changes to parameter order as versions change.
-     * @todo Not certain about the logic of ignoring the failover exception, because the channel won't be
+     * TODO  Be aware of possible changes to parameter order as versions change.
+     * TODO Not certain about the logic of ignoring the failover exception, because the channel won't be
      * re-opened. May need to examine this more carefully.
-     * @todo Note that taking the failover mutex doesn't prevent this operation being interrupted by a failover,
+     * TODO  Note that taking the failover mutex doesn't prevent this operation being interrupted by a failover,
      * because the failover process sends the failover event before acquiring the mutex itself.
      */
     public void close(long timeout) throws JMSException
@@ -802,8 +797,8 @@ public abstract class AMQSession<C exten
     }
     /**
      * Commits all messages done in this transaction and releases any locks currently held.
-     *
-     * <p/>If the commit fails, because the commit itself is interrupted by a fail-over between requesting that the
+     * <p>
+     * If the commit fails, because the commit itself is interrupted by a fail-over between requesting that the
      * commit be done, and receiving an acknowledgement that it has been done, then a JMSException will be thrown.
      * The client will be unable to determine whether or not the commit actually happened on the broker in this case.
      *
@@ -1237,8 +1232,8 @@ public abstract class AMQSession<C exten
 
     /**
      * Declares the named queue.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param name       The name of the queue to declare.
      * @param autoDelete
@@ -1246,7 +1241,7 @@ public abstract class AMQSession<C exten
      * @param exclusive  Flag to indicate that the queue is exclusive to this client.
      *
      * @throws AMQException If the queue cannot be declared for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     public void createQueue(final AMQShortString name, final boolean autoDelete, final boolean durable,
                             final boolean exclusive) throws AMQException
@@ -1256,8 +1251,8 @@ public abstract class AMQSession<C exten
 
     /**
      * Declares the named queue.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param name       The name of the queue to declare.
      * @param autoDelete
@@ -1266,7 +1261,7 @@ public abstract class AMQSession<C exten
      * @param arguments  Arguments used to set special properties of the queue
      *
      * @throws AMQException If the queue cannot be declared for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     public void createQueue(final AMQShortString name, final boolean autoDelete, final boolean durable,
                             final boolean exclusive, final Map<String, Object> arguments) throws AMQException
@@ -1684,11 +1679,11 @@ public abstract class AMQSession<C exten
 
     /**
      * Stops message delivery in this session, and restarts message delivery with the oldest unacknowledged message.
-     *
-     * <p/>All consumers deliver messages in a serial order. Acknowledging a received message automatically acknowledges
+     * <p>
+     * All consumers deliver messages in a serial order. Acknowledging a received message automatically acknowledges
      * all messages that have been delivered to the client.
-     *
-     * <p/>Restarting a session causes it to take the following actions:
+     * <p>
+     * Restarting a session causes it to take the following actions:
      *
      * <ul>
      * <li>Stop message delivery.</li>
@@ -1697,14 +1692,15 @@ public abstract class AMQSession<C exten
      * Redelivered messages do not have to be delivered in exactly their original delivery order.</li>
      * </ul>
      *
-     * <p/>If the recover operation is interrupted by a fail-over, between asking that the broker begin recovery and
+     * <p>
+     * If the recover operation is interrupted by a fail-over, between asking that the broker begin recovery and
      * receiving acknowledgment that it has then a JMSException will be thrown. In this case it will not be possible
      * for the client to determine whether the broker is going to recover the session or not.
      *
      * @throws JMSException If the JMS provider fails to stop and restart message delivery due to some internal error.
      *                      Not that this does not necessarily mean that the recovery has failed, but simply that it is
      *                      not possible to tell if it has or not.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      *
      * Strategy for handling recover.
      * Flush any acks not yet sent.
@@ -1806,15 +1802,15 @@ public abstract class AMQSession<C exten
 
     /**
      * Commits all messages done in this transaction and releases any locks currently held.
-     *
-     * <p/>If the rollback fails, because the rollback itself is interrupted by a fail-over between requesting that the
+     * <p>
+     * If the rollback fails, because the rollback itself is interrupted by a fail-over between requesting that the
      * rollback be done, and receiving an acknowledgement that it has been done, then a JMSException will be thrown.
      * The client will be unable to determine whether or not the rollback actually happened on the broker in this case.
      *
      * @throws JMSException If the JMS provider fails to rollback the transaction due to some internal error. This does
      *                      not mean that the rollback is known to have failed, merely that it is not known whether it
      *                      failed or not.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     public void rollback() throws JMSException
     {
@@ -2120,8 +2116,8 @@ public abstract class AMQSession<C exten
 
     /**
      * Tests whether or not the specified queue is bound to the specified exchange under a particular routing key.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param exchangeName The exchange name to test for binding against.
      * @param queueName    The queue name to check if bound.
@@ -2130,7 +2126,7 @@ public abstract class AMQSession<C exten
      * @return <tt>true</tt> if the queue is bound to the exchange and routing key, <tt>false</tt> if not.
      *
      * @throws JMSException If the query fails for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     public abstract boolean isQueueBound(final AMQShortString exchangeName, final AMQShortString queueName, final AMQShortString routingKey)
             throws JMSException;
@@ -2141,7 +2137,9 @@ public abstract class AMQSession<C exten
 
     /**
      * Called to mark the session as being closed. Useful when the session needs to be made invalid, e.g. after failover
-     * when the client has veoted resubscription. <p/> The caller of this method must already hold the failover mutex.
+     * when the client has veoted resubscription.
+     * <p>
+     * The caller of this method must already hold the failover mutex.
      */
     void markClosed()
     {
@@ -2296,7 +2294,7 @@ public abstract class AMQSession<C exten
      * Starts the session, which ensures that it is not suspended and that its event dispatcher is running.
      *
      * @throws AMQException If the session cannot be started for any reason.
-     * @todo This should be controlled by _stopped as it pairs with the stop method fixme or check the
+     * TODO  This should be controlled by _stopped as it pairs with the stop method fixme or check the
      * FlowControlledBlockingQueue _queue to see if we have flow controlled. will result in sending Flow messages
      * for each subsequent call to flow.. only need to do this if we have called stop.
      */
@@ -2638,8 +2636,8 @@ public abstract class AMQSession<C exten
 
     /**
      * Returns the number of messages currently queued for the given destination.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param amqd The destination to be checked
      *
@@ -2685,8 +2683,8 @@ public abstract class AMQSession<C exten
 
     /**
      * Declares the named exchange and type of exchange.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param name            The name of the exchange to declare.
      * @param type            The type of the exchange to declare.
@@ -2695,7 +2693,7 @@ public abstract class AMQSession<C exten
      * @param autoDelete
      * @param internal
      * @throws AMQException If the exchange cannot be declared for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     private void declareExchange(final AMQShortString name, final AMQShortString type,
                                  final boolean nowait, final boolean durable,
@@ -2716,12 +2714,12 @@ public abstract class AMQSession<C exten
 
     /**
      * Declares a queue for a JMS destination.
-     *
-     * <p/>Note that for queues but not topics the name is generated in the client rather than the server. This allows
+     * <p>
+     * Note that for queues but not topics the name is generated in the client rather than the server. This allows
      * the name to be reused on failover if required. In general, the destination indicates whether it wants a name
      * generated or not.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      *
      * @param amqd            The destination to declare as a queue.
@@ -2731,8 +2729,8 @@ public abstract class AMQSession<C exten
      *
      *
      * @throws AMQException If the queue cannot be declared for any reason.
-     * @todo Verify the destiation is valid or throw an exception.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Verify the destiation is valid or throw an exception.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     protected AMQShortString declareQueue(final AMQDestination amqd,
                                           final boolean noLocal) throws AMQException
@@ -2752,13 +2750,13 @@ public abstract class AMQSession<C exten
 
     /**
      * Undeclares the specified queue.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param queueName The name of the queue to delete.
      *
      * @throws JMSException If the queue could not be deleted for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     protected void deleteQueue(final AMQShortString queueName) throws JMSException
     {
@@ -2781,13 +2779,13 @@ public abstract class AMQSession<C exten
 
     /**
      * Undeclares the specified temporary queue/topic.
-     *
-     * <p/>Note that this operation automatically retries in the event of fail-over.
+     * <p>
+     * Note that this operation automatically retries in the event of fail-over.
      *
      * @param amqQueue The name of the temporary destination to delete.
      *
      * @throws JMSException If the queue could not be deleted for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     protected void deleteTemporaryDestination(final TemporaryDestination amqQueue) throws JMSException
     {
@@ -3014,11 +3012,11 @@ public abstract class AMQSession<C exten
     /**
      * Suspends or unsuspends this session.
      *
-     * @param suspend <tt>true</tt> indicates that the session should be suspended, <tt>false<tt> indicates that it
+     * @param suspend true indicates that the session should be suspended, false indicates that it
      *                should be unsuspended.
      *
      * @throws AMQException If the session cannot be suspended for any reason.
-     * @todo Be aware of possible changes to parameter order as versions change.
+     * TODO  Be aware of possible changes to parameter order as versions change.
      */
     protected void suspendChannel(boolean suspend) throws AMQException // , FailoverException
     {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSessionDirtyException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSessionDirtyException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSessionDirtyException.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQSessionDirtyException.java Fri Aug  8 16:39:32 2014
@@ -27,11 +27,6 @@ import org.apache.qpid.protocol.AMQConst
  * AMQSessionDirtyException represents all failures to send data on a transacted session that is
  * no longer in a state that the client expects. i.e. failover has occured so previously sent messages
  * will not be part of the transaction.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent attempt to perform additional sends on a dirty session.
- * </table>
  */
 public class AMQSessionDirtyException extends AMQException
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQTopic.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQTopic.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQTopic.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/AMQTopic.java Fri Aug  8 16:39:32 2014
@@ -218,7 +218,7 @@ public class AMQTopic extends AMQDestina
      * Override since the queue is always private and we must ensure it remains null. If not,
      * reuse of the topic when registering consumers will make all consumers listen on the same (private) queue rather
      * than getting their own (private) queue.
-     * <p/>
+     * <p>
      * This is relatively nasty but it is difficult to come up with a more elegant solution, given
      * the requirement in the case on AMQQueue and possibly other AMQDestination subclasses to
      * use the underlying queue name even where it is server generated.

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageConsumer.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageConsumer.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageConsumer.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/BasicMessageConsumer.java Fri Aug  8 16:39:32 2014
@@ -1024,8 +1024,11 @@ public abstract class BasicMessageConsum
     }
 
     /**
-     * Used in the blocking receive methods to receive a message from the Session thread. <p/> Or to notify of errors
-     * <p/> Argument true indicates we want strict FIFO semantics
+     * Used in the blocking receive methods to receive a message from the Session thread.
+     * <p>
+     * Or to notify of errors.
+     * <p>
+     * Argument true indicates we want strict FIFO semantics
      */
     protected BlockingQueue getSynchronousQueue()
     {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/Closeable.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/Closeable.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/Closeable.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/Closeable.java Fri Aug  8 16:39:32 2014
@@ -27,18 +27,11 @@ import java.util.concurrent.atomic.Atomi
 /**
  * Captures the 'closed' state of an object, that is initially open, can be tested to see if it is closed, and provides
  * a 'close' method to close it.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Mark an object as closed.
- * <tr><td> Check if an object is closed.
- * <tr><td> Raise a JMS exception if an object is closed.
- * </table>
- *
- * @todo Might be better to make this an interface. This whole class doesn't really encapsulate a terribly neat
+ * <p>
+ * TODO  Might be better to make this an interface. This whole class doesn't really encapsulate a terribly neat
  *       piece of re-usable functionality. A simple interface defining a close method would suffice.
- *
- * @todo The convenience method {@link #checkNotClosed} is not that helpfull, what if the caller wants to do something
+ * <p>
+ * TODO  The convenience method {@link #checkNotClosed} is not that helpfull, what if the caller wants to do something
  *       other than throw an exception? It doesn't really represent a very usefull re-usable piece of code. Consider
  *       inlining it and dropping the method.
  */

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/JMSAMQException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/JMSAMQException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/JMSAMQException.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/JMSAMQException.java Fri Aug  8 16:39:32 2014
@@ -28,11 +28,6 @@ import javax.jms.JMSException;
  * JMSException does not accept wrapped exceptions in its constructor. Presumably this is because it is a relatively old
  * Java exception class, before this was added as a default to Throwable. This exception class accepts wrapped exceptions
  * as well as error messages, through its constructor, but is a JMSException.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Accept wrapped exceptions as a JMSException.
- * </table>
  */
 public class JMSAMQException extends JMSException
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/RejectBehaviour.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/RejectBehaviour.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/RejectBehaviour.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/RejectBehaviour.java Fri Aug  8 16:39:32 2014
@@ -23,7 +23,7 @@ package org.apache.qpid.client;
 /**
  * This enum can be used only with for 0-8/0-9/0-9-1 protocols connections to notify
  * the client to delegate the requeue/DLQ decision to the server
- * if <code>SERVER</server> value is specified. Otherwise the messages won't be moved to
+ * if <code>SERVER</code> value is specified. Otherwise the messages won't be moved to
  * the DLQ (or dropped) when delivery count exceeds the maximum.
  */
 public enum RejectBehaviour

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/XAResourceImpl.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/XAResourceImpl.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/XAResourceImpl.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/XAResourceImpl.java Fri Aug  8 16:39:32 2014
@@ -121,7 +121,7 @@ public class XAResourceImpl implements A
      * The transaction context is in a suspended state and must be resumed via the start method with TMRESUME specified.
      * <li> If TMFAIL is specified, the portion of work has failed. The resource manager may mark the transaction as rollback-only
      * <li> If TMSUCCESS is specified, the portion of work has completed successfully.
-     * /ul>
+     * </ul>
      *
      * @param xid  A global transaction identifier that is the same as the identifier used previously in the start method
      * @param flag One of TMSUCCESS, TMFAIL, or TMSUSPEND.
@@ -312,7 +312,7 @@ public class XAResourceImpl implements A
 
     /**
      * Obtains a list of prepared transaction branches.
-     * <p/>
+     * <p>
      * The transaction manager calls this method during recovery to obtain the list of transaction branches
      * that are currently in prepared or heuristically completed states.
      *

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverException.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverException.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverException.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverException.java Fri Aug  8 16:39:32 2014
@@ -24,13 +24,8 @@ package org.apache.qpid.client.failover;
  * FailoverException is used to indicate that a synchronous request has failed to receive the reply that it is waiting
  * for because the fail-over process has been started whilst it was waiting for its reply. Synchronous methods generally
  * raise this exception to indicate that they must be re-tried once the fail-over process has completed.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Used to indicate failure of a synchronous request due to fail-over.
- * </table>
- *
- * @todo This exception is created and passed as an argument to a method, rather than thrown. The exception is being
+ * <p>
+ * TODO This exception is created and passed as an argument to a method, rather than thrown. The exception is being
  *       used to represent an event, passed out to other threads. Use of exceptions as arguments rather than as
  *       exceptions is extremly confusing. Ideally use a condition or set a flag and check it instead.
  *       This exceptions-as-events pattern seems to be in a similar style to Mina code, which is not pretty, but

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverHandler.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverHandler.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverHandler.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverHandler.java Fri Aug  8 16:39:32 2014
@@ -36,13 +36,13 @@ import java.util.concurrent.CountDownLat
  * connections, failing over to a new connection if the transport connection fails. The procedure to establish a new
  * connection is expressed as a continuation, in order that it may be run in a seperate thread to the i/o thread that
  * detected the failure and is used to handle the communication to establish a new connection.
- *
- * </p>The reason this needs to be a separate thread is because this work cannot be done inside the i/o processor
+ * <p>
+ * The reason this needs to be a separate thread is because this work cannot be done inside the i/o processor
  * thread. The significant task is the connection setup which involves a protocol exchange until a particular state
  * is achieved. This procedure waits until the state is achieved which would prevent the i/o thread doing the work
  * it needs to do to achieve the new state.
- *
- * <p/>The failover procedure does the following:
+ * <p>
+ * The failover procedure does the following:
  *
  * <ol>
  * <li>Sets the failing over condition to true.</li>
@@ -57,21 +57,17 @@ import java.util.concurrent.CountDownLat
  * <li>Resets the failing over condition and releases the mutex.</li>
  * </ol>
  *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Update fail-over state <td> {@link AMQProtocolHandler}
- * </table>
- *
- * @todo The failover latch and mutex are used like a lock and condition. If the retrotranlator supports lock/condition
+ * <p>
+ * TODO  The failover latch and mutex are used like a lock and condition. If the retrotranlator supports lock/condition
  *       then could change over to using them. 1.4 support still needed.
- *
- * @todo If the condition is set to null on a vetoes fail-over and there are already other threads waiting on the
+ * <p>
+ * TODO  If the condition is set to null on a vetoes fail-over and there are already other threads waiting on the
  *       condition, they will never be released. It might be an idea to reset the condition in a finally block.
- *
- * @todo Creates a {@link AMQDisconnectedException} and passes it to the AMQConnection. No need to use an
+ * <p>
+ * TODO  Creates a {@link AMQDisconnectedException} and passes it to the AMQConnection. No need to use an
  *       exception-as-argument here, could just as easily call a specific method for this purpose on AMQConnection.
- *
- * @todo Creates a {@link FailoverException} and propagates it to the MethodHandlers. No need to use an
+ * <p>
+ * TODO  Creates a {@link FailoverException} and propagates it to the MethodHandlers. No need to use an
  *       exception-as-argument here, could just as easily call a specific method for this purpose on
  *       {@link org.apache.qpid.protocol.AMQMethodListener}.
  */

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverProtectedOperation.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverProtectedOperation.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverProtectedOperation.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverProtectedOperation.java Fri Aug  8 16:39:32 2014
@@ -25,16 +25,11 @@ package org.apache.qpid.client.failover;
  * FailoverProtectedOperation is a continuation for an operation that may throw a {@link FailoverException} because
  * it has been interrupted by the fail-over process. The {@link FailoverRetrySupport} class defines support wrappers
  * for failover protected operations, in order to provide different handling schemes when failovers occurr.
- *
- * <p/>The type of checked exception that the operation may perform has been generified, in order that fail over
+ * <p>
+ * The type of checked exception that the operation may perform has been generified, in order that fail over
  * protected operations can be defined that raise arbitrary exceptions. The actuall exception types used should not
  * be sub-classes of FailoverException, or else catching FailoverException in the {@link FailoverRetrySupport} classes
  * will mask the exception.
- *
- * <p><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities
- * <tr><td> Perform an operation that may be interrupted by fail-over.
- * </table>
  */
 public interface FailoverProtectedOperation<T, E extends Exception>
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverRetrySupport.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverRetrySupport.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverRetrySupport.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverRetrySupport.java Fri Aug  8 16:39:32 2014
@@ -32,40 +32,34 @@ import org.apache.qpid.client.AMQConnect
  * FailoverRetrySupport automatcally rechecks the condition and re-acquires the mutex and re-runs the continution. This
  * automatic retrying is continued until the continuation succeeds, or throws an exception (different to
  * FailoverException, which is used to signal the failure of the original condition).
- *
- * <p/>The blocking condition used is that the connection is not currently failing over, and the mutex used is the
+ * <p>
+ * The blocking condition used is that the connection is not currently failing over, and the mutex used is the
  * connection failover mutex, which guards against the fail-over process being run during fail-over vulnerable methods.
  * These are used like a lock and condition variable.
- *
- * <p/>The wrapped operation may throw a FailoverException, this is an exception that can be raised by a
+ * <p>
+ * The wrapped operation may throw a FailoverException, this is an exception that can be raised by a
  * {@link org.apache.qpid.client.protocol.BlockingMethodFrameListener}, in response to it being notified that a
  * fail-over wants to start whilst it was waiting. Methods that are vulnerable to fail-over are those that are
  * synchronous, where a failure will prevent them from getting the reply they are waiting for and asynchronous
  * methods that should not be attempted when a fail-over is in progress.
- *
- * <p/>Wrapping a synchronous method in a FailoverRetrySupport will have the effect that the operation will not be
+ * <p>
+ * Wrapping a synchronous method in a FailoverRetrySupport will have the effect that the operation will not be
  * started during fail-over, but be delayed until any current fail-over has completed. Should a fail-over process want
  * to start whilst waiting for the synchrnous reply, the FailoverRetrySupport will detect this and rety the operation
  * until it succeeds. Synchronous methods are usually coordinated with a
  * {@link org.apache.qpid.client.protocol.BlockingMethodFrameListener} which is notified when a fail-over process wants
  * to start and throws a FailoverException in response to this.
- *
- * <p/>Wrapping an asynchronous method in a FailoverRetrySupport will have the effect that the operation will not be
+ * <p>
+ * Wrapping an asynchronous method in a FailoverRetrySupport will have the effect that the operation will not be
  * started during fail-over, but be delayed until any current fail-over has completed.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Provide a continuation synchronized on a fail-over lock and condition.
- * <tr><td> Automatically retry the continuation accross fail-overs until it succeeds, or raises an exception.
- * </table>
- *
- * @todo Another continuation. Could use an interface Continuation (as described in other todos)
+ * <p>
+ * TODO  Another continuation. Could use an interface Continuation (as described in other todos)
  *      Then have a wrapping continuation (this), which blocks on an arbitrary
  *      Condition or Latch (specified in constructor call), that this blocks on before calling the wrapped Continuation.
  *      Must work on Java 1.4, so check retrotranslator works on Lock/Condition or latch first. Argument and return type
  *      to match wrapped condition as type parameters. Rename to AsyncConditionalContinuation or something like that.
- *
- * @todo InterruptedException not handled well.
+ * <p>
+ * TODO  InterruptedException not handled well.
  */
 public class FailoverRetrySupport<T, E extends Exception> implements FailoverSupport<T, E>
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverState.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverState.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverState.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverState.java Fri Aug  8 16:39:32 2014
@@ -22,11 +22,6 @@ package org.apache.qpid.client.failover;
 
 /**
  * Defines the possible states of the failover process; not started, in progress, failed.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Represent a one of the states of the fail-over process.
- * </table>
  */
 public final class FailoverState
 {

Modified: qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverSupport.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverSupport.java?rev=1616823&r1=1616822&r2=1616823&view=diff
==============================================================================
--- qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverSupport.java (original)
+++ qpid/branches/0.30/qpid/java/client/src/main/java/org/apache/qpid/client/failover/FailoverSupport.java Fri Aug  8 16:39:32 2014
@@ -26,13 +26,8 @@ package org.apache.qpid.client.failover;
  * behaviour for handling fail-overs during operations that can be interrupted by the fail-over process. For example,
  * the support could automatically retry once the fail-over process completes, could prevent an operation from being
  * started whilst fail-over is running, or could quietly abandon the operation or raise an exception, and so on.
- *
- * <p><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities
- * <tr><td> Perform a fail-over protected operation with handling for fail-over conditions.
- * </table>
- *
- * @todo Continuation, extend some sort of re-usable Continuation interface, which might look very like this one.
+ * <p>
+ * TODO  Continuation, extend some sort of re-usable Continuation interface, which might look very like this one.
  */
 public interface FailoverSupport<T, E extends Exception>
 {



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