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 17:06:46 UTC

svn commit: r1616792 - in /qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid: codec/ exchange/ filter/ framing/ transport/ transport/codec/ transport/network/ typedmessage/ util/

Author: robbie
Date: Fri Aug  8 15:06:46 2014
New Revision: 1616792

URL: http://svn.apache.org/r1616792
Log:
QPID-5980: more javadoc fixups

Modified:
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Connection.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/ConnectionSettings.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Session.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Decoder.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Encoder.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/network/NetworkConnection.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/typedmessage/TypedBytesContentReader.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/CommandLineParser.java
    qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/FileUtils.java

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQCodecFactory.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/codec/AMQDecoder.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/exchange/ExchangeDefaults.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ArithmeticExpression.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BinaryExpression.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/BooleanExpression.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ComparisonExpression.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/ConstantExpression.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/Expression.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/filter/LogicExpression.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQMethodBodyImpl.java Fri Aug  8 15:06:46 2014
@@ -46,7 +46,9 @@ public abstract class AMQMethodBodyImpl 
     }
 
 
-    /** unsigned short */
+    /** unsigned short
+     *
+     * @return body size*/
     abstract protected int getBodySize();
 
 

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/AMQTypedValue.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ContentHeaderBody.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/EncodingUtils.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/FieldTable.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/framing/ProtocolInitiation.java Fri Aug  8 15:06:46 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/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Connection.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Connection.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Connection.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Connection.java Fri Aug  8 15:06:46 2014
@@ -54,7 +54,7 @@ import java.util.concurrent.atomic.Atomi
  *
  * @author Rafael H. Schloming
  *
- * @todo the channels map should probably be replaced with something
+ * TODO the channels map should probably be replaced with something
  * more efficient, e.g. an array or a map implementation that can use
  * short instead of Short
  */

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/ConnectionSettings.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/ConnectionSettings.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/ConnectionSettings.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/ConnectionSettings.java Fri Aug  8 15:06:46 2014
@@ -109,6 +109,7 @@ public class ConnectionSettings
      * Gets the heartbeat interval (seconds) for 0-8/9/9-1 protocols.
      * 0 means heartbeating is disabled.
      * null means use the broker-supplied value.
+     * @return the heartbeat interval
      */
     public Integer getHeartbeatInterval08()
     {
@@ -129,6 +130,7 @@ public class ConnectionSettings
     /**
      * Gets the heartbeat interval (seconds) for the 0-10 protocol.
      * 0 means heartbeating is disabled.
+     * @return the heartbeat interval
      */
     public int getHeartbeatInterval010()
     {

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Session.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Session.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Session.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/Session.java Fri Aug  8 15:06:46 2014
@@ -1206,6 +1206,7 @@ public class Session extends SessionInvo
 
     /**
      * An auxiliary method for test purposes only
+     * @return true if flow is blocked
      */
     public boolean isFlowBlocked()
     {

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Decoder.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Decoder.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Decoder.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Decoder.java Fri Aug  8 15:06:46 2014
@@ -82,7 +82,7 @@ public interface Decoder
 	 * The uuid type encodes a universally unique id as defined by RFC-4122. 
 	 * The format and operations for this type can be found in section 4.1.2 of RFC-4122.
 	 * 
-	 * return a universally unique id as defined by RFC-4122.
+	 * @return a universally unique id as defined by RFC-4122.
 	 */    
     UUID readUuid();
 
@@ -114,14 +114,14 @@ public interface Decoder
 	 * Note that the encoded size refers to the number of octets of unicode, not necessarily the number of unicode 
 	 * characters since the UTF-8 unicode may include multi-byte character sequences.
 	 * 
-	 * return a string.
+	 * @return a string.
 	 */
     String readStr16();
 
 	/**
 	 * The vbin8 type encodes up to 255 octets of opaque binary data. 
 	 * 
-	 * return a byte array.
+	 * @return a byte array.
 	 */
     byte[] readVbin8();
     

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Encoder.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Encoder.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Encoder.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/codec/Encoder.java Fri Aug  8 15:06:46 2014
@@ -60,7 +60,7 @@ public interface Encoder
 	/**
 	 * The uint64 type is a 64-bit unsigned integral value encoded in network byte order.
 	 * 
-	 * @param b the unsigned integer to be encoded.
+	 * @param l the unsigned integer to be encoded.
 	 */    
     void writeUint64(long l);
 

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/network/NetworkConnection.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/network/NetworkConnection.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/network/NetworkConnection.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/transport/network/NetworkConnection.java Fri Aug  8 15:06:46 2014
@@ -34,12 +34,12 @@ public interface NetworkConnection
     void close();
 
     /**
-     * Returns the remote address of the underlying socket.
+     * @return the remote address of the underlying socket.
      */
     SocketAddress getRemoteAddress();
 
     /**
-     * Returns the local address of the underlying socket.
+     * @return the local address of the underlying socket.
      */
     SocketAddress getLocalAddress();
 

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/typedmessage/TypedBytesContentReader.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/typedmessage/TypedBytesContentReader.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/typedmessage/TypedBytesContentReader.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/typedmessage/TypedBytesContentReader.java Fri Aug  8 15:06:46 2014
@@ -54,7 +54,7 @@ public class TypedBytesContentReader imp
      * Check that there is at least a certain number of bytes available to read
      *
      * @param len the number of bytes
-     * @throws javax.jms.MessageEOFException if there are less than len bytes available to read
+     * @throws EOFException if there are less than len bytes available to read
      */
     public void checkAvailable(int len) throws EOFException
     {
@@ -183,7 +183,8 @@ public class TypedBytesContentReader imp
      * Note that this method reads a unicode character as two bytes from the stream
      *
      * @return the character read from the stream
-     * @throws javax.jms.JMSException
+     * @throws EOFException if there are less than the required bytes available to read
+     * @throws TypedBytesFormatException if the current write type is not compatible
      */
     public char readChar() throws EOFException, TypedBytesFormatException
     {

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/CommandLineParser.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/CommandLineParser.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/CommandLineParser.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/CommandLineParser.java Fri Aug  8 15:06:46 2014
@@ -31,13 +31,13 @@ import java.util.regex.Pattern;
 
 /**
  * CommandLineParser provides a utility for specifying the format of a command line and parsing command lines to ensure
- * that they fit their specified format. A command line is made up of flags and options, both may be refered to as
+ * that they fit their specified format. A command line is made up of flags and options, both may be referred to as
  * options. A flag is an option that does not take an argument (specifying it means it has the value 'true' and not
  * specifying it means it has the value 'false'). Options must take arguments but they can be set up with defaults so
- * that they take a default value when not set. Options may be mandatory in wich case it is an error not to specify
+ * that they take a default value when not set. Options may be mandatory in which case it is an error not to specify
  * them on the command line. Flags are never mandatory because they are implicitly set to false when not specified.
  *
- * <p/>Some example command lines are:
+ * <p>Some example command lines are:
  *
  * <ul>
  * <li>This one has two options that expect arguments:
@@ -52,14 +52,15 @@ import java.util.regex.Pattern;
  * <pre>
  * jar -tvf mytar.tar
  * </pre>
+ * </ul>
  *
- * <p/>The parsing rules are:
+ * <p>The parsing rules are:
  *
  * <ol>
  * <li>Flags may be combined after a single '-' because they never take arguments. Normally such flags are single letter
  * flags but this is only a convention and not enforced. Flags of more than one letter are usually specified on their own.
  * <li>Options expecting arguments must always be on their own.
- * <li>The argument to an option may be seperated from it by whitespace or appended directly onto the option.
+ * <li>The argument to an option may be separated from it by whitespace or appended directly onto the option.
  * <li>The argument to an option may never begin with a '-' character.
  * <li>All other arguments not beginning with a '-' character are free arguments that do not belong to any option.
  * <li>The second or later of a set of duplicate or repeated flags are ignored.
@@ -70,18 +71,8 @@ import java.util.regex.Pattern;
  * the "bar" argument.
  * </ol>
  *
- * <p/>By default, unknown options are simply ignored if specified on the command line. This behaviour may be changed
+ * <p>By default, unknown options are simply ignored if specified on the command line. This behaviour may be changed
  * so that the parser reports all unknowns as errors by using the {@link #setErrorsOnUnknowns} method.
- *
- * <p><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Accept a command line specification.
- * <tr><td> Parse a command line into properties, validating it against its specification.
- * <tr><td> Report all errors between a command line and its specification.
- * <tr><td> Provide a formatted usage string for a command line.
- * <tr><td> Provide a formatted options in force string for a command line.
- * <tr><td> Allow errors on unknowns behaviour to be turned on or off.
- * </table>
  */
 public class CommandLineParser
 {
@@ -106,7 +97,7 @@ public class CommandLineParser
      * array may therefore easily be used to configure the command line parser in a single method call with an easily
      * readable format.
      *
-     * <p/>Each array of strings must be 2, 3, 4 or 5 elements long. If any of the last three elements are missing they
+     * <p>Each array of strings must be 2, 3, 4 or 5 elements long. If any of the last three elements are missing they
      * are assumed to be null. The elements specify the following parameters:
      * <ol>
      * <li>The name of the option without the leading '-'. For example, "file".  To specify the format of the 'free'
@@ -121,7 +112,7 @@ public class CommandLineParser
      *     this is ignored for flags.
      * <li>A regular expression describing the format that the argument must take. Ignored if null.
      * </ol>
-     * <p/>An example call to this constructor is:
+     * <p>An example call to this constructor is:
      *
      * <pre>
      * CommandLineParser commandLine = new CommandLineParser(
@@ -234,7 +225,7 @@ public class CommandLineParser
      * Parses a set of command line arguments into a set of properties, keyed by the argument flag. The free arguments
      * are keyed by integers as strings starting at "1" and then "2", ... and so on.
      *
-     * <p/>See the class level comment for a description of the parsing rules.
+     * <p>See the class level comment for a description of the parsing rules.
      *
      * @param args The command line arguments.
      *
@@ -488,6 +479,7 @@ public class CommandLineParser
 
     /**
      * If a command line has been parsed, calling this method sets all of its parsed options into the specified properties.
+     * @param properties properties
      */
     public void addCommandLineToProperties(Properties properties)
     {
@@ -508,7 +500,7 @@ public class CommandLineParser
      * to be called to use this parser a second time which is not likely seeing as a command line is usually only
      * specified once. However, it is exposed as a public method for the rare case where this may be done.
      *
-     * <p/>Cleans the internal state of this parser, removing all stored errors and information about the options in
+     * <p>Cleans the internal state of this parser, removing all stored errors and information about the options in
      * force.
      */
     public void reset()
@@ -643,11 +635,6 @@ public class CommandLineParser
      * Holds information about a command line options. This includes what its name is, whether or not it is a flag,
      * whether or not it is mandatory, what its user comment is, what its argument reminder text is and what its
      * regular expression format is.
-     *
-     * <p><table id="crc"><caption>CRC Card</caption>
-     * <tr><th> Responsibilities <th> Collaborations
-     * <tr><td> Hold details of a command line option.
-     * </table>
      */
     protected static class CommandLineOption
     {

Modified: qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/FileUtils.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/FileUtils.java?rev=1616792&r1=1616791&r2=1616792&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/FileUtils.java (original)
+++ qpid/trunk/qpid/java/common/src/main/java/org/apache/qpid/util/FileUtils.java Fri Aug  8 15:06:46 2014
@@ -37,12 +37,6 @@ import java.util.List;
  * FileUtils provides some simple helper methods for working with files. It follows the convention of wrapping all
  * checked exceptions as runtimes, so code using these methods is free of try-catch blocks but does not expect to
  * recover from errors.
- *
- * <p/><table id="crc"><caption>CRC Card</caption>
- * <tr><th> Responsibilities <th> Collaborations
- * <tr><td> Read a text file as a string.
- * <tr><td> Open a file or default resource as an input stream.
- * </table>
  */
 public class FileUtils
 {
@@ -214,7 +208,7 @@ public class FileUtils
      *
      * @param src The source file name.
      * @param dst The destination file name.
-     * @throws IOException
+     * @throws IOException if there is an issue copying the file
      */
     public static void copyCheckedEx(File src, File dst) throws IOException
     {
@@ -228,7 +222,7 @@ public class FileUtils
      *
      * @param in The InputStream
      * @param dst The destination file name.
-     * @throws IOException
+     * @throws IOException if there is an issue copying the stream
      */
     public static void copy(InputStream in, File dst) throws IOException
     {
@@ -383,7 +377,7 @@ public class FileUtils
      * @param file the file to search
      * @param search the search String
      *
-     * @throws java.io.IOException
+     * @throws java.io.IOException if there is an issue searching the file
      * @return the list of matching entries
      */
     public static List<String> searchFile(File file, String search)



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