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

[1/9] activemq-cpp git commit: Formatting cleanup.

Repository: activemq-cpp
Updated Branches:
  refs/heads/master f0b1ff965 -> cb372c077


http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/Inflater.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Inflater.h b/activemq-cpp/src/main/decaf/util/zip/Inflater.h
index b99627f..31e0262 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Inflater.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Inflater.h
@@ -58,8 +58,8 @@ namespace zip {
 
     private:
 
-        Inflater( const Inflater& );
-        Inflater& operator=( const Inflater& );
+        Inflater(const Inflater&);
+        Inflater& operator=(const Inflater&);
 
     public:
 
@@ -78,7 +78,7 @@ namespace zip {
          * byte as input. This is required by the ZLIB native library in order to support
          * certain optimizations.
          */
-        Inflater( bool nowrap );
+        Inflater(bool nowrap);
 
         virtual ~Inflater();
 
@@ -99,7 +99,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        void setInput( const unsigned char* buffer, int size, int offset, int length );
+        void setInput(const unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Sets input data for decompression. This should be called whenever needsInput() returns
@@ -115,7 +115,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        void setInput( const std::vector<unsigned char>& buffer, int offset, int length );
+        void setInput(const std::vector<unsigned char>& buffer, int offset, int length);
 
         /**
          * Sets input data for decompression. This should be called whenever needsInput() returns
@@ -126,7 +126,7 @@ namespace zip {
          *
          * @throws IllegalStateException if in the end state.
          */
-        void setInput( const std::vector<unsigned char>& buffer );
+        void setInput(const std::vector<unsigned char>& buffer);
 
         /**
          * Returns the total number of bytes remaining in the input buffer. This can be used to
@@ -157,7 +157,7 @@ namespace zip {
          * @throws IllegalArgumentException if the given dictionary doesn't match thre required
          *         dictionaries checksum value.
          */
-        void setDictionary( const unsigned char* buffer, int size, int offset, int length );
+        void setDictionary(const unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Sets the preset dictionary to the given array of bytes. Should be called when inflate()
@@ -177,7 +177,7 @@ namespace zip {
          * @throws IllegalArgumentException if the given dictionary doesn't match thre required
          *         dictionaries checksum value.
          */
-        void setDictionary( const std::vector<unsigned char>& buffer, int offset, int length );
+        void setDictionary(const std::vector<unsigned char>& buffer, int offset, int length);
 
         /**
          * Sets the preset dictionary to the given array of bytes. Should be called when inflate()
@@ -192,7 +192,7 @@ namespace zip {
          * @throws IllegalArgumentException if the given dictionary doesn't match the required
          *         dictionaries checksum value.
          */
-        void setDictionary( const std::vector<unsigned char>& buffer );
+        void setDictionary(const std::vector<unsigned char>& buffer);
 
         /**
          * @return true if the input data buffer is empty and setInput() should be called in
@@ -236,7 +236,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws DataFormatException if the compressed data format is invalid.
          */
-        int inflate( unsigned char* buffer, int size, int offset, int length );
+        int inflate(unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Uncompresses bytes into specified buffer. Returns actual number of bytes uncompressed.
@@ -255,7 +255,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws DataFormatException if the compressed data format is invalid.
          */
-        int inflate( std::vector<unsigned char>& buffer, int offset, int length );
+        int inflate(std::vector<unsigned char>& buffer, int offset, int length);
 
         /**
          * Uncompresses bytes into specified buffer. Returns actual number of bytes uncompressed.
@@ -269,7 +269,7 @@ namespace zip {
          * @throws IllegalStateException if in the end state.
          * @throws DataFormatException if the compressed data format is invalid.
          */
-        int inflate( std::vector<unsigned char>& buffer );
+        int inflate(std::vector<unsigned char>& buffer);
 
         /**
          * @returns the ADLER-32 value of the uncompressed data.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.cpp b/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.cpp
index 9ccd3ac..b158188 100644
--- a/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.cpp
@@ -31,55 +31,55 @@ using namespace decaf::util::zip;
 const int InflaterInputStream::DEFAULT_BUFFER_SIZE = 512;
 
 ////////////////////////////////////////////////////////////////////////////////
-InflaterInputStream::InflaterInputStream( InputStream* inputStream, bool own ) :
-    FilterInputStream( inputStream, own ),
+InflaterInputStream::InflaterInputStream(InputStream* inputStream, bool own ) :
+    FilterInputStream(inputStream, own),
     inflater(new Inflater()), buff(), length(0), ownInflater(true), atEOF(false) {
 
     this->buff.resize( DEFAULT_BUFFER_SIZE );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-InflaterInputStream::InflaterInputStream( InputStream* inputStream, Inflater* inflater, bool own, bool ownInflater )
- :  FilterInputStream( inputStream, own ),
-    inflater(inflater), buff(), length(0), ownInflater(ownInflater), atEOF(false) {
+InflaterInputStream::InflaterInputStream(InputStream* inputStream, Inflater* inflater, bool own, bool ownInflater) :
+     FilterInputStream(inputStream, own),
+     inflater(inflater), buff(), length(0), ownInflater(ownInflater), atEOF(false) {
 
-    if( inflater == NULL ) {
+    if (inflater == NULL) {
         throw NullPointerException(
-             __FILE__, __LINE__, "Inflater passed was NULL." );
+             __FILE__, __LINE__, "Inflater passed was NULL.");
     }
 
     this->buff.resize( DEFAULT_BUFFER_SIZE );
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-InflaterInputStream::InflaterInputStream( InputStream* inputStream, Inflater* inflater,
-                                          int bufferSize, bool own, bool ownInflater )
- :  FilterInputStream( inputStream, own ),
+InflaterInputStream::InflaterInputStream(InputStream* inputStream, Inflater* inflater,
+                                         int bufferSize, bool own, bool ownInflater) :
+    FilterInputStream(inputStream, own),
     inflater(inflater), buff(), length(0), ownInflater(ownInflater), atEOF(false) {
 
-    if( inflater == NULL ) {
+    if (inflater == NULL) {
         throw NullPointerException(
-             __FILE__, __LINE__, "Inflater passed was NULL." );
+             __FILE__, __LINE__, "Inflater passed was NULL.");
     }
 
-    if( bufferSize <= 0 ) {
+    if (bufferSize <= 0) {
         throw IllegalArgumentException(
-             __FILE__, __LINE__, "Cannot create a zero sized buffer." );
+             __FILE__, __LINE__, "Cannot create a zero sized buffer.");
     }
 
-    this->buff.resize( bufferSize );
+    this->buff.resize(bufferSize);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 InflaterInputStream::~InflaterInputStream() {
-    try{
+    try {
         this->close();
 
-        if( ownInflater ) {
+        if (ownInflater) {
             delete inflater;
         }
     }
-    DECAF_CATCH_NOTHROW( Exception )
+    DECAF_CATCH_NOTHROW(Exception)
     DECAF_CATCHALL_NOTHROW()
 }
 
@@ -91,135 +91,135 @@ bool InflaterInputStream::markSupported() const {
 ////////////////////////////////////////////////////////////////////////////////
 void InflaterInputStream::reset() {
     throw IOException(
-         __FILE__, __LINE__, "Not Supported for this class." );
+         __FILE__, __LINE__, "Not Supported for this class.");
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void InflaterInputStream::mark( int readLimit DECAF_UNUSED ) {
+void InflaterInputStream::mark(int readLimit DECAF_UNUSED) {
     // No-op
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-long long InflaterInputStream::skip( long long num ) {
+long long InflaterInputStream::skip(long long num) {
 
-    try{
+    try {
 
-        if( num <= 0 ) {
+        if (num <= 0) {
             return 0;
         }
 
         long long count = 0;
-        long long remaining = (std::size_t)Math::min( num, (long long)buff.size() );
+        long long remaining = (std::size_t) Math::min(num, (long long) buff.size());
 
-        std::vector<unsigned char> buffer( (std::size_t)remaining );
+        std::vector<unsigned char> buffer((std::size_t) remaining);
 
-        while( count < num ) {
-            int x = read( &buffer[0], (int)buffer.size() , 0, (int)remaining );
-            if( x == -1 ) {
+        while (count < num) {
+            int x = read(&buffer[0], (int) buffer.size(), 0, (int) remaining);
+            if (x == -1) {
                 return count;
             }
             count += x;
-            remaining = ( num - count ) < (long long)buffer.size() ? num - count : buffer.size();
+            remaining = (num - count) < (long long) buffer.size() ? num - count : buffer.size();
         }
 
         return count;
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 void InflaterInputStream::close() {
 
-    try{
+    try {
 
-        if( !isClosed() ) {
+        if (!isClosed()) {
             inflater->end();
             this->atEOF = true;
             FilterInputStream::close();
         }
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int InflaterInputStream::available() const {
 
-    try{
+    try {
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                __FILE__, __LINE__, "Stream already closed." );
+                __FILE__, __LINE__, "Stream already closed.");
         }
 
-        if( atEOF ) {
+        if (atEOF) {
             return 0;
         }
 
         return 1;
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int InflaterInputStream::doReadByte() {
 
-    try{
+    try {
 
         unsigned char buffer[1];
-        if( doReadArrayBounded( buffer, 1, 0, 1 ) < 0 ) {
+        if (doReadArrayBounded(buffer, 1, 0, 1) < 0) {
             return -1;
         }
 
-        return (int)buffer[0];
+        return (int) buffer[0];
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int InflaterInputStream::doReadArrayBounded( unsigned char* buffer, int size, int offset, int length ) {
+int InflaterInputStream::doReadArrayBounded(unsigned char* buffer, int size, int offset, int length) {
 
     try{
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Buffer passed was NULL." );
+                __FILE__, __LINE__, "Buffer passed was NULL.");
         }
 
-        if( size < 0 ) {
+        if (size < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size );
+                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size);
         }
 
-        if( offset > size || offset < 0 ) {
+        if (offset > size || offset < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset );
+                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset);
         }
 
-        if( length < 0 || length > size - offset ) {
+        if (length < 0 || length > size - offset) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length );
+                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length);
         }
 
-        if( length == 0 ) {
+        if (length == 0) {
             return 0;
         }
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                __FILE__, __LINE__, "Stream already closed." );
+                __FILE__, __LINE__, "Stream already closed.");
         }
 
-        if( atEOF ) {
+        if (atEOF) {
             return -1;
         }
 
         do {
 
-            if( inflater->needsInput() ) {
+            if (inflater->needsInput()) {
                 this->fill();
             }
 
@@ -227,42 +227,42 @@ int InflaterInputStream::doReadArrayBounded( unsigned char* buffer, int size, in
             // It may also be true if the next read() should return -1.
             try {
 
-                int result = inflater->inflate( buffer, size, offset, length );
+                int result = inflater->inflate(buffer, size, offset, length);
 
                 atEOF = inflater->finished();
 
-                if( result > 0 ) {
+                if (result > 0) {
                     return result;
-                } else if( atEOF ) {
+                } else if (atEOF) {
                     return -1;
-                } else if( inflater->needsDictionary() ) {
+                } else if (inflater->needsDictionary()) {
                     atEOF = true;
                     return -1;
-                } else if( this->length == -1 ) {
+                } else if (this->length == -1) {
                     atEOF = true;
                     throw EOFException(
-                        __FILE__, __LINE__, "Reached end of Input." );
+                        __FILE__, __LINE__, "Reached end of Input.");
                 }
 
-            } catch( DataFormatException& e ) {
+            } catch (DataFormatException& e) {
 
                 atEOF = true;
-                if( this->length == -1 ) {
+                if (this->length == -1) {
                     throw EOFException(
                         __FILE__, __LINE__, "Reached end of Input." );
                 }
 
-                IOException ex( __FILE__, __LINE__, "Error from Inflater" );
+                IOException ex(__FILE__, __LINE__, "Error from Inflater");
                 ex.initCause(e.clone());
                 throw ex;
             }
 
-        } while(true);
+        } while (true);
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -270,18 +270,18 @@ void InflaterInputStream::fill() {
 
     try{
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                __FILE__, __LINE__, "Stream already closed." );
+                __FILE__, __LINE__, "Stream already closed.");
         }
 
         // Try and fill the input buffer, whatever we get goes into the inflater.
-        length = inputStream->read( &buff[0], (int)buff.size(), 0, (int)buff.size() );
+        length = inputStream->read(&buff[0], (int) buff.size(), 0, (int) buff.size());
 
-        if( length > 0 ) {
-            inflater->setInput( &buff[0], (int)buff.size(), 0, length );
+        if (length > 0) {
+            inflater->setInput(&buff[0], (int) buff.size(), 0, length);
         }
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.h b/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.h
index bce992b..c34df41 100644
--- a/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.h
+++ b/activemq-cpp/src/main/decaf/util/zip/InflaterInputStream.h
@@ -60,8 +60,8 @@ namespace zip {
 
     private:
 
-        InflaterInputStream( const InflaterInputStream& );
-        InflaterInputStream& operator= ( const InflaterInputStream& );
+        InflaterInputStream(const InflaterInputStream&);
+        InflaterInputStream& operator=(const InflaterInputStream&);
 
     public:
 
@@ -73,7 +73,7 @@ namespace zip {
          * @param own
          *      Should this Filter take ownership of the InputStream pointer (defaults to false).
          */
-        InflaterInputStream( decaf::io::InputStream* inputStream, bool own = false );
+        InflaterInputStream(decaf::io::InputStream* inputStream, bool own = false);
 
         /**
          * Creates a new InflaterInputStream with a user supplied Inflater and a default buffer size.
@@ -92,8 +92,8 @@ namespace zip {
          *
          * @throws NullPointerException if the Inflater given is NULL.
          */
-        InflaterInputStream( decaf::io::InputStream* inputStream, Inflater* inflater,
-                             bool own = false, bool ownInflater = false );
+        InflaterInputStream(decaf::io::InputStream* inputStream, Inflater* inflater,
+                            bool own = false, bool ownInflater = false);
 
         /**
          * Creates a new DeflateOutputStream with a user supplied Inflater and specified buffer size.
@@ -115,8 +115,8 @@ namespace zip {
          * @throws NullPointerException if the Inflater given is NULL.
          * @throws IllegalArgumentException if the bufferSize value is zero.
          */
-        InflaterInputStream( decaf::io::InputStream* inputStream, Inflater* inflater,
-                             int bufferSize, bool own = false, bool ownInflater = false );
+        InflaterInputStream(decaf::io::InputStream* inputStream, Inflater* inflater,
+                            int bufferSize, bool own = false, bool ownInflater = false);
 
         virtual ~InflaterInputStream();
 
@@ -139,14 +139,14 @@ namespace zip {
          *
          * Skips the specified amount of uncompressed input data.
          */
-        virtual long long skip( long long num );
+        virtual long long skip(long long num);
 
         /**
          * {@inheritDoc}
          *
          * Does nothing.
          */
-        virtual void mark( int readLimit );
+        virtual void mark(int readLimit);
 
         /**
          * {@inheritDoc}
@@ -175,7 +175,7 @@ namespace zip {
 
         virtual int doReadByte();
 
-        virtual int doReadArrayBounded( unsigned char* buffer, int size, int offset, int length );
+        virtual int doReadArrayBounded(unsigned char* buffer, int size, int offset, int length);
 
     };
 


[7/9] activemq-cpp git commit: Fix some documentation generation issues.

Posted by ta...@apache.org.
http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/URIHelper.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/URIHelper.h b/activemq-cpp/src/main/decaf/internal/net/URIHelper.h
index b70c7f2..9c29d5e 100644
--- a/activemq-cpp/src/main/decaf/internal/net/URIHelper.h
+++ b/activemq-cpp/src/main/decaf/internal/net/URIHelper.h
@@ -69,7 +69,7 @@ namespace net {
          * Parse the passed in URI.
          * @param uri - the URI to Parse
          * @param forceServer - if true invalid URI data throws an Exception
-         * @returns a URIType instance containing the parsed data.
+         * @return a URIType instance containing the parsed data.
          * @throws URISyntaxException if forceServer is true and the URI is invalid.
          */
         URIType parseURI( const std::string& uri, bool forceServer );
@@ -147,7 +147,7 @@ namespace net {
          * <p>
          * @param forceServer
          * @param authority
-         * @returns a URIType instance containing the parsed data.
+         * @return a URIType instance containing the parsed data.
          * @throw URISyntaxException
          */
         URIType parseAuthority( bool forceServer, const std::string& authority );

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/URIType.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/URIType.h b/activemq-cpp/src/main/decaf/internal/net/URIType.h
index cc68789..42df07d 100644
--- a/activemq-cpp/src/main/decaf/internal/net/URIType.h
+++ b/activemq-cpp/src/main/decaf/internal/net/URIType.h
@@ -57,7 +57,7 @@ namespace net {
         /**
          * Gets the source URI string that was parsed to obtain this URIType
          * instance and the resulting data,
-         * @returns the source URI string
+         * @return the source URI string
          */
         std::string getSource() const {
             return this->source;
@@ -269,7 +269,7 @@ namespace net {
         /**
          * Gets if the URI is valid, meaning that the source has been set and
          * parsed and all relevant data fields have been set.
-         * @returns true if the URIType contains valid data.
+         * @return true if the URIType contains valid data.
          */
         bool isValid() const {
             return valid;
@@ -287,7 +287,7 @@ namespace net {
         /**
          * Gets the computed hashCode for this URIType or return -1 if non is set
          *
-         * @returns the hash code for this URIType instance or -1 if not set.
+         * @return the hash code for this URIType instance or -1 if not set.
          */
         int getHashCode() const {
             return this->hashCode;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/URLStreamHandlerManager.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/URLStreamHandlerManager.h b/activemq-cpp/src/main/decaf/internal/net/URLStreamHandlerManager.h
index 159e9a1..a8d05d4 100644
--- a/activemq-cpp/src/main/decaf/internal/net/URLStreamHandlerManager.h
+++ b/activemq-cpp/src/main/decaf/internal/net/URLStreamHandlerManager.h
@@ -57,7 +57,7 @@ namespace net {
          * application.  The returned pointer should never be deleted by the
          * application.
          *
-         * @returns a URLStreamHandlerManager instance.
+         * @return a URLStreamHandlerManager instance.
          */
         static URLStreamHandlerManager* getInstance();
 
@@ -69,7 +69,7 @@ namespace net {
          * @param protocol
          *      The protocol to return a URL Stream Handler instance for.
          *
-         * @returns a URLStreamHandler instance for the given protocol.
+         * @return a URLStreamHandler instance for the given protocol.
          */
         decaf::net::URLStreamHandler* getURLStreamHandler(const decaf::lang::String& protocol);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/URLType.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/URLType.h b/activemq-cpp/src/main/decaf/internal/net/URLType.h
index e12eb3a..25cc013 100644
--- a/activemq-cpp/src/main/decaf/internal/net/URLType.h
+++ b/activemq-cpp/src/main/decaf/internal/net/URLType.h
@@ -198,7 +198,7 @@ namespace net {
         /**
          * Gets the computed hashCode for this URLType or return -1 if non is set
          *
-         * @returns the hash code for this URLType instance or -1 if not set.
+         * @return the hash code for this URLType instance or -1 if not set.
          */
         int getHashCode() const {
             return this->hashCode;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/URLUtils.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/URLUtils.h b/activemq-cpp/src/main/decaf/internal/net/URLUtils.h
index b75cfb7..2c99add 100644
--- a/activemq-cpp/src/main/decaf/internal/net/URLUtils.h
+++ b/activemq-cpp/src/main/decaf/internal/net/URLUtils.h
@@ -40,7 +40,7 @@ namespace net {
          * @param url
          *      the URL whose host value is to be returned.
          *
-         * @returns the host value or 'localhost' for file based protocols.
+         * @return the host value or 'localhost' for file based protocols.
          */
         static decaf::lang::String getHost(const decaf::net::URL& url);
 
@@ -53,7 +53,7 @@ namespace net {
          *      true to remove leading ".." segments from the path. This is appropriate
          *      for paths that are known to be absolute.
          *
-         * @returns the canonicalized Path value.
+         * @return the canonicalized Path value.
          */
         static decaf::lang::String canonicalizePath(const decaf::lang::String& original, bool discardRelativePrefix);
 
@@ -67,7 +67,7 @@ namespace net {
          * @param path
          *      The path value from a given URL.
          *
-         * @returns a safe version of the Path value.
+         * @return a safe version of the Path value.
          */
         static decaf::lang::String authoritySafePath(const decaf::lang::String& authority,
                                                      const decaf::lang::String& path);
@@ -81,7 +81,7 @@ namespace net {
          * @param c
          *      The value from the given index.
          *
-         * @returns true if the char value is valid for the given index.
+         * @return true if the char value is valid for the given index.
          */
         static bool isValidSchemeChar(int index, char c);
 
@@ -110,7 +110,7 @@ namespace net {
          * @param end
          *      The end index to stop the search at.
          *
-         * @returns the first index that matches one of the chars or the end value if no matches..
+         * @return the first index that matches one of the chars or the end value if no matches..
          */
         static int findFirstOf(const decaf::lang::String& string,
                                const decaf::lang::String& chars, int start, int end);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocket.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocket.h b/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocket.h
index b5b3860..509efcb 100644
--- a/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocket.h
+++ b/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocket.h
@@ -236,7 +236,7 @@ namespace openssl {
         /**
          * Gets the number of bytes in the Socket buffer that can be read without blocking.
          *
-         * @returns the number of bytes that can be read from the Socket without blocking.
+         * @return the number of bytes that can be read from the Socket without blocking.
          *
          * @throws IOException if an I/O error occurs while performing this operation.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocketException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocketException.h b/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocketException.h
index 9aa0bfb..da94033 100644
--- a/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocketException.h
+++ b/activemq-cpp/src/main/decaf/internal/net/ssl/openssl/OpenSSLSocketException.h
@@ -134,7 +134,7 @@ namespace openssl {
         /**
          * Gets and formats an error message string from the OpenSSL error stack.
          *
-         * @returns a string containing the complete OpenSSL error string.
+         * @return a string containing the complete OpenSSL error string.
          */
         std::string getErrorString() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/tcp/TcpSocket.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/tcp/TcpSocket.h b/activemq-cpp/src/main/decaf/internal/net/tcp/TcpSocket.h
index 92ae876..3696869 100644
--- a/activemq-cpp/src/main/decaf/internal/net/tcp/TcpSocket.h
+++ b/activemq-cpp/src/main/decaf/internal/net/tcp/TcpSocket.h
@@ -65,12 +65,12 @@ namespace tcp {
         virtual ~TcpSocket();
 
         /**
-         * @returns true if the socketHandle is not in a disconnected state.
+         * @return true if the socketHandle is not in a disconnected state.
          */
         bool isConnected() const;
 
         /**
-         * @returns true if the close method has been called on this Socket.
+         * @return true if the close method has been called on this Socket.
          */
         bool isClosed() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/nio/BufferFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/nio/BufferFactory.h b/activemq-cpp/src/main/decaf/internal/nio/BufferFactory.h
index 1d45d3d..5056dfb 100644
--- a/activemq-cpp/src/main/decaf/internal/nio/BufferFactory.h
+++ b/activemq-cpp/src/main/decaf/internal/nio/BufferFactory.h
@@ -50,7 +50,7 @@ namespace nio{
          * @param capacity
          *      The internal buffer's capacity.
          *
-         * @returns a newly allocated ByteBuffer which the caller owns.
+         * @return a newly allocated ByteBuffer which the caller owns.
          *
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
          */
@@ -74,7 +74,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new ByteBuffer that is backed by buffer, caller owns the returned pointer.
+         * @return a new ByteBuffer that is backed by buffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if the buffer given in Null.
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
@@ -95,7 +95,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new ByteBuffer that is backed by buffer, caller owns.
+         * @return a new ByteBuffer that is backed by buffer, caller owns.
          */
         static decaf::nio::ByteBuffer* createByteBuffer( std::vector<unsigned char>& buffer );
 
@@ -106,7 +106,7 @@ namespace nio{
          * @param capacity
          *      The internal buffer's capacity.
          *
-         * @returns a newly allocated CharBuffer which the caller owns.
+         * @return a newly allocated CharBuffer which the caller owns.
          *
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
          */
@@ -130,7 +130,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new CharBuffer that is backed by buffer, caller owns the returned pointer.
+         * @return a new CharBuffer that is backed by buffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if the buffer given in Null.
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
@@ -150,7 +150,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new CharBuffer that is backed by buffer, caller owns.
+         * @return a new CharBuffer that is backed by buffer, caller owns.
          */
         static decaf::nio::CharBuffer* createCharBuffer( std::vector<char>& buffer );
 
@@ -161,7 +161,7 @@ namespace nio{
          * @param capacity
          *      The internal buffer's capacity.
          *
-         * @returns a newly allocated DoubleBuffer which the caller owns.
+         * @return a newly allocated DoubleBuffer which the caller owns.
          *
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
          */
@@ -185,7 +185,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new DoubleBuffer that is backed by buffer, caller owns the returned pointer.
+         * @return a new DoubleBuffer that is backed by buffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if the buffer given in Null.
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
@@ -205,7 +205,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new DoubleBuffer that is backed by buffer, caller owns.
+         * @return a new DoubleBuffer that is backed by buffer, caller owns.
          */
         static decaf::nio::DoubleBuffer* createDoubleBuffer( std::vector<double>& buffer );
 
@@ -216,7 +216,7 @@ namespace nio{
          * @param capacity
          *      The internal buffer's capacity.
          *
-         * @returns a newly allocated FloatBuffer which the caller owns.
+         * @return a newly allocated FloatBuffer which the caller owns.
          *
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
          */
@@ -240,7 +240,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new FloatBuffer that is backed by buffer, caller owns the returned pointer.
+         * @return a new FloatBuffer that is backed by buffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if the buffer given in Null.
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
@@ -260,7 +260,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new FloatBuffer that is backed by buffer, caller owns.
+         * @return a new FloatBuffer that is backed by buffer, caller owns.
          */
         static decaf::nio::FloatBuffer* createFloatBuffer( std::vector<float>& buffer );
 
@@ -268,7 +268,7 @@ namespace nio{
          * Allocates a new long long buffer whose position will be zero its limit will
          * be its capacity and its mark is not set.
          * @param capacity - the internal buffer's capacity.
-         * @returns a newly allocated DoubleBuffer which the caller owns.
+         * @return a newly allocated DoubleBuffer which the caller owns.
          *
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
          */
@@ -292,7 +292,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new LongBuffer that is backed by buffer, caller owns the returned pointer.
+         * @return a new LongBuffer that is backed by buffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if the buffer given in Null.
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
@@ -312,7 +312,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new LongBuffer that is backed by buffer, caller owns.
+         * @return a new LongBuffer that is backed by buffer, caller owns.
          */
         static decaf::nio::LongBuffer* createLongBuffer( std::vector<long long>& buffer );
 
@@ -323,7 +323,7 @@ namespace nio{
          * @param capacity
          *      The internal buffer's capacity.
          *
-         * @returns a newly allocated IntBuffer which the caller owns.
+         * @return a newly allocated IntBuffer which the caller owns.
          *
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
          */
@@ -347,7 +347,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new IntBuffer that is backed by buffer, caller owns the returned pointer.
+         * @return a new IntBuffer that is backed by buffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if the buffer given in Null.
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
@@ -367,7 +367,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new IntBuffer that is backed by buffer, caller owns.
+         * @return a new IntBuffer that is backed by buffer, caller owns.
          */
         static decaf::nio::IntBuffer* createIntBuffer( std::vector<int>& buffer );
 
@@ -378,7 +378,7 @@ namespace nio{
          * @param capacity
          *      The internal buffer's capacity.
          *
-         * @returns a newly allocated ShortBuffer which the caller owns.
+         * @return a newly allocated ShortBuffer which the caller owns.
          *
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
          */
@@ -402,7 +402,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new ShortBuffer that is backed by buffer, caller owns the returned pointer.
+         * @return a new ShortBuffer that is backed by buffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if the buffer given in Null.
          * @throws IndexOutOfBoundsException if the capacity specified is negative.
@@ -422,7 +422,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new DoubleBuffer that is backed by buffer, caller owns.
+         * @return a new DoubleBuffer that is backed by buffer, caller owns.
          */
         static decaf::nio::ShortBuffer* createShortBuffer( std::vector<short>& buffer );
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/security/Engine.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/security/Engine.h b/activemq-cpp/src/main/decaf/internal/security/Engine.h
index ae1432b..7aff84b 100644
--- a/activemq-cpp/src/main/decaf/internal/security/Engine.h
+++ b/activemq-cpp/src/main/decaf/internal/security/Engine.h
@@ -60,7 +60,7 @@ namespace security {
          * Returns the name of the service type that this Engine will be a
          * builder of SecuritySpi instances for.
          *
-         * @returns the service class name of this engine, e.g. MessageDigest.
+         * @return the service class name of this engine, e.g. MessageDigest.
          */
         std::string getServiceName() const {
             return this->serviceName;
@@ -82,7 +82,7 @@ namespace security {
          * Return a new instance of the SercuritySpi implementation that is named by
          * this engine's serviceName and the passed algorithmName.
          *
-         * @returns a new instance of the SecuritySpi provided by serviceName.algorithmName
+         * @return a new instance of the SecuritySpi provided by serviceName.algorithmName
          */
         decaf::security::SecuritySpi* newInstance(const std::string& algorithmName);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/security/SecurityRuntime.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/security/SecurityRuntime.h b/activemq-cpp/src/main/decaf/internal/security/SecurityRuntime.h
index 6ef270a..492a673 100644
--- a/activemq-cpp/src/main/decaf/internal/security/SecurityRuntime.h
+++ b/activemq-cpp/src/main/decaf/internal/security/SecurityRuntime.h
@@ -58,7 +58,7 @@ namespace security {
         /**
          * Return the Security Framework's Service Registry.
          *
-         * @returns a pointer to the frameworks Service Registry.
+         * @return a pointer to the frameworks Service Registry.
          */
         ServiceRegistry* getServiceRegistry();
 
@@ -70,7 +70,7 @@ namespace security {
          * The pointer returned is owned by the Security runtime and should not be
          * deleted or copied by the caller.
          *
-         * @returns a pointer to the Security Runtime's single Lock instance.
+         * @return a pointer to the Security Runtime's single Lock instance.
          */
         decaf::util::concurrent::Mutex* getRuntimeLock();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/security/ServiceRegistry.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/security/ServiceRegistry.h b/activemq-cpp/src/main/decaf/internal/security/ServiceRegistry.h
index c16f735..08f6237 100644
--- a/activemq-cpp/src/main/decaf/internal/security/ServiceRegistry.h
+++ b/activemq-cpp/src/main/decaf/internal/security/ServiceRegistry.h
@@ -69,7 +69,7 @@ namespace security {
          * @param name
          *      The name of the service to find, format is "serviceName.algorithmName"
          *
-         * @returns a caller owned pointer to a new ProviderService for the named service.
+         * @return a caller owned pointer to a new ProviderService for the named service.
          */
         decaf::security::ProviderService* getService(const std::string& name);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/util/ByteArrayAdapter.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/util/ByteArrayAdapter.h b/activemq-cpp/src/main/decaf/internal/util/ByteArrayAdapter.h
index 10d52f1..4a33b9c 100644
--- a/activemq-cpp/src/main/decaf/internal/util/ByteArrayAdapter.h
+++ b/activemq-cpp/src/main/decaf/internal/util/ByteArrayAdapter.h
@@ -251,7 +251,7 @@ namespace util {
         /**
          * Gets the pointer to the array we are wrapping.  Changes to the data in this
          * array are reflected by all ByteArrayAdapter objects that point to this array.
-         * @returns an unsigned char* pointer to the array this object wraps.
+         * @return an unsigned char* pointer to the array this object wraps.
          */
         virtual unsigned char* getByteArray() {
             return this->array.bytes;
@@ -260,7 +260,7 @@ namespace util {
         /**
          * Gets the pointer to the array we are wrapping.  Changes to the data in this
          * array are reflected by all ByteArrayAdapter objects that point to this array.
-         * @returns an char* pointer to the array this object wraps.
+         * @return an char* pointer to the array this object wraps.
          */
         virtual char* getCharArray() {
             return this->array.chars;
@@ -269,7 +269,7 @@ namespace util {
         /**
          * Gets the pointer to the array we are wrapping.  Changes to the data in this
          * array are reflected by all ByteArrayAdapter objects that point to this array.
-         * @returns an short* pointer to the array this object wraps.
+         * @return an short* pointer to the array this object wraps.
          */
         virtual short* getShortArray() {
             return this->array.shorts;
@@ -278,7 +278,7 @@ namespace util {
         /**
          * Gets the pointer to the array we are wrapping.  Changes to the data in this
          * array are reflected by all ByteArrayAdapter objects that point to this array.
-         * @returns an int* pointer to the array this object wraps.
+         * @return an int* pointer to the array this object wraps.
          */
         virtual int* getIntArray() {
             return this->array.ints;
@@ -287,7 +287,7 @@ namespace util {
         /**
          * Gets the pointer to the array we are wrapping.  Changes to the data in this
          * array are reflected by all ByteArrayAdapter objects that point to this array.
-         * @returns an long long* pointer to the array this object wraps.
+         * @return an long long* pointer to the array this object wraps.
          */
         virtual long long* getLongArray() {
             return this->array.longs;
@@ -296,7 +296,7 @@ namespace util {
         /**
          * Gets the pointer to the array we are wrapping.  Changes to the data in this
          * array are reflected by all ByteArrayAdapter objects that point to this array.
-         * @returns an double* pointer to the array this object wraps.
+         * @return an double* pointer to the array this object wraps.
          */
         virtual double* getDoubleArray() {
             return this->array.doubles;
@@ -305,7 +305,7 @@ namespace util {
         /**
          * Gets the pointer to the array we are wrapping.  Changes to the data in this
          * array are reflected by all ByteArrayAdapter objects that point to this array.
-         * @returns an float* pointer to the array this object wraps.
+         * @return an float* pointer to the array this object wraps.
          */
         virtual float* getFloatArray() {
             return this->array.floats;
@@ -396,7 +396,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the byte is to be read.
          *
-         * @returns the byte that is located at the given index.
+         * @return the byte that is located at the given index.
          *
          * @throws IndexOutOfBoundsException If index is not smaller than the
          *         buffer's limit or is negative.
@@ -409,7 +409,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the byte is to be read.
          *
-         * @returns the byte that is located at the given index.
+         * @return the byte that is located at the given index.
          *
          * @throws IndexOutOfBoundsException If index is not smaller than the
          *         buffer's limit or is negative.
@@ -425,7 +425,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -438,7 +438,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -454,7 +454,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -467,7 +467,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -483,7 +483,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -496,7 +496,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -512,7 +512,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -525,7 +525,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -541,7 +541,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -554,7 +554,7 @@ namespace util {
          * @param index
          *      The index in the Buffer where the bytes are to be read
          *
-         * @returns the value at the given index in the buffer.
+         * @return the value at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes remaining
          *         to fill the requested Data Type, or index is negative.
@@ -572,7 +572,7 @@ namespace util {
          * @param value
          *      The value to write to the array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -590,7 +590,7 @@ namespace util {
          * @param value
          *      The value to write to the array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -608,7 +608,7 @@ namespace util {
          * @param value
          *      The value to write to the array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -624,7 +624,7 @@ namespace util {
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -642,7 +642,7 @@ namespace util {
          * @param value
          *      The value to write to the array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -658,7 +658,7 @@ namespace util {
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -676,7 +676,7 @@ namespace util {
          * @param value
          *      The value to write to the array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -692,7 +692,7 @@ namespace util {
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -710,7 +710,7 @@ namespace util {
          * @param value
          *      The value to write to the array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -726,7 +726,7 @@ namespace util {
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -744,7 +744,7 @@ namespace util {
          * @param value
          *      The value to write to the array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -760,7 +760,7 @@ namespace util {
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/util/HexStringParser.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/util/HexStringParser.h b/activemq-cpp/src/main/decaf/internal/util/HexStringParser.h
index 0399a13..8c65675 100644
--- a/activemq-cpp/src/main/decaf/internal/util/HexStringParser.h
+++ b/activemq-cpp/src/main/decaf/internal/util/HexStringParser.h
@@ -73,7 +73,7 @@ namespace util {
          * and returns a long long with the bits of the parsed string, the
          * caller can then convert those to a float or doulbe as needed.
          * @param hexString - string to parse
-         * @returns the bits parsed from the string
+         * @return the bits parsed from the string
          */
         long long parse(const std::string& hexString);
 
@@ -156,14 +156,14 @@ namespace util {
         /*
          * Parses the hex string to a double number.
          * @param hexString - string to parse
-         * @returns the parsed double value
+         * @return the parsed double value
          */
         static double parseDouble(const std::string& hexString);
 
         /*
          * Parses the hex string to a float number.
          * @param hexString - string to parse
-         * @returns the parsed float value
+         * @return the parsed float value
          */
         static float parseFloat(const std::string& hexString);
 
@@ -173,7 +173,7 @@ namespace util {
         /*
          * Analyzes the hex string and extracts the sign and digit segments.
          * @param hexString - string to parse
-         * @returns array of three strings holding the segments caller owns
+         * @return array of three strings holding the segments caller owns
          */
         static std::string* getSegmentsFromHexString(const std::string& hexString);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/util/StringUtils.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/util/StringUtils.h b/activemq-cpp/src/main/decaf/internal/util/StringUtils.h
index 63d0f60..e470be5 100644
--- a/activemq-cpp/src/main/decaf/internal/util/StringUtils.h
+++ b/activemq-cpp/src/main/decaf/internal/util/StringUtils.h
@@ -44,7 +44,7 @@ namespace util {
          * @param string
          *      The C style string to check.
          *
-         * @returns the length of the string if the size is < Integer::MAX_VALUE.
+         * @return the length of the string if the size is < Integer::MAX_VALUE.
          *
          * @throws RuntimeException if the length becomes larger than
          *         the max value of an int.
@@ -59,7 +59,7 @@ namespace util {
          * @param right
          *      The right-hand string of the comparison.
          *
-         * @returns a negative integer, zero, or a positive integer as the specified string
+         * @return a negative integer, zero, or a positive integer as the specified string
          *          is greater than, equal to, or less than this String, ignoring case considerations.
          */
         static int compareIgnoreCase(const char* left, const char* right);
@@ -73,7 +73,7 @@ namespace util {
          * @param right
          *      The right-hand string of the comparison.
          *
-         * @returns a negative integer, zero, or a positive integer as the specified string
+         * @return a negative integer, zero, or a positive integer as the specified string
          *          is greater than, equal to, or less than this String, ignoring case considerations.
          */
         static int compare(const char* left, const char* right);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/util/TimerTaskHeap.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/util/TimerTaskHeap.h b/activemq-cpp/src/main/decaf/internal/util/TimerTaskHeap.h
index a96915d..c9e8e28 100644
--- a/activemq-cpp/src/main/decaf/internal/util/TimerTaskHeap.h
+++ b/activemq-cpp/src/main/decaf/internal/util/TimerTaskHeap.h
@@ -58,12 +58,12 @@ namespace util {
         Pointer<TimerTask> peek();
 
         /**
-         * @returns true if the heap is empty.
+         * @return true if the heap is empty.
          */
         bool isEmpty() const;
 
         /**
-         * @returns the size of the heap.
+         * @return the size of the heap.
          */
         std::size_t size() const;
 
@@ -108,7 +108,7 @@ namespace util {
          * Searches the heap for the specified TimerTask element and returns its position in the
          * heap.  Returns the unsigned equivalent of -1 if the element is not found.
          *
-         * @returns the position in the Heap where the Task is stored, or npos.
+         * @return the position in the Heap where the Task is stored, or npos.
          */
         std::size_t find(const Pointer<TimerTask>& task) const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/util/concurrent/ThreadLocalImpl.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/util/concurrent/ThreadLocalImpl.h b/activemq-cpp/src/main/decaf/internal/util/concurrent/ThreadLocalImpl.h
index df9e93a..7750b50 100644
--- a/activemq-cpp/src/main/decaf/internal/util/concurrent/ThreadLocalImpl.h
+++ b/activemq-cpp/src/main/decaf/internal/util/concurrent/ThreadLocalImpl.h
@@ -45,7 +45,7 @@ namespace concurrent {
          * Returns the current threads assigned value, but retains ownership
          * to this value unless the remove method is subsequently called.
          *
-         * @returns the currently held value for this thread.
+         * @return the currently held value for this thread.
          */
         void* getRawValue() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/util/concurrent/Threading.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/util/concurrent/Threading.h b/activemq-cpp/src/main/decaf/internal/util/concurrent/Threading.h
index 466e631..2cb6e50 100644
--- a/activemq-cpp/src/main/decaf/internal/util/concurrent/Threading.h
+++ b/activemq-cpp/src/main/decaf/internal/util/concurrent/Threading.h
@@ -79,7 +79,7 @@ namespace concurrent {
          * initialized and ready for use.  Each monitor that is taken must be returned before
          * the Threading library is shutdown.
          *
-         * @returns handle to a Monitor instance that has been initialized.
+         * @return handle to a Monitor instance that has been initialized.
          */
         static MonitorHandle* takeMonitor(bool alreadyLocked = false);
 
@@ -113,7 +113,7 @@ namespace concurrent {
          * @param monitor
          *      The handle to the monitor that the current thread is attempting to lock.
          *
-         * @returns true if the caller obtains the lock on the Monitor, false otherwise.
+         * @return true if the caller obtains the lock on the Monitor, false otherwise.
          */
         static bool tryEnterMonitor(MonitorHandle* monitor);
 
@@ -144,7 +144,7 @@ namespace concurrent {
          * @param nanos
          *      The time in nanoseconds to wait for the monitor to be signaled.
          *
-         * @returns true if the timeout given expires before the caller was signaled.
+         * @return true if the timeout given expires before the caller was signaled.
          *
          * @throws IllegalMonitorStateException if the caller does not own the monitor.
          */
@@ -195,7 +195,7 @@ namespace concurrent {
          * @param stackSize
          *      The size to allocate for the new thread's stack.
          *
-         * @returns a new ThreadHandle that identifies the thread and allows the parent
+         * @return a new ThreadHandle that identifies the thread and allows the parent
          *          to interact with it.
          */
         static ThreadHandle* createNewThread(Thread* parant, const char* name,
@@ -222,7 +222,7 @@ namespace concurrent {
          * @param nanos
          *      The number of nanoseconds to wait [0-999999].
          *
-         * @returns true if the timeout period expired, false otherwise.
+         * @return true if the timeout period expired, false otherwise.
          *
          * @throws InterruptedException if the Join was interrupted.
          * @throws IllegalArgumentException if the value of mills or nanos is invalid.
@@ -265,17 +265,17 @@ namespace concurrent {
          * @param name
          *      The name to assign to the returned ThreadHandle.
          *
-         * @returns a new ThreadHandle instance for the parent Decaf Thread.
+         * @return a new ThreadHandle instance for the parent Decaf Thread.
          */
         static ThreadHandle* createThreadWrapper(decaf::lang::Thread* parent, const char* name);
 
         /**
-         * @returns the Decaf Thread pointer instance for the currently running thread.
+         * @return the Decaf Thread pointer instance for the currently running thread.
          */
         static Thread* getCurrentThread();
 
         /**
-         * @returns the ThreadHandle instance for the currently running thread.
+         * @return the ThreadHandle instance for the currently running thread.
          */
         static ThreadHandle* getCurrentThreadHandle();
 
@@ -324,7 +324,7 @@ namespace concurrent {
          * @param threadLocal
          *      The ThreadLocalImpl to assign a storage slot.
          *
-         * @returns a new storage slot Id for the given ThreadLocalImpl's value to be assigned.
+         * @return a new storage slot Id for the given ThreadLocalImpl's value to be assigned.
          */
         static int createThreadLocalSlot(ThreadLocalImpl* threadLocal);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/io/ByteArrayOutputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/io/ByteArrayOutputStream.h b/activemq-cpp/src/main/decaf/io/ByteArrayOutputStream.h
index 46796c3..aa684d3 100644
--- a/activemq-cpp/src/main/decaf/io/ByteArrayOutputStream.h
+++ b/activemq-cpp/src/main/decaf/io/ByteArrayOutputStream.h
@@ -97,7 +97,7 @@ namespace io{
 
         /**
          * Converts the bytes in the buffer into a standard C++ string
-         * @returns a string containing the bytes in the buffer
+         * @return a string containing the bytes in the buffer
          */
         virtual std::string toString() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/io/DataInput.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/io/DataInput.h b/activemq-cpp/src/main/decaf/io/DataInput.h
index 3f2c8c4..ebb6ce9 100644
--- a/activemq-cpp/src/main/decaf/io/DataInput.h
+++ b/activemq-cpp/src/main/decaf/io/DataInput.h
@@ -57,7 +57,7 @@ namespace io {
          * Reads in one byte and returns true if that byte is nonzero, false if that
          * byte is zero.
          *
-         * @returns the boolean value of the read in byte (0=false, 1=true).
+         * @return the boolean value of the read in byte (0=false, 1=true).
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -68,7 +68,7 @@ namespace io {
          * Reads and returns one input byte. The byte is treated as a
          * signed value in the range -128 through 127, inclusive.
          *
-         * @returns the 8-bit value read.
+         * @return the 8-bit value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -79,7 +79,7 @@ namespace io {
          * Reads one input byte, zero-extends it to type int, and returns
          * the result, which is therefore in the range 0  through 255.
          *
-         * @returns the 8 bit unsigned value read.
+         * @return the 8 bit unsigned value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -91,7 +91,7 @@ namespace io {
          * is made up of one bytes.  This returns the same result as
          * <code>readByte</code>
          *
-         * @returns the 8 bit char read.
+         * @return the 8 bit char read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -104,7 +104,7 @@ namespace io {
          * the readlong  method, then converting this long  value to a double
          * in exactly the manner of the method Double::longBitsToDouble.
          *
-         * @returns the double value read.
+         * @return the double value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -117,7 +117,7 @@ namespace io {
          * readInt  method, then converting this int  value to a float in
          * exactly the manner of the method Float::intBitsToFloat.
          *
-         * @returns the float value read.
+         * @return the float value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -132,7 +132,7 @@ namespace io {
          *  (((a & 0xff) << 24) | ((b & 0xff) << 16) |
          *   ((c & 0xff) << 8) | (d & 0xff))
          *
-         * @returns the int value read.
+         * @return the int value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -155,7 +155,7 @@ namespace io {
          *   ((long)(g & 0xff) <<  8) |
          *   ((long)(h & 0xff)))
          *
-         * @returns the 64 bit long long read.
+         * @return the 64 bit long long read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -168,7 +168,7 @@ namespace io {
          *
          *   (short)((a << 8) | (b & 0xff))
          *
-         * @returns the 16 bit short value read.
+         * @return the 16 bit short value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -182,7 +182,7 @@ namespace io {
          *
          *   (((a & 0xff) << 8) | (b & 0xff))
          *
-         * @returns the 16 bit unsigned short read.
+         * @return the 16 bit unsigned short read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -193,7 +193,7 @@ namespace io {
          * Reads an NULL terminated ASCII string to the stream and returns the
          * string to the caller.
          *
-         * @returns string object containing the string read.
+         * @return string object containing the string read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -230,7 +230,7 @@ namespace io {
          * encoded UTF-8 bytes is an unsigned short, which implies that the String will
          * be no longer than 65535 characters.
          *
-         * @returns The decoded string read from stream.
+         * @return The decoded string read from stream.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/io/DataInputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/io/DataInputStream.h b/activemq-cpp/src/main/decaf/io/DataInputStream.h
index 686c4d9..c6ad27a 100644
--- a/activemq-cpp/src/main/decaf/io/DataInputStream.h
+++ b/activemq-cpp/src/main/decaf/io/DataInputStream.h
@@ -75,7 +75,7 @@ namespace io{
          * Reads in one byte and returns true if that byte is nonzero, false if that
          * byte is zero.
          *
-         * @returns the boolean value of the read in byte (0=false, 1=true).
+         * @return the boolean value of the read in byte (0=false, 1=true).
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -86,7 +86,7 @@ namespace io{
          * Reads and returns one input byte. The byte is treated as a
          * signed value in the range -128 through 127, inclusive.
          *
-         * @returns the 8-bit value read.
+         * @return the 8-bit value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -97,7 +97,7 @@ namespace io{
          * Reads one input byte, zero-extends it to type int, and returns
          * the result, which is therefore in the range 0  through 255.
          *
-         * @returns the 8 bit unsigned value read.
+         * @return the 8 bit unsigned value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -109,7 +109,7 @@ namespace io{
          * is made up of one bytes.  This returns the same result as
          * <code>readByte</code>
          *
-         * @returns the 8 bit char read.
+         * @return the 8 bit char read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -122,7 +122,7 @@ namespace io{
          * the readlong  method, then converting this long  value to a double
          * in exactly the manner of the method Double::longBitsToDouble.
          *
-         * @returns the double value read.
+         * @return the double value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -135,7 +135,7 @@ namespace io{
          * readInt  method, then converting this int  value to a float in
          * exactly the manner of the method Float::intBitsToFloat.
          *
-         * @returns the float value read.
+         * @return the float value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -150,7 +150,7 @@ namespace io{
          *  (((a & 0xff) << 24) | ((b & 0xff) << 16) |
          *   ((c & 0xff) << 8) | (d & 0xff))
          *
-         * @returns the int value read.
+         * @return the int value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -173,7 +173,7 @@ namespace io{
          *   ((long)(g & 0xff) <<  8) |
          *   ((long)(h & 0xff)))
          *
-         * @returns the 64 bit long long read.
+         * @return the 64 bit long long read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -186,7 +186,7 @@ namespace io{
          *
          *   (short)((a << 8) | (b & 0xff))
          *
-         * @returns the 16 bit short value read.
+         * @return the 16 bit short value read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -200,7 +200,7 @@ namespace io{
          *
          *   (((a & 0xff) << 8) | (b & 0xff))
          *
-         * @returns the 16 bit unsigned short read.
+         * @return the 16 bit unsigned short read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -211,7 +211,7 @@ namespace io{
          * Reads an NULL terminated ASCII string to the stream and returns the
          * string to the caller.
          *
-         * @returns string object containing the string read.
+         * @return string object containing the string read.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.
@@ -248,7 +248,7 @@ namespace io{
          * encoded UTF-8 bytes is an unsigned short, which implies that the String will
          * be no longer than 65535 characters.
          *
-         * @returns The decoded string read from stream.
+         * @return The decoded string read from stream.
          *
          * @throws IOException if an I/O Error occurs.
          * @throws EOFException if the end of input is reached.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/io/FilterInputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/io/FilterInputStream.h b/activemq-cpp/src/main/decaf/io/FilterInputStream.h
index 43d04f7..c7b702b 100644
--- a/activemq-cpp/src/main/decaf/io/FilterInputStream.h
+++ b/activemq-cpp/src/main/decaf/io/FilterInputStream.h
@@ -105,7 +105,7 @@ namespace io{
         virtual int doReadArrayBounded(unsigned char* buffer, int size, int offset, int length);
 
         /**
-         * @returns true if this stream has been closed.
+         * @return true if this stream has been closed.
          */
         virtual bool isClosed() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/io/FilterOutputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/io/FilterOutputStream.h b/activemq-cpp/src/main/decaf/io/FilterOutputStream.h
index 9f4a734..97c8119 100644
--- a/activemq-cpp/src/main/decaf/io/FilterOutputStream.h
+++ b/activemq-cpp/src/main/decaf/io/FilterOutputStream.h
@@ -110,7 +110,7 @@ namespace io{
     protected:
 
         /**
-         * @returns true if this stream has been closed.
+         * @return true if this stream has been closed.
          */
         virtual bool isClosed() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/io/InputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/io/InputStream.h b/activemq-cpp/src/main/decaf/io/InputStream.h
index 4dd58b4..533491d 100644
--- a/activemq-cpp/src/main/decaf/io/InputStream.h
+++ b/activemq-cpp/src/main/decaf/io/InputStream.h
@@ -117,7 +117,7 @@ namespace io{
          *
          * The default implementation of this method returns false.
          *
-         * @returns true if this stream instance supports marks
+         * @return true if this stream instance supports marks
          */
         virtual bool markSupported() const {
             return false;
@@ -247,7 +247,7 @@ namespace io{
          * @param num
          *       The number of bytes to skip.
          *
-         * @returns total bytes skipped
+         * @return total bytes skipped
          *
          * @throws IOException if an I/O error occurs.
          * @throws UnsupportedOperationException if the concrete stream class does

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/AbstractStringBuilder.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/AbstractStringBuilder.h b/activemq-cpp/src/main/decaf/lang/AbstractStringBuilder.h
index 34c4cee..3b5a5d3 100644
--- a/activemq-cpp/src/main/decaf/lang/AbstractStringBuilder.h
+++ b/activemq-cpp/src/main/decaf/lang/AbstractStringBuilder.h
@@ -67,7 +67,7 @@ namespace lang {
          * the internal character buffer, when the number of characters inserted exceeds the current
          * capacity the internal buffer is reallocated and old contents copied to the new buffer.
          *
-         * @returns the current capacity value.
+         * @return the current capacity value.
          */
         virtual int capacity() const;
 
@@ -125,7 +125,7 @@ namespace lang {
          * @param value
          *      The String to locate within this string buffer.
          *
-         * @returns the index of the specified substring within this string buffer or -1 if not found.
+         * @return the index of the specified substring within this string buffer or -1 if not found.
          */
         virtual int indexOf(const String& value) const;
 
@@ -138,7 +138,7 @@ namespace lang {
          * @param start
          *      The index to start the search from.
          *
-         * @returns the index of the specified substring within this string buffer or -1 if not found.
+         * @return the index of the specified substring within this string buffer or -1 if not found.
          */
         virtual int indexOf(const String& value, int start) const;
 
@@ -148,7 +148,7 @@ namespace lang {
          * @param value
          *      The String to locate within this string buffer.
          *
-         * @returns the last index of the specified substring within this string buffer or -1
+         * @return the last index of the specified substring within this string buffer or -1
          *          if not found.
          */
         virtual int lastIndexOf(const String& value) const;
@@ -162,7 +162,7 @@ namespace lang {
          * @param start
          *      The index to start the search from.
          *
-         * @returns the last index of the specified substring within this string buffer or -1
+         * @return the last index of the specified substring within this string buffer or -1
          *          if not found.
          */
         virtual int lastIndexOf(const String& value, int start) const;
@@ -170,7 +170,7 @@ namespace lang {
         /**
          * Returns the current length of the String that has been built.
          *
-         * @returns the current number of characters that have been inserted.
+         * @return the current number of characters that have been inserted.
          */
         virtual int length() const;
 
@@ -208,7 +208,7 @@ namespace lang {
          * @param start
          *      The starting index of the substring to create.
          *
-         * @returns a new String that is a subset of this character buffer.
+         * @return a new String that is a subset of this character buffer.
          *
          * @throws StringIndexOutOfBoundsException
          *      if start is less than zero, or greater than the length of this buffer.
@@ -225,7 +225,7 @@ namespace lang {
          * @param end
          *      The ending index of the substring to create. (exclusive)
          *
-         * @returns a new String that is a subset of this character buffer.
+         * @return a new String that is a subset of this character buffer.
          *
          * @throws StringIndexOutOfBoundsException
          *      if start or end is less than zero, or end is greater than the length of this buffer
@@ -244,7 +244,7 @@ namespace lang {
          * @param end
          *      The ending index of the substring to create. (exclusive)
          *
-         * @returns a new CharSequence pointer that is a subset of this character buffer.
+         * @return a new CharSequence pointer that is a subset of this character buffer.
          *
          * @throws StringIndexOutOfBoundsException
          *      if start or end is less than zero, or end is greater than the length of this buffer

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Appendable.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Appendable.h b/activemq-cpp/src/main/decaf/lang/Appendable.h
index 6109b50..226a280 100644
--- a/activemq-cpp/src/main/decaf/lang/Appendable.h
+++ b/activemq-cpp/src/main/decaf/lang/Appendable.h
@@ -50,7 +50,7 @@ namespace lang {
          * @param value
          *      The character to append.
          *
-         * @returns a Reference to this Appendable
+         * @return a Reference to this Appendable
          *
          * @throws Exception if an error occurs.
          */
@@ -64,7 +64,7 @@ namespace lang {
          *      If csq is NULL, then characters will be appended as if csq contained the
          *      string "null".
          *
-         * @returns a Reference to this Appendable.
+         * @return a Reference to this Appendable.
          *
          * @throws Exception if an error occurs.
          */
@@ -81,7 +81,7 @@ namespace lang {
          * @param end
          *      The index of the character following the last character in the subsequence.
          *
-         * @returns a Reference to this Appendable
+         * @return a Reference to this Appendable
          *
          * @throws Exception if an error occurs.
          * @throws IndexOutOfBoundsException start is greater than end, or end is

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/ArrayPointer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/ArrayPointer.h b/activemq-cpp/src/main/decaf/lang/ArrayPointer.h
index 6893c11..4c030ca 100755
--- a/activemq-cpp/src/main/decaf/lang/ArrayPointer.h
+++ b/activemq-cpp/src/main/decaf/lang/ArrayPointer.h
@@ -216,7 +216,7 @@ namespace lang {
          *
          * @param value - The new value to contain.
          *
-         * @returns The pointer instance that was held by this Pointer object, the pointer is
+         * @return The pointer instance that was held by this Pointer object, the pointer is
          *          no longer owned by this Pointer and won't be freed when this Pointer goes
          *          out of scope.
          */
@@ -244,7 +244,7 @@ namespace lang {
          * Returns the current size of the contained array or zero if the array is
          * NULL.
          *
-         * @returns the size of the array or zero if the array is NULL
+         * @return the size of the array or zero if the array is NULL
          */
         int length() const {
             return this->array->length;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Boolean.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Boolean.h b/activemq-cpp/src/main/decaf/lang/Boolean.h
index ec37b61..842612c 100644
--- a/activemq-cpp/src/main/decaf/lang/Boolean.h
+++ b/activemq-cpp/src/main/decaf/lang/Boolean.h
@@ -60,14 +60,14 @@ namespace lang{
         virtual ~Boolean() {}
 
         /**
-         * @returns the primitive boolean value of this object
+         * @return the primitive boolean value of this object
          */
         bool booleanValue() const {
             return value;
         }
 
         /**
-         * @returns the string representation of this Booleans value.
+         * @return the string representation of this Booleans value.
          */
         std::string toString() const;
 
@@ -97,7 +97,7 @@ namespace lang{
         virtual bool operator<(const Boolean& value) const;
 
         /**
-         * @returns true if the two Boolean Objects have the same value.
+         * @return true if the two Boolean Objects have the same value.
          */
         bool equals(const Boolean& b) const {
             return this->value == b.value;
@@ -129,7 +129,7 @@ namespace lang{
         virtual bool operator<(const bool& value) const;
 
         /**
-         * @returns true if the two Boolean Objects have the same value.
+         * @return true if the two Boolean Objects have the same value.
          */
         bool equals(const bool& b) const {
             return this->value == b;
@@ -141,7 +141,7 @@ namespace lang{
          * @param value
          *      The bool value to convert to a <code>Boolean</code> instance.
          *
-         * @returns a Boolean instance of the primitive boolean value
+         * @return a Boolean instance of the primitive boolean value
          */
         static Boolean valueOf(bool value);
 
@@ -149,7 +149,7 @@ namespace lang{
          * @param value
          *      The std::string value to convert to a <code>Boolean</code> instance.
          *
-         * @returns a Boolean instance of the string value
+         * @return a Boolean instance of the string value
          */
         static Boolean valueOf(const String& value);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Byte.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Byte.h b/activemq-cpp/src/main/decaf/lang/Byte.h
index 6ae606b..83bcc52 100644
--- a/activemq-cpp/src/main/decaf/lang/Byte.h
+++ b/activemq-cpp/src/main/decaf/lang/Byte.h
@@ -128,21 +128,21 @@ namespace lang {
         }
 
         /**
-         * @returns true if the two Byte Objects have the same value.
+         * @return true if the two Byte Objects have the same value.
          */
         bool equals(const Byte& c) const {
             return this->value == c.value;
         }
 
         /**
-         * @returns true if the two Bytes have the same value.
+         * @return true if the two Bytes have the same value.
          */
         bool equals(const unsigned char& c) const {
             return this->value == c;
         }
 
         /**
-         * @returns this Byte Object as a String Representation
+         * @return this Byte Object as a String Representation
          */
         std::string toString() const;
 
@@ -197,7 +197,7 @@ namespace lang {
     public:
 
         /**
-         * @returns a string representing the primitive value as Base 10
+         * @return a string representing the primitive value as Base 10
          */
         static std::string toString(unsigned char value);
 
@@ -216,7 +216,7 @@ namespace lang {
          * @param value
          *      The string to decode
          *
-         * @returns a Byte object containing the decoded value
+         * @return a Byte object containing the decoded value
          *
          * @throws NumberFomatException if the string is not formatted correctly.
          */
@@ -263,7 +263,7 @@ namespace lang {
          * @param s
          *      String to convert to a unsigned char
          *
-         * @returns the converted unsigned char value
+         * @return the converted unsigned char value
          *
          * @throws NumberFormatException if the string is not a unsigned char.
          */
@@ -275,7 +275,7 @@ namespace lang {
          * @param value
          *      The primitive char to wrap.
          *
-         * @returns a new Character instance that wraps this value.
+         * @return a new Character instance that wraps this value.
          */
         static Byte valueOf(unsigned char value) {
             return Byte(value);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/CharSequence.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/CharSequence.h b/activemq-cpp/src/main/decaf/lang/CharSequence.h
index 507a4ec..e955469 100644
--- a/activemq-cpp/src/main/decaf/lang/CharSequence.h
+++ b/activemq-cpp/src/main/decaf/lang/CharSequence.h
@@ -39,7 +39,7 @@ namespace lang {
         virtual ~CharSequence();
 
         /**
-         * @returns the length of the underlying character sequence.
+         * @return the length of the underlying character sequence.
          */
         virtual int length() const = 0;
 
@@ -50,7 +50,7 @@ namespace lang {
          * @param index
          *      The position to return the char at.
          *
-         * @returns the char at the given position.
+         * @return the char at the given position.
          *
          * @throws IndexOutOfBoundsException if index is > than length() or negative
          */
@@ -67,14 +67,14 @@ namespace lang {
          * @param end
          *      The end index, exclusive.
          *
-         * @returns a new CharSequence
+         * @return a new CharSequence
          *
          * @throws IndexOutOfBoundsException if start or end > length() or start or end are negative.
          */
         virtual CharSequence* subSequence(int start, int end) const = 0;
 
         /**
-         * @returns the String representation of this CharSequence
+         * @return the String representation of this CharSequence
          */
         virtual std::string toString() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Character.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Character.h b/activemq-cpp/src/main/decaf/lang/Character.h
index ad60fd1..0c666b9 100644
--- a/activemq-cpp/src/main/decaf/lang/Character.h
+++ b/activemq-cpp/src/main/decaf/lang/Character.h
@@ -139,21 +139,21 @@ namespace lang{
         }
 
         /**
-         * @returns true if the two Character Objects have the same value.
+         * @return true if the two Character Objects have the same value.
          */
         bool equals(const Character& c) const {
             return this->value == c.value;
         }
 
         /**
-         * @returns true if the two Characters have the same value.
+         * @return true if the two Characters have the same value.
          */
         bool equals(const char& c) const {
             return this->value == c;
         }
 
         /**
-         * @returns this Character Object as a String Representation
+         * @return this Character Object as a String Representation
          */
         std::string toString() const;
 
@@ -219,7 +219,7 @@ namespace lang{
          * @param value
          *      the primitive char to wrap.
          *
-         * @returns a new Character instance that wraps this value.
+         * @return a new Character instance that wraps this value.
          */
         static Character valueOf(char value) {
             return Character(value);
@@ -232,7 +232,7 @@ namespace lang{
          * @param c
          *      The character whose value is being checked.
          *
-         * @returns true if the character is a whitespace value.
+         * @return true if the character is a whitespace value.
          */
         static bool isWhitespace(char c) {
             switch (c) {
@@ -253,7 +253,7 @@ namespace lang{
          * @param c
          *      The character whose value is being checked.
          *
-         * @returns true if the character is a digit value.
+         * @return true if the character is a digit value.
          */
         static bool isDigit(char c) {
             return c >= '0' && c <= '9';
@@ -265,7 +265,7 @@ namespace lang{
          * @param c
          *      The character whose value is being checked.
          *
-         * @returns true if the character is a lower case ASCII value.
+         * @return true if the character is a lower case ASCII value.
          */
         static bool isLowerCase(char c) {
             return c >= 'a' && c <= 'z';
@@ -278,7 +278,7 @@ namespace lang{
          * @param c
          *      The character whose value is being checked.
          *
-         * @returns true if the character is a upper case ASCII value.
+         * @return true if the character is a upper case ASCII value.
          */
         static bool isUpperCase(char c) {
             return c >= 'A' && c <= 'Z';
@@ -290,7 +290,7 @@ namespace lang{
          * @param c
          *      The character whose value is being checked.
          *
-         * @returns true if the character is an ASCII letter value.
+         * @return true if the character is an ASCII letter value.
          */
         static bool isLetter(char c) {
             return isUpperCase(c) || isLowerCase(c);
@@ -303,7 +303,7 @@ namespace lang{
          * @param c
          *      The character whose value is being checked.
          *
-         * @returns true if the character is an ASCII letter or numeric value.
+         * @return true if the character is an ASCII letter or numeric value.
          */
         static bool isLetterOrDigit(char c) {
             return isLetter(c) || isDigit(c);
@@ -344,7 +344,7 @@ namespace lang{
          * @param radix
          *      the radix of the number
          *
-         * @returns the numeric value of the number represented in the given radix
+         * @return the numeric value of the number represented in the given radix
          */
         static int digit(char c, int radix);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Comparable.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Comparable.h b/activemq-cpp/src/main/decaf/lang/Comparable.h
index 18e3e0c..72c86c6 100644
--- a/activemq-cpp/src/main/decaf/lang/Comparable.h
+++ b/activemq-cpp/src/main/decaf/lang/Comparable.h
@@ -60,7 +60,7 @@ namespace lang {
          * "Note: this class has a natural ordering that is inconsistent with
          * equals."
          * @param value - the Object to be compared.
-         * @returns a negative integer, zero, or a positive integer as this
+         * @return a negative integer, zero, or a positive integer as this
          * object is less than, equal to, or greater than the specified object.
          */
         virtual int compareTo(const T& value) const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Double.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Double.h b/activemq-cpp/src/main/decaf/lang/Double.h
index a296561..c762675 100644
--- a/activemq-cpp/src/main/decaf/lang/Double.h
+++ b/activemq-cpp/src/main/decaf/lang/Double.h
@@ -91,7 +91,7 @@ namespace lang {
 
         /**
          * @param d - the Double object to compare against.
-         * @returns true if the two Double Objects have the same value.
+         * @return true if the two Double Objects have the same value.
          */
         bool equals(const Double& d) const {
             return this->value == d.value;
@@ -128,7 +128,7 @@ namespace lang {
 
         /**
          * @param d - the Double object to compare against.
-         * @returns true if the two Double Objects have the same value.
+         * @return true if the two Double Objects have the same value.
          */
         bool equals(const double& d) const {
             return this->value == d;
@@ -154,7 +154,7 @@ namespace lang {
         }
 
         /**
-         * @returns this Double Object as a String Representation
+         * @return this Double Object as a String Representation
          */
         std::string toString() const;
 
@@ -207,12 +207,12 @@ namespace lang {
         }
 
         /**
-         * @returns true if the double is equal to positive infinity.
+         * @return true if the double is equal to positive infinity.
          */
         bool isInfinite() const;
 
         /**
-         * @returns true if the double is equal to NaN.
+         * @return true if the double is equal to NaN.
          */
         bool isNaN() const;
 
@@ -225,7 +225,7 @@ namespace lang {
          *        new Double(d1).compareTo(new Double(d2))
          * @param d1 - the first double to compare
          * @param d2 - the second double to compare
-         * @returns the value 0 if d1 is numerically equal to d2; a value less than
+         * @return the value 0 if d1 is numerically equal to d2; a value less than
          * 0 if d1 is numerically less than d2; and a value greater than 0  if d1 is
          * numerically greater than d2.
          */
@@ -251,7 +251,7 @@ namespace lang {
          * same as the argument to doubleToLongBits (except all NaN values are
          * collapsed to a single "canonical" NaN value).
          * @param value - double to be converted
-         * @returns the long long bits that make up the double
+         * @return the long long bits that make up the double
          */
         static long long doubleToLongBits(double value);
 
@@ -278,19 +278,19 @@ namespace lang {
          * longBitsToDouble(long) method, will produce a floating-point value the
          * same as the argument to doubleToRawLongBits.
          * @param value - double to be converted
-         * @returns the long long bits that make up the double
+         * @return the long long bits that make up the double
          */
         static long long doubleToRawLongBits(double value);
 
         /**
          * @param value - The double to check.
-         * @returns true if the double is equal to infinity.
+         * @return true if the double is equal to infinity.
          */
         static bool isInfinite(double value);
 
         /**
          * @param value - The double to check.
-         * @returns true if the double is equal to NaN.
+         * @return true if the double is equal to NaN.
          */
         static bool isNaN(double value);
 
@@ -319,7 +319,7 @@ namespace lang {
          * @param value
          *      The string to parse to an double.
          *
-         * @returns a double parsed from the passed string
+         * @return a double parsed from the passed string
          *
          * @throws NumberFormatException
          */
@@ -357,7 +357,7 @@ namespace lang {
          *        there must be at least one nonzero digit in a subnormal significand.
          *
          * @param value - The double to convert to a string
-         * @returns the Hex formatted double string.
+         * @return the Hex formatted double string.
          */
         static std::string toHexString(double value);
 
@@ -390,7 +390,7 @@ namespace lang {
          *    followed by a representation of n as a decimal integer, as produced
          *    by the method Integer.toString(int).
          * @param value - The double to convert to a string
-         * @returns the formatted double string.
+         * @return the formatted double string.
          */
         static std::string toString(double value);
 
@@ -400,7 +400,7 @@ namespace lang {
          * @param value
          *      The double to wrap.
          *
-         * @returns new Double instance wrapping the primitive value
+         * @return new Double instance wrapping the primitive value
          */
         static Double valueOf(double value);
 
@@ -411,7 +411,7 @@ namespace lang {
          * @param value
          *      The string to parse
          *
-         * @returns a new Double instance wrapping the double parsed from value
+         * @return a new Double instance wrapping the double parsed from value
          *
          * @throws NumberFormatException on error.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Exception.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Exception.h b/activemq-cpp/src/main/decaf/lang/Exception.h
index 968ab4f..17c80d2 100644
--- a/activemq-cpp/src/main/decaf/lang/Exception.h
+++ b/activemq-cpp/src/main/decaf/lang/Exception.h
@@ -115,7 +115,7 @@ namespace lang {
          * exception to be passed only in case the caller knows about that
          * type of exception and wishes to respond to it.
          *
-         * @returns a const pointer reference to the causal exception, if there
+         * @return a const pointer reference to the causal exception, if there
          *          was no cause associated with this exception then NULL is returned.
          */
         virtual const std::exception* getCause() const;


[5/9] activemq-cpp git commit: Fix some documentation generation issues.

Posted by ta...@apache.org.
http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/URI.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/URI.h b/activemq-cpp/src/main/decaf/net/URI.h
index da3a786..187c723 100644
--- a/activemq-cpp/src/main/decaf/net/URI.h
+++ b/activemq-cpp/src/main/decaf/net/URI.h
@@ -134,7 +134,7 @@ namespace net {
          * negative integer, zero, or a positive integer as this object is less
          * than, equal to, or greater than the specified object.
          * @param value - the value to compare to this one.
-         * @returns zero if equal minus one if less than and one if greater than.
+         * @return zero if equal minus one if less than and one if greater than.
          */
         virtual int compareTo(const URI& value) const;
 
@@ -159,42 +159,42 @@ namespace net {
         virtual bool operator<(const URI& value) const;
 
         /**
-         * @returns the decoded authority component of this URI.
+         * @return the decoded authority component of this URI.
          */
         std::string getAuthority() const;
 
         /**
-         * @returns the decoded fragment component of this URI.
+         * @return the decoded fragment component of this URI.
          */
         std::string getFragment() const;
 
         /**
-         * @returns the host component of this URI.
+         * @return the host component of this URI.
          */
         std::string getHost() const;
 
         /**
-         * @returns the path component of this URI.
+         * @return the path component of this URI.
          */
         std::string getPath() const;
 
         /**
-         * @returns the port component of this URI.
+         * @return the port component of this URI.
          */
         int getPort() const;
 
         /**
-         * @returns the query component of this URI.
+         * @return the query component of this URI.
          */
         std::string getQuery() const;
 
         /**
-         * @returns the scheme component of this URI
+         * @return the scheme component of this URI
          */
         std::string getScheme() const;
 
         /**
-         * @returns the user info component of this URI
+         * @return the user info component of this URI
          */
         std::string getUserInfo() const;
 
@@ -207,7 +207,7 @@ namespace net {
          * it is further constrained to have valid user-information, host, and
          * port components.
          *
-         * @returns the raw authority component of the URI
+         * @return the raw authority component of the URI
          */
         std::string getRawAuthority() const;
 
@@ -217,7 +217,7 @@ namespace net {
          * The fragment component of a URI, if defined, only contains legal URI
          * characters.
          *
-         * @returns the raw fragment component of this URI
+         * @return the raw fragment component of this URI
          */
         std::string getRawFragment() const;
 
@@ -228,7 +228,7 @@ namespace net {
          * character ('/'), the commercial-at character ('@'), and characters
          * in the unreserved, punct, escaped, and other categories.
          *
-         * @returns the raw path component of this URI
+         * @return the raw path component of this URI
          */
         std::string getRawPath() const;
 
@@ -237,7 +237,7 @@ namespace net {
          *
          * The query component of a URI, if defined, only contains legal URI characters.
          *
-         * @returns the raw query component of the URI.
+         * @return the raw query component of the URI.
          */
         std::string getRawQuery() const;
 
@@ -247,7 +247,7 @@ namespace net {
          *
          * The scheme-specific part of a URI only contains legal URI characters.
          *
-         * @returns the raw scheme special part of the uri
+         * @return the raw scheme special part of the uri
          */
         std::string getRawSchemeSpecificPart() const;
 
@@ -257,7 +257,7 @@ namespace net {
          * getRawSchemeSpecificPart method except that all sequences of escaped
          * octets are decoded.
          *
-         * @returns the raw scheme specific part of the uri.
+         * @return the raw scheme specific part of the uri.
          */
         std::string getSchemeSpecificPart() const;
 
@@ -266,7 +266,7 @@ namespace net {
          * The user-information component of a URI, if defined, only contains
          * characters in the unreserved, punct, escaped, and other categories.
          *
-         * @returns the raw user-information component of the URI
+         * @return the raw user-information component of the URI
          */
         std::string getRawUserInfo() const;
 
@@ -274,7 +274,7 @@ namespace net {
          * Tells whether or not this URI is absolute.  A URI is absolute if,
          * and only if, it has a scheme component.
          *
-         * @returns true if, and only if, this URI is absolute
+         * @return true if, and only if, this URI is absolute
          */
         bool isAbsolute() const;
 
@@ -284,7 +284,7 @@ namespace net {
          * slash character ('/'). An opaque URI has a scheme, a scheme-specific
          * part, and possibly a fragment; all other components are undefined.
          *
-         * @returns true if, and only if, this URI is opaque
+         * @return true if, and only if, this URI is opaque
          */
         bool isOpaque() const;
 
@@ -311,7 +311,7 @@ namespace net {
          * 3 above. Otherwise, a normalized path will not contain any "." or ".."
          * segments.
          *
-         * @returns A URI equivalent to this URI, but whose path is in normal form
+         * @return A URI equivalent to this URI, but whose path is in normal form
          */
         URI normalize() const;
 
@@ -328,7 +328,7 @@ namespace net {
          * into user-information, host, and port components, and throws an exception
          * describing why the authority component could not be parsed in that way.
          *
-         * @returns A URI whose authority field has been parsed as a server-based
+         * @return A URI whose authority field has been parsed as a server-based
          *          authority
          *
          * @throws URISyntaxException If the authority component of this URI is
@@ -352,7 +352,7 @@ namespace net {
          * @param uri
          *      The URI to be relativized against this URI
          *
-         * @returns The resulting URI
+         * @return The resulting URI
          */
         URI relativize(const URI& uri) const;
 
@@ -366,7 +366,7 @@ namespace net {
          * @param str
          *      The string to be parsed into a URI
          *
-         * @returns The resulting URI
+         * @return The resulting URI
          *
          * @throws IllegalArgumentException - If the given string violates RFC 2396
          */
@@ -409,7 +409,7 @@ namespace net {
          * @param uri
          *      The URI to be resolved against this URI
          *
-         * @returns The resulting URI
+         * @return The resulting URI
          */
         URI resolve(const URI& uri) const;
 
@@ -423,7 +423,7 @@ namespace net {
          * relativization, and so a string is constructed from this URI's components
          * according to the rules specified in RFC 2396, section 5.2, step 7.
          *
-         * @returns the string form of this URI
+         * @return the string form of this URI
          */
         std::string toString() const;
 
@@ -434,7 +434,7 @@ namespace net {
          * evaluating the expression new URL(this.toString()) after first checking
          * that this URI is absolute.
          *
-         * @returns A URL constructed from this URI
+         * @return A URL constructed from this URI
          *
          * @throws IllegalArgumentException - If this URL is not absolute
          * @throws MalformedURLException - If a protocol handler for the URL could not

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/URISyntaxException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/URISyntaxException.h b/activemq-cpp/src/main/decaf/net/URISyntaxException.h
index 9c23083..a653bda 100644
--- a/activemq-cpp/src/main/decaf/net/URISyntaxException.h
+++ b/activemq-cpp/src/main/decaf/net/URISyntaxException.h
@@ -124,21 +124,21 @@ namespace net{
         virtual ~URISyntaxException() throw();
 
         /**
-         * @returns the Input string that cause this exception or ""
+         * @return the Input string that cause this exception or ""
          */
         std::string getInput() const {
             return input;
         }
 
         /**
-         * @returns the Reason given for this failure, or ""
+         * @return the Reason given for this failure, or ""
          */
         std::string getReason() const {
             return reason;
         }
 
         /**
-         * @returns the index in the input string where the error occured or -1
+         * @return the index in the input string where the error occured or -1
          */
         int getIndex() const {
             return index;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/URL.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/URL.h b/activemq-cpp/src/main/decaf/net/URL.h
index 17bf81a..138b605 100644
--- a/activemq-cpp/src/main/decaf/net/URL.h
+++ b/activemq-cpp/src/main/decaf/net/URL.h
@@ -280,14 +280,14 @@ namespace net {
          *
          * Since hosts comparison requires name resolution, this operation is a blocking operation.
          *
-         * @returns true if this URL is considered equal to the given URL instance.
+         * @return true if this URL is considered equal to the given URL instance.
          */
         bool equals(const URL& other) const;
 
         /**
          * Gets the authority part of this URL.
          *
-         * @returns the authority part of this URL.
+         * @return the authority part of this URL.
          */
         decaf::lang::String getAuthority() const;
 
@@ -296,7 +296,7 @@ namespace net {
          * scheme or the URLStreamHandler for the URL do not define a default port number, then
          * -1 is returned.
          *
-         * @returns the default port for the given scheme.
+         * @return the default port for the given scheme.
          */
         int getDefaultPort() const;
 
@@ -305,7 +305,7 @@ namespace net {
          * plus the concatenation of the value of getQuery(), if any. If there is no query portion,
          * this method and getPath() will return identical results.
          *
-         * @returns the file name associated with this URL.
+         * @return the file name associated with this URL.
          */
         decaf::lang::String getFile() const;
 
@@ -314,49 +314,49 @@ namespace net {
          * RFC 2732, i.e. for a literal IPv6 address, this method will return the IPv6 address
          * enclosed in square brackets ('[' and ']').
          *
-         * @returns the host name for this URL.
+         * @return the host name for this URL.
          */
         decaf::lang::String getHost() const;
 
         /**
          * Gets the path part of this URL.
          *
-         * @returns the path part of this URL.
+         * @return the path part of this URL.
          */
         decaf::lang::String getPath() const;
 
         /**
          * Gets the user Info part of this URL.
          *
-         * @returns the user info part of this URL.
+         * @return the user info part of this URL.
          */
         decaf::lang::String getUserInfo() const;
 
         /**
          * Gets the port of this URL.
          *
-         * @returns the port of this URL or -1 if not set.
+         * @return the port of this URL or -1 if not set.
          */
         int getPort() const;
 
         /**
          * Gets the protocol of this URL.
          *
-         * @returns the path part of this URL.
+         * @return the path part of this URL.
          */
         decaf::lang::String getProtocol() const;
 
         /**
          * Gets the query part of this URL.
          *
-         * @returns the query part of this URL or empty string if not set.
+         * @return the query part of this URL or empty string if not set.
          */
         decaf::lang::String getQuery() const;
 
         /**
          * Gets the anchor or "reference" portion of this URL.
          *
-         * @returns the anchor or "reference" portion of this URL.
+         * @return the anchor or "reference" portion of this URL.
          */
         decaf::lang::String getRef() const;
 
@@ -366,7 +366,7 @@ namespace net {
          * The hash code is based upon all the URL components relevant for URL comparison which
          * means that the host resolution may cause this operation to block.
          *
-         * @returns the integer has code for this URL.
+         * @return the integer has code for this URL.
          */
         int hashCode() const;
 
@@ -383,7 +383,7 @@ namespace net {
          * be of that subclass. For example, for HTTP an HttpURLConnection will be returned,
          * and for JAR a JarURLConnection will be returned.
          *
-         * @returns a new URLConnection instance for this URL.
+         * @return a new URLConnection instance for this URL.
          *
          * @throws IOException if an error occurs while opening the connection.
          */
@@ -397,7 +397,7 @@ namespace net {
          * @param proxy
          *      The proxy instance to use to make the connection.
          *
-         * @returns a new URLConnection instance for this URL.
+         * @return a new URLConnection instance for this URL.
          *
          * @throws IOException if an error occurs while opening the connection.
          * @throws IllegalArgumentException if proxy is null, or proxy has the wrong type.
@@ -409,7 +409,7 @@ namespace net {
          * Shortcut method to opens a connection to this URL and fetch an InputStream
          * for reading from that connection.
          *
-         * @returns an InputStream that reads from this URL's location.
+         * @return an InputStream that reads from this URL's location.
          *
          * @throws IOException if an error occurs.
          */
@@ -419,7 +419,7 @@ namespace net {
          * Compares this URL to the other ignoring the fragment portion to determine if both
          * reference the same remote object.
          *
-         * @returns true if both URL's reference the same external object.
+         * @return true if both URL's reference the same external object.
          */
         bool sameFile(const URL& other) const;
 
@@ -427,21 +427,21 @@ namespace net {
          * Constructs a string representation of this URL, by calling the toExternalForm
          * method of the stream protocol handler for this object.
          *
-         * @returns the string representation of this URL.
+         * @return the string representation of this URL.
          */
         decaf::lang::String toExternalForm() const;
 
         /**
          * Calls toExternalForm to create a string representation of this URL.
          *
-         * @returns the string representation of this URL.
+         * @return the string representation of this URL.
          */
         std::string toString() const;
 
         /**
          * Returns a URI instance that is the equivalent of this URL.
          *
-         * @returns the URI that is the equivalent of this URL.
+         * @return the URI that is the equivalent of this URL.
          */
         URI toURI() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/URLEncoder.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/URLEncoder.h b/activemq-cpp/src/main/decaf/net/URLEncoder.h
index a83bf05..6281ffe 100644
--- a/activemq-cpp/src/main/decaf/net/URLEncoder.h
+++ b/activemq-cpp/src/main/decaf/net/URLEncoder.h
@@ -51,7 +51,7 @@ namespace net{
          * In addition, spaces are substituted by '+'
          *
          * @param value - the string to be converted
-         * @returns the converted string
+         * @return the converted string
          */
         static std::string encode( const std::string& value );
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/URLStreamHandler.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/URLStreamHandler.h b/activemq-cpp/src/main/decaf/net/URLStreamHandler.h
index 5b1944a..a065a41 100644
--- a/activemq-cpp/src/main/decaf/net/URLStreamHandler.h
+++ b/activemq-cpp/src/main/decaf/net/URLStreamHandler.h
@@ -89,7 +89,7 @@ namespace net {
          * @param other
          *      The URL that is being compared to source.
          *
-         * @returns true if the two URL instances are considered equal.
+         * @return true if the two URL instances are considered equal.
          */
         virtual bool equals(const URL& source, const URL& other) const;
 
@@ -110,7 +110,7 @@ namespace net {
          * @param other
          *      The URL that is being compared to source.
          *
-         * @returns true if the two URL instances are considered to point to the same host.
+         * @return true if the two URL instances are considered to point to the same host.
          */
         virtual bool hostsEqual(const URL& source, const URL& other) const;
 
@@ -123,7 +123,7 @@ namespace net {
          * @param other
          *      The URL that is being compared to source.
          *
-         * @returns true if the two URL instances are considered to be the same file.
+         * @return true if the two URL instances are considered to be the same file.
          */
         virtual bool sameFile(const URL& source, const URL& other) const;
 
@@ -133,7 +133,7 @@ namespace net {
          * @param url
          *      The URL to construct the string from.
          *
-         * @returns string form of the provided URL.
+         * @return string form of the provided URL.
          */
         virtual decaf::lang::String toExternalForm(const URL& url) const;
 
@@ -153,7 +153,7 @@ namespace net {
          * be overidden by handlers with knowledge of the default port numbers as the default
          * implementation simply returns -1.
          *
-         * @returns the default port number for this URL's protocol.
+         * @return the default port number for this URL's protocol.
          */
         virtual int getDefaultPort() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ssl/SSLContext.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ssl/SSLContext.h b/activemq-cpp/src/main/decaf/net/ssl/SSLContext.h
index 91d2276..8f0ce83 100644
--- a/activemq-cpp/src/main/decaf/net/ssl/SSLContext.h
+++ b/activemq-cpp/src/main/decaf/net/ssl/SSLContext.h
@@ -53,7 +53,7 @@ namespace ssl {
          * The default instance of the SSLContext should be immediately usable without any need
          * for the client to initialize this context.
          *
-         * @returns a pointer to the Default SSLContext instance.
+         * @return a pointer to the Default SSLContext instance.
          */
         static SSLContext* getDefault();
 
@@ -77,7 +77,7 @@ namespace ssl {
          * Returns an SocketFactory instance for use with this Context, the SocketFactory is owned
          * by the Context and should not be deleted by the caller.
          *
-         * @returns a pointer to this SSLContext's SocketFactory for creating SSLSocket objects.
+         * @return a pointer to this SSLContext's SocketFactory for creating SSLSocket objects.
          *
          * @throws IllegalStateException if the SSLContextSpi requires initialization but it
          *         has not yet been initialized.
@@ -88,7 +88,7 @@ namespace ssl {
          * Returns an ServerSocketFactory instance for use with this Context, the ServerSocketFactory
          * is owned by the Context and should not be deleted by the caller.
          *
-         * @returns a pointer to this SSLContext's ServerSocketFactory for creating SSLServerSocket objects.
+         * @return a pointer to this SSLContext's ServerSocketFactory for creating SSLServerSocket objects.
          *
          * @throws IllegalStateException if the SSLContextSpi requires initialization but it
          *         has not yet been initialized.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ssl/SSLContextSpi.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ssl/SSLContextSpi.h b/activemq-cpp/src/main/decaf/net/ssl/SSLContextSpi.h
index 9610fac..3a14079 100644
--- a/activemq-cpp/src/main/decaf/net/ssl/SSLContextSpi.h
+++ b/activemq-cpp/src/main/decaf/net/ssl/SSLContextSpi.h
@@ -60,7 +60,7 @@ namespace ssl {
          * The returned SSLParameters instance is requires to have non-empty values in its ciphersuites
          * and protocols.
          *
-         * @returns new SSLParameters instance with the SSLContext defaults.
+         * @return new SSLParameters instance with the SSLContext defaults.
          *
          * @throws UnsupportedOperationException if the defaults cannot be obtained.
          */
@@ -73,7 +73,7 @@ namespace ssl {
          * The returned SSLParameters instance is requires to have non-empty values in its ciphersuites
          * and protocols.
          *
-         * @returns a new SSLParameters instance with the full set of settings that are supported.
+         * @return a new SSLParameters instance with the full set of settings that are supported.
          *
          * @throws UnsupportedOperationException if the supported parameters cannot be obtained.
          */
@@ -84,7 +84,7 @@ namespace ssl {
          *
          * The SocketFactory is owned by the Service Provider and should not be destroyed by the caller.
          *
-         * @returns SocketFactory instance that can be used to create new SSLSockets.
+         * @return SocketFactory instance that can be used to create new SSLSockets.
          *
          * @throws IllegalStateException if the SSLContextSpi object requires initialization but
          *         has not been initialized yet.
@@ -96,7 +96,7 @@ namespace ssl {
          *
          * The ServerSocketFactory is owned by the Service Provider and should not be destroyed by the caller.
          *
-         * @returns SocketFactory instance that can be used to create new SSLServerSockets.
+         * @return SocketFactory instance that can be used to create new SSLServerSockets.
          *
          * @throws IllegalStateException if the SSLContextSpi object requires initialization but
          *         has not been initialized yet.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ssl/SSLParameters.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ssl/SSLParameters.h b/activemq-cpp/src/main/decaf/net/ssl/SSLParameters.h
index 304e71f..64f636a 100644
--- a/activemq-cpp/src/main/decaf/net/ssl/SSLParameters.h
+++ b/activemq-cpp/src/main/decaf/net/ssl/SSLParameters.h
@@ -67,7 +67,7 @@ namespace ssl {
         virtual ~SSLParameters();
 
         /**
-         * @returns a copy of the vector of ciphersuites or an empty vector if none have been set.
+         * @return a copy of the vector of ciphersuites or an empty vector if none have been set.
          */
         std::vector<std::string> getCipherSuites() const {
             return this->cipherSuites;
@@ -84,7 +84,7 @@ namespace ssl {
         }
 
         /**
-         * @returns a copy of the vector of protocols or an empty vector if none have been set.
+         * @return a copy of the vector of protocols or an empty vector if none have been set.
          */
         std::vector<std::string> getProtocols() const {
             return this->protocols;
@@ -101,7 +101,7 @@ namespace ssl {
         }
 
         /**
-         * @returns whether client authentication should be requested.
+         * @return whether client authentication should be requested.
          */
         bool getWantClientAuth() const {
             return this->wantClientAuth;
@@ -119,7 +119,7 @@ namespace ssl {
         }
 
         /**
-         * @returns whether client authentication should be required.
+         * @return whether client authentication should be required.
          */
         bool getNeedClientAuth() const {
             return this->needClientAuth;
@@ -154,7 +154,7 @@ namespace ssl {
          * of the list so that it cannot be modified.  If updates are needed a new list
          * must be set via {#setServerNames}.
          *
-         * @returns a list of server names if any were previously configured.
+         * @return a list of server names if any were previously configured.
          */
         std::vector<std::string> getServerNames() const {
             return this->serverNames;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocket.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocket.h b/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocket.h
index e77aa56..e7d20c9 100644
--- a/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocket.h
+++ b/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocket.h
@@ -112,7 +112,7 @@ namespace ssl {
          * Gets a vector containing the names of all the cipher suites that are supported by this
          * SSLServerSocket.  Normally not all of these cipher suites will be enabled on the Socket.
          *
-         * @returns a vector containing the names of all the supported cipher suites.
+         * @return a vector containing the names of all the supported cipher suites.
          */
         virtual std::vector<std::string> getSupportedCipherSuites() const = 0;
 
@@ -120,7 +120,7 @@ namespace ssl {
          * Gets a vector containing the names of all the protocols that could be enabled for
          * this SSLServerSocket instance.
          *
-         * @returns a vector containing the names of all the supported protocols.
+         * @return a vector containing the names of all the supported protocols.
          */
         virtual std::vector<std::string> getSupportedProtocols() const = 0;
 
@@ -165,7 +165,7 @@ namespace ssl {
         virtual void setEnabledProtocols( const std::vector<std::string>& protocols ) = 0;
 
         /**
-         * @returns true if the Socket request client Authentication.
+         * @return true if the Socket request client Authentication.
          */
         virtual bool getWantClientAuth() const = 0;
 
@@ -180,7 +180,7 @@ namespace ssl {
         virtual void setWantClientAuth( bool value ) = 0;
 
         /**
-         * @returns true if the Socket requires client Authentication.
+         * @return true if the Socket requires client Authentication.
          */
         virtual bool getNeedClientAuth() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocketFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocketFactory.h b/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocketFactory.h
index 6bd9d8b..b911fba 100644
--- a/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocketFactory.h
+++ b/activemq-cpp/src/main/decaf/net/ssl/SSLServerSocketFactory.h
@@ -54,7 +54,7 @@ namespace ssl {
          * This method returns SSLContext::getDefault()->getServerSocketFactory(). If that call fails,
          * a non-functional factory is returned.
          *
-         * @returns the default SSL ServerSocketFactory pointer.
+         * @return the default SSL ServerSocketFactory pointer.
          *
          * @see decaf::net::ssl::SSLContext::getDefault()
          */
@@ -66,7 +66,7 @@ namespace ssl {
          * minimum quality of service for these defaults requires confidentiality protection and
          * server authentication (that is, no anonymous cipher suites).
          *
-         * @returns an STL vector containing the list of cipher suites enabled by default.
+         * @return an STL vector containing the list of cipher suites enabled by default.
          *
          * @see getSupportedCipherSuites()
          */
@@ -78,7 +78,7 @@ namespace ssl {
          * include cipher suites which do not meet quality of service requirements for those defaults.
          * Such cipher suites are useful in specialized applications.
          *
-         * @returns an STL vector containing the list of supported cipher suites.
+         * @return an STL vector containing the list of supported cipher suites.
          *
          * @see getDefaultCipherSuites()
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ssl/SSLSocket.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ssl/SSLSocket.h b/activemq-cpp/src/main/decaf/net/ssl/SSLSocket.h
index 9e715d5..e649f30 100644
--- a/activemq-cpp/src/main/decaf/net/ssl/SSLSocket.h
+++ b/activemq-cpp/src/main/decaf/net/ssl/SSLSocket.h
@@ -117,7 +117,7 @@ namespace ssl {
          * Gets a vector containing the names of all the cipher suites that are supported by this
          * SSLSocket.  Normally not all of these cipher suites will be enabled on the Socket.
          *
-         * @returns a vector containing the names of all the supported cipher suites.
+         * @return a vector containing the names of all the supported cipher suites.
          */
         virtual std::vector<std::string> getSupportedCipherSuites() const = 0;
 
@@ -125,7 +125,7 @@ namespace ssl {
          * Gets a vector containing the names of all the protocols that could be enabled for
          * this SSLSocket instance.
          *
-         * @returns a vector containing the names of all the supported protocols.
+         * @return a vector containing the names of all the supported protocols.
          */
         virtual std::vector<std::string> getSupportedProtocols() const = 0;
 
@@ -175,7 +175,7 @@ namespace ssl {
          * The cipherSuites and protocols vectors in the returned SSLParameters reference will
          * never be empty.
          *
-         * @returns an SSLParameters object with the settings in use for the SSLSocket.
+         * @return an SSLParameters object with the settings in use for the SSLSocket.
          */
         virtual SSLParameters getSSLParameters() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ssl/SSLSocketFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ssl/SSLSocketFactory.h b/activemq-cpp/src/main/decaf/net/ssl/SSLSocketFactory.h
index c9a741b..b12a856 100644
--- a/activemq-cpp/src/main/decaf/net/ssl/SSLSocketFactory.h
+++ b/activemq-cpp/src/main/decaf/net/ssl/SSLSocketFactory.h
@@ -54,7 +54,7 @@ namespace ssl {
          * This method returns SSLContext::getDefault()->getSocketFactory(). If that call fails,
          * a non-functional factory is returned.
          *
-         * @returns the default SSL SocketFactory pointer.
+         * @return the default SSL SocketFactory pointer.
          *
          * @see decaf::net::ssl::SSLContext::getDefault()
          */
@@ -66,7 +66,7 @@ namespace ssl {
          * minimum quality of service for these defaults requires confidentiality protection and
          * server authentication (that is, no anonymous cipher suites).
          *
-         * @returns an STL vector containing the list of cipher suites enabled by default.
+         * @return an STL vector containing the list of cipher suites enabled by default.
          *
          * @see getSupportedCipherSuites()
          */
@@ -78,7 +78,7 @@ namespace ssl {
          * include cipher suites which do not meet quality of service requirements for those defaults.
          * Such cipher suites are useful in specialized applications.
          *
-         * @returns an STL vector containing the list of supported cipher suites.
+         * @return an STL vector containing the list of supported cipher suites.
          *
          * @see getDefaultCipherSuites()
          */
@@ -99,7 +99,7 @@ namespace ssl {
          * @param autoClose
          *      Should the layered over Socket be closed when the topmost socket is closed.
          *
-         * @returns a new Socket instance that wraps the given Socket.
+         * @return a new Socket instance that wraps the given Socket.
          *
          * @throws IOException if an I/O exception occurs while performing this operation.
          * @throws UnknownHostException if the host is unknown.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/Buffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/Buffer.h b/activemq-cpp/src/main/decaf/nio/Buffer.h
index 4c5df4f..e7d4bed 100644
--- a/activemq-cpp/src/main/decaf/nio/Buffer.h
+++ b/activemq-cpp/src/main/decaf/nio/Buffer.h
@@ -140,14 +140,14 @@ namespace nio {
     public:
 
         /**
-         * @returns this buffer's capacity.
+         * @return this buffer's capacity.
          */
         virtual int capacity() const {
             return this->_capacity;
         }
 
         /**
-         * @returns the current position in the buffer
+         * @return the current position in the buffer
          */
         virtual int position() const {
             return this->_position;
@@ -160,14 +160,14 @@ namespace nio {
          * @param newPosition
          *      The new postion in the buffer to set.
          *
-         * @returns a reference to This buffer.
+         * @return a reference to This buffer.
          *
          * @throws IllegalArgumentException if preconditions on the new pos don't hold.
          */
         virtual Buffer& position(int newPosition);
 
         /**
-         * @returns this buffers Limit
+         * @return this buffers Limit
          */
         virtual int limit() const {
             return this->_limit;
@@ -181,7 +181,7 @@ namespace nio {
          * @param newLimit
          *      The new limit value; must be no larger than this buffer's capacity.
          *
-         * @returns A reference to This buffer
+         * @return A reference to This buffer
          *
          * @throws IllegalArgumentException if preconditions on the new pos don't hold.
          */
@@ -190,14 +190,14 @@ namespace nio {
         /**
          * Sets this buffer's mark at its position.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          */
         virtual Buffer& mark();
 
         /**
          * Resets this buffer's position to the previously-marked position.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws InvalidMarkException - If the mark has not been set
          */
@@ -217,7 +217,7 @@ namespace nio {
          * as if it did because it will most often be used in situations in which that
          * might as well be the case.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          */
         virtual Buffer& clear();
 
@@ -237,7 +237,7 @@ namespace nio {
          * This method is often used in conjunction with the compact method when
          * transferring data from one place to another.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          */
         virtual Buffer& flip();
 
@@ -251,14 +251,14 @@ namespace nio {
          *    buf.rewind();      // Rewind buffer
          *    buf.get(array);    // Copy data into array
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          */
         virtual Buffer& rewind();
 
         /**
          * Returns the number of elements between the current position and the limit.
          *
-         * @returns The number of elements remaining in this buffer
+         * @return The number of elements remaining in this buffer
          */
         virtual int remaining() const {
             return _limit - _position;
@@ -267,7 +267,7 @@ namespace nio {
         /**
          * Tells whether there are any elements between the current position and the limit.
          *
-         * @returns true if, and only if, there is at least one element remaining in
+         * @return true if, and only if, there is at least one element remaining in
          *          this buffer.
          */
         virtual bool hasRemaining() const {
@@ -277,7 +277,7 @@ namespace nio {
         /**
          * Tells whether or not this buffer is read-only.
          *
-         * @returns true if, and only if, this buffer is read-only.
+         * @return true if, and only if, this buffer is read-only.
          */
         virtual bool isReadOnly() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/ByteBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/ByteBuffer.h b/activemq-cpp/src/main/decaf/nio/ByteBuffer.h
index 82c5d70..4685f2e 100644
--- a/activemq-cpp/src/main/decaf/nio/ByteBuffer.h
+++ b/activemq-cpp/src/main/decaf/nio/ByteBuffer.h
@@ -115,7 +115,7 @@ namespace nio{
         virtual ~ByteBuffer() {}
 
         /**
-         * @returns a std::string describing this object
+         * @return a std::string describing this object
          */
         virtual std::string toString() const;
 
@@ -128,7 +128,7 @@ namespace nio{
          * amount of data that is to be read, that is to say, the caller should call
          * buffer.resize( N ) before calling this get method.
          *
-         * @returns a reference to this Byte Buffer.
+         * @return a reference to this Byte Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length bytes remaining
          *         in this buffer
@@ -156,7 +156,7 @@ namespace nio{
          * @param length
          *      The amount of data to put in the passed buffer.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws IndexOutOfBoundsException if the preconditions of size, offset, or length
          *         are not met.
@@ -179,7 +179,7 @@ namespace nio{
          * @param src
          *      The buffer to take bytes from an place in this one.
          *
-         * @returns a reference to this buffer
+         * @return a reference to this buffer
          *
          * @throws BufferOverflowException if there is insufficient space in this
          *         buffer for the remaining bytes in the source buffer
@@ -207,7 +207,7 @@ namespace nio{
          * @param length
          *      The number of bytes to be read from the given array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -224,7 +224,7 @@ namespace nio{
          * @param buffer
          *      The buffer whose contents are copied to this ByteBuffer.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -236,7 +236,7 @@ namespace nio{
         /**
          * Tells whether or not this buffer is read-only.
          *
-         * @returns true if, and only if, this buffer is read-only
+         * @return true if, and only if, this buffer is read-only
          */
         virtual bool isReadOnly() const = 0;
 
@@ -249,7 +249,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure
          * that this buffer has an accessible backing array.
          *
-         * @returns The array that backs this buffer
+         * @return The array that backs this buffer
          *
          * @throws ReadOnlyBufferException if this buffer is backed by an array but
          *         is read-only
@@ -268,7 +268,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure
          * that this buffer has an accessible backing array.
          *
-         * @returns The offset within this buffer's array of the first element of
+         * @return The offset within this buffer's array of the first element of
          *          the buffer.
          *
          * @throws ReadOnlyBufferException if this buffer is backed by an array but
@@ -284,7 +284,7 @@ namespace nio{
          * be invoked.  Subclasses should override this method if they do not have a
          * backing array as this class always returns true.
          *
-         * @returns true if, and only if, this buffer is backed by an array and is not
+         * @return true if, and only if, this buffer is backed by an array and is not
          *          read-only.
          */
         virtual bool hasArray() const = 0;
@@ -300,7 +300,7 @@ namespace nio{
          * the number of bytes remaining in this buffer, and its mark will be undefined.
          * The new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the new Char Buffer, which the caller then owns.
+         * @return the new Char Buffer, which the caller then owns.
          */
         virtual CharBuffer* asCharBuffer() const = 0;
 
@@ -316,7 +316,7 @@ namespace nio{
          * will be undefined. The new buffer will be read-only if, and only if, this
          * buffer is read-only.
          *
-         * @returns the new double Buffer, which the caller then owns.
+         * @return the new double Buffer, which the caller then owns.
          */
         virtual DoubleBuffer* asDoubleBuffer() const = 0;
 
@@ -332,7 +332,7 @@ namespace nio{
          * will be undefined. The new buffer will be read-only if, and only if, this
          * buffer is read-only.
          *
-         * @returns the new float Buffer, which the caller then owns.
+         * @return the new float Buffer, which the caller then owns.
          */
         virtual FloatBuffer* asFloatBuffer() const = 0;
 
@@ -348,7 +348,7 @@ namespace nio{
          * will be undefined. The new buffer will be read-only if, and only if, this
          * buffer is read-only.
          *
-         * @returns the new int Buffer, which the caller then owns.
+         * @return the new int Buffer, which the caller then owns.
          */
         virtual IntBuffer* asIntBuffer() const = 0;
 
@@ -364,7 +364,7 @@ namespace nio{
          * will be undefined. The new buffer will be read-only if, and only if, this
          * buffer is read-only.
          *
-         * @returns the new long Buffer, which the caller then owns.
+         * @return the new long Buffer, which the caller then owns.
          */
         virtual LongBuffer* asLongBuffer() const = 0;
 
@@ -380,7 +380,7 @@ namespace nio{
          * will be undefined. The new buffer will be read-only if, and only if, this
          * buffer is read-only.
          *
-         * @returns the new short Buffer, which the caller then owns.
+         * @return the new short Buffer, which the caller then owns.
          */
         virtual ShortBuffer* asShortBuffer() const = 0;
 
@@ -417,7 +417,7 @@ namespace nio{
          * zero, so that an invocation of this method can be followed immediately by
          * an invocation of another relative put method.
          *
-         * @returns a reference to this ByteBuffer.
+         * @return a reference to this ByteBuffer.
          *
          * @throws ReadOnlyBufferException if this buffer is read-only.
          */
@@ -434,7 +434,7 @@ namespace nio{
          * to those of this buffer. The new buffer will be read-only if, and only if,
          * this buffer is read-only.
          *
-         * @returns a new Byte Buffer which the caller owns.
+         * @return a new Byte Buffer which the caller owns.
          */
         virtual ByteBuffer* duplicate() = 0;
 
@@ -442,7 +442,7 @@ namespace nio{
          * Relative get method. Reads the byte at this buffer's current position, and
          * then increments the position.
          *
-         * @returns The byte at the buffer's current position.
+         * @return The byte at the buffer's current position.
          *
          * @throws BufferUnderflowException if the buffer's current position is not
          *         smaller than its limit.
@@ -455,7 +455,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the byte is to be read.
          *
-         * @returns the byte that is located at the given index.
+         * @return the byte that is located at the given index.
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit, or index is negative.
@@ -466,7 +466,7 @@ namespace nio{
          * Reads the next byte at this buffer's current position, and then increments
          * the position by one
          *
-         * @returns the next char in the buffer.
+         * @return the next char in the buffer.
          *
          * @throws BufferUnderflowException if there are no more bytes remaining in
          *         this buffer, meaning we have reached the set limit.
@@ -479,7 +479,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the byte is to be read.
          *
-         * @returns the char at the given index in the buffer
+         * @return the char at the given index in the buffer
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit, or index is negative.
@@ -490,7 +490,7 @@ namespace nio{
          * Reads the next eight bytes at this buffer's current position, and then
          * increments the position by that amount.
          *
-         * @returns the next double in the buffer.
+         * @return the next double in the buffer.
          *
          * @throws BufferUnderflowException if there are no more bytes remaining in
          *         this buffer, meaning we have reached the set limit.
@@ -503,7 +503,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the double at the given index in the buffer.
+         * @return the double at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit, or index is negative.
@@ -514,7 +514,7 @@ namespace nio{
          * Reads the next four bytes at this buffer's current position, and then
          * increments the position by that amount.
          *
-         * @returns the next float in the buffer.
+         * @return the next float in the buffer.
          *
          * @throws BufferUnderflowException if there are no more bytes remaining in
          *         this buffer, meaning we have reached the set limit.
@@ -527,7 +527,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the float at the given index in the buffer.
+         * @return the float at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes
          *         remaining to fill the requested Data Type, or index is negative.
@@ -538,7 +538,7 @@ namespace nio{
          * Reads the next eight bytes at this buffer's current position, and then
          * increments the position by that amount.
          *
-         * @returns the next long long in the buffer.
+         * @return the next long long in the buffer.
          *
          * @throws BufferUnderflowException if there are no more bytes remaining in
          *         this buffer, meaning we have reached the set limit.
@@ -551,7 +551,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the long long at the given index in the buffer.
+         * @return the long long at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes
          *         remaining to fill the requested Data Type, or index is negative.
@@ -562,7 +562,7 @@ namespace nio{
          * Reads the next four bytes at this buffer's current position, and then
          * increments the position by that amount.
          *
-         * @returns the next int in the buffer.
+         * @return the next int in the buffer.
          *
          * @throws BufferUnderflowException if there are no more bytes remaining in
          *         this buffer, meaning we have reached the set limit.
@@ -575,7 +575,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the int at the given index in the buffer.
+         * @return the int at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes
          *         remaining to fill the requested Data Type, or index is negative.
@@ -586,7 +586,7 @@ namespace nio{
          * Reads the next two bytes at this buffer's current position, and then
          * increments the position by that amount.
          *
-         * @returns the next short in the buffer.
+         * @return the next short in the buffer.
          *
          * @throws BufferUnderflowException if there are no more bytes remaining in
          *         this buffer, meaning we have reached the set limit.
@@ -599,7 +599,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the bytes are to be read.
          *
-         * @returns the short at the given index in the buffer.
+         * @return the short at the given index in the buffer.
          *
          * @throws IndexOutOfBoundsException if there are not enough bytes
          *         remaining to fill the requested Data Type, or index is negative.
@@ -612,7 +612,7 @@ namespace nio{
          *
          * @param value - the byte value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          *         smaller than its limit.
@@ -626,7 +626,7 @@ namespace nio{
          * @param index - position in the Buffer to write the data
          * @param value - the byte to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -641,7 +641,7 @@ namespace nio{
          * @param value
          *      The value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw BufferOverflowException if there are fewer than bytes remaining
          *        in this buffer than the size of the data to be written
@@ -658,7 +658,7 @@ namespace nio{
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -673,7 +673,7 @@ namespace nio{
          * @param value
          *      The value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw BufferOverflowException if there are fewer than bytes remaining
          *        in this buffer than the size of the data to be written
@@ -690,7 +690,7 @@ namespace nio{
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -705,7 +705,7 @@ namespace nio{
          * @param value
          *      The value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw BufferOverflowException if there are fewer than bytes remaining
          *        in this buffer than the size of the data to be written.
@@ -722,7 +722,7 @@ namespace nio{
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -737,7 +737,7 @@ namespace nio{
          * @param value
          *      The value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw BufferOverflowException if there are fewer than bytes remaining
          *        in this buffer than the size of the data to be written.
@@ -754,7 +754,7 @@ namespace nio{
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -769,7 +769,7 @@ namespace nio{
          * @param value
          *      The value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw BufferOverflowException if there are fewer than bytes remaining
          *        in this buffer than the size of the data to be written
@@ -786,7 +786,7 @@ namespace nio{
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer
+         * @return a reference to this buffer
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -801,7 +801,7 @@ namespace nio{
          * @param value
          *      The value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throw BufferOverflowException if there are fewer than bytes remaining
          *        in this buffer than the size of the data to be written.
@@ -818,7 +818,7 @@ namespace nio{
          * @param value
          *      The value to write.
          *
-         * @returns a reference to this buffer
+         * @return a reference to this buffer
          *
          * @throw IndexOutOfBoundsException if index greater than the buffer's limit
          *        minus the size of the type being written, or index is negative.
@@ -837,7 +837,7 @@ namespace nio{
          * number of bytes remaining in this buffer, and its mark will be undefined. The
          * new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the newly create ByteBuffer which the caller owns.
+         * @return the newly create ByteBuffer which the caller owns.
          */
         virtual ByteBuffer* slice() const = 0;
 
@@ -873,7 +873,7 @@ namespace nio{
          * @param capacity
          *      The internal buffer's capacity.
          *
-         * @returns a newly allocated ByteBuffer which the caller owns.
+         * @return a newly allocated ByteBuffer which the caller owns.
          *
          * @throws IllegalArgumentException if capacity is negative.
          */
@@ -897,7 +897,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new ByteBuffer that is backed by buffer, caller owns.
+         * @return a new ByteBuffer that is backed by buffer, caller owns.
          *
          * @throws NullPointerException if the array passed in is NULL.
          * @throws IndexOutOfBoundsException if the preconditions of size, offset, or length
@@ -918,7 +918,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must
          *      have been sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new ByteBuffer that is backed by buffer, caller owns.
+         * @return a new ByteBuffer that is backed by buffer, caller owns.
          */
         static ByteBuffer* wrap(std::vector<unsigned char>& buffer);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/CharBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/CharBuffer.h b/activemq-cpp/src/main/decaf/nio/CharBuffer.h
index 3f20bf8..a5bec6f 100644
--- a/activemq-cpp/src/main/decaf/nio/CharBuffer.h
+++ b/activemq-cpp/src/main/decaf/nio/CharBuffer.h
@@ -85,7 +85,7 @@ namespace nio{
         virtual ~CharBuffer() {}
 
         /**
-         * @returns a std::string describing this object
+         * @return a std::string describing this object
          */
         virtual std::string toString() const;
 
@@ -95,7 +95,7 @@ namespace nio{
          * @param value
          *      The char to append.
          *
-         * @returns a reference to this modified CharBuffer.
+         * @return a reference to this modified CharBuffer.
          *
          * @throws BufferOverflowException if there is no more space
          * @throws ReadOnlyBufferException if this Buffer is read only.
@@ -109,7 +109,7 @@ namespace nio{
          * @param value
          *      The CharSequence to append.
          *
-         * @returns a reference to this modified CharBuffer
+         * @return a reference to this modified CharBuffer
          *
          * @throws BufferOverflowException if there is no more space
          * @throws ReadOnlyBufferException if this Buffer is read only.
@@ -127,7 +127,7 @@ namespace nio{
          * @param end
          *      The index to append to.
          *
-         * @returns a reference to this modified CharBuffer.
+         * @return a reference to this modified CharBuffer.
          *
          * @throws BufferOverflowException if there is no more space
          * @throws ReadOnlyBufferException if this Buffer is read only.
@@ -144,7 +144,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns the array that backs this Buffer.
+         * @return the array that backs this Buffer.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -158,7 +158,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns The offset into the backing array where index zero starts.
+         * @return The offset into the backing array where index zero starts.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -189,7 +189,7 @@ namespace nio{
          *
          * @param index - The index of the character to be read relative to position
          *
-         * @returns The character at index position() + index.
+         * @return The character at index position() + index.
          *
          * @throws IndexOutOfBoundsException if the index + the current position exceeds the
          *         size of the buffer or the index is negative.
@@ -210,7 +210,7 @@ namespace nio{
          * zero, so that an invocation of this method can be followed immediately by
          * an invocation of another relative put method.
          *
-         * @returns a reference to this CharBuffer.
+         * @return a reference to this CharBuffer.
          *
          * @throws ReadOnlyBufferException - If this buffer is read-only
          */
@@ -227,7 +227,7 @@ namespace nio{
          * to those of this buffer. The new buffer will be read-only if, and only if,
          * this buffer is read-only.
          *
-         * @returns a new char Buffer which the caller owns.
+         * @return a new char Buffer which the caller owns.
          */
         virtual CharBuffer* duplicate() = 0;
 
@@ -235,7 +235,7 @@ namespace nio{
          * Relative get method. Reads the character at this buffer's current position,
          * and then increments the position.
          *
-         * @returns the char at the current position.
+         * @return the char at the current position.
          *
          * @throws BufferUnderflowException if there no more data to return
          */
@@ -247,7 +247,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the char is to be read.
          *
-         * @returns the char that is located at the given index.
+         * @return the char that is located at the given index.
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit or is negative.
@@ -263,7 +263,7 @@ namespace nio{
          * amount of data that is to be read, that is to say, the caller should call
          * buffer.resize( N ) before calling this get method.
          *
-         * @returns a reference to this CharBuffer.
+         * @return a reference to this CharBuffer.
          *
          * @throws BufferUnderflowException if there are fewer than length chars
          *         remaining in this buffer.
@@ -291,7 +291,7 @@ namespace nio{
          * @param length
          *      The amount of data to put in the passed buffer.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length chars
          *         remaining in this buffer
@@ -307,7 +307,7 @@ namespace nio{
          * be invoked.  Subclasses should override this method if they do not have a
          * backing array as this class always returns true.
          *
-         * @returns true if, and only if, this buffer is backed by an array and is not
+         * @return true if, and only if, this buffer is backed by an array and is not
          *          read-only
          */
         virtual bool hasArray() const = 0;
@@ -315,7 +315,7 @@ namespace nio{
         /**
          * Returns the length of this character buffer.
          *
-         * @returns the length of this buffer from the position to the limit.
+         * @return the length of this buffer from the position to the limit.
          */
         int length() const {
             return this->remaining();
@@ -333,7 +333,7 @@ namespace nio{
          *
          * @param src - the buffer to take chars from an place in this one.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer
          *         for the remaining chars in the source buffer.
@@ -361,7 +361,7 @@ namespace nio{
          * @param length
          *      The number of chars to be read from the given array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer
          * @throws ReadOnlyBufferException if this buffer is read-only
@@ -378,7 +378,7 @@ namespace nio{
          * @param buffer
          *      The buffer whose contents are copied to this CharBuffer.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -392,7 +392,7 @@ namespace nio{
          * @param value
          *      The char value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          *         smaller than its limit
@@ -408,7 +408,7 @@ namespace nio{
          * @param value
          *      The char to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws IndexOutOfBoundsException if index greater than the buffer's limit
          *         minus the size of the type being written, or index is negative.
@@ -423,7 +423,7 @@ namespace nio{
          * there are more characters to be copied from the string than remain in this
          * buffer, that is, if end - start > remaining(), then no characters are
          * transferred and a BufferOverflowException is thrown.
-         * @returns a reference to this buffer
+         * @return a reference to this buffer
          *
          * Otherwise, this method copies n = end - start characters from the given string
          * into this buffer, starting at the given start index and at the current position
@@ -436,7 +436,7 @@ namespace nio{
          * @param end
          *      The position in src to stop at.
          *
-         * @returns a reference to this CharBuffer.
+         * @return a reference to this CharBuffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          * @throws IndexOutOfBoundsException if index greater than the buffer's limit
@@ -455,7 +455,7 @@ namespace nio{
          * @param src
          *      The string to copy from.
          *
-         * @returns a reference to this CharBuffer.
+         * @return a reference to this CharBuffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -470,7 +470,7 @@ namespace nio{
          * @param target
          *      The buffer to read characters into
          *
-         * @returns The number of characters added to the buffer, or string::npos if this
+         * @return The number of characters added to the buffer, or string::npos if this
          *          source of characters is at its end
          *
          * @throws NullPointerException if target is Null.
@@ -514,7 +514,7 @@ namespace nio{
          * number of bytes remaining in this buffer, and its mark will be undefined. The
          * new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the newly create CharBuffer which the caller owns.
+         * @return the newly create CharBuffer which the caller owns.
          */
         virtual CharBuffer* slice() const = 0;
 
@@ -552,7 +552,7 @@ namespace nio{
          * @param capacity
          *      The size of the Char buffer in chars ( 1 byte ).
          *
-         * @returns the CharBuffer that was allocated, caller owns.
+         * @return the CharBuffer that was allocated, caller owns.
          *
          * @throws IndexOutOfBoundsException if capacity is negative.
          */
@@ -576,7 +576,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new CharBuffer that is backed by buffer, caller owns.
+         * @return a new CharBuffer that is backed by buffer, caller owns.
          *
          * @throws NullPointerException if the array pointer is Null.
          * @throws IndexOutOfBoundsException if capacity is negative.
@@ -596,7 +596,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new CharBuffer that is backed by buffer, caller owns.
+         * @return a new CharBuffer that is backed by buffer, caller owns.
          */
         static CharBuffer* wrap( std::vector<char>& buffer );
 
@@ -616,7 +616,7 @@ namespace nio{
          *      The index of the character following the last character to be used; must be
          *      no smaller than start and no larger than the size of the sequence.
          *
-         * @returns a ReadOnly CharBuffer, caller owns the returned pointer.
+         * @return a ReadOnly CharBuffer, caller owns the returned pointer.
          *
          * @throws NullPointerException if csq is null.
          * @throws IndexOutOfBoundsException if the preconditions on start and end fail
@@ -635,7 +635,7 @@ namespace nio{
          *      The character sequence from which the new character buffer is to
          *      be created, cannot be null.
          *
-         * @returns the newly created CharBuffer, caller owns.
+         * @return the newly created CharBuffer, caller owns.
          *
          * @throws NullPointerException if csq is null.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/DoubleBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/DoubleBuffer.h b/activemq-cpp/src/main/decaf/nio/DoubleBuffer.h
index aeccad0..95d18c6 100644
--- a/activemq-cpp/src/main/decaf/nio/DoubleBuffer.h
+++ b/activemq-cpp/src/main/decaf/nio/DoubleBuffer.h
@@ -70,7 +70,7 @@ namespace nio{
         virtual ~DoubleBuffer() {}
 
         /**
-         * @returns a std::string describing this object
+         * @return a std::string describing this object
          */
         virtual std::string toString() const;
 
@@ -83,7 +83,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns the array that backs this Buffer.
+         * @return the array that backs this Buffer.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -97,7 +97,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns The offset into the backing array where index zero starts.
+         * @return The offset into the backing array where index zero starts.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -137,7 +137,7 @@ namespace nio{
          * zero, so that an invocation of this method can be followed immediately by
          * an invocation of another relative put method.
          *
-         * @returns a reference to this DoubleBuffer.
+         * @return a reference to this DoubleBuffer.
          *
          * @throws ReadOnlyBufferException if this buffer is read-only.
          */
@@ -154,7 +154,7 @@ namespace nio{
          * to those of this buffer. The new buffer will be read-only if, and only if,
          * this buffer is read-only.
          *
-         * @returns a new double Buffer which the caller owns.
+         * @return a new double Buffer which the caller owns.
          */
         virtual DoubleBuffer* duplicate() = 0;
 
@@ -162,7 +162,7 @@ namespace nio{
          * Relative get method. Reads the value at this buffer's current position,
          * and then increments the position.
          *
-         * @returns the double at the current position.
+         * @return the double at the current position.
          *
          * @throws BufferUnderflowException if there no more data to return.
          */
@@ -174,7 +174,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the double is to be read.
          *
-         * @returns the double that is located at the given index.
+         * @return the double that is located at the given index.
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit
@@ -190,7 +190,7 @@ namespace nio{
          * amount of data that is to be read, that is to say, the caller should call
          * buffer.resize( N ) before calling this get method.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException iIf there are fewer than length doubles
          *         remaining in this buffer
@@ -218,7 +218,7 @@ namespace nio{
          * @param length
          *      The amount of data to put in the passed buffer.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length doubles
          *         remaining in this buffer
@@ -234,7 +234,7 @@ namespace nio{
          * be invoked.  Subclasses should override this method if they do not have a
          * backing array as this class always returns true.
          *
-         * @returns true if, and only if, this buffer is backed by an array and is not
+         * @return true if, and only if, this buffer is backed by an array and is not
          *          read-only
          */
         virtual bool hasArray() const = 0;
@@ -252,7 +252,7 @@ namespace nio{
          * @param src
          *      The buffer to take doubles from an place in this one.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this
          *         buffer for the remaining doubles in the source buffer
@@ -280,7 +280,7 @@ namespace nio{
          * @param length
          *      The number of doubles to be read from the given array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer
          * @throws ReadOnlyBufferException if this buffer is read-only
@@ -297,7 +297,7 @@ namespace nio{
          * @param buffer
          *      The buffer whose contents are copied to this DoubleBuffer.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -311,7 +311,7 @@ namespace nio{
          * @param value
          *      The doubles value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          *         smaller than its limit.
@@ -327,7 +327,7 @@ namespace nio{
          * @param value
          *      The doubles to write.
          *
-         * @returns a reference to this buffer
+         * @return a reference to this buffer
          *
          * @throws IndexOutOfBoundsException if index greater than the buffer's limit
          *         minus the size of the type being written, or the index is negative.
@@ -346,7 +346,7 @@ namespace nio{
          * number of bytes remaining in this buffer, and its mark will be undefined. The
          * new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the newly create DoubleBuffer which the caller owns.
+         * @return the newly create DoubleBuffer which the caller owns.
          */
         virtual DoubleBuffer* slice() const = 0;
 
@@ -384,7 +384,7 @@ namespace nio{
          * @param capacity
          *      The size of the Double buffer in doubles.
          *
-         * @returns the DoubleBuffer that was allocated, caller owns.
+         * @return the DoubleBuffer that was allocated, caller owns.
          *
          * @throws IllegalArgumentException is the capacity value is negative.
          */
@@ -408,7 +408,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new DoubleBuffer that is backed by buffer, caller owns.
+         * @return a new DoubleBuffer that is backed by buffer, caller owns.
          *
          * @throws NullPointerException if the array pointer is NULL.
          * @throws IndexOutOfBoundsException if the preconditions of size, offset, or length
@@ -429,7 +429,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been sized
          *      to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new DoubleBuffer that is backed by buffer, caller owns.
+         * @return a new DoubleBuffer that is backed by buffer, caller owns.
          */
         static DoubleBuffer* wrap( std::vector<double>& buffer );
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/FloatBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/FloatBuffer.h b/activemq-cpp/src/main/decaf/nio/FloatBuffer.h
index 5cc82a6..754412b 100644
--- a/activemq-cpp/src/main/decaf/nio/FloatBuffer.h
+++ b/activemq-cpp/src/main/decaf/nio/FloatBuffer.h
@@ -68,7 +68,7 @@ namespace nio{
         virtual ~FloatBuffer() {}
 
         /**
-         * @returns a std::string describing this object
+         * @return a std::string describing this object
          */
         virtual std::string toString() const;
 
@@ -81,7 +81,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns the array that backs this Buffer.
+         * @return the array that backs this Buffer.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -95,7 +95,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns The offset into the backing array where index zero starts.
+         * @return The offset into the backing array where index zero starts.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -135,7 +135,7 @@ namespace nio{
          * zero, so that an invocation of this method can be followed immediately by
          * an invocation of another relative put method.
          *
-         * @returns a reference to this FloatBuffer.
+         * @return a reference to this FloatBuffer.
          *
          * @throws ReadOnlyBufferException if this buffer is read-only
          */
@@ -152,7 +152,7 @@ namespace nio{
          * to those of this buffer. The new buffer will be read-only if, and only if,
          * this buffer is read-only.
          *
-         * @returns a new float Buffer which the caller owns.
+         * @return a new float Buffer which the caller owns.
          */
         virtual FloatBuffer* duplicate() = 0;
 
@@ -160,7 +160,7 @@ namespace nio{
          * Relative get method. Reads the value at this buffer's current position,
          * and then increments the position.
          *
-         * @returns the float at the current position.
+         * @return the float at the current position.
          *
          * @throws BufferUnderflowException if there no more data to return.
          */
@@ -172,7 +172,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the float is to be read
          *
-         * @returns the float that is located at the given index
+         * @return the float that is located at the given index
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit
@@ -188,7 +188,7 @@ namespace nio{
          * amount of data that is to be read, that is to say, the caller should call
          * buffer.resize( N ) before calling this get method.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length floats
          *         remaining in this buffer
@@ -216,7 +216,7 @@ namespace nio{
          * @param length
          *      The amount of data to put in the passed buffer.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length floats
          *         remaining in this buffer
@@ -232,7 +232,7 @@ namespace nio{
          * be invoked.  Subclasses should override this method if they do not have a
          * backing array as this class always returns true.
          *
-         * @returns true if, and only if, this buffer is backed by an array and is not
+         * @return true if, and only if, this buffer is backed by an array and is not
          *          read-only
          */
         virtual bool hasArray() const = 0;
@@ -250,7 +250,7 @@ namespace nio{
          * @param src
          *      The buffer to take floats from an place in this one.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this
          *         buffer for the remaining floats in the source buffer
@@ -278,7 +278,7 @@ namespace nio{
          * @param length
          *      The number of floats to be read from the given array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer
          * @throws ReadOnlyBufferException if this buffer is read-only
@@ -295,7 +295,7 @@ namespace nio{
          * @param buffer
          *      The buffer whose contents are copied to this FloatBuffer
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer
          * @throws ReadOnlyBufferException if this buffer is read-only
@@ -309,7 +309,7 @@ namespace nio{
          * @param value
          *      The floats value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          *         smaller than its limit
@@ -325,7 +325,7 @@ namespace nio{
          * @param value
          *      The floats to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws IndexOutOfBoundsException if index greater than the buffer's limit
          *         minus the size of the type being written, or index is negative.
@@ -344,7 +344,7 @@ namespace nio{
          * number of bytes remaining in this buffer, and its mark will be undefined. The
          * new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the newly create FloatBuffer which the caller owns.
+         * @return the newly create FloatBuffer which the caller owns.
          */
         virtual FloatBuffer* slice() const = 0;
 
@@ -382,7 +382,7 @@ namespace nio{
          * @param capacity
          *      The size of the Double buffer in floats.
          *
-         * @returns the FloatBuffer that was allocated, caller owns.
+         * @return the FloatBuffer that was allocated, caller owns.
          */
         static FloatBuffer* allocate( int capacity );
 
@@ -404,7 +404,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new FloatBuffer that is backed by buffer, caller owns.
+         * @return a new FloatBuffer that is backed by buffer, caller owns.
          *
          * @throws NullPointerException if the array pointer is NULL.
          * @throws IndexOutOfBoundsException if the preconditions of size, offset, or length
@@ -422,7 +422,7 @@ namespace nio{
          * array offset will be zero.
          * @param buffer - The vector that will back the new buffer, the vector must
          * have been sized to the desired size already by calling vector.resize( N ).
-         * @returns a new FloatBuffer that is backed by buffer, caller owns.
+         * @return a new FloatBuffer that is backed by buffer, caller owns.
          */
         static FloatBuffer* wrap( std::vector<float>& buffer );
 


[9/9] activemq-cpp git commit: Fix some documentation generation issues.

Posted by ta...@apache.org.
Fix some documentation generation issues.

Project: http://git-wip-us.apache.org/repos/asf/activemq-cpp/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq-cpp/commit/cb372c07
Tree: http://git-wip-us.apache.org/repos/asf/activemq-cpp/tree/cb372c07
Diff: http://git-wip-us.apache.org/repos/asf/activemq-cpp/diff/cb372c07

Branch: refs/heads/master
Commit: cb372c077d75899a85caf2cce8681e91256d1807
Parents: e058de2
Author: Timothy Bish <ta...@gmail.com>
Authored: Wed Aug 5 18:47:49 2015 -0400
Committer: Timothy Bish <ta...@gmail.com>
Committed: Wed Aug 5 18:47:49 2015 -0400

----------------------------------------------------------------------
 .../activemq/commands/ActiveMQBlobMessage.h     |   6 +-
 .../activemq/commands/ActiveMQDestination.h     |  12 +--
 .../main/activemq/commands/ActiveMQMapMessage.h |   2 +-
 .../activemq/commands/ActiveMQTempDestination.h |   4 +-
 .../src/main/activemq/commands/BaseCommand.h    |   2 +-
 .../src/main/activemq/commands/BrokerError.h    |  12 +--
 .../src/main/activemq/commands/DataStructure.h  |   4 +-
 .../src/main/activemq/commands/Message.h        |  12 +--
 .../src/main/activemq/commands/WireFormatInfo.h |   4 +-
 .../src/main/activemq/core/ActiveMQConnection.h |  36 +++----
 .../activemq/core/ActiveMQConnectionFactory.h   |  34 +++----
 .../src/main/activemq/core/ActiveMQConsumer.h   |  12 +--
 .../activemq/core/ActiveMQDestinationEvent.h    |   2 +-
 .../main/activemq/core/ActiveMQMessageAudit.h   |   6 +-
 .../src/main/activemq/core/ActiveMQProducer.h   |   4 +-
 .../src/main/activemq/core/ActiveMQSession.h    |   4 +-
 .../activemq/core/ActiveMQSessionExecutor.h     |   2 +-
 .../activemq/core/ActiveMQTransactionContext.h  |   4 +-
 .../src/main/activemq/core/Dispatcher.h         |   2 +-
 .../src/main/activemq/core/PrefetchPolicy.h     |  10 +-
 .../src/main/activemq/core/RedeliveryPolicy.h   |   4 +-
 .../core/kernels/ActiveMQConsumerKernel.h       |  16 +--
 .../core/kernels/ActiveMQProducerKernel.h       |   8 +-
 .../core/kernels/ActiveMQSessionKernel.h        |  18 ++--
 .../main/activemq/exceptions/BrokerException.h  |   2 +-
 .../transport/AbstractTransportFactory.h        |   2 +-
 .../src/main/activemq/transport/Transport.h     |   8 +-
 .../main/activemq/transport/TransportRegistry.h |   4 +-
 .../discovery/AbstractDiscoveryAgent.h          |  18 ++--
 .../discovery/AbstractDiscoveryAgentFactory.h   |   4 +-
 .../transport/discovery/DiscoveredBrokerData.h  |   8 +-
 .../transport/discovery/DiscoveryAgentFactory.h |   2 +-
 .../discovery/DiscoveryAgentRegistry.h          |   4 +-
 .../transport/discovery/DiscoveryTransport.h    |   4 +-
 .../discovery/http/HttpDiscoveryAgent.h         |   4 +-
 .../transport/failover/BackupTransport.h        |   6 +-
 .../transport/failover/BackupTransportPool.h    |   2 +-
 .../transport/failover/FailoverTransport.h      |   2 +-
 .../main/activemq/transport/failover/URIPool.h  |  16 +--
 .../src/main/activemq/util/AdvisorySupport.h    |  60 +++++------
 .../src/main/activemq/util/IdGenerator.h        |   8 +-
 .../main/activemq/util/LongSequenceGenerator.h  |   4 +-
 .../src/main/activemq/util/MarshallingSupport.h |   4 +-
 .../src/main/activemq/util/PrimitiveList.h      |   2 +-
 .../src/main/activemq/util/PrimitiveMap.h       |  24 ++---
 .../src/main/activemq/util/URISupport.h         |   4 +-
 .../src/main/activemq/wireformat/MarshalAware.h |   2 +-
 .../src/main/activemq/wireformat/WireFormat.h   |   8 +-
 .../activemq/wireformat/WireFormatRegistry.h    |   4 +-
 .../wireformat/openwire/OpenWireFormat.h        |   8 +-
 .../openwire/marshal/BaseDataStreamMarshaller.h |  50 +++++-----
 .../openwire/marshal/DataStreamMarshaller.h     |   4 +-
 .../wireformat/openwire/utils/BooleanStream.h   |   4 +-
 .../wireformat/openwire/utils/HexTable.h        |   4 +-
 .../activemq/wireformat/stomp/StompHelper.h     |   2 +-
 .../activemq/wireformat/stomp/StompWireFormat.h |   6 +-
 activemq-cpp/src/main/cms/BytesMessage.h        |  26 ++---
 activemq-cpp/src/main/cms/CMSException.h        |   4 +-
 activemq-cpp/src/main/cms/CMSProperties.h       |   8 +-
 activemq-cpp/src/main/cms/Connection.h          |   4 +-
 activemq-cpp/src/main/cms/ConnectionFactory.h   |   4 +-
 activemq-cpp/src/main/cms/ConnectionMetaData.h  |  16 +--
 activemq-cpp/src/main/cms/Destination.h         |   2 +-
 activemq-cpp/src/main/cms/DestinationEvent.h    |   6 +-
 activemq-cpp/src/main/cms/DestinationSource.h   |  10 +-
 activemq-cpp/src/main/cms/MapMessage.h          |   4 +-
 activemq-cpp/src/main/cms/Message.h             |   2 +-
 activemq-cpp/src/main/cms/MessageConsumer.h     |   2 +-
 activemq-cpp/src/main/cms/MessageProducer.h     |   2 +-
 activemq-cpp/src/main/cms/MessageTransformer.h  |   4 +-
 activemq-cpp/src/main/cms/ObjectMessage.h       |   2 +-
 activemq-cpp/src/main/cms/QueueBrowser.h        |   6 +-
 activemq-cpp/src/main/cms/Session.h             |   2 +-
 activemq-cpp/src/main/cms/StreamMessage.h       |  26 ++---
 activemq-cpp/src/main/cms/XAConnection.h        |   2 +-
 activemq-cpp/src/main/cms/XAConnectionFactory.h |   4 +-
 activemq-cpp/src/main/cms/XAException.h         |   2 +-
 activemq-cpp/src/main/cms/XASession.h           |   2 +-
 activemq-cpp/src/main/cms/Xid.h                 |   4 +-
 activemq-cpp/src/main/decaf/internal/AprPool.h  |   2 +-
 .../src/main/decaf/internal/DecafRuntime.h      |   2 +-
 .../src/main/decaf/internal/net/Network.h       |   2 +-
 .../src/main/decaf/internal/net/URIHelper.h     |   4 +-
 .../src/main/decaf/internal/net/URIType.h       |   6 +-
 .../internal/net/URLStreamHandlerManager.h      |   4 +-
 .../src/main/decaf/internal/net/URLType.h       |   2 +-
 .../src/main/decaf/internal/net/URLUtils.h      |  10 +-
 .../internal/net/ssl/openssl/OpenSSLSocket.h    |   2 +-
 .../net/ssl/openssl/OpenSSLSocketException.h    |   2 +-
 .../src/main/decaf/internal/net/tcp/TcpSocket.h |   4 +-
 .../src/main/decaf/internal/nio/BufferFactory.h |  42 ++++----
 .../src/main/decaf/internal/security/Engine.h   |   4 +-
 .../decaf/internal/security/SecurityRuntime.h   |   4 +-
 .../decaf/internal/security/ServiceRegistry.h   |   2 +-
 .../main/decaf/internal/util/ByteArrayAdapter.h |  62 ++++++------
 .../main/decaf/internal/util/HexStringParser.h  |   8 +-
 .../src/main/decaf/internal/util/StringUtils.h  |   6 +-
 .../main/decaf/internal/util/TimerTaskHeap.h    |   6 +-
 .../internal/util/concurrent/ThreadLocalImpl.h  |   2 +-
 .../decaf/internal/util/concurrent/Threading.h  |  18 ++--
 .../src/main/decaf/io/ByteArrayOutputStream.h   |   2 +-
 activemq-cpp/src/main/decaf/io/DataInput.h      |  24 ++---
 .../src/main/decaf/io/DataInputStream.h         |  24 ++---
 .../src/main/decaf/io/FilterInputStream.h       |   2 +-
 .../src/main/decaf/io/FilterOutputStream.h      |   2 +-
 activemq-cpp/src/main/decaf/io/InputStream.h    |   4 +-
 .../src/main/decaf/lang/AbstractStringBuilder.h |  18 ++--
 activemq-cpp/src/main/decaf/lang/Appendable.h   |   6 +-
 activemq-cpp/src/main/decaf/lang/ArrayPointer.h |   4 +-
 activemq-cpp/src/main/decaf/lang/Boolean.h      |  12 +--
 activemq-cpp/src/main/decaf/lang/Byte.h         |  14 +--
 activemq-cpp/src/main/decaf/lang/CharSequence.h |   8 +-
 activemq-cpp/src/main/decaf/lang/Character.h    |  22 ++--
 activemq-cpp/src/main/decaf/lang/Comparable.h   |   2 +-
 activemq-cpp/src/main/decaf/lang/Double.h       |  30 +++---
 activemq-cpp/src/main/decaf/lang/Exception.h    |   2 +-
 activemq-cpp/src/main/decaf/lang/Float.h        |  30 +++---
 activemq-cpp/src/main/decaf/lang/Integer.h      |  20 ++--
 activemq-cpp/src/main/decaf/lang/Iterable.h     |   2 +-
 activemq-cpp/src/main/decaf/lang/Long.h         |  18 ++--
 activemq-cpp/src/main/decaf/lang/Math.h         |  52 +++++-----
 activemq-cpp/src/main/decaf/lang/Pointer.h      |   2 +-
 activemq-cpp/src/main/decaf/lang/Runtime.h      |   2 +-
 activemq-cpp/src/main/decaf/lang/Short.h        |  12 +--
 activemq-cpp/src/main/decaf/lang/String.h       |  52 +++++-----
 activemq-cpp/src/main/decaf/lang/StringBuffer.h |  64 ++++++------
 .../src/main/decaf/lang/StringBuilder.h         |  64 ++++++------
 activemq-cpp/src/main/decaf/lang/System.h       |  18 ++--
 activemq-cpp/src/main/decaf/lang/Thread.h       |  10 +-
 activemq-cpp/src/main/decaf/lang/ThreadLocal.h  |   2 +-
 activemq-cpp/src/main/decaf/lang/Throwable.h    |   2 +-
 .../src/main/decaf/net/DatagramPacket.h         |   2 +-
 activemq-cpp/src/main/decaf/net/InetAddress.h   |  10 +-
 activemq-cpp/src/main/decaf/net/ServerSocket.h  |   8 +-
 activemq-cpp/src/main/decaf/net/Socket.h        |  20 ++--
 activemq-cpp/src/main/decaf/net/SocketFactory.h |   2 +-
 activemq-cpp/src/main/decaf/net/SocketImpl.h    |  20 ++--
 activemq-cpp/src/main/decaf/net/URI.h           |  50 +++++-----
 .../src/main/decaf/net/URISyntaxException.h     |   6 +-
 activemq-cpp/src/main/decaf/net/URL.h           |  38 +++----
 activemq-cpp/src/main/decaf/net/URLEncoder.h    |   2 +-
 .../src/main/decaf/net/URLStreamHandler.h       |  10 +-
 .../src/main/decaf/net/ssl/SSLContext.h         |   6 +-
 .../src/main/decaf/net/ssl/SSLContextSpi.h      |   8 +-
 .../src/main/decaf/net/ssl/SSLParameters.h      |  10 +-
 .../src/main/decaf/net/ssl/SSLServerSocket.h    |   8 +-
 .../main/decaf/net/ssl/SSLServerSocketFactory.h |   6 +-
 activemq-cpp/src/main/decaf/net/ssl/SSLSocket.h |   6 +-
 .../src/main/decaf/net/ssl/SSLSocketFactory.h   |   8 +-
 activemq-cpp/src/main/decaf/nio/Buffer.h        |  26 ++---
 activemq-cpp/src/main/decaf/nio/ByteBuffer.h    | 100 +++++++++----------
 activemq-cpp/src/main/decaf/nio/CharBuffer.h    |  60 +++++------
 activemq-cpp/src/main/decaf/nio/DoubleBuffer.h  |  38 +++----
 activemq-cpp/src/main/decaf/nio/FloatBuffer.h   |  38 +++----
 activemq-cpp/src/main/decaf/nio/IntBuffer.h     |  38 +++----
 activemq-cpp/src/main/decaf/nio/LongBuffer.h    |  38 +++----
 activemq-cpp/src/main/decaf/nio/ShortBuffer.h   |  38 +++----
 .../src/main/decaf/security/MessageDigest.h     |  18 ++--
 .../src/main/decaf/security/MessageDigestSpi.h  |  10 +-
 .../src/main/decaf/security/ProviderService.h   |   4 +-
 .../src/main/decaf/util/AbstractCollection.h    |   2 +-
 activemq-cpp/src/main/decaf/util/BitSet.h       |  22 ++--
 activemq-cpp/src/main/decaf/util/Collection.h   |  18 ++--
 activemq-cpp/src/main/decaf/util/Comparator.h   |   2 +-
 activemq-cpp/src/main/decaf/util/Deque.h        |  26 ++---
 activemq-cpp/src/main/decaf/util/Iterator.h     |   4 +-
 activemq-cpp/src/main/decaf/util/LRUCache.h     |   2 +-
 activemq-cpp/src/main/decaf/util/Map.h          |   8 +-
 activemq-cpp/src/main/decaf/util/Properties.h   |  10 +-
 activemq-cpp/src/main/decaf/util/Timer.h        |   2 +-
 activemq-cpp/src/main/decaf/util/TimerTask.h    |   4 +-
 activemq-cpp/src/main/decaf/util/UUID.h         |  18 ++--
 .../util/concurrent/BrokenBarrierException.h    |   2 +-
 .../src/main/decaf/util/concurrent/Callable.h   |   2 +-
 .../util/concurrent/CancellationException.h     |   2 +-
 .../util/concurrent/CopyOnWriteArrayList.h      |   8 +-
 .../main/decaf/util/concurrent/CountDownLatch.h |   4 +-
 .../src/main/decaf/util/concurrent/Delayed.h    |   2 +-
 .../decaf/util/concurrent/ExecutionException.h  |   2 +-
 .../decaf/util/concurrent/ExecutorService.h     |   2 +-
 .../src/main/decaf/util/concurrent/Executors.h  |  16 +--
 .../src/main/decaf/util/concurrent/Future.h     |  10 +-
 .../src/main/decaf/util/concurrent/Semaphore.h  |  22 ++--
 .../main/decaf/util/concurrent/ThreadFactory.h  |   2 +-
 .../decaf/util/concurrent/ThreadPoolExecutor.h  |  14 +--
 .../src/main/decaf/util/concurrent/TimeUnit.h   |   4 +-
 .../util/concurrent/atomic/AtomicBoolean.h      |   8 +-
 .../util/concurrent/atomic/AtomicInteger.h      |  28 +++---
 .../util/concurrent/atomic/AtomicReference.h    |   2 +-
 .../locks/AbstractQueuedSynchronizer.h          |  48 ++++-----
 .../decaf/util/concurrent/locks/Condition.h     |   6 +-
 .../src/main/decaf/util/concurrent/locks/Lock.h |   8 +-
 .../decaf/util/concurrent/locks/ReadWriteLock.h |   4 +-
 .../decaf/util/concurrent/locks/ReentrantLock.h |  28 +++---
 .../concurrent/locks/ReentrantReadWriteLock.h   |   6 +-
 .../src/main/decaf/util/logging/Filter.h        |   2 +-
 .../src/main/decaf/util/logging/Formatter.h     |   4 +-
 .../src/main/decaf/util/logging/Handler.h       |   8 +-
 .../src/main/decaf/util/logging/LogManager.h    |   2 +-
 .../src/main/decaf/util/logging/Logger.h        |   4 +-
 activemq-cpp/src/main/decaf/util/zip/Adler32.h  |   2 +-
 .../main/decaf/util/zip/CheckedOutputStream.h   |   2 +-
 activemq-cpp/src/main/decaf/util/zip/Checksum.h |   2 +-
 activemq-cpp/src/main/decaf/util/zip/Deflater.h |  10 +-
 activemq-cpp/src/main/decaf/util/zip/Inflater.h |   8 +-
 .../benchmark/PerformanceTimer.h                |   4 +-
 .../activemq/test/CMSTestFixture.h              |   2 +-
 207 files changed, 1197 insertions(+), 1197 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/ActiveMQBlobMessage.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/ActiveMQBlobMessage.h b/activemq-cpp/src/main/activemq/commands/ActiveMQBlobMessage.h
index 2b6e5b7..0bc960d 100644
--- a/activemq-cpp/src/main/activemq/commands/ActiveMQBlobMessage.h
+++ b/activemq-cpp/src/main/activemq/commands/ActiveMQBlobMessage.h
@@ -69,7 +69,7 @@ namespace commands {
 
         /**
          * Get the Remote URL of the Blob.
-         * @returns string from of the Remote Blob URL.
+         * @return string from of the Remote Blob URL.
          */
         std::string getRemoteBlobUrl() const {
             return this->remoteBlobUrl;
@@ -85,7 +85,7 @@ namespace commands {
 
         /**
          * Get the Mime Type of the Blob.
-         * @returns string holding the MIME Type.
+         * @return string holding the MIME Type.
          */
         std::string getMimeType() const {
             return this->mimeType;
@@ -101,7 +101,7 @@ namespace commands {
 
         /**
          * Gets the Name of the Blob.
-         * @returns string name of the Blob.
+         * @return string name of the Blob.
          */
         std::string getName() const {
             return this->name;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/ActiveMQDestination.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/ActiveMQDestination.h b/activemq-cpp/src/main/activemq/commands/ActiveMQDestination.h
index ba6d9d8..3a78912 100644
--- a/activemq-cpp/src/main/activemq/commands/ActiveMQDestination.h
+++ b/activemq-cpp/src/main/activemq/commands/ActiveMQDestination.h
@@ -110,7 +110,7 @@ namespace commands {
 
         /**
          * Fetch this destination's physical name
-         * @returns const string containing the name
+         * @return const string containing the name
          */
         virtual std::string getPhysicalName() const {
             return this->physicalName;
@@ -118,7 +118,7 @@ namespace commands {
 
         /**
          * Set this destination's physical name
-         * @returns const string containing the name
+         * @return const string containing the name
          */
         virtual void setPhysicalName(const std::string& physicalName);
 
@@ -180,7 +180,7 @@ namespace commands {
 
         /**
          * Returns the Type of Destination that this object represents
-         * @returns int type qualifier.
+         * @return int type qualifier.
          */
         virtual cms::Destination::DestinationType getDestinationType() const = 0;
 
@@ -188,7 +188,7 @@ namespace commands {
          * Returns the type of Destination that this object represents as a string, the
          * available string values are, "Queue", "Topic", "TempQueue" and "TempTopic".
          *
-         * @returns The string value that represents the type of this destination.
+         * @return The string value that represents the type of this destination.
          */
         std::string getDestinationTypeAsString() const;
 
@@ -246,14 +246,14 @@ namespace commands {
         }
 
         /**
-         * @returns a reference (const) to the options properties for this Destination.
+         * @return a reference (const) to the options properties for this Destination.
          */
         const activemq::util::ActiveMQProperties& getOptions() const {
             return options;
         }
 
         /**
-         * @returns the cms::Destination interface pointer that the
+         * @return the cms::Destination interface pointer that the
          *          objects that derive from this class implement.
          */
         virtual const cms::Destination* getCMSDestination() const {

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/ActiveMQMapMessage.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/ActiveMQMapMessage.h b/activemq-cpp/src/main/activemq/commands/ActiveMQMapMessage.h
index f30ddbe..7064342 100644
--- a/activemq-cpp/src/main/activemq/commands/ActiveMQMapMessage.h
+++ b/activemq-cpp/src/main/activemq/commands/ActiveMQMapMessage.h
@@ -129,7 +129,7 @@ namespace commands {
          * Fetches a reference to this objects PrimitiveMap, if one needs
          * to be created or unmarshaled, this will perform the correct steps.
          *
-         * @returns reference to a PrimtiveMap;
+         * @return reference to a PrimtiveMap;
          *
          * @throws NullPointerException if the internal Map is Null.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/ActiveMQTempDestination.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/ActiveMQTempDestination.h b/activemq-cpp/src/main/activemq/commands/ActiveMQTempDestination.h
index 11cfe18..c89e25b 100644
--- a/activemq-cpp/src/main/activemq/commands/ActiveMQTempDestination.h
+++ b/activemq-cpp/src/main/activemq/commands/ActiveMQTempDestination.h
@@ -121,14 +121,14 @@ namespace commands{
         /**
          * Retrieves the Parent Connection that created this Connection.
          *
-         * @returns pointer to a Connection if one was set, false otherwise.
+         * @return pointer to a Connection if one was set, false otherwise.
          */
         core::ActiveMQConnection* getConnection() const {
             return this->connection;
         }
 
         /**
-         * @returns the connection Id of the Connection that created this temporary destination.
+         * @return the connection Id of the Connection that created this temporary destination.
          */
         std::string getConnectionId() const {
             return this->connectionId;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/BaseCommand.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/BaseCommand.h b/activemq-cpp/src/main/activemq/commands/BaseCommand.h
index 684c613..247ebb0 100644
--- a/activemq-cpp/src/main/activemq/commands/BaseCommand.h
+++ b/activemq-cpp/src/main/activemq/commands/BaseCommand.h
@@ -80,7 +80,7 @@ namespace commands {
          * Compares the DataStructure passed in to this one, and returns if
          * they are equivalent.  Equivalent here means that they are of the
          * same type, and that each element of the objects are the same.
-         * @returns true if DataStructure's are Equal.
+         * @return true if DataStructure's are Equal.
          */
         virtual bool equals(const DataStructure* value) const {
             return BaseDataStructure::equals(value);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/BrokerError.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/BrokerError.h b/activemq-cpp/src/main/activemq/commands/BrokerError.h
index c3a106e..5984e43 100644
--- a/activemq-cpp/src/main/activemq/commands/BrokerError.h
+++ b/activemq-cpp/src/main/activemq/commands/BrokerError.h
@@ -74,7 +74,7 @@ namespace commands {
         /**
          * Clone this object and return a new instance that the
          * caller now owns, this will be an exact copy of this one
-         * @returns new copy of this object.
+         * @return new copy of this object.
          */
         virtual BrokerError* cloneDataStructure() const {
             BrokerError* error = new BrokerError();
@@ -100,7 +100,7 @@ namespace commands {
 
         /**
          * Gets the string holding the error message
-         * @returns String Message
+         * @return String Message
          */
         virtual const std::string& getMessage() const {
             return message;
@@ -116,7 +116,7 @@ namespace commands {
 
         /**
          * Gets the string holding the Exception Class name
-         * @returns Exception Class name
+         * @return Exception Class name
          */
         virtual const std::string& getExceptionClass() const {
             return exceptionClass;
@@ -132,7 +132,7 @@ namespace commands {
 
         /**
          * Gets the Broker Error that caused this exception
-         * @returns Broker Error Pointer
+         * @return Broker Error Pointer
          */
         virtual const decaf::lang::Pointer<BrokerError>& getCause() const {
             return cause;
@@ -148,7 +148,7 @@ namespace commands {
 
         /**
          * Gets the Stack Trace Elements for the Exception
-         * @returns Stack Trace Elements
+         * @return Stack Trace Elements
          */
         virtual const std::vector<decaf::lang::Pointer<StackTraceElement> >& getStackTraceElements() const {
             return stackTraceElements;
@@ -163,7 +163,7 @@ namespace commands {
         }
 
         /**
-         * @returns the local Exception that was the source of this BrokerError instance
+         * @return the local Exception that was the source of this BrokerError instance
          */
         decaf::lang::Pointer<decaf::lang::Exception> getLocalException() const {
             return this->exCause;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/DataStructure.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/DataStructure.h b/activemq-cpp/src/main/activemq/commands/DataStructure.h
index a2cd544..b3319e1 100644
--- a/activemq-cpp/src/main/activemq/commands/DataStructure.h
+++ b/activemq-cpp/src/main/activemq/commands/DataStructure.h
@@ -38,7 +38,7 @@ namespace commands{
         /**
          * Clone this obbject and return a new instance that the
          * caller now owns, this will be an exact copy of this one
-         * @returns new copy of this object.
+         * @return new copy of this object.
          */
         virtual DataStructure* cloneDataStructure() const = 0;
 
@@ -60,7 +60,7 @@ namespace commands{
          * Compares the DataStructure passed in to this one, and returns if
          * they are equivalent.  Equivalent here means that they are of the
          * same type, and that each element of the objects are the same.
-         * @returns true if DataStructure's are Equal.
+         * @return true if DataStructure's are Equal.
          */
         virtual bool equals( const DataStructure* value ) const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/Message.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/Message.h b/activemq-cpp/src/main/activemq/commands/Message.h
index bc5de7f..611f232 100644
--- a/activemq-cpp/src/main/activemq/commands/Message.h
+++ b/activemq-cpp/src/main/activemq/commands/Message.h
@@ -143,7 +143,7 @@ namespace commands{
          *
          *   Pointer<cms::Message> cmsMsg = message->copy().dynamic_cast<cms::Message>();
          *
-         * @returns a Pointer<Message> which is a duplicate of this object.
+         * @return a Pointer<Message> which is a duplicate of this object.
          */
         Pointer<Message> copy() const {
             return Pointer<Message>(this->cloneDataStructure());
@@ -167,7 +167,7 @@ namespace commands{
         /**
          * Indicates that this command is aware of Marshaling, and needs
          * to have its Marshaling methods invoked.
-         * @returns boolean indicating desire to be in marshaling stages
+         * @return boolean indicating desire to be in marshaling stages
          */
         virtual bool isMarshalAware() const {
             return true;
@@ -185,7 +185,7 @@ namespace commands{
         /**
          * Gets the Acknowledgment Handler that this Message will use
          * when the Acknowledge method is called.
-         * @returns handler ActiveMQAckHandler to call or NULL if not set
+         * @return handler ActiveMQAckHandler to call or NULL if not set
          */
         virtual Pointer<core::ActiveMQAckHandler> getAckHandler() const {
             return this->ackHandler;
@@ -203,7 +203,7 @@ namespace commands{
         /**
          * Gets the ActiveMQConnection instance that this Command was created from
          * when the session create methods are called to create a Message..
-         * @returns the ActiveMQConnection parent for this Message or NULL if not set.
+         * @return the ActiveMQConnection parent for this Message or NULL if not set.
          */
         core::ActiveMQConnection* getConnection() const {
             return this->connection;
@@ -211,14 +211,14 @@ namespace commands{
 
         /**
          * Returns the Size of this message in Bytes.
-         * @returns number of bytes this message equates to.
+         * @return number of bytes this message equates to.
          */
         virtual unsigned int getSize() const;
 
         /**
          * Returns if this message has expired, meaning that its
          * Expiration time has elapsed.
-         * @returns true if message is expired.
+         * @return true if message is expired.
          */
         virtual bool isExpired() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/commands/WireFormatInfo.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/commands/WireFormatInfo.h b/activemq-cpp/src/main/activemq/commands/WireFormatInfo.h
index 3fffc4a..05f9898 100644
--- a/activemq-cpp/src/main/activemq/commands/WireFormatInfo.h
+++ b/activemq-cpp/src/main/activemq/commands/WireFormatInfo.h
@@ -244,12 +244,12 @@ namespace commands{
 
         /**
          * Determines if we think this is a Valid WireFormatInfo command
-         * @returns true if its valid.
+         * @return true if its valid.
          */
         bool isValid() const;
 
         /**
-         * @returns answers true to the isWireFormatInfo query
+         * @return answers true to the isWireFormatInfo query
          */
         virtual bool isWireFormatInfo() const {
             return true;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQConnection.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQConnection.h b/activemq-cpp/src/main/activemq/core/ActiveMQConnection.h
index 573a44f..cf30c0e 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQConnection.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQConnection.h
@@ -247,7 +247,7 @@ namespace core {
          * @param message
          *      The Message that should be checked.
          *
-         * @returns true if the Message was seen before.
+         * @return true if the Message was seen before.
          */
         bool isDuplicate(Dispatcher* dispatcher, Pointer<commands::Message> message);
 
@@ -399,7 +399,7 @@ namespace core {
         /**
          * Gets the pointer to the current PrefetchPolicy that is in use by this ConnectionFactory.
          *
-         * @returns a pointer to this objects PrefetchPolicy.
+         * @return a pointer to this objects PrefetchPolicy.
          */
         PrefetchPolicy* getPrefetchPolicy() const;
 
@@ -416,7 +416,7 @@ namespace core {
         /**
          * Gets the pointer to the current RedeliveryPolicy that is in use by this ConnectionFactory.
          *
-         * @returns a pointer to this objects RedeliveryPolicy.
+         * @return a pointer to this objects RedeliveryPolicy.
          */
         RedeliveryPolicy* getRedeliveryPolicy() const;
 
@@ -451,7 +451,7 @@ namespace core {
 
         /**
          * Gets if the useAsyncSend option is set
-         * @returns true if on false if not.
+         * @return true if on false if not.
          */
         bool isUseAsyncSend() const;
 
@@ -463,7 +463,7 @@ namespace core {
 
         /**
          * Gets if the Connection is configured for Message body compression.
-         * @returns if the Message body will be Compressed or not.
+         * @return if the Message body will be Compressed or not.
          */
         bool isUseCompression() const;
 
@@ -536,7 +536,7 @@ namespace core {
         void setProducerWindowSize(unsigned int windowSize);
 
         /**
-         * @returns true if the Connections that this factory creates should support the
+         * @return true if the Connections that this factory creates should support the
          * message based priority settings.
          */
         bool isMessagePrioritySupported() const;
@@ -585,7 +585,7 @@ namespace core {
          * for duplication, and the larger the performance impact of duplicate
          * detection will be.
          *
-         * @returns the configured audit depth.
+         * @return the configured audit depth.
          */
         int getAuditDepth() const;
 
@@ -603,7 +603,7 @@ namespace core {
         /**
          * The number of Producers that will be audited.
          *
-         * @returns the configured number of producers to include in the audit.
+         * @return the configured number of producers to include in the audit.
          */
         int getAuditMaximumProducerNumber() const;
 
@@ -649,7 +649,7 @@ namespace core {
          * completion.  This allows the acks to represent delivery status which can be persisted on
          * rollback Used in conjunction with KahaDB set to Rewrite On Redelivery.
          *
-         * @returns true if this option is enabled.
+         * @return true if this option is enabled.
          */
         bool isTransactedIndividualAck() const;
 
@@ -684,7 +684,7 @@ namespace core {
         /**
          * Gets the delay period for a consumer redelivery.
          *
-         * @returns configured time delay in milliseconds.
+         * @return configured time delay in milliseconds.
          */
         long long getConsumerFailoverRedeliveryWaitPeriod() const;
 
@@ -712,7 +712,7 @@ namespace core {
         /**
          * Gets the time between optimized ack batches in milliseconds.
          *
-         * @returns time between optimized ack batches in Milliseconds.
+         * @return time between optimized ack batches in Milliseconds.
          */
         long long getOptimizeAcknowledgeTimeOut() const;
 
@@ -748,7 +748,7 @@ namespace core {
         /**
          * Should all created consumers be retroactive.
          *
-         * @returns true if consumer will be created with the retroactive flag set.
+         * @return true if consumer will be created with the retroactive flag set.
          */
         bool isUseRetroactiveConsumer() const;
 
@@ -765,7 +765,7 @@ namespace core {
         /**
          * Should all created consumers be exclusive.
          *
-         * @returns true if consumer will be created with the exclusive flag set.
+         * @return true if consumer will be created with the exclusive flag set.
          */
         bool isExclusiveConsumer() const;
 
@@ -823,7 +823,7 @@ namespace core {
         void setConsumerExpiryCheckEnabled(bool consumerExpiryCheckEnabled);
 
         /**
-         * @returns the current connection's OpenWire protocol version.
+         * @return the current connection's OpenWire protocol version.
          */
         int getProtocolVersion() const;
 
@@ -911,7 +911,7 @@ namespace core {
          * Returns the Id of the Resource Manager that this client will use should
          * it be entered into an XA Transaction.
          *
-         * @returns a string containing the resource manager Id for XA Transactions.
+         * @return a string containing the resource manager Id for XA Transactions.
          */
         std::string getResourceManagerId() const;
 
@@ -942,7 +942,7 @@ namespace core {
          * @param timeout
          *      The time in milliseconds to wait for a response, default is zero or infinite.
          *
-         * @returns a Pointer instance to the Response object sent from the Broker.
+         * @return a Pointer instance to the Response object sent from the Broker.
          *
          * @throws BrokerException if the response from the broker is of type ExceptionResponse.
          * @throws ActiveMQException if any other error occurs while sending the Command.
@@ -986,7 +986,7 @@ namespace core {
         /**
          * Gets the pointer to the first exception that caused the Connection to become failed.
          *
-         * @returns pointer to an Exception instance or NULL if none is set.
+         * @return pointer to an Exception instance or NULL if none is set.
          */
         decaf::lang::Exception* getFirstFailureError() const;
 
@@ -1026,7 +1026,7 @@ namespace core {
         void ensureConnectionInfoSent();
 
         /**
-         * @returns the ExecutorService used to run jobs for this Connection
+         * @return the ExecutorService used to run jobs for this Connection
          */
         decaf::util::concurrent::ExecutorService* getExecutor() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQConnectionFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQConnectionFactory.h b/activemq-cpp/src/main/activemq/core/ActiveMQConnectionFactory.h
index 97b54d9..7fd0918 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQConnectionFactory.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQConnectionFactory.h
@@ -92,7 +92,7 @@ namespace core {
          * delivered until the Connection.start method is explicitly
          * called.
          *
-         * @returns a Connection Pointer
+         * @return a Connection Pointer
          *
          * @throws CMSException if an error occurs.
          */
@@ -112,7 +112,7 @@ namespace core {
          * @param password
          *      The password to authenticate with this connection.
          *
-         * @returns a Connection Pointer
+         * @return a Connection Pointer
          *
          * @throws CMSSecurityException if the user credentials are invalid.
          * @throws CMSException if an error occurs.
@@ -137,7 +137,7 @@ namespace core {
          *      The client Id to assign to connection if "" then a random client
          *      Id is created for this connection.
          *
-         * @returns a Connection Pointer
+         * @return a Connection Pointer
          *
          * @throws CMSSecurityException if the user credentials are invalid.
          * @throws CMSException if an error occurs.
@@ -239,7 +239,7 @@ namespace core {
         /**
          * Gets the currently configured MessageTransformer for this ConnectionFactory.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const;
 
@@ -256,7 +256,7 @@ namespace core {
         /**
          * Gets the pointer to the current PrefetchPolicy that is in use by this ConnectionFactory.
          *
-         * @returns a pointer to this objects PrefetchPolicy.
+         * @return a pointer to this objects PrefetchPolicy.
          */
         PrefetchPolicy* getPrefetchPolicy() const;
 
@@ -273,7 +273,7 @@ namespace core {
         /**
          * Gets the pointer to the current RedeliveryPolicy that is in use by this ConnectionFactory.
          *
-         * @returns a pointer to this objects RedeliveryPolicy.
+         * @return a pointer to this objects RedeliveryPolicy.
          */
         RedeliveryPolicy* getRedeliveryPolicy() const;
 
@@ -308,7 +308,7 @@ namespace core {
 
         /**
          * Gets if the useAsyncSend option is set
-         * @returns true if on false if not.
+         * @return true if on false if not.
          */
         bool isUseAsyncSend() const;
 
@@ -337,7 +337,7 @@ namespace core {
 
         /**
          * Gets if the Connection is configured for Message body compression.
-         * @returns if the Message body will be Compressed or not.
+         * @return if the Message body will be Compressed or not.
          */
         bool isUseCompression() const;
 
@@ -410,7 +410,7 @@ namespace core {
         void setProducerWindowSize(unsigned int windowSize);
 
         /**
-         * @returns true if the Connections that this factory creates should support the
+         * @return true if the Connections that this factory creates should support the
          * message based priority settings.
          */
         bool isMessagePrioritySupported() const;
@@ -427,7 +427,7 @@ namespace core {
         /**
          * Should all created consumers be retroactive.
          *
-         * @returns true if consumer will be created with the retroactive flag set.
+         * @return true if consumer will be created with the retroactive flag set.
          */
         bool isUseRetroactiveConsumer() const;
 
@@ -444,7 +444,7 @@ namespace core {
         /**
          * Should all created consumers be exclusive.
          *
-         * @returns true if consumer will be created with the exclusive flag set.
+         * @return true if consumer will be created with the exclusive flag set.
          */
         bool isExclusiveConsumer() const;
 
@@ -480,7 +480,7 @@ namespace core {
          * for duplication, and the larger the performance impact of duplicate
          * detection will be.
          *
-         * @returns the configured audit depth.
+         * @return the configured audit depth.
          */
         int getAuditDepth() const;
 
@@ -498,7 +498,7 @@ namespace core {
         /**
          * The number of Producers that will be audited.
          *
-         * @returns the configured number of producers to include in the audit.
+         * @return the configured number of producers to include in the audit.
          */
         int getAuditMaximumProducerNumber() const;
 
@@ -544,7 +544,7 @@ namespace core {
          * completion.  This allows the acks to represent delivery status which can be persisted on
          * rollback Used in conjunction with KahaDB set to Rewrite On Redelivery.
          *
-         * @returns true if this option is enabled.
+         * @return true if this option is enabled.
          */
         bool isTransactedIndividualAck() const;
 
@@ -579,7 +579,7 @@ namespace core {
         /**
          * Gets the delay period for a consumer redelivery.
          *
-         * @returns configured time delay in milliseconds.
+         * @return configured time delay in milliseconds.
          */
         long long getConsumerFailoverRedeliveryWaitPeriod() const;
 
@@ -607,7 +607,7 @@ namespace core {
         /**
          * Gets the time between optimized ack batches in milliseconds.
          *
-         * @returns time between optimized ack batches in Milliseconds.
+         * @return time between optimized ack batches in Milliseconds.
          */
         long long getOptimizeAcknowledgeTimeOut() const;
 
@@ -705,7 +705,7 @@ namespace core {
          * @param properties
          *      The Properties that are assigned to the new Connection instance.
          *
-         * @returns a new ActiveMQConnection pointer instance.
+         * @return a new ActiveMQConnection pointer instance.
          */
         virtual ActiveMQConnection* createActiveMQConnection(const Pointer<transport::Transport>& transport,
                                                              const Pointer<decaf::util::Properties>& properties);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQConsumer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQConsumer.h b/activemq-cpp/src/main/activemq/core/ActiveMQConsumer.h
index d845bd2..9254c8e 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQConsumer.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQConsumer.h
@@ -103,12 +103,12 @@ namespace core {
         const Pointer<commands::ConsumerId>& getConsumerId() const;
 
         /**
-         * @returns if this Consumer has been closed.
+         * @return if this Consumer has been closed.
          */
         bool isClosed() const;
 
         /**
-         * @returns the number of Message's this consumer is waiting to Dispatch.
+         * @return the number of Message's this consumer is waiting to Dispatch.
          */
         int getMessageAvailableCount() const;
 
@@ -127,7 +127,7 @@ namespace core {
          * Gets a pointer to this Consumer's Redelivery Policy object, the Consumer
          * retains ownership of this pointer so the caller should not delete it.
          *
-         * @returns a Pointer to a RedeliveryPolicy that is in use by this Consumer.
+         * @return a Pointer to a RedeliveryPolicy that is in use by this Consumer.
          */
         RedeliveryPolicy* getRedeliveryPolicy() const;
 
@@ -135,7 +135,7 @@ namespace core {
          * Gets the error that caused this Consumer to be in a Failed state, or NULL if
          * there is no Error.
          *
-         * @returns pointer to the error that faulted this Consumer or NULL.
+         * @return pointer to the error that faulted this Consumer or NULL.
          */
         decaf::lang::Exception* getFailureError() const;
 
@@ -143,7 +143,7 @@ namespace core {
          * Time in Milliseconds before an automatic acknowledge is done for any outstanding
          * delivered Messages.  A value less than one means no task is scheduled.
          *
-         * @returns time in milliseconds for the scheduled ack task.
+         * @return time in milliseconds for the scheduled ack task.
          */
         long long getOptimizedAckScheduledAckInterval() const;
 
@@ -158,7 +158,7 @@ namespace core {
         void setOptimizedAckScheduledAckInterval(long long value);
 
         /**
-         * @returns true if this consumer is using optimize acknowledge mode.
+         * @return true if this consumer is using optimize acknowledge mode.
          */
         bool isOptimizeAcknowledge() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQDestinationEvent.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQDestinationEvent.h b/activemq-cpp/src/main/activemq/core/ActiveMQDestinationEvent.h
index 471bf1d..ffa399e 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQDestinationEvent.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQDestinationEvent.h
@@ -54,7 +54,7 @@ namespace core {
         /**
          * Returns the DestinationInfo object that triggered this event.
          *
-         * @returns the DestinationInfo object that triggered this event.
+         * @return the DestinationInfo object that triggered this event.
          */
         decaf::lang::Pointer<commands::DestinationInfo> getDestinationInfo() const {
             return this->destination;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQMessageAudit.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQMessageAudit.h b/activemq-cpp/src/main/activemq/core/ActiveMQMessageAudit.h
index e57f0f3..ccc6789 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQMessageAudit.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQMessageAudit.h
@@ -63,7 +63,7 @@ namespace core {
         /**
          * Gets the currently configured Audit Depth
          *
-         * @returns the current audit depth setting
+         * @return the current audit depth setting
          */
         int getAuditDepth() const;
 
@@ -76,7 +76,7 @@ namespace core {
         void setAuditDepth(int value);
 
         /**
-         * @returns the current number of producers that will be tracked.
+         * @return the current number of producers that will be tracked.
          */
         int getMaximumNumberOfProducersToTrack() const;
 
@@ -146,7 +146,7 @@ namespace core {
         bool isInOrder(decaf::lang::Pointer<commands::MessageId> msgId) const;
 
         /**
-         * @returns the last sequence Id that we've audited for the given producer.
+         * @return the last sequence Id that we've audited for the given producer.
          */
         long long getLastSeqId(decaf::lang::Pointer<commands::ProducerId> id) const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQProducer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQProducer.h b/activemq-cpp/src/main/activemq/core/ActiveMQProducer.h
index e69730d..5e891d0 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQProducer.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQProducer.h
@@ -120,7 +120,7 @@ namespace core {
 
         /**
          * Gets if Message Time Stamps are disabled for this Producer
-         * @returns boolean indicating state of enable / disable (true / false)
+         * @return boolean indicating state of enable / disable (true / false)
          */
         virtual bool getDisableMessageTimeStamp() const {
             return this->kernel->getDisableMessageTimeStamp();
@@ -185,7 +185,7 @@ namespace core {
     public:
 
         /**
-         * @returns true if this Producer has been closed.
+         * @return true if this Producer has been closed.
          */
         bool isClosed() const {
             return this->kernel->isClosed();

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQSession.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQSession.h b/activemq-cpp/src/main/activemq/core/ActiveMQSession.h
index 626a0e8..949f6ac 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQSession.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQSession.h
@@ -142,7 +142,7 @@ namespace core {
          * connection and returns it.  Mainly intended for use by the objects
          * that this session creates so that they can notify the client of
          * exceptions that occur in the context of another thread.
-         * @returns cms::ExceptionListener pointer or NULL
+         * @return cms::ExceptionListener pointer or NULL
          */
         cms::ExceptionListener* getExceptionListener() {
             return this->kernel->getExceptionListener();
@@ -162,7 +162,7 @@ namespace core {
         /**
          * Gets the currently configured MessageTransformer for this Session.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const {
             return this->kernel->getMessageTransformer();

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQSessionExecutor.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQSessionExecutor.h b/activemq-cpp/src/main/activemq/core/ActiveMQSessionExecutor.h
index 46fdda0..68d4e00 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQSessionExecutor.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQSessionExecutor.h
@@ -151,7 +151,7 @@ namespace kernels {
         virtual bool iterate();
 
         /**
-         * @returns a vector containing all the unconsumed messages, this clears the
+         * @return a vector containing all the unconsumed messages, this clears the
          *          Message Dispatch Channel when called.
          */
         std::vector< Pointer<MessageDispatch> > getUnconsumedMessages() {

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/ActiveMQTransactionContext.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/ActiveMQTransactionContext.h b/activemq-cpp/src/main/activemq/core/ActiveMQTransactionContext.h
index 73e6f1f..c289ef7 100644
--- a/activemq-cpp/src/main/activemq/core/ActiveMQTransactionContext.h
+++ b/activemq-cpp/src/main/activemq/core/ActiveMQTransactionContext.h
@@ -141,7 +141,7 @@ namespace kernels {
          * Checks to see if there is currently an Local Transaction in progess, returns
          * false if not, true otherwise.
          *
-         * @returns true if an Local Transaction is in progress.
+         * @return true if an Local Transaction is in progress.
          */
         virtual bool isInLocalTransaction() const;
 
@@ -149,7 +149,7 @@ namespace kernels {
          * Checks to see if there is currently an XA Transaction in progress, returns
          * false if not, true otherwise.
          *
-         * @returns true if an XA Transaction is in progress.
+         * @return true if an XA Transaction is in progress.
          */
         virtual bool isInXATransaction() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/Dispatcher.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/Dispatcher.h b/activemq-cpp/src/main/activemq/core/Dispatcher.h
index 876efc8..cd3a369 100644
--- a/activemq-cpp/src/main/activemq/core/Dispatcher.h
+++ b/activemq-cpp/src/main/activemq/core/Dispatcher.h
@@ -45,7 +45,7 @@ namespace core {
         /**
          * HashCode method allowing Dispatcher instances to be used in HashMap etc.
          *
-         * @returns hash value for this Dispatcher.
+         * @return hash value for this Dispatcher.
          */
         virtual int getHashCode() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/PrefetchPolicy.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/PrefetchPolicy.h b/activemq-cpp/src/main/activemq/core/PrefetchPolicy.h
index 04552de..b69b5b9 100644
--- a/activemq-cpp/src/main/activemq/core/PrefetchPolicy.h
+++ b/activemq-cpp/src/main/activemq/core/PrefetchPolicy.h
@@ -56,7 +56,7 @@ namespace core {
         /**
          * Gets the amount of messages to prefetch for a Durable Topic.
          *
-         * @returns value of the number of messages to prefetch.
+         * @return value of the number of messages to prefetch.
          */
         virtual int getDurableTopicPrefetch() const = 0;
 
@@ -71,7 +71,7 @@ namespace core {
         /**
          * Gets the amount of messages to prefetch for a Queue.
          *
-         * @returns value of the number of messages to prefetch.
+         * @return value of the number of messages to prefetch.
          */
         virtual int getQueuePrefetch() const = 0;
 
@@ -86,7 +86,7 @@ namespace core {
         /**
          * Gets the amount of messages to prefetch for a Queue Browser.
          *
-         * @returns value of the number of messages to prefetch.
+         * @return value of the number of messages to prefetch.
          */
         virtual int getQueueBrowserPrefetch() const = 0;
 
@@ -101,7 +101,7 @@ namespace core {
         /**
          * Gets the amount of messages to prefetch for a Topic.
          *
-         * @returns value of the number of messages to prefetch.
+         * @return value of the number of messages to prefetch.
          */
         virtual int getTopicPrefetch() const = 0;
 
@@ -118,7 +118,7 @@ namespace core {
          * prefetch value and return either the requested value or the maximum allowable
          * value for prefetch.
          *
-         * @returns the allowable value for a prefetch limit, either requested or the max.
+         * @return the allowable value for a prefetch limit, either requested or the max.
          */
         virtual int getMaxPrefetchLimit(int value) const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/RedeliveryPolicy.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/RedeliveryPolicy.h b/activemq-cpp/src/main/activemq/core/RedeliveryPolicy.h
index 0e52d51..6997e66 100644
--- a/activemq-cpp/src/main/activemq/core/RedeliveryPolicy.h
+++ b/activemq-cpp/src/main/activemq/core/RedeliveryPolicy.h
@@ -131,7 +131,7 @@ namespace core {
         virtual long long getNextRedeliveryDelay(long long previousDelay) = 0;
 
         /**
-         * @returns whether or not collision avoidance is enabled for this Policy.
+         * @return whether or not collision avoidance is enabled for this Policy.
          */
         virtual bool isUseCollisionAvoidance() const = 0;
 
@@ -142,7 +142,7 @@ namespace core {
         virtual void setUseCollisionAvoidance(bool value) = 0;
 
         /**
-         * @returns whether or not the exponential back off option is enabled.
+         * @return whether or not the exponential back off option is enabled.
          */
         virtual bool isUseExponentialBackOff() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/kernels/ActiveMQConsumerKernel.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/kernels/ActiveMQConsumerKernel.h b/activemq-cpp/src/main/activemq/core/kernels/ActiveMQConsumerKernel.h
index dc5d1c8..bb1f413 100644
--- a/activemq-cpp/src/main/activemq/core/kernels/ActiveMQConsumerKernel.h
+++ b/activemq-cpp/src/main/activemq/core/kernels/ActiveMQConsumerKernel.h
@@ -183,7 +183,7 @@ namespace kernels {
         const Pointer<commands::ConsumerId>& getConsumerId() const;
 
         /**
-         * @returns if this Consumer has been closed.
+         * @return if this Consumer has been closed.
          */
         bool isClosed() const;
 
@@ -227,7 +227,7 @@ namespace kernels {
         /**
          * Gets the currently set Last Delivered Sequence Id
          *
-         * @returns long long containing the sequence id of the last delivered Message.
+         * @return long long containing the sequence id of the last delivered Message.
          */
         long long getLastDeliveredSequenceId() const;
 
@@ -249,7 +249,7 @@ namespace kernels {
         /**
          * Returns the delay after a failover before Message redelivery starts.
          *
-         * @returns time in milliseconds to wait after failover.
+         * @return time in milliseconds to wait after failover.
          */
         long long setFailoverRedeliveryWaitPeriod() const;
 
@@ -271,7 +271,7 @@ namespace kernels {
         void setLastDeliveredSequenceId(long long value);
 
         /**
-         * @returns the number of Message's this consumer is waiting to Dispatch.
+         * @return the number of Message's this consumer is waiting to Dispatch.
          */
         int getMessageAvailableCount() const;
 
@@ -290,7 +290,7 @@ namespace kernels {
          * Gets a pointer to this Consumer's Redelivery Policy object, the Consumer
          * retains ownership of this pointer so the caller should not delete it.
          *
-         * @returns a Pointer to a RedeliveryPolicy that is in use by this Consumer.
+         * @return a Pointer to a RedeliveryPolicy that is in use by this Consumer.
          */
         RedeliveryPolicy* getRedeliveryPolicy() const;
 
@@ -306,7 +306,7 @@ namespace kernels {
          * Gets the error that caused this Consumer to be in a Failed state, or NULL if
          * there is no Error.
          *
-         * @returns pointer to the error that faulted this Consumer or NULL.
+         * @return pointer to the error that faulted this Consumer or NULL.
          */
         decaf::lang::Exception* getFailureError() const;
 
@@ -327,7 +327,7 @@ namespace kernels {
          * Time in Milliseconds before an automatic acknowledge is done for any outstanding
          * delivered Messages.  A value less than one means no task is scheduled.
          *
-         * @returns time in milliseconds for the scheduled ack task.
+         * @return time in milliseconds for the scheduled ack task.
          */
         long long getOptimizedAckScheduledAckInterval() const;
 
@@ -342,7 +342,7 @@ namespace kernels {
         void setOptimizedAckScheduledAckInterval(long long value);
 
         /**
-         * @returns true if this consumer is using optimize acknowledge mode.
+         * @return true if this consumer is using optimize acknowledge mode.
          */
         bool isOptimizeAcknowledge() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/kernels/ActiveMQProducerKernel.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/kernels/ActiveMQProducerKernel.h b/activemq-cpp/src/main/activemq/core/kernels/ActiveMQProducerKernel.h
index 8da574e..b0cb059 100644
--- a/activemq-cpp/src/main/activemq/core/kernels/ActiveMQProducerKernel.h
+++ b/activemq-cpp/src/main/activemq/core/kernels/ActiveMQProducerKernel.h
@@ -148,7 +148,7 @@ namespace kernels {
         /**
          * Gets the currently configured MessageTransformer for this MessageProducer.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const {
             return this->transformer;
@@ -196,7 +196,7 @@ namespace kernels {
 
         /**
          * Gets if Message Time Stamps are disabled for this Producer
-         * @returns boolean indicating state of enable / disable (true / false)
+         * @return boolean indicating state of enable / disable (true / false)
          */
         virtual bool getDisableMessageTimeStamp() const {
             return this->disableTimestamps;
@@ -251,7 +251,7 @@ namespace kernels {
         }
 
         /**
-         * @returns true if this Producer has been closed.
+         * @return true if this Producer has been closed.
          */
         bool isClosed() const {
             return this->closed;
@@ -290,7 +290,7 @@ namespace kernels {
         void dispose();
 
         /**
-         * @returns the next sequence number for a Message sent from this Producer.
+         * @return the next sequence number for a Message sent from this Producer.
          */
         long long getNextMessageSequence() {
             return this->messageSequence.getNextSequenceId();

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/core/kernels/ActiveMQSessionKernel.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/core/kernels/ActiveMQSessionKernel.h b/activemq-cpp/src/main/activemq/core/kernels/ActiveMQSessionKernel.h
index 5247e7c..ee031f3 100644
--- a/activemq-cpp/src/main/activemq/core/kernels/ActiveMQSessionKernel.h
+++ b/activemq-cpp/src/main/activemq/core/kernels/ActiveMQSessionKernel.h
@@ -286,7 +286,7 @@ namespace kernels {
          * that this session creates so that they can notify the client of
          * exceptions that occur in the context of another thread.
          *
-         * @returns the registered cms::ExceptionListener pointer or NULL
+         * @return the registered cms::ExceptionListener pointer or NULL
          */
         cms::ExceptionListener* getExceptionListener();
 
@@ -302,7 +302,7 @@ namespace kernels {
         /**
          * Gets the currently configured MessageTransformer for this Session.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const;
 
@@ -341,7 +341,7 @@ namespace kernels {
         /**
          * Gets the currently set Last Delivered Sequence Id
          *
-         * @returns long long containing the sequence id of the last delivered Message.
+         * @return long long containing the sequence id of the last delivered Message.
          */
         long long getLastDeliveredSequenceId() const {
             return this->lastDeliveredSequenceId;
@@ -377,7 +377,7 @@ namespace kernels {
          * @param timeout
          *      The time to wait for a response, default is zero or infinite.
          *
-         * @returns Pointer to a Response object that the broker has returned for the Command sent.
+         * @return Pointer to a Response object that the broker has returned for the Command sent.
          *
          * @throws ActiveMQException thrown if an error response was received
          *         from the broker, or if any other error occurred.
@@ -527,12 +527,12 @@ namespace kernels {
         bool isInUse(Pointer<commands::ActiveMQDestination> destination);
 
         /**
-         * @returns a Pointer to an ActiveMQProducerKernel using its ProducerId, or NULL.
+         * @return a Pointer to an ActiveMQProducerKernel using its ProducerId, or NULL.
          */
         Pointer<ActiveMQProducerKernel> lookupProducerKernel(Pointer<commands::ProducerId> id);
 
         /**
-         * @returns a Pointer to an ActiveMQConsumerKernel using its ConsumerId, or NULL.
+         * @return a Pointer to an ActiveMQConsumerKernel using its ConsumerId, or NULL.
          */
         Pointer<ActiveMQConsumerKernel> lookupConsumerKernel(Pointer<commands::ConsumerId> id);
 
@@ -542,7 +542,7 @@ namespace kernels {
          * because a consumer requires further processing time to complete its dispatching.  Once
          * all consumers are done this method returns false.
          *
-         * @returns true if more iterations are needed false otherwise.
+         * @return true if more iterations are needed false otherwise.
          */
         bool iterateConsumers();
 
@@ -556,7 +556,7 @@ namespace kernels {
         /**
          * Returns a Hash Code for this Session based on its SessionId.
          *
-         * @returns an int hash code based on the string balue of SessionId.
+         * @return an int hash code based on the string balue of SessionId.
          */
         virtual int getHashCode() const;
 
@@ -619,7 +619,7 @@ namespace kernels {
 
        // Creates a new Temporary Destination name using the connection id
        // and a rolling count.
-       // @returns a unique Temporary Destination name
+       // @return a unique Temporary Destination name
        std::string createTemporaryDestinationName();
 
     };

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/exceptions/BrokerException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/exceptions/BrokerException.h b/activemq-cpp/src/main/activemq/exceptions/BrokerException.h
index 0926c94..b450a98 100644
--- a/activemq-cpp/src/main/activemq/exceptions/BrokerException.h
+++ b/activemq-cpp/src/main/activemq/exceptions/BrokerException.h
@@ -43,7 +43,7 @@ namespace exceptions {
          * to preserve the type of the original exception as well as the message.
          * All subclasses should override.
          *
-         * @returns new BrokerException instance that is a clone of this one.
+         * @return new BrokerException instance that is a clone of this one.
          */
         virtual BrokerException* clone() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/AbstractTransportFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/AbstractTransportFactory.h b/activemq-cpp/src/main/activemq/transport/AbstractTransportFactory.h
index f8458f6..d606e25 100644
--- a/activemq-cpp/src/main/activemq/transport/AbstractTransportFactory.h
+++ b/activemq-cpp/src/main/activemq/transport/AbstractTransportFactory.h
@@ -52,7 +52,7 @@ namespace transport {
          * @param properties
          *        The properties that were configured on the URI.
          *
-         * @returns a pointer to a WireFormat instance that the caller then owns.
+         * @return a pointer to a WireFormat instance that the caller then owns.
          *
          * @throws NoSuchElementException if the configured WireFormat is not found.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/Transport.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/Transport.h b/activemq-cpp/src/main/activemq/transport/Transport.h
index deb7213..a7161fb 100644
--- a/activemq-cpp/src/main/activemq/transport/Transport.h
+++ b/activemq-cpp/src/main/activemq/transport/Transport.h
@@ -142,7 +142,7 @@ namespace transport{
          * nested transport this method delegates down to the lowest level transport that
          * actually maintains a WireFormat info instance.
          *
-         * @returns The WireFormat the object used to encode / decode commands.
+         * @return The WireFormat the object used to encode / decode commands.
          */
         virtual Pointer<wireformat::WireFormat> getWireFormat() const = 0;
 
@@ -180,21 +180,21 @@ namespace transport{
          * Is this Transport fault tolerant, meaning that it will reconnect to
          * a broker on disconnect.
          *
-         * @returns true if the Transport is fault tolerant.
+         * @return true if the Transport is fault tolerant.
          */
         virtual bool isFaultTolerant() const = 0;
 
         /**
          * Is the Transport Connected to its Broker.
          *
-         * @returns true if a connection has been made.
+         * @return true if a connection has been made.
          */
         virtual bool isConnected() const = 0;
 
         /**
          * Has the Transport been shutdown and no longer usable.
          *
-         * @returns true if the Transport
+         * @return true if the Transport
          */
         virtual bool isClosed() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/TransportRegistry.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/TransportRegistry.h b/activemq-cpp/src/main/activemq/transport/TransportRegistry.h
index 00ba4ce..c3ad8ca 100644
--- a/activemq-cpp/src/main/activemq/transport/TransportRegistry.h
+++ b/activemq-cpp/src/main/activemq/transport/TransportRegistry.h
@@ -65,7 +65,7 @@ namespace transport {
          * @param name
          *        The name of the Factory to find in the Registry.
          *
-         * @returns the Factory registered under the given name.
+         * @return the Factory registered under the given name.
          *
          * @throws NoSuchElementException if no factory is registered with that name.
          */
@@ -105,7 +105,7 @@ namespace transport {
          * Retrieves a list of the names of all the Registered Transport's in this
          * Registry.
          *
-         * @returns stl vector of strings with all the Transport names registered.
+         * @return stl vector of strings with all the Transport names registered.
          */
         std::vector<std::string> getTransportNames() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgent.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgent.h b/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgent.h
index ba16c60..098f0aa 100644
--- a/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgent.h
+++ b/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgent.h
@@ -75,7 +75,7 @@ namespace discovery {
         virtual decaf::net::URI getDiscoveryURI() const;
 
         /**
-         * @returns true if this agent is currently started.
+         * @return true if this agent is currently started.
          */
         bool isStarted() const;
 
@@ -91,7 +91,7 @@ namespace discovery {
          * Gets the configured service to publish, not all agents can publish so this value
          * may not mean that an actual service advertisement is ever done.
          *
-         * @returns the configured service to publish.
+         * @return the configured service to publish.
          */
         std::string getServiceName() const;
 
@@ -110,7 +110,7 @@ namespace discovery {
          * seen is kept in the list of discovered services before being idle to long.  Also this
          * value controls how often this service will advertise itself if it supports that.
          *
-         * @returns Time in milliseconds for the keep alive interval.
+         * @return Time in milliseconds for the keep alive interval.
          */
         long long getKeepAliveInterval() const;
 
@@ -125,7 +125,7 @@ namespace discovery {
         /**
          * Gets the configured backoff multiplier for calculating the next recovery time.
          *
-         * @returns the configured backoff multiplier for calculating the next recovery time.
+         * @return the configured backoff multiplier for calculating the next recovery time.
          */
         long long getBackOffMultiplier() const;
 
@@ -142,7 +142,7 @@ namespace discovery {
          * Gets the initial amount of time the agent should wait before attempt a reconnect on
          * a discovered service.
          *
-         * @returns The time to wait before the initial reconnect attempt in milliseconds.
+         * @return The time to wait before the initial reconnect attempt in milliseconds.
          */
         long long getInitialReconnectDelay() const;
 
@@ -159,7 +159,7 @@ namespace discovery {
          * Returns the maximum number of reconnect attempts that will be attempted before a
          * service is considered to be failed.
          *
-         * @returns the maximum number of allowed reconnect attempts.
+         * @return the maximum number of allowed reconnect attempts.
          */
         int getMaxReconnectAttempts() const;
 
@@ -175,7 +175,7 @@ namespace discovery {
          * Returns the maximum time allowed between reconnect attempts.  This limits the amount
          * of time that reconnect will wait when exponential backoff is enabled.
          *
-         * @returns the maximum reconnect delay in milliseconds.
+         * @return the maximum reconnect delay in milliseconds.
          */
         long long getMaxReconnectDelay() const;
 
@@ -194,7 +194,7 @@ namespace discovery {
          * Returns true if successive attempts to reconnect to a discovered service are delayed
          * by an exponentially growing time factor.
          *
-         * @returns whether exponential back-off is enabled.
+         * @return whether exponential back-off is enabled.
          */
         bool isUseExponentialBackOff() const;
 
@@ -210,7 +210,7 @@ namespace discovery {
         /**
          * Returns the assigned group for this discovery agent.
          *
-         * @returns the assigned group for this discovery agent.
+         * @return the assigned group for this discovery agent.
          */
         std::string getGroup() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgentFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgentFactory.h b/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgentFactory.h
index 1582d3c..76dfa4a 100644
--- a/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgentFactory.h
+++ b/activemq-cpp/src/main/activemq/transport/discovery/AbstractDiscoveryAgentFactory.h
@@ -45,7 +45,7 @@ namespace discovery {
          * @param agentURI
          *      The URI that describes the agent and any requested configuration changes.
          *
-         * @returns a new DiscoveryAgent instance with all URI options applied.
+         * @return a new DiscoveryAgent instance with all URI options applied.
          */
         virtual decaf::lang::Pointer<DiscoveryAgent> createAgent(const decaf::net::URI& agentURI);
 
@@ -57,7 +57,7 @@ namespace discovery {
          * After this method is called by createAgent the configuration method will be invoked to
          * allow the URI options to be applied.
          *
-         * @returns a Pointer to the newly created discovery agent instance.
+         * @return a Pointer to the newly created discovery agent instance.
          *
          * @throws ActiveMQException if an error occurs while creating the agent.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/discovery/DiscoveredBrokerData.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveredBrokerData.h b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveredBrokerData.h
index 8254a97..6aaf6e7 100644
--- a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveredBrokerData.h
+++ b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveredBrokerData.h
@@ -49,7 +49,7 @@ namespace discovery {
         /**
          * Gets the time of the last heart best from this Broker
          *
-         * @returns the time of the last received heart beat event from this Broker
+         * @return the time of the last received heart beat event from this Broker
          */
         long long getLastHeartBeatTime() const {
             return this->lastHeartBeatTime;
@@ -66,7 +66,7 @@ namespace discovery {
         }
 
         /**
-         * @returns true is this service has been marked as failed.
+         * @return true is this service has been marked as failed.
          */
         bool isFailed() const {
             return failed;
@@ -85,7 +85,7 @@ namespace discovery {
         /**
          * Gets the number of times that there was a failure contacting this broker.
          *
-         * @returns count of the number of failures of this service.
+         * @return count of the number of failures of this service.
          */
         int getFailureCount() const {
             return failureCount;
@@ -104,7 +104,7 @@ namespace discovery {
         /**
          * Gets the set time for the next recovery attempt on this service.
          *
-         * @returns the next set time that this service can have a recovery attempt.
+         * @return the next set time that this service can have a recovery attempt.
          */
         long long getNextRecoveryTime() const {
             return nextRecoveryTime;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentFactory.h b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentFactory.h
index 2273e95..302e476 100644
--- a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentFactory.h
+++ b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentFactory.h
@@ -48,7 +48,7 @@ namespace discovery {
          * @param agentURI
          *      The URI that defines the agent to create along with it configuration options.
          *
-         * @returns a new DiscoveryAgent instance for the given URI.
+         * @return a new DiscoveryAgent instance for the given URI.
          *
          * @throws IOException if an error occurs creating the given agent.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentRegistry.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentRegistry.h b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentRegistry.h
index b16be73..bf680b7 100644
--- a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentRegistry.h
+++ b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryAgentRegistry.h
@@ -64,7 +64,7 @@ namespace discovery {
          * @param name
          *        The name of the Factory to find in the Registry.
          *
-         * @returns the Factory registered under the given name.
+         * @return the Factory registered under the given name.
          *
          * @throws NoSuchElementException if no factory is registered with that name.
          */
@@ -104,7 +104,7 @@ namespace discovery {
          * Retrieves a list of the names of all the Registered Agents in this
          * Registry.
          *
-         * @returns stl vector of strings with all the Agent names registered.
+         * @return stl vector of strings with all the Agent names registered.
          */
         std::vector<std::string> getAgentNames() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryTransport.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryTransport.h b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryTransport.h
index 782d4a1..b0e47ce 100644
--- a/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryTransport.h
+++ b/activemq-cpp/src/main/activemq/transport/discovery/DiscoveryTransport.h
@@ -67,7 +67,7 @@ namespace discovery {
         /**
          * Returns the currently configured Discovery Agent
          *
-         * @returns the pointer to the currently configured agent or NULL if not set.
+         * @return the pointer to the currently configured agent or NULL if not set.
          */
         Pointer<DiscoveryAgent> getDiscoveryAgent() const;
 
@@ -82,7 +82,7 @@ namespace discovery {
         /**
          * Gets the currently set parameters that are applied to newly discovered services URIs.
          *
-         * @returns the currently set Properties to apply to new service URIs.
+         * @return the currently set Properties to apply to new service URIs.
          */
         decaf::util::Properties getParameters() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/discovery/http/HttpDiscoveryAgent.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/discovery/http/HttpDiscoveryAgent.h b/activemq-cpp/src/main/activemq/transport/discovery/http/HttpDiscoveryAgent.h
index 80cea9e..b31b461 100644
--- a/activemq-cpp/src/main/activemq/transport/discovery/http/HttpDiscoveryAgent.h
+++ b/activemq-cpp/src/main/activemq/transport/discovery/http/HttpDiscoveryAgent.h
@@ -75,7 +75,7 @@ namespace http {
          * Gets the amount of time the agent waits before attempting to fetch the list
          * of registered Brokers from the configured HTTP registry service.
          *
-         * @returns Time in milliseconds to wait between update attempts.
+         * @return Time in milliseconds to wait between update attempts.
          */
         long long getUpdateInterval() const;
 
@@ -90,7 +90,7 @@ namespace http {
         /**
          * Gets the URL for the Broker registry where the agent gets its updates.
          *
-         * @returns The URL to poll for registry entries.
+         * @return The URL to poll for registry entries.
          */
         std::string getRegistryURL() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/failover/BackupTransport.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/failover/BackupTransport.h b/activemq-cpp/src/main/activemq/transport/failover/BackupTransport.h
index 14e676d..0a9236c 100644
--- a/activemq-cpp/src/main/activemq/transport/failover/BackupTransport.h
+++ b/activemq-cpp/src/main/activemq/transport/failover/BackupTransport.h
@@ -80,7 +80,7 @@ namespace failover {
 
         /**
          * Gets the currently held transport
-         * @returns pointer to the held transport or NULL if not set.
+         * @return pointer to the held transport or NULL if not set.
          */
         const Pointer<Transport>& getTransport() {
             return transport;
@@ -115,7 +115,7 @@ namespace failover {
         /**
          * Has the Transport been shutdown and no longer usable.
          *
-         * @returns true if the Transport
+         * @return true if the Transport
          */
         bool isClosed() const {
             return this->closed;
@@ -130,7 +130,7 @@ namespace failover {
         }
 
         /**
-         * @returns true if this transport was in the priority backup list.
+         * @return true if this transport was in the priority backup list.
          */
         bool isPriority() const {
             return this->priority;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/failover/BackupTransportPool.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/failover/BackupTransportPool.h b/activemq-cpp/src/main/activemq/transport/failover/BackupTransportPool.h
index ce9e028..940d1ed 100644
--- a/activemq-cpp/src/main/activemq/transport/failover/BackupTransportPool.h
+++ b/activemq-cpp/src/main/activemq/transport/failover/BackupTransportPool.h
@@ -138,7 +138,7 @@ namespace failover {
          * Returns true if there is a Backup in the pool that's on the priority
          * backups list.
          *
-         * @returns true if there is a priority backup available.
+         * @return true if there is a priority backup available.
          */
         bool isPriorityBackupAvailable() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/failover/FailoverTransport.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/failover/FailoverTransport.h b/activemq-cpp/src/main/activemq/transport/failover/FailoverTransport.h
index fd674aa..3a18693 100644
--- a/activemq-cpp/src/main/activemq/transport/failover/FailoverTransport.h
+++ b/activemq-cpp/src/main/activemq/transport/failover/FailoverTransport.h
@@ -140,7 +140,7 @@ namespace failover {
     public:
 
         /**
-         * @returns true if there is a need for the iterate method to be called by this
+         * @return true if there is a need for the iterate method to be called by this
          *          classes task runner.
          */
         virtual bool isPending() const;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/transport/failover/URIPool.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/transport/failover/URIPool.h b/activemq-cpp/src/main/activemq/transport/failover/URIPool.h
index ae1c856..9a499e9 100644
--- a/activemq-cpp/src/main/activemq/transport/failover/URIPool.h
+++ b/activemq-cpp/src/main/activemq/transport/failover/URIPool.h
@@ -70,14 +70,14 @@ namespace failover {
         /**
          * Gets a static view of the URI List contained in this URI Pool
          *
-         * @returns a static reference to this Pools list of URIs.
+         * @return a static reference to this Pools list of URIs.
          */
         const decaf::util::List<decaf::net::URI>& getURIList() const {
             return this->uriPool;
         }
 
         /**
-         * @returns true if this URI Pool is empty.
+         * @return true if this URI Pool is empty.
          */
         bool isEmpty() const;
 
@@ -118,7 +118,7 @@ namespace failover {
          *
          * @param uri - a URI previously taken from the pool.
          *
-         * @returns true if the URI was added or false if its already in the list.
+         * @return true if the URI was added or false if its already in the list.
          */
         bool addURI(const decaf::net::URI& uri);
 
@@ -128,7 +128,7 @@ namespace failover {
          *
          * @param uris - List of URIs to add into the Pool.
          *
-         * @returns true if any URI was added or false if they were already in the list.
+         * @return true if any URI was added or false if they were already in the list.
          */
         bool addURIs(const decaf::util::List<decaf::net::URI>& uris);
 
@@ -138,7 +138,7 @@ namespace failover {
          * @param uri
          *      The URI to find and remove from the free list
          *
-         * @returns true if the URI was removed or false if no change was made.
+         * @return true if the URI was removed or false if no change was made.
          */
         bool removeURI(const decaf::net::URI& uri);
 
@@ -165,7 +165,7 @@ namespace failover {
         /**
          * Returns true if the given URI is contained in this set of URIs.
          *
-         * @returns true if the URI is in the list.
+         * @return true if the URI is in the list.
          */
         bool contains(const decaf::net::URI& uri) const;
 
@@ -173,7 +173,7 @@ namespace failover {
          * Returns true if the URI given is the first in the list of
          * URIs contained in this pool.
          *
-         * @returns true if the URI is index 0 in the URI list.
+         * @return true if the URI is index 0 in the URI list.
          */
         bool isPriority(const decaf::net::URI& uri) const;
 
@@ -185,7 +185,7 @@ namespace failover {
         /**
          * Compares the URIs in this set to that of another URIPool
          *
-         * @returns true if the URIPool instance contains the same values.
+         * @return true if the URIPool instance contains the same values.
          */
         bool equals(const URIPool& other) const;
 


[3/9] activemq-cpp git commit: Fix some documentation generation issues.

Posted by ta...@apache.org.
http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicInteger.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicInteger.h b/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicInteger.h
index e0241fe..418760c 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicInteger.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicInteger.h
@@ -61,7 +61,7 @@ namespace atomic {
 
         /**
          * Gets the current value.
-         * @returns the current value.
+         * @return the current value.
          */
         int get() const {
             return this->value;
@@ -78,7 +78,7 @@ namespace atomic {
         /**
          * Atomically sets to the given value and returns the old value.
          * @param newValue - the new value.
-         * @returns the previous value.
+         * @return the previous value.
          */
         int getAndSet( int newValue );
 
@@ -88,52 +88,52 @@ namespace atomic {
          *
          * @param expect - the expected value
          * @param update - the new value
-         * @returns true if successful. False return indicates that the actual
+         * @return true if successful. False return indicates that the actual
          * value was not equal to the expected value.
          */
         bool compareAndSet( int expect, int update );
 
         /**
          * Atomically increments by one the current value.
-         * @returns the previous value.
+         * @return the previous value.
          */
         int getAndIncrement();
 
         /**
          * Atomically decrements by one the current value.
-         * @returns the previous value.
+         * @return the previous value.
          */
         int getAndDecrement();
 
         /**
          * Atomically adds the given value to the current value.
          * @param delta - The value to add.
-         * @returns the previous value.
+         * @return the previous value.
          */
         int getAndAdd( int delta );
 
         /**
          * Atomically increments by one the current value.
-         * @returns the updated value.
+         * @return the updated value.
          */
         int incrementAndGet();
 
         /**
          * Atomically decrements by one the current value.
-         * @returns the updated value.
+         * @return the updated value.
          */
         int decrementAndGet();
 
         /**
          * Atomically adds the given value to the current value.
          * @param delta - the value to add.
-         * @returns the updated value.
+         * @return the updated value.
          */
         int addAndGet( int delta );
 
         /**
          * Returns the String representation of the current value.
-         * @returns the String representation of the current value.
+         * @return the String representation of the current value.
          */
         std::string toString() const;
 
@@ -141,7 +141,7 @@ namespace atomic {
          * Description copied from class: Number
          * Returns the value of the specified number as an int. This may involve
          * rounding or truncation.
-         * @returns the numeric value represented by this object after conversion
+         * @return the numeric value represented by this object after conversion
          * to type int.
          */
         int intValue() const;
@@ -150,7 +150,7 @@ namespace atomic {
          * Description copied from class: Number
          * Returns the value of the specified number as a long. This may involve
          * rounding or truncation.
-         * @returns the numeric value represented by this object after conversion
+         * @return the numeric value represented by this object after conversion
          * to type long long.
          */
         long long longValue() const;
@@ -159,7 +159,7 @@ namespace atomic {
          * Description copied from class: Number
          * Returns the value of the specified number as a float. This may involve
          * rounding.
-         * @returns the numeric value represented by this object after conversion
+         * @return the numeric value represented by this object after conversion
          * to type float.
          */
         float floatValue() const;
@@ -168,7 +168,7 @@ namespace atomic {
          * Description copied from class: Number
          * Returns the value of the specified number as a double. This may
          * involve rounding.
-         * @returns the numeric value represented by this object after conversion
+         * @return the numeric value represented by this object after conversion
          * to type double.
          */
         double doubleValue() const;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicReference.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicReference.h b/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicReference.h
index e45f62e..78f49e0 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicReference.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicReference.h
@@ -93,7 +93,7 @@ namespace atomic {
 
         /**
          * Returns the String representation of the current value.
-         * @returns string representation of the current value.
+         * @return string representation of the current value.
          */
         std::string toString() const {
             return decaf::lang::Long::toString( (long long)this->value );

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/locks/AbstractQueuedSynchronizer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/locks/AbstractQueuedSynchronizer.h b/activemq-cpp/src/main/decaf/util/concurrent/locks/AbstractQueuedSynchronizer.h
index 337c565..2fbdfa7 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/locks/AbstractQueuedSynchronizer.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/locks/AbstractQueuedSynchronizer.h
@@ -72,7 +72,7 @@ namespace locks {
             /**
              * Used to check on the ownership status of this ConditionObject
              *
-             * @returns true if the ConditionObject is owned by the given AbstractQueuedSynchronizer
+             * @return true if the ConditionObject is owned by the given AbstractQueuedSynchronizer
              */
             virtual bool isOwnedBy(const AbstractQueuedSynchronizer* sync) const = 0;
 
@@ -80,7 +80,7 @@ namespace locks {
              * Returns true if there are any waiters on this Condition object at the time
              * of its calling.
              *
-             * @returns true if there are currently waiters false otherwise.
+             * @return true if there are currently waiters false otherwise.
              */
             virtual bool hasWaiters() const = 0;
 
@@ -96,7 +96,7 @@ namespace locks {
              * Retrieves a new Collection object that contains Threads that may be waiting
              * on this Condition object.
              *
-             * @returns new Collection object that holds possible waiters. Caller owns.
+             * @return new Collection object that holds possible waiters. Caller owns.
              */
             virtual Collection<decaf::lang::Thread*>* getWaitingThreads() const = 0;
         };
@@ -154,7 +154,7 @@ namespace locks {
          * Creates and returns a new Collection object that contains only those threads that may
          * be waiting to acquire this Synchronization in exclusive mode.
          *
-         * @returns a Collection pointer that contains waiting threads for exclusive acquisition.
+         * @return a Collection pointer that contains waiting threads for exclusive acquisition.
          *          The caller owns the returned pointer.
          */
         Collection<decaf::lang::Thread*>* getExclusiveQueuedThreads() const;
@@ -163,7 +163,7 @@ namespace locks {
          * Creates and returns a new Collection object that contains only those threads that may
          * be waiting to acquire this Synchronization in shared mode.
          *
-         * @returns a Collection pointer that contains waiting threads for shared acquisition.
+         * @return a Collection pointer that contains waiting threads for shared acquisition.
          *          The caller owns the returned pointer.
          */
         Collection<decaf::lang::Thread*>* getSharedQueuedThreads() const;
@@ -172,7 +172,7 @@ namespace locks {
          * Returns the first thread queue (the thread that's been waiting the longest) if there
          * are currently no queued threads this method returns NULL.
          *
-         * @returns the first thread in the queue or NULL if none are currently waiting.
+         * @return the first thread in the queue or NULL if none are currently waiting.
          */
         decaf::lang::Thread* getFirstQueuedThread() const;
 
@@ -180,7 +180,7 @@ namespace locks {
          * Creates and returns a new Collection object that contains a best effort snapshot of the
          * threads that are currently waiting to acquire.
          *
-         * @returns a Collection pointer that contains waiting threads for lock acquisition.
+         * @return a Collection pointer that contains waiting threads for lock acquisition.
          *          The caller owns the returned pointer.
          */
         Collection<decaf::lang::Thread*>* getQueuedThreads() const;
@@ -190,7 +190,7 @@ namespace locks {
          * value changes dynamically so the result of this method can be invalid immediately after it
          * is called.
          *
-         * @returns an estimate of the number of waiting threads.
+         * @return an estimate of the number of waiting threads.
          */
         int getQueueLength() const;
 
@@ -198,7 +198,7 @@ namespace locks {
          * Creates and returns a new Collection object that contains all the threads that may be waiting
          * on the given ConditionOject instance at the time this method is called.
          *
-         * @returns a Collection pointer that contains waiting threads on given ConditionObject.
+         * @return a Collection pointer that contains waiting threads on given ConditionObject.
          *          The caller owns the returned pointer.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.
@@ -213,7 +213,7 @@ namespace locks {
          * immediately after it is called.  The ConditionObject must be associated with this
          * AbstractQueuedSynchronizer or an exception will be thrown.
          *
-         * @returns an estimate of the number of waiting threads.
+         * @return an estimate of the number of waiting threads.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.
          * @throws IllegalArgumentException if the ConditionObject is not associated with this Synchronizer.
@@ -222,12 +222,12 @@ namespace locks {
         int getWaitQueueLength(const AbstractQueuedSynchronizer::ConditionObject* condition) const;
 
         /**
-         * @returns true if there has ever been the need for the acquire method to block.
+         * @return true if there has ever been the need for the acquire method to block.
          */
         bool hasContended() const;
 
         /**
-         * @returns true if there are threads that are currently waiting to acquire.
+         * @return true if there are threads that are currently waiting to acquire.
          */
         bool hasQueuedThreads() const;
 
@@ -235,7 +235,7 @@ namespace locks {
          * Returns true if there are any threads that are currently waiting on the given ConditionObject,
          * the condition must be associated with this synchronizer instance.
          *
-         * @returns true if the condition object has waiting threads.
+         * @return true if the condition object has waiting threads.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.
          * @throws IllegalArgumentException if the ConditionObject is not associated with this Synchronizer.
@@ -246,7 +246,7 @@ namespace locks {
         /**
          * Traverse the Queue if waiting threads to see if the given thread is present.
          *
-         * @returns true if the given thread is in the wait Queue.
+         * @return true if the given thread is in the wait Queue.
          *
          * @throws NullPointerException if the thread pointer is NULL.
          */
@@ -255,7 +255,7 @@ namespace locks {
         /**
          * Checks whether the given ConditionObject uses this Synchronizer as its lock object.
          *
-         * @returns true if the ConditionObject uses this Synchronizer as its lock.
+         * @return true if the ConditionObject uses this Synchronizer as its lock.
          *
          * @throws NullPointerException if the condition pointer is NULL.
          */
@@ -291,7 +291,7 @@ namespace locks {
          * and also contains the indicators "nonempty" or "empty" based on whether the thread queue
          * is empty or not.
          *
-         * @returns a string value that identifies this AbstractQueuedSynchronizer.
+         * @return a string value that identifies this AbstractQueuedSynchronizer.
          */
         std::string toString() const;
 
@@ -305,7 +305,7 @@ namespace locks {
          * @param nanos
          *      Time in nanoseconds to wait before reporting the acquisition as failed.
          *
-         * @returns true if the acquire succeeded, false otherwise.
+         * @return true if the acquire succeeded, false otherwise.
          *
          * @throws InterruptedException if the calling thread is interrupted.
          */
@@ -321,7 +321,7 @@ namespace locks {
          * @param nanos
          *      Time in nanoseconds to wait before reporting the acquisition as failed.
          *
-         * @returns true if the acquire succeeded, false otherwise.
+         * @return true if the acquire succeeded, false otherwise.
          *
          * @throws InterruptedException if the calling thread is interrupted.
          */
@@ -332,7 +332,7 @@ namespace locks {
         /**
          * Gets and returns the currently set value of this object Synchronization sate.
          *
-         * @returns the value of the synchronization sate.
+         * @return the value of the synchronization sate.
          */
         virtual int getState() const;
 
@@ -353,7 +353,7 @@ namespace locks {
          * @param update
          *      The new value to assign the state if the current value matches the expected.
          *
-         * @returns true if a change is made, false otherwise.
+         * @return true if a change is made, false otherwise.
          */
         virtual bool compareAndSetState(int expect, int update);
 
@@ -382,7 +382,7 @@ namespace locks {
          * @param arg
          *      The value passed to the acquire method.
          *
-         * @returns true if the acquire succeeded, false otherwise.
+         * @return true if the acquire succeeded, false otherwise.
          *
          * @throws IllegalMonitorStateException if the acquire places the object in an invalid state.
          * @throws UnsupportedOperationException if exclusive mode is not supported.
@@ -421,7 +421,7 @@ namespace locks {
          * @param arg
          *      The value that was passed to the release method.
          *
-         * @returns true if the synchronization is now fully released such that waiting threads can
+         * @return true if the synchronization is now fully released such that waiting threads can
          *          now attempt to acquire it, false if not fully released.
          *
          * @throws IllegalMonitorStateException if the release places the object in an invalid state.
@@ -438,7 +438,7 @@ namespace locks {
          * @param arg
          *      The value that was passed to the release method.
          *
-         * @returns true if the synchronization is now fully released such that waiting threads can
+         * @return true if the synchronization is now fully released such that waiting threads can
          *          now attempt to acquire it, false if not fully released.
          *
          * @throws IllegalMonitorStateException if the release places the object in an invalid state.
@@ -451,7 +451,7 @@ namespace locks {
          * logic implemented inside this class.  Can be overridden by derived classes that wish to
          * provide their own implementation of a ConditionObject.
          *
-         * @returns a new ConditionObject that is owned by the caller.
+         * @return a new ConditionObject that is owned by the caller.
          */
         virtual ConditionObject* createDefaultConditionObject();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h b/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h
index 3d21a38..926a95e 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/locks/Condition.h
@@ -285,7 +285,7 @@ namespace locks {
          *
          * @param nanosTimeout - the maximum time to wait, in nanoseconds
          *
-         * @returns an estimate of the nanosTimeout value minus the time spent waiting upon
+         * @return an estimate of the nanosTimeout value minus the time spent waiting upon
          *          return from this method. A positive value may be used as the argument to
          *          a subsequent call to this method to finish waiting out the desired time.
          *          A value less than or equal to zero indicates that no time remains.
@@ -311,7 +311,7 @@ namespace locks {
          * @param time - the maximum time to wait
          * @param unit - the time unit of the time argument
          *
-         * @returns false if the waiting time detectably elapsed before return from the
+         * @return false if the waiting time detectably elapsed before return from the
          *          method, else true
          *
          * @throws RuntimeException
@@ -383,7 +383,7 @@ namespace locks {
          *
          * @param deadline - the absolute time to wait until
          *
-         * @returns false if the deadline has elapsed upon return, else true
+         * @return false if the deadline has elapsed upon return, else true
          *
          * @throws RuntimeException
          *         if an unexpected error occurs while trying to wait on the Condition.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h b/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h
index 75c71f8..861bd37 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/locks/Lock.h
@@ -182,7 +182,7 @@ namespace locks {
          * This usage ensures that the lock is unlocked if it was acquired, and doesn't
          * try to unlock if the lock was not acquired.
          *
-         * @returns true if the lock was acquired and false otherwise
+         * @return true if the lock was acquired and false otherwise
          *
          * @throws RuntimeException if an error occurs while acquiring the lock.
          */
@@ -235,7 +235,7 @@ namespace locks {
          * @param unit
          *        the time unit of the time argument
          *
-         * @returns true if the lock was acquired and false if the waiting time elapsed
+         * @return true if the lock was acquired and false if the waiting time elapsed
          *          before the lock was acquired
          *
          * @throws RuntimeException if an error occurs while acquiring the lock.
@@ -272,7 +272,7 @@ namespace locks {
          * The exact operation of the Condition instance depends on the Lock implementation
          * and must be documented by that implementation.
          *
-         * @returns A new Condition instance for this Lock instance the caller must
+         * @return A new Condition instance for this Lock instance the caller must
          *          delete the returned Condition object when done with it.
          *
          * @throws RuntimeException if an error occurs while creating the Condition.
@@ -282,7 +282,7 @@ namespace locks {
         virtual Condition* newCondition() = 0;
 
         /**
-         * @returns a string representation of the Lock useful for debugging purposes.
+         * @return a string representation of the Lock useful for debugging purposes.
          */
         virtual std::string toString() const = 0;
     };

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h b/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h
index 1834d3c..d40e4b2 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/locks/ReadWriteLock.h
@@ -94,13 +94,13 @@ namespace locks {
 
         /**
          * Returns the lock used for reading.
-         * @returns the lock used for reading.
+         * @return the lock used for reading.
          */
         virtual Lock& readLock() = 0;
 
         /**
          * Returns the lock used for writing.
-         * @returns the lock used for writing.
+         * @return the lock used for writing.
          */
         virtual Lock& writeLock() = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantLock.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantLock.h b/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantLock.h
index 6546dcf..b8fbd2e 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantLock.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantLock.h
@@ -174,7 +174,7 @@ namespace locks {
          * If the lock is held by another thread then this method will return immediately with the
          * value false.
          *
-         * @returns true if the lock was acquired and false otherwise
+         * @return true if the lock was acquired and false otherwise
          *
          * @throws RuntimeException if an error occurs while acquiring the lock.
          */
@@ -223,7 +223,7 @@ namespace locks {
          * @param unit
          *        the time unit of the time argument
          *
-         * @returns true if the lock was acquired and false if the waiting time elapsed
+         * @return true if the lock was acquired and false if the waiting time elapsed
          *          before the lock was acquired
          *
          * @throws RuntimeException if an error occurs while acquiring the lock.
@@ -298,7 +298,7 @@ namespace locks {
          *        }
          *    }
          *
-         * @returns the number of holds on this lock by the current thread, or zero if this lock
+         * @return the number of holds on this lock by the current thread, or zero if this lock
          *          is not held by the current thread
          */
         int getHoldCount() const;
@@ -341,7 +341,7 @@ namespace locks {
          *     }
          *   }
          *
-         * @returns true if current thread holds this lock and false otherwise
+         * @return true if current thread holds this lock and false otherwise
          */
         bool isHeldByCurrentThread() const;
 
@@ -349,14 +349,14 @@ namespace locks {
          * Queries if this lock is held by any thread. This method is designed for use in
          * monitoring of the system state, not for synchronization control.
          *
-         * @returns true if any thread holds this lock and false otherwise
+         * @return true if any thread holds this lock and false otherwise
          */
         bool isLocked() const;
 
         /**
          * Returns true if this lock has fairness set true.
          *
-         * @returns true if this lock has fairness set true
+         * @return true if this lock has fairness set true
          */
         bool isFair() const;
 
@@ -365,7 +365,7 @@ namespace locks {
          * brackets, includes either the String "Unlocked" or the String "Locked by" followed
          * by the name of the owning thread.
          *
-         * @returns a string identifying this lock, as well as its lock state
+         * @return a string identifying this lock, as well as its lock state
          */
         std::string toString() const;
 
@@ -374,7 +374,7 @@ namespace locks {
          * value changes dynamically so the result of this method can be invalid immediately after it
          * is called.
          *
-         * @returns an estimate of the number of waiting threads.
+         * @return an estimate of the number of waiting threads.
          */
         int getQueueLength() const;
 
@@ -384,7 +384,7 @@ namespace locks {
          * immediately after it is called.  The Condition object must be associated with this Lock
          * or an exception will be thrown.
          *
-         * @returns an estimate of the number of waiting threads.
+         * @return an estimate of the number of waiting threads.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.
          * @throws IllegalArgumentException if the ConditionObject is not associated with this Synchronizer.
@@ -396,7 +396,7 @@ namespace locks {
          * Returns true if there are any threads that are currently waiting on the given Condition object,
          * the condition must be associated with this Lock instance.
          *
-         * @returns true if the condition object has waiting threads.
+         * @return true if the condition object has waiting threads.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.
          * @throws IllegalArgumentException if the ConditionObject is not associated with this Lock.
@@ -405,12 +405,12 @@ namespace locks {
         bool hasWaiters(Condition* condition) const;
 
         /**
-         * @returns true if there are threads that are currently waiting to acquire this Lock.
+         * @return true if there are threads that are currently waiting to acquire this Lock.
          */
         bool hasQueuedThreads() const;
 
         /**
-         * @returns true if the given Thread is waiting to acquire this Lock object.  Because of cancellations
+         * @return true if the given Thread is waiting to acquire this Lock object.  Because of cancellations
          *          this method can return true but the given Thread is not in the Queue afterwards.
          *
          * @throws NullPointerException if the given thread is NULL.
@@ -423,7 +423,7 @@ namespace locks {
          * Creates and returns a new Collection object that contains all the threads that may be waiting
          * on the given Condition object instance at the time this method is called.
          *
-         * @returns a Collection pointer that contains waiting threads on given Condition object.
+         * @return a Collection pointer that contains waiting threads on given Condition object.
          *          The caller owns the returned pointer.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.
@@ -448,7 +448,7 @@ namespace locks {
          * Creates and returns a new Collection object that contains a best effort snapshot of the
          * threads that are currently waiting to acquire.
          *
-         * @returns a Collection pointer that contains waiting threads for lock acquisition.
+         * @return a Collection pointer that contains waiting threads for lock acquisition.
          *          The caller owns the returned pointer.
          */
         decaf::util::Collection<decaf::lang::Thread*>* getQueuedThreads() const;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantReadWriteLock.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantReadWriteLock.h b/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantReadWriteLock.h
index 096466e..92b67b8 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantReadWriteLock.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/locks/ReentrantReadWriteLock.h
@@ -77,7 +77,7 @@ namespace locks {
         /**
          * Returns true if this lock has fairness set true.
          *
-         * @returns true if the Lock uses a fair policy otherwise false.
+         * @return true if the Lock uses a fair policy otherwise false.
          */
         bool isFair() const;
 
@@ -147,7 +147,7 @@ namespace locks {
          * immediately after it is called.  The Condition object must be associated with this Lock
          * or an exception will be thrown.
          *
-         * @returns an estimate of the number of waiting threads.
+         * @return an estimate of the number of waiting threads.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.
          * @throws IllegalArgumentException if the ConditionObject is not associated with this Synchronizer.
@@ -207,7 +207,7 @@ namespace locks {
          * Creates and returns a new Collection object that contains all the threads that may be waiting
          * on the given Condition object instance at the time this method is called.
          *
-         * @returns a Collection pointer that contains waiting threads on given Condition object.
+         * @return a Collection pointer that contains waiting threads on given Condition object.
          *          The caller owns the returned pointer.
          *
          * @throws NullPointerException if the ConditionObject pointer is NULL.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/logging/Filter.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/logging/Filter.h b/activemq-cpp/src/main/decaf/util/logging/Filter.h
index c1132b8..24b2592 100644
--- a/activemq-cpp/src/main/decaf/util/logging/Filter.h
+++ b/activemq-cpp/src/main/decaf/util/logging/Filter.h
@@ -40,7 +40,7 @@ namespace logging{
         /**
          * Check if a given log record should be published.
          * @param record the <code>LogRecord</code> to check.
-         * @returns true if the record is loggable.
+         * @return true if the record is loggable.
          */
         virtual bool isLoggable( const LogRecord& record ) const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/logging/Formatter.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/logging/Formatter.h b/activemq-cpp/src/main/decaf/util/logging/Formatter.h
index 0ff79dd..b99654d 100644
--- a/activemq-cpp/src/main/decaf/util/logging/Formatter.h
+++ b/activemq-cpp/src/main/decaf/util/logging/Formatter.h
@@ -42,14 +42,14 @@ namespace logging{
         /**
          * Format the given log record and return the formatted string.
          * @param record The Log Record to Format
-         * @returns the formatted record.
+         * @return the formatted record.
          */
         virtual std::string format( const LogRecord& record ) const = 0;
 
         /**
          * Format the message string from a log record.
          * @param record The Log Record to Format
-         * @returns the formatted message
+         * @return the formatted message
          */
         virtual std::string formatMessage( const LogRecord& record ) const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/logging/Handler.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/logging/Handler.h b/activemq-cpp/src/main/decaf/util/logging/Handler.h
index 2bde16e..44f2d35 100644
--- a/activemq-cpp/src/main/decaf/util/logging/Handler.h
+++ b/activemq-cpp/src/main/decaf/util/logging/Handler.h
@@ -112,7 +112,7 @@ namespace logging{
 
         /**
          * Gets the Filter that this Handler uses to filter Log Records
-         * @returns <code>Filter</code> derived instance
+         * @return <code>Filter</code> derived instance
          */
         virtual Filter* getFilter() {
             return this->filter;
@@ -133,7 +133,7 @@ namespace logging{
         /**
          * Get the log level specifying which message levels will be logged
          * by this Handler.
-         * @returns Level enumeration value
+         * @return Level enumeration value
          */
         virtual Level getLevel() {
             return this->level;
@@ -150,7 +150,7 @@ namespace logging{
 
         /**
          * Gets the <code>Formatter</code> used by this Handler
-         * @returns <code>Filter</code> derived instance
+         * @return <code>Filter</code> derived instance
          */
         virtual Formatter* getFormatter() {
             return this->formatter;
@@ -168,7 +168,7 @@ namespace logging{
 
         /**
          * Gets the <code>ErrorManager</code> used by this Handler.
-         * @returns <code>ErrorManager</code> derived pointer or NULL.
+         * @return <code>ErrorManager</code> derived pointer or NULL.
          */
         virtual ErrorManager* getErrorManager() {
             return this->errorManager;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/logging/LogManager.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/logging/LogManager.h b/activemq-cpp/src/main/decaf/util/logging/LogManager.h
index 22afaad..21a94b3 100644
--- a/activemq-cpp/src/main/decaf/util/logging/LogManager.h
+++ b/activemq-cpp/src/main/decaf/util/logging/LogManager.h
@@ -203,7 +203,7 @@ namespace logging{
         /**
          * Gets a reference to the Logging Properties used by this
          * logger.
-         * @returns The Logger Properties Pointer
+         * @return The Logger Properties Pointer
          */
         const util::Properties& getProperties() const {
             return properties;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/logging/Logger.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/logging/Logger.h b/activemq-cpp/src/main/decaf/util/logging/Logger.h
index a387f09..e0411a3 100644
--- a/activemq-cpp/src/main/decaf/util/logging/Logger.h
+++ b/activemq-cpp/src/main/decaf/util/logging/Logger.h
@@ -190,7 +190,7 @@ namespace logging{
         /**
          * Gets a vector containing all the handlers that this class
          * has been assigned to use.
-         * @returns a list of handlers that are used by this logger
+         * @return a list of handlers that are used by this logger
          */
         const std::list<Handler*>& getHandlers() const;
 
@@ -490,7 +490,7 @@ namespace logging{
          * by this logger. This check is based on the Loggers effective
          * level, which may be inherited from its parent.
          * @param level - a message logging level
-         * @returns true if the given message level is currently being logged.
+         * @return true if the given message level is currently being logged.
          */
         virtual bool isLoggable( const Level& level ) const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/zip/Adler32.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Adler32.h b/activemq-cpp/src/main/decaf/util/zip/Adler32.h
index 1d8d2fe..677c827 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Adler32.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Adler32.h
@@ -43,7 +43,7 @@ namespace zip {
         virtual ~Adler32();
 
         /**
-         * @returns the current checksum value.
+         * @return the current checksum value.
          */
         virtual long long getValue() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h b/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
index 870ddf8..f6da719 100644
--- a/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
+++ b/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
@@ -63,7 +63,7 @@ namespace zip {
         virtual ~CheckedOutputStream();
 
         /**
-         * @returns a pointer to the Checksum instance in use by this object.
+         * @return a pointer to the Checksum instance in use by this object.
          */
         Checksum* getChecksum() const {
             return this->sum;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/zip/Checksum.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Checksum.h b/activemq-cpp/src/main/decaf/util/zip/Checksum.h
index 0cb0d2a..109a4f7 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Checksum.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Checksum.h
@@ -40,7 +40,7 @@ namespace zip {
         virtual ~Checksum();
 
         /**
-         * @returns the current checksum value.
+         * @return the current checksum value.
          */
         virtual long long getValue() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/zip/Deflater.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Deflater.h b/activemq-cpp/src/main/decaf/util/zip/Deflater.h
index 6e0b59e..22cb556 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Deflater.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Deflater.h
@@ -277,7 +277,7 @@ namespace zip {
          * @param length
          *      The maximum number of byte of data to write.
          *
-         * @returns the actual number of bytes of compressed data.
+         * @return the actual number of bytes of compressed data.
          *
          * @throws NullPointerException if buffer is NULL.
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
@@ -297,7 +297,7 @@ namespace zip {
          * @param length
          *      The maximum number of byte of data to write.
          *
-         * @returns the actual number of bytes of compressed data.
+         * @return the actual number of bytes of compressed data.
          *
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
@@ -312,21 +312,21 @@ namespace zip {
          * @param buffer
          *      The Buffer to write the compressed data to.
          *
-         * @returns the actual number of bytes of compressed data.
+         * @return the actual number of bytes of compressed data.
          *
          * @throws IllegalStateException if in the end state.
          */
         int deflate(std::vector<unsigned char>& buffer);
 
         /**
-         * @returns the ADLER-32 value of the uncompressed data.
+         * @return the ADLER-32 value of the uncompressed data.
          *
          * @throws IllegalStateException if in the end state.
          */
         long long getAdler() const;
 
         /**
-         * @returns the total number of uncompressed bytes input so far.
+         * @return the total number of uncompressed bytes input so far.
          *
          * @throws IllegalStateException if in the end state.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/zip/Inflater.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Inflater.h b/activemq-cpp/src/main/decaf/util/zip/Inflater.h
index 31e0262..d1ca564 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Inflater.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Inflater.h
@@ -132,7 +132,7 @@ namespace zip {
          * Returns the total number of bytes remaining in the input buffer. This can be used to
          * find out what bytes still remain in the input buffer after decompression has finished.
          *
-         * @returns the total number of bytes remaining in the input buffer
+         * @return the total number of bytes remaining in the input buffer
          */
         int getRemaining() const;
 
@@ -201,7 +201,7 @@ namespace zip {
         bool needsInput() const;
 
         /**
-         * @returns true if a preset dictionary is needed for decompression.
+         * @return true if a preset dictionary is needed for decompression.
          */
         bool needsDictionary() const;
 
@@ -272,14 +272,14 @@ namespace zip {
         int inflate(std::vector<unsigned char>& buffer);
 
         /**
-         * @returns the ADLER-32 value of the uncompressed data.
+         * @return the ADLER-32 value of the uncompressed data.
          *
          * @throws IllegalStateException if in the end state.
          */
         long long getAdler() const;
 
         /**
-         * @returns the total number of compressed bytes input so far.
+         * @return the total number of compressed bytes input so far.
          *
          * @throws IllegalStateException if in the end state.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/test-benchmarks/benchmark/PerformanceTimer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/test-benchmarks/benchmark/PerformanceTimer.h b/activemq-cpp/src/test-benchmarks/benchmark/PerformanceTimer.h
index edeafd2..00dc8b8 100644
--- a/activemq-cpp/src/test-benchmarks/benchmark/PerformanceTimer.h
+++ b/activemq-cpp/src/test-benchmarks/benchmark/PerformanceTimer.h
@@ -61,7 +61,7 @@ namespace benchmark{
 
         /**
          * Gets the number of runs made so far
-         * @returns unsigned int that counts the number of runs
+         * @return unsigned int that counts the number of runs
          */
         long long getNumberOfRuns() const {
             return numberOfRuns;
@@ -70,7 +70,7 @@ namespace benchmark{
         /**
          * Gets the overall average time that the count has recoreded
          * for all start / stop cycles.
-         * @returns the average time for all the runs times / numberOfRuns
+         * @return the average time for all the runs times / numberOfRuns
          */
         long long getAverageTime() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/test-integration/activemq/test/CMSTestFixture.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/test-integration/activemq/test/CMSTestFixture.h b/activemq-cpp/src/test-integration/activemq/test/CMSTestFixture.h
index f128f55..57e8c96 100644
--- a/activemq-cpp/src/test-integration/activemq/test/CMSTestFixture.h
+++ b/activemq-cpp/src/test-integration/activemq/test/CMSTestFixture.h
@@ -47,7 +47,7 @@ namespace test {
         /**
          * Return the URL for the Broker that is customized for the
          * test in question.
-         * @returns the BrokerURL string for this test.
+         * @return the BrokerURL string for this test.
          */
         virtual std::string getBrokerURL() const = 0;
 


[4/9] activemq-cpp git commit: Fix some documentation generation issues.

Posted by ta...@apache.org.
http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/IntBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/IntBuffer.h b/activemq-cpp/src/main/decaf/nio/IntBuffer.h
index b03cd93..096e5ab 100644
--- a/activemq-cpp/src/main/decaf/nio/IntBuffer.h
+++ b/activemq-cpp/src/main/decaf/nio/IntBuffer.h
@@ -68,7 +68,7 @@ namespace nio{
         virtual ~IntBuffer() {}
 
         /**
-         * @returns a std::string describing this object
+         * @return a std::string describing this object
          */
         virtual std::string toString() const;
 
@@ -81,7 +81,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns the array that backs this Buffer.
+         * @return the array that backs this Buffer.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -95,7 +95,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns The offset into the backing array where index zero starts.
+         * @return The offset into the backing array where index zero starts.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -135,7 +135,7 @@ namespace nio{
          * zero, so that an invocation of this method can be followed immediately by
          * an invocation of another relative put method.
          *
-         * @returns a reference to this IntBuffer
+         * @return a reference to this IntBuffer
          *
          * @throws ReadOnlyBufferException if this buffer is read-only.
          */
@@ -152,7 +152,7 @@ namespace nio{
          * to those of this buffer. The new buffer will be read-only if, and only if,
          * this buffer is read-only.
          *
-         * @returns a new int Buffer which the caller owns.
+         * @return a new int Buffer which the caller owns.
          */
         virtual IntBuffer* duplicate() = 0;
 
@@ -160,7 +160,7 @@ namespace nio{
          * Relative get method. Reads the value at this buffer's current position,
          * and then increments the position.
          *
-         * @returns the int at the current position.
+         * @return the int at the current position.
          *
          * @throws BufferUnderflowException if there no more data to return.
          */
@@ -172,7 +172,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the int is to be read.
          *
-         * @returns the int that is located at the given index.
+         * @return the int that is located at the given index.
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit, or index is negative.
@@ -188,7 +188,7 @@ namespace nio{
          * amount of data that is to be read, that is to say, the caller should call
          * buffer.resize( N ) before calling this get method.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length ints
          *         remaining in this buffer.
@@ -216,7 +216,7 @@ namespace nio{
          * @param length
          *      The amount of data to put in the passed buffer.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length ints
          *         remaining in this buffer.
@@ -232,7 +232,7 @@ namespace nio{
          * be invoked.  Subclasses should override this method if they do not have a
          * backing array as this class always returns true.
          *
-         * @returns true if, and only if, this buffer is backed by an array and is not
+         * @return true if, and only if, this buffer is backed by an array and is not
          * read-only.
          */
         virtual bool hasArray() const = 0;
@@ -250,7 +250,7 @@ namespace nio{
          * @param src
          *      The buffer to take ints from an place in this one.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this
          *         buffer for the remaining ints in the source buffer.
@@ -278,7 +278,7 @@ namespace nio{
          * @param length
          *      The number of integers to be read from the given array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -295,7 +295,7 @@ namespace nio{
          * @param buffer
          *      The buffer whose contents are copied to this IntBuffer.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -309,7 +309,7 @@ namespace nio{
          * @param value
          *      The integer value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          *         smaller than its limit.
@@ -325,7 +325,7 @@ namespace nio{
          * @param value
          *      The ints to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws IndexOutOfBoundsException - If index greater than the buffer's limit
          *         minus the size of the type being written, or the index is negative.
@@ -344,7 +344,7 @@ namespace nio{
          * number of bytes remaining in this buffer, and its mark will be undefined. The
          * new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the newly create IntBuffer which the caller owns.
+         * @return the newly create IntBuffer which the caller owns.
          */
         virtual IntBuffer* slice() const = 0;
 
@@ -382,7 +382,7 @@ namespace nio{
          * @param capacity
          *      The size of the Double buffer in integers.
          *
-         * @returns the IntBuffer that was allocated, caller owns.
+         * @return the IntBuffer that was allocated, caller owns.
          */
         static IntBuffer* allocate( int capacity );
 
@@ -404,7 +404,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new IntBuffer that is backed by buffer, caller owns.
+         * @return a new IntBuffer that is backed by buffer, caller owns.
          *
          * @throws NullPointerException if the array pointer is NULL.
          * @throws IndexOutOfBoundsException if the preconditions of size, offset, or length
@@ -425,7 +425,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been sized
          *      to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new IntBuffer that is backed by buffer, caller owns.
+         * @return a new IntBuffer that is backed by buffer, caller owns.
          */
         static IntBuffer* wrap( std::vector<int>& buffer );
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/LongBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/LongBuffer.h b/activemq-cpp/src/main/decaf/nio/LongBuffer.h
index fe1f83f..6f6df6d 100644
--- a/activemq-cpp/src/main/decaf/nio/LongBuffer.h
+++ b/activemq-cpp/src/main/decaf/nio/LongBuffer.h
@@ -68,7 +68,7 @@ namespace nio{
         virtual ~LongBuffer() {}
 
         /**
-         * @returns a std::string describing this object
+         * @return a std::string describing this object
          */
         virtual std::string toString() const;
 
@@ -81,7 +81,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns the array that backs this Buffer.
+         * @return the array that backs this Buffer.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -95,7 +95,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns The offset long longo the backing array where index zero starts.
+         * @return The offset long longo the backing array where index zero starts.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -135,7 +135,7 @@ namespace nio{
          * zero, so that an invocation of this method can be followed immediately by
          * an invocation of another relative put method.
          *
-         * @returns a reference to this LongBuffer.
+         * @return a reference to this LongBuffer.
          *
          * @throws ReadOnlyBufferException if this buffer is read-only.
          */
@@ -152,7 +152,7 @@ namespace nio{
          * to those of this buffer. The new buffer will be read-only if, and only if,
          * this buffer is read-only.
          *
-         * @returns a new long long Buffer which the caller owns.
+         * @return a new long long Buffer which the caller owns.
          */
         virtual LongBuffer* duplicate() = 0;
 
@@ -160,7 +160,7 @@ namespace nio{
          * Relative get method. Reads the value at this buffer's current position,
          * and then increments the position.
          *
-         * @returns the long long at the current position.
+         * @return the long long at the current position.
          *
          * @throws BufferUnderflowException if there no more data to return.
          */
@@ -172,7 +172,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the long long is to be read.
          *
-         * @returns the long long that is located at the given index.
+         * @return the long long that is located at the given index.
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit, or index is negative.
@@ -188,7 +188,7 @@ namespace nio{
          * amount of data that is to be read, that is to say, the caller should call
          * buffer.resize( N ) before calling this get method.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length long longs
          *         remaining in this buffer.
@@ -216,7 +216,7 @@ namespace nio{
          * @param length
          *      The amount of data to put in the passed buffer.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length long longs
          *         remaining in this buffer
@@ -232,7 +232,7 @@ namespace nio{
          * be invoked.  Subclasses should override this method if they do not have a
          * backing array as this class always returns true.
          *
-         * @returns true if, and only if, this buffer is backed by an array and is not
+         * @return true if, and only if, this buffer is backed by an array and is not
          *          read-only.
          */
         virtual bool hasArray() const = 0;
@@ -250,7 +250,7 @@ namespace nio{
          * @param src
          *      The buffer to take long longs from an place in this one.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this
          *         buffer for the remaining long longs in the source buffer
@@ -278,7 +278,7 @@ namespace nio{
          * @param length
          *      The number of long longs to be read from the given array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer
          * @throws ReadOnlyBufferException if this buffer is read-only
@@ -295,7 +295,7 @@ namespace nio{
          * @param buffer
          *      The buffer whose contents are copied to this LongBuffer.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -309,7 +309,7 @@ namespace nio{
          * @param value
          *      The long longs value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          *         smaller than its limit
@@ -325,7 +325,7 @@ namespace nio{
          * @param value
          *      The long longs to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws IndexOutOfBoundsException if index greater than the buffer's limit
          *         minus the size of the type being written.
@@ -344,7 +344,7 @@ namespace nio{
          * number of bytes remaining in this buffer, and its mark will be undefined. The
          * new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the newly create LongBuffer which the caller owns.
+         * @return the newly create LongBuffer which the caller owns.
          */
         virtual LongBuffer* slice() const = 0;
 
@@ -382,7 +382,7 @@ namespace nio{
          * @param capacity
          *      The size of the Double buffer in long longs.
          *
-         * @returns the LongBuffer that was allocated, caller owns.
+         * @return the LongBuffer that was allocated, caller owns.
          */
         static LongBuffer* allocate( int capacity );
 
@@ -404,7 +404,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new LongBuffer that is backed by buffer, caller owns.
+         * @return a new LongBuffer that is backed by buffer, caller owns.
          *
          * @throws NullPointerException if the array pointer is NULL.
          * @throws IndexOutOfBoundsException if the preconditions of size, offset, or length
@@ -425,7 +425,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been sized
          *      to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new LongBuffer that is backed by buffer, caller owns.
+         * @return a new LongBuffer that is backed by buffer, caller owns.
          */
         static LongBuffer* wrap( std::vector<long long>& buffer );
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/nio/ShortBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/nio/ShortBuffer.h b/activemq-cpp/src/main/decaf/nio/ShortBuffer.h
index 168730c..b211303 100644
--- a/activemq-cpp/src/main/decaf/nio/ShortBuffer.h
+++ b/activemq-cpp/src/main/decaf/nio/ShortBuffer.h
@@ -68,7 +68,7 @@ namespace nio{
         virtual ~ShortBuffer() {}
 
         /**
-         * @returns a std::string describing this object
+         * @return a std::string describing this object
          */
         virtual std::string toString() const;
 
@@ -81,7 +81,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns the array that backs this Buffer
+         * @return the array that backs this Buffer
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -95,7 +95,7 @@ namespace nio{
          * Invoke the hasArray method before invoking this method in order to ensure that
          * this buffer has an accessible backing array.
          *
-         * @returns The offset into the backing array where index zero starts.
+         * @return The offset into the backing array where index zero starts.
          *
          * @throws ReadOnlyBufferException if this Buffer is read only.
          * @throws UnsupportedOperationException if the underlying store has no array.
@@ -135,7 +135,7 @@ namespace nio{
          * zero, so that an invocation of this method can be followed immediately by
          * an invocation of another relative put method.
          *
-         * @returns a reference to this ShortBuffer.
+         * @return a reference to this ShortBuffer.
          *
          * @throws ReadOnlyBufferException if this buffer is read-only.
          */
@@ -152,7 +152,7 @@ namespace nio{
          * to those of this buffer. The new buffer will be read-only if, and only if,
          * this buffer is read-only.
          *
-         * @returns a new short Buffer which the caller owns.
+         * @return a new short Buffer which the caller owns.
          */
         virtual ShortBuffer* duplicate() = 0;
 
@@ -160,7 +160,7 @@ namespace nio{
          * Relative get method. Reads the value at this buffer's current position,
          * and then increments the position.
          *
-         * @returns the short at the current position.
+         * @return the short at the current position.
          *
          * @throws BufferUnderflowException if there no more data to return.
          */
@@ -172,7 +172,7 @@ namespace nio{
          * @param index
          *      The index in the Buffer where the short is to be read.
          *
-         * @returns the short that is located at the given index.
+         * @return the short that is located at the given index.
          *
          * @throws IndexOutOfBoundsException if index is not smaller than the
          *         buffer's limit, or the index is negative.
@@ -188,7 +188,7 @@ namespace nio{
          * amount of data that is to be read, that is to say, the caller should call
          * buffer.resize( N ) before calling this get method.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length shorts
          *         remaining in this buffer.
@@ -216,7 +216,7 @@ namespace nio{
          * @param length
          *      The amount of data to put in the passed buffer.
          *
-         * @returns a reference to this Buffer.
+         * @return a reference to this Buffer.
          *
          * @throws BufferUnderflowException if there are fewer than length shorts
          *         remaining in this buffer
@@ -232,7 +232,7 @@ namespace nio{
          * be invoked.  Subclasses should override this method if they do not have a
          * backing array as this class always returns true.
          *
-         * @returns true if, and only if, this buffer is backed by an array and is not
+         * @return true if, and only if, this buffer is backed by an array and is not
          *          read-only.
          */
         virtual bool hasArray() const = 0;
@@ -250,7 +250,7 @@ namespace nio{
          * @param src
          *      The buffer to take shorts from an place in this one.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this
          *         buffer for the remaining shorts in the source buffer.
@@ -278,7 +278,7 @@ namespace nio{
          * @param length
          *      The number of shorts to be read from the given array.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer
          * @throws ReadOnlyBufferException if this buffer is read-only
@@ -295,7 +295,7 @@ namespace nio{
          * @param buffer
          *      The buffer whose contents are copied to this ShortBuffer.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if there is insufficient space in this buffer.
          * @throws ReadOnlyBufferException if this buffer is read-only.
@@ -309,7 +309,7 @@ namespace nio{
          * @param value
          *      The shorts value to be written.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws BufferOverflowException if this buffer's current position is not
          *         smaller than its limit.
@@ -325,7 +325,7 @@ namespace nio{
          * @param value
          *      The shorts to write.
          *
-         * @returns a reference to this buffer.
+         * @return a reference to this buffer.
          *
          * @throws IndexOutOfBoundsException if index greater than the buffer's limit
          *         minus the size of the type being written.
@@ -344,7 +344,7 @@ namespace nio{
          * number of bytes remaining in this buffer, and its mark will be undefined. The
          * new buffer will be read-only if, and only if, this buffer is read-only.
          *
-         * @returns the newly create ShortBuffer which the caller owns.
+         * @return the newly create ShortBuffer which the caller owns.
          */
         virtual ShortBuffer* slice() const = 0;
 
@@ -382,7 +382,7 @@ namespace nio{
          * @param capacity
          *      The size of the Double buffer in shorts.
          *
-         * @returns the ShortBuffer that was allocated, caller owns.
+         * @return the ShortBuffer that was allocated, caller owns.
          */
         static ShortBuffer* allocate( int capacity );
 
@@ -404,7 +404,7 @@ namespace nio{
          * @param length
          *      The length of the subarray to be used.
          *
-         * @returns a new ShortBuffer that is backed by buffer, caller owns.
+         * @return a new ShortBuffer that is backed by buffer, caller owns.
          *
          * @throws NullPointerException if the array pointer is NULL.
          * @throws IndexOutOfBoundsException if the preconditions of size, offset, or length
@@ -425,7 +425,7 @@ namespace nio{
          *      The vector that will back the new buffer, the vector must have been
          *      sized to the desired size already by calling vector.resize( N ).
          *
-         * @returns a new ShortBuffer that is backed by buffer, caller owns.
+         * @return a new ShortBuffer that is backed by buffer, caller owns.
          */
         static ShortBuffer* wrap( std::vector<short>& buffer );
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/security/MessageDigest.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/security/MessageDigest.h b/activemq-cpp/src/main/decaf/security/MessageDigest.h
index 7df30df..47fd9c3 100644
--- a/activemq-cpp/src/main/decaf/security/MessageDigest.h
+++ b/activemq-cpp/src/main/decaf/security/MessageDigest.h
@@ -109,7 +109,7 @@ namespace security {
          * @param length
          *      The number of bytes within buf allotted for the digest.
          *
-         * @returns the number of bytes placed into buffer.
+         * @return the number of bytes placed into buffer.
          *
          * @throws DigestException if an error occurs.
          */
@@ -125,7 +125,7 @@ namespace security {
          * @param size
          *      The length in bytes of the input buffer.
          *
-         * @returns the array of bytes for the resulting hash value.
+         * @return the array of bytes for the resulting hash value.
          */
         std::vector<unsigned char> digest(const unsigned char* input, int size);
 
@@ -137,7 +137,7 @@ namespace security {
          * @param input
          *      The input to be updated before the digest is completed.
          *
-         * @returns the array of bytes for the resulting hash value.
+         * @return the array of bytes for the resulting hash value.
          */
         std::vector<unsigned char> digest(const std::vector<unsigned char>& input);
 
@@ -145,7 +145,7 @@ namespace security {
          * Returns a string that identifies the algorithm, independent of implementation
          * details. The name should be a standard name (such as "SHA", "MD5", etc).
          *
-         * @returns the algorithm name.
+         * @return the algorithm name.
          */
         std::string getAlgorithmName() const {
             return this->algorithm;
@@ -167,7 +167,7 @@ namespace security {
          * Returns the length of the digest in bytes, or 0 if this operation is not supported
          * by the provider and the implementation is not cloneable.
          *
-         * @returns the digest length in bytes, or 0 if this operation is not supported by the
+         * @return the digest length in bytes, or 0 if this operation is not supported by the
          *          provider and the implementation is not cloneable.
          */
         int getDigestLength() const;
@@ -176,7 +176,7 @@ namespace security {
          * Returns a clone of this MessageDisgest instance if the MessageDigestSpi in use
          * is cloneable.
          *
-         * @returns a clone of this MessageDigest if possible.
+         * @return a clone of this MessageDigest if possible.
          *
          * @throws CloneNotSupportedException if the SPI in use cannot be cloned.
          */
@@ -190,7 +190,7 @@ namespace security {
         /**
          * Returns a string representation of this message digest object.
          *
-         * @returns a string representation of this message digest object.
+         * @return a string representation of this message digest object.
          */
         std::string toString() const;
 
@@ -249,7 +249,7 @@ namespace security {
          * @param algorithm
          *      The name of the algorithm requested. (MD5, SHA-1, etc)
          *
-         * @returns a Message Digest object that implements the specified algorithm.
+         * @return a Message Digest object that implements the specified algorithm.
          * @throws NoSuchAlgorithmException if no Provider supports a MessageDigestSpi implementation
          *         for the specified algorithm.
          */
@@ -263,7 +263,7 @@ namespace security {
          * @param digesta
          *      The second digest for comparison.
          *
-         * @returns true if the two digests are equal.
+         * @return true if the two digests are equal.
          */
         static bool isEqual(const std::vector<unsigned char>& digesta,
                             const std::vector<unsigned char>& digestb);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/security/MessageDigestSpi.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/security/MessageDigestSpi.h b/activemq-cpp/src/main/decaf/security/MessageDigestSpi.h
index 39f5069..1966cf1 100644
--- a/activemq-cpp/src/main/decaf/security/MessageDigestSpi.h
+++ b/activemq-cpp/src/main/decaf/security/MessageDigestSpi.h
@@ -55,14 +55,14 @@ namespace security {
          * Queries the SPI implementation and returns true if the SPI can be
          * cloned.
          *
-         * @returns true if the SPI is clonable.
+         * @return true if the SPI is clonable.
          */
         virtual bool isCloneable() const;
 
         /**
          * Returns a clone if the implementation supports being cloned.
          *
-         * @returns a new pointer that is a copy of this object.
+         * @return a new pointer that is a copy of this object.
          *
          * @throws CloneNotSupportedException
          *      if this is called on an implementation that does not support cloning.
@@ -74,7 +74,7 @@ namespace security {
         /**
          * Returns the digest length in bytes.
          *
-         * @returns The digest length in bytes.
+         * @return The digest length in bytes.
          */
         virtual int engineGetDigestLength() = 0;
 
@@ -130,7 +130,7 @@ namespace security {
          * Once engineDigest has been called, the engine should be reset (see engineReset).
          * Resetting is the responsibility of the engine implementor.
          *
-         * @returns an STL vector of bytes containing the resulting hash value.
+         * @return an STL vector of bytes containing the resulting hash value.
          */
         virtual std::vector<unsigned char> engineDigest() = 0;
 
@@ -154,7 +154,7 @@ namespace security {
          *      DigestException. This parameter is ignored if its value is greater
          *      than or equal to the actual digest length.
          *
-         * @returns the length of the digest stored in the output buffer.
+         * @return the length of the digest stored in the output buffer.
          *
          * @throws DigestException if an error occurs.
          * @throws NullPointerException if the buffer pointer is NULL.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/security/ProviderService.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/security/ProviderService.h b/activemq-cpp/src/main/decaf/security/ProviderService.h
index aef58fe..418117d 100644
--- a/activemq-cpp/src/main/decaf/security/ProviderService.h
+++ b/activemq-cpp/src/main/decaf/security/ProviderService.h
@@ -77,7 +77,7 @@ namespace security {
          * security provider framework uses this method to construct implementations.
          * Applications will typically not need to call it.
          *
-         * @returns a new instance of the SecuritySpi provided by this ProviderService.
+         * @return a new instance of the SecuritySpi provided by this ProviderService.
          */
         virtual SecuritySpi* newInstance() = 0;
 
@@ -85,7 +85,7 @@ namespace security {
          * Return a String representation of this service.  The format of this string is
          * always, "type.algorithm"
          *
-         * @returns string describing this ProviderService.
+         * @return string describing this ProviderService.
          */
         std::string toString() const {
             return getType() + "." + getAlgorithm();

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/AbstractCollection.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/AbstractCollection.h b/activemq-cpp/src/main/decaf/util/AbstractCollection.h
index 6610aeb..51fa0ec 100644
--- a/activemq-cpp/src/main/decaf/util/AbstractCollection.h
+++ b/activemq-cpp/src/main/decaf/util/AbstractCollection.h
@@ -209,7 +209,7 @@ namespace util {
          *
          * This implementation returns size() == 0.
          *
-         * @returns true if the size method return 0.
+         * @return true if the size method return 0.
          */
         virtual bool isEmpty() const {
             return this->size() == 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/BitSet.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/BitSet.h b/activemq-cpp/src/main/decaf/util/BitSet.h
index 02eaf8f..cca2415 100644
--- a/activemq-cpp/src/main/decaf/util/BitSet.h
+++ b/activemq-cpp/src/main/decaf/util/BitSet.h
@@ -147,7 +147,7 @@ namespace util {
         /**
          * Returns the number of bits set to true in this BitSet.
          *
-         * @returns the number of bits set to true in this BitSet.
+         * @return the number of bits set to true in this BitSet.
          */
         int cardinality();
 
@@ -189,7 +189,7 @@ namespace util {
          *
          * must be true. The current sizes of the two bit sets are not compared.
          *
-         * @returns true if the sets are the same, false otherwise.
+         * @return true if the sets are the same, false otherwise.
          */
         bool equals(const BitSet& set) const;
 
@@ -224,7 +224,7 @@ namespace util {
          * @param index
          *      The index of the bit in question.
          *
-         * @returns the value of the bit with the specified index.
+         * @return the value of the bit with the specified index.
          *
          * @throws IndexOutOfBoundsException if the index value is negative.
          */
@@ -239,7 +239,7 @@ namespace util {
          * @param toIndex
          *      The index (exclusive) to stop at.
          *
-         * @returns a new BitSet containing the specified values.
+         * @return a new BitSet containing the specified values.
          *
          * @throws IndexOutOfBoundsException if fromIndex is negative, or toIndex is negative, or
          *                                   fromIndex is larger than toIndex.
@@ -253,14 +253,14 @@ namespace util {
          * @param set
          *      BitSet to intersect with.
          *
-         * @returns boolean indicating whether this BitSet intersects the specified BitSet.
+         * @return boolean indicating whether this BitSet intersects the specified BitSet.
          */
         bool intersects(const BitSet& set) const;
 
         /**
          * Returns true if this BitSet contains no bits that are set to true.
          *
-         * @returns true if the set is empty, false otherwise.
+         * @return true if the set is empty, false otherwise.
          */
         bool isEmpty() const;
 
@@ -268,7 +268,7 @@ namespace util {
          * Returns the "logical size" of this BitSet: the index of the highest set bit in the
          * BitSet plus one. Returns zero if the BitSet contains no set bits.
          *
-         * @returns the logical size of the BitSet.
+         * @return the logical size of the BitSet.
          */
         int length() const;
 
@@ -279,7 +279,7 @@ namespace util {
          * @param index
          *      The index to start the search from (inclusive).
          *
-         * @returns the index of the next clear bit.
+         * @return the index of the next clear bit.
          *
          * @throws IndexOutOfBoundsException if the index value is negative.
          */
@@ -292,7 +292,7 @@ namespace util {
          * @param index
          *      The index to start the search from (inclusive).
          *
-         * @returns the index of the next set bit.
+         * @return the index of the next set bit.
          *
          * @throws IndexOutOfBoundsException if the index value is negative.
          */
@@ -354,7 +354,7 @@ namespace util {
          * Returns the number of bits of space actually in use by this BitSet to represent bit
          * values. The maximum element in the set is the size - 1st element.
          *
-         * @returns the number of bits currently in this bit set.
+         * @return the number of bits currently in this bit set.
          */
         int size() const;
 
@@ -365,7 +365,7 @@ namespace util {
          * ", " (a comma and a space) and surrounded by braces, resulting in the usual mathematical
          * notation for a set of integers.
          *
-         * @returns string representation of the BitSet.
+         * @return string representation of the BitSet.
          */
         std::string toString() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/Collection.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Collection.h b/activemq-cpp/src/main/decaf/util/Collection.h
index 9a8e192..34649c8 100644
--- a/activemq-cpp/src/main/decaf/util/Collection.h
+++ b/activemq-cpp/src/main/decaf/util/Collection.h
@@ -109,7 +109,7 @@ namespace util {
          * @param value
          *      The reference to the element to add to this Collection.
          *
-         * @returns true if the element was added to this Collection.
+         * @return true if the element was added to this Collection.
          *
          * @throws UnsupportedOperationExceptio if this is an unmodifiable collection.
          * @throws NullPointerException if the Collection is a container of pointers
@@ -161,7 +161,7 @@ namespace util {
          * @param value
          *      The value to check for presence in the collection.
          *
-         * @returns true if there is at least one of the elements in the collection
+         * @return true if there is at least one of the elements in the collection
          *
          * @throws NullPointerException if the Collection contains pointers and the
          *         Collection does not allow for NULL elements (optional check).
@@ -185,12 +185,12 @@ namespace util {
          * same elements, i.e. all their elements are equivalent, then it
          * returns true.
          *
-         * @returns true if the Collections contain the same elements.
+         * @return true if the Collections contain the same elements.
          */
         virtual bool equals(const Collection<E>& value) const = 0;
 
         /**
-         * @returns true if this collection contains no elements.
+         * @return true if this collection contains no elements.
          */
         virtual bool isEmpty() const = 0;
 
@@ -205,7 +205,7 @@ namespace util {
          * @param value
          *      The reference to the element to remove from this Collection.
          *
-         * @returns true if the collection was changed, false otherwise.
+         * @return true if the collection was changed, false otherwise.
          *
          * @throws UnsupportedOperationExceptio if this is an unmodifiable collection.
          * @throws NullPointerException if the Collection is a container of pointers
@@ -222,7 +222,7 @@ namespace util {
          * @param collection
          *      The Collection whose elements are to be removed from this one.
          *
-         * @returns true if the collection changed as a result of this call.
+         * @return true if the collection changed as a result of this call.
          *
          * @throws UnsupportedOperationExceptio if this is an unmodifiable collection.
          * @throws NullPointerException if the Collection is a container of pointers
@@ -239,7 +239,7 @@ namespace util {
          * @param collection
          *      The Collection whose elements are to be retained.
          *
-         * @returns true if the collection changed as a result of this call.
+         * @return true if the collection changed as a result of this call.
          *
          * @throws UnsupportedOperationExceptio if this is an unmodifiable collection.
          * @throws NullPointerException if the Collection is a container of pointers
@@ -251,7 +251,7 @@ namespace util {
          * Returns the number of elements in this collection. If this collection
          * contains more than Integer::MAX_VALUE elements, returns Integer::MAX_VALUE.
          *
-         * @returns the number of elements in this collection
+         * @return the number of elements in this collection
          */
         virtual int size() const = 0;
 
@@ -263,7 +263,7 @@ namespace util {
          *
          * This method acts as bridge between array-based and collection-based APIs.
          *
-         * @returns an array of the elements in this collection in the form of an
+         * @return an array of the elements in this collection in the form of an
          *          STL vector.
          */
         virtual std::vector<E> toArray() const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/Comparator.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Comparator.h b/activemq-cpp/src/main/decaf/util/Comparator.h
index afe980e..db90566 100644
--- a/activemq-cpp/src/main/decaf/util/Comparator.h
+++ b/activemq-cpp/src/main/decaf/util/Comparator.h
@@ -82,7 +82,7 @@ namespace util{
          * @param o2
          *      The second object to be compared
          *
-         * @returns a negative integer, zero, or a positive integer as the first
+         * @return a negative integer, zero, or a positive integer as the first
          *          argument is less than, equal to, or greater than the second.
          */
         virtual int compare(const T& o1, const T& o2) const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/Deque.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Deque.h b/activemq-cpp/src/main/decaf/util/Deque.h
index c8b035e..677c0ea 100644
--- a/activemq-cpp/src/main/decaf/util/Deque.h
+++ b/activemq-cpp/src/main/decaf/util/Deque.h
@@ -86,7 +86,7 @@ namespace util {
          * @param element
          *      The element to add to this Deque.
          *
-         * @returns true if the element was added, false otherwise.
+         * @return true if the element was added, false otherwise.
          *
          * @throws NullPointerException if the specified element is NULL and this deque is a Collection
          *         of pointers and does not permit null elements.
@@ -103,7 +103,7 @@ namespace util {
          * @param element
          *      The element to add to this Deque.
          *
-         * @returns true if the element was added, false otherwise.
+         * @return true if the element was added, false otherwise.
          *
          * @throws NullPointerException if the specified element is NULL and this deque is a Collection
          *         of pointers and does not permit null elements.
@@ -116,7 +116,7 @@ namespace util {
          * Removes the topmost element from the Deque and returns it.  Unlike the pollFirst
          * method this method throws a NuSuchElementException if the Deque is empty.
          *
-         * @returns the element at the Head of the Deque.
+         * @return the element at the Head of the Deque.
          *
          * @throws NoSuchElementException if the Deque is empty.
          */
@@ -126,7 +126,7 @@ namespace util {
          * Removes the last element from the Deque and returns it.  Unlike the pollLast
          * method this method throws a NuSuchElementException if the Deque is empty.
          *
-         * @returns the element at the Tail of the Deque.
+         * @return the element at the Tail of the Deque.
          *
          * @throws NoSuchElementException if the Deque is empty.
          */
@@ -138,7 +138,7 @@ namespace util {
          * @param element
          *      Reference to an variable that can be assigned the value of the head of this Deque.
          *
-         * @returns true if an element was available to remove, false otherwise.
+         * @return true if an element was available to remove, false otherwise.
          */
         virtual bool pollFirst(E& element) = 0;
 
@@ -148,7 +148,7 @@ namespace util {
          * @param element
          *      Reference to an variable that can be assigned the value of the tail of this Deque.
          *
-         * @returns true if an element was available to remove, false otherwise.
+         * @return true if an element was available to remove, false otherwise.
          */
         virtual bool pollLast(E& element) = 0;
 
@@ -156,7 +156,7 @@ namespace util {
          * Attempts to fetch a reference to the first element in the Deque.  This method does
          * not remove the element from the Deque but simply returns a reference to it.
          *
-         * @returns reference to the first element in the Deque.
+         * @return reference to the first element in the Deque.
          *
          * @throws NoSuchElementException if the Deque is empty.
          */
@@ -167,7 +167,7 @@ namespace util {
          * Attempts to fetch a reference to the last element in the Deque.  This method does
          * not remove the element from the Deque but simply returns a reference to it.
          *
-         * @returns reference to the last element in the Deque.
+         * @return reference to the last element in the Deque.
          *
          * @throws NoSuchElementException if the Deque is empty.
          */
@@ -180,7 +180,7 @@ namespace util {
          * call is successful it returns true.  Unlike getFirst this method does not throw an
          * exception if the Deque is empty.
          *
-         * @returns true if an element was assigned to the reference passed, false otherwise.
+         * @return true if an element was assigned to the reference passed, false otherwise.
          */
         virtual bool peekFirst(E& value) const = 0;
 
@@ -190,7 +190,7 @@ namespace util {
          * call is successful it returns true.  Unlike getLast this method does not throw an
          * exception if the Deque is empty.
          *
-         * @returns true if an element was assigned to the reference passed, false otherwise.
+         * @return true if an element was assigned to the reference passed, false otherwise.
          */
         virtual bool peekLast(E& value) const = 0;
 
@@ -201,7 +201,7 @@ namespace util {
          * @param value
          *      The value to be removed from this Deque.
          *
-         * @returns true if the Deque was modified as a result of this operation.
+         * @return true if the Deque was modified as a result of this operation.
          *
          * @throws NullPointerException if the specified element is NULL and this deque is a Collection
          *         of pointers and does not permit null elements.
@@ -215,7 +215,7 @@ namespace util {
          * @param value
          *      The value to be removed from this Deque.
          *
-         * @returns true if the Deque was modified as a result of this operation.
+         * @return true if the Deque was modified as a result of this operation.
          *
          * @throws NullPointerException if the specified element is NULL and this deque is a Collection
          *         of pointers and does not permit null elements.
@@ -257,7 +257,7 @@ namespace util {
         /**
          * Provides an Iterator over this Collection that traverses the element in reverse order.
          *
-         * @returns a new Iterator instance that moves from last to first.
+         * @return a new Iterator instance that moves from last to first.
          */
         virtual Iterator<E>* descendingIterator() = 0;
         virtual Iterator<E>* descendingIterator() const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/Iterator.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Iterator.h b/activemq-cpp/src/main/decaf/util/Iterator.h
index 1b72a69..9c50435 100644
--- a/activemq-cpp/src/main/decaf/util/Iterator.h
+++ b/activemq-cpp/src/main/decaf/util/Iterator.h
@@ -41,7 +41,7 @@ namespace util{
          * repeatedly until the hasNext() method returns false will return
          * each element in the underlying collection exactly once.
          *
-         * @returns the next element in the iteration of elements.
+         * @return the next element in the iteration of elements.
          *
          * @throws NoSuchElementException if the iteration has no more elements.
          */
@@ -52,7 +52,7 @@ namespace util{
          * the next call to next would result in an NoSuchElementException to
          * be thrown.
          *
-         * @returns true if there are more elements available for iteration.
+         * @return true if there are more elements available for iteration.
          */
         virtual bool hasNext() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/LRUCache.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/LRUCache.h b/activemq-cpp/src/main/decaf/util/LRUCache.h
index 7b4961e..6e0f672 100644
--- a/activemq-cpp/src/main/decaf/util/LRUCache.h
+++ b/activemq-cpp/src/main/decaf/util/LRUCache.h
@@ -98,7 +98,7 @@ namespace util {
         /**
          * Gets the currently configured Max Cache Size setting.
          *
-         * @returns the current max cache size value.
+         * @return the current max cache size value.
          */
         int getMaxCacheSize() const {
             return maxCacheSize;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/Map.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Map.h b/activemq-cpp/src/main/decaf/util/Map.h
index ed5acc4..e025364 100644
--- a/activemq-cpp/src/main/decaf/util/Map.h
+++ b/activemq-cpp/src/main/decaf/util/Map.h
@@ -104,7 +104,7 @@ namespace util{
          * @param source
          *      Map to compare to this one.
          *
-         * @returns true if the Map passed is equal in value to this one.
+         * @return true if the Map passed is equal in value to this one.
          */
         virtual bool equals(const Map& source) const = 0;
 
@@ -200,7 +200,7 @@ namespace util{
          * @param value
          *      The value to be set.
          *
-         * @returns true if the put operation replaced a value that was associated with
+         * @return true if the put operation replaced a value that was associated with
          *          an existing mapping to the given key or false otherwise.
          *
          * @throws UnsupportedOperationException if this map is unmodifiable.
@@ -227,7 +227,7 @@ namespace util{
          * @param oldValue (out)
          *      The value previously held in the mapping for this key.  .
          *
-         * @returns true if the put operation replaced a value that was associated with
+         * @return true if the put operation replaced a value that was associated with
          *          an existing mapping to the given key or false otherwise.
          *
          * @throws UnsupportedOperationException if this map is unmodifiable.
@@ -276,7 +276,7 @@ namespace util{
          * Iterator.remove, Set.remove, removeAll, retainAll and clear operations. It does not
          * support the add or addAll operations.
          *
-         * @returns a reference  to a Set<MapEntry<K,V>> that is backed by this Map.
+         * @return a reference  to a Set<MapEntry<K,V>> that is backed by this Map.
          */
         virtual Set< MapEntry<K,V> >& entrySet() = 0;
         virtual const Set< MapEntry<K,V> >& entrySet() const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/Properties.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Properties.h b/activemq-cpp/src/main/decaf/util/Properties.h
index c24cc9c..ae5cc53 100644
--- a/activemq-cpp/src/main/decaf/util/Properties.h
+++ b/activemq-cpp/src/main/decaf/util/Properties.h
@@ -126,7 +126,7 @@ namespace util{
          * @param value
          *      The value to be written.
          *
-         * @returns the old value of the property or empty string if not set.
+         * @return the old value of the property or empty string if not set.
          */
         std::string setProperty(const std::string& name, const std::string& value);
 
@@ -146,7 +146,7 @@ namespace util{
          * @param name
          *      The name of the property to remove.
          *
-         * @returns the previous value of the property if set, or empty string.
+         * @return the previous value of the property if set, or empty string.
          */
         std::string remove(const std::string& name);
 
@@ -155,7 +155,7 @@ namespace util{
          * in the default property list if a key of the same name has not already been found from
          * the main properties list.
          *
-         * @returns a set of keys in this property list where the key and its corresponding value are
+         * @return a set of keys in this property list where the key and its corresponding value are
          *          strings, including the keys in the default property list.
          */
         std::vector<std::string> propertyNames() const;
@@ -180,7 +180,7 @@ namespace util{
         /**
          * Clones this object.
          *
-         * @returns a replica of this object.
+         * @return a replica of this object.
          */
         Properties* clone() const;
 
@@ -206,7 +206,7 @@ namespace util{
         /**
          * Formats the contents of the Properties Object into a string that can be logged, etc.
          *
-         * @returns string value of this object.
+         * @return string value of this object.
          */
         std::string toString() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/Timer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Timer.h b/activemq-cpp/src/main/decaf/util/Timer.h
index 01a5685..ed22b8a 100644
--- a/activemq-cpp/src/main/decaf/util/Timer.h
+++ b/activemq-cpp/src/main/decaf/util/Timer.h
@@ -120,7 +120,7 @@ namespace util {
          *
          * This method can be called on a Timer object that has no scheduled tasks without error.
          *
-         * @returns the number of tasks removed from the queue.
+         * @return the number of tasks removed from the queue.
          */
         int purge();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/TimerTask.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/TimerTask.h b/activemq-cpp/src/main/decaf/util/TimerTask.h
index 888e51b..1b2abdc 100644
--- a/activemq-cpp/src/main/decaf/util/TimerTask.h
+++ b/activemq-cpp/src/main/decaf/util/TimerTask.h
@@ -71,7 +71,7 @@ namespace util {
          *
          * This method may be called repeatedly; the second and subsequent calls have no effect.
          *
-         * @returns true if this task is scheduled for one-time execution and has not yet run, or this
+         * @return true if this task is scheduled for one-time execution and has not yet run, or this
          * task is scheduled for repeated execution. Returns false if the task was scheduled for one-time
          * execution and has already run, or if the task was never scheduled, or if the task was already
          * canceled. (Loosely speaking, this method returns true if it prevents one or more scheduled
@@ -97,7 +97,7 @@ namespace util {
          * This method is typically not used in conjunction with fixed-delay execution repeating tasks, as
          * their scheduled execution times are allowed to drift over time, and so are not terribly significant.
          *
-         * @returns the time at which the most recent execution of this task was scheduled to occur, in the
+         * @return the time at which the most recent execution of this task was scheduled to occur, in the
          * format returned by Date.getTime(). The return value is undefined if the task has yet to commence its
          * first execution.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/UUID.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/UUID.h b/activemq-cpp/src/main/decaf/util/UUID.h
index 5937ccd..94a729d 100644
--- a/activemq-cpp/src/main/decaf/util/UUID.h
+++ b/activemq-cpp/src/main/decaf/util/UUID.h
@@ -167,7 +167,7 @@ namespace util {
         /**
          * Returns a Hash Code value for this UUID.
          *
-         * @returns a Hash Code for this UUID
+         * @return a Hash Code for this UUID
          */
         int hashCode() const;
 
@@ -206,17 +206,17 @@ namespace util {
          *      | "a" | "b" | "c" | "d" | "e" | "f"
          *      | "A" | "B" | "C" | "D" | "E" | "F"
          *
-         * @returns formatted string for this UUID
+         * @return formatted string for this UUID
          */
         std::string toString() const;
 
         /**
-         * @returns the most significant 64 bits of this UUID's 128 bit value.
+         * @return the most significant 64 bits of this UUID's 128 bit value.
          */
         long long getLeastSignificantBits() const;
 
         /**
-         * @returns the most significant 64 bits of this UUID's 128 bit value.
+         * @return the most significant 64 bits of this UUID's 128 bit value.
          */
         long long getMostSignificantBits() const;
 
@@ -231,7 +231,7 @@ namespace util {
          * version type 1. If this UUID is not a time-based UUID then this method
          * throws UnsupportedOperationException.
          *
-         * @returns the node value of this UUID
+         * @return the node value of this UUID
          *
          * @throws UnsupportedOperationException if this UUID version does not support this operation.
          */
@@ -248,7 +248,7 @@ namespace util {
          * version type 1. If this UUID is not a time-based UUID then this method
          * throws UnsupportedOperationException.
          *
-         * @returns the timestamp associated with a V1 UUID
+         * @return the timestamp associated with a V1 UUID
          *
          * @throws UnsupportedOperationException if this UUID version does not support this operation.
          */
@@ -265,7 +265,7 @@ namespace util {
          * has version type 1. If this UUID is not a time-based UUID then this
          * method throws UnsupportedOperationException.
          *
-         * @returns the clockSequeunce associated with a V1 UUID
+         * @return the clockSequeunce associated with a V1 UUID
          *
          * @throws UnsupportedOperationException if this UUID version does not support this operation.
          */
@@ -280,7 +280,7 @@ namespace util {
          *     * 6 Reserved, Microsoft Corporation backward compatibility
          *     * 7 Reserved for future definition
          *
-         * @returns the variant associated with a V1 UUID
+         * @return the variant associated with a V1 UUID
          *
          * @throws UnsupportedOperationException if this UUID version does not support this operation.
          */
@@ -295,7 +295,7 @@ namespace util {
          *     * 3 Name-based UUID
          *     * 4 Randomly generated UUID
          *
-         * @returns the version associated with a V1 UUID
+         * @return the version associated with a V1 UUID
          *
          * @throws UnsupportedOperationException if this UUID version does not support this operation.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/BrokenBarrierException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/BrokenBarrierException.h b/activemq-cpp/src/main/decaf/util/concurrent/BrokenBarrierException.h
index c755030..2fa3505 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/BrokenBarrierException.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/BrokenBarrierException.h
@@ -117,7 +117,7 @@ namespace concurrent{
          * to preserve the type of the original exception as well as the message.
          * All subclasses should override.
          *
-         * @returns a new instance of an exception that is a clone of this one.
+         * @return a new instance of an exception that is a clone of this one.
          */
         virtual BrokenBarrierException* clone() const{
             return new BrokenBarrierException( *this );

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/Callable.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/Callable.h b/activemq-cpp/src/main/decaf/util/concurrent/Callable.h
index 337cf92..7a65e40 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/Callable.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/Callable.h
@@ -51,7 +51,7 @@ namespace concurrent {
 
         /**
          * Computes a result, or throws an exception if unable to do so.
-         * @returns
+         * @return
          *      Computed Result.
          * @throws Exception
          *      If unable to compute a result.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h b/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h
index 4151ac2..c9df4a8 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/CancellationException.h
@@ -88,7 +88,7 @@ namespace concurrent {
          * to preserve the type of the original exception as well as the message.
          * All subclasses should override.
          *
-         * @returns a new instance of an exception that is a clone of this one.
+         * @return a new instance of an exception that is a clone of this one.
          */
         virtual CancellationException* clone() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/CopyOnWriteArrayList.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/CopyOnWriteArrayList.h b/activemq-cpp/src/main/decaf/util/concurrent/CopyOnWriteArrayList.h
index 148260b..0975cb7 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/CopyOnWriteArrayList.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/CopyOnWriteArrayList.h
@@ -781,7 +781,7 @@ namespace concurrent {
          * @param value
          *      The element to be added if not already contained in this List.
          *
-         * @returns true if the element is added to this List.
+         * @return true if the element is added to this List.
          */
         bool addIfAbsent(const E& value) {
             this->arrayLock.writeLock().lock();
@@ -816,7 +816,7 @@ namespace concurrent {
          * @param collection
          *      The collection whose elements are to be added if not already in this List.
          *
-         * @returns the number of elements that are added to this List.
+         * @return the number of elements that are added to this List.
          */
         int addAllAbsent(const Collection<E>& collection) {
 
@@ -861,7 +861,7 @@ namespace concurrent {
          * @param index
          *      The index in the list to begin the search from.
          *
-         * @returns the index in the list that matches the value given, or -1 if not found.
+         * @return the index in the list that matches the value given, or -1 if not found.
          *
          * @throws IndexOutOfBoundsException if the given index is greater than or equal to the List size.
          */
@@ -900,7 +900,7 @@ namespace concurrent {
          * @param index
          *      The index in the List to begin the search from.
          *
-         * @returns the index in the List that matches the given element or -1 if not found.
+         * @return the index in the List that matches the given element or -1 if not found.
          *
          * @throws IndexOutOfBoundsException if the given index is negative.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/CountDownLatch.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/CountDownLatch.h b/activemq-cpp/src/main/decaf/util/concurrent/CountDownLatch.h
index 9eab873..8d3ab53 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/CountDownLatch.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/CountDownLatch.h
@@ -148,7 +148,7 @@ namespace concurrent{
 
         /**
          * Gets the current count
-         * @returns int count value
+         * @return int count value
          */
         virtual int getCount() const;
 
@@ -156,7 +156,7 @@ namespace concurrent{
          * Returns the string representation of this latch, includes the current
          * count value at the time of calling.
          *
-         * @returns string describing this CountDownLatch instance.
+         * @return string describing this CountDownLatch instance.
          */
         virtual std::string toString() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/Delayed.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/Delayed.h b/activemq-cpp/src/main/decaf/util/concurrent/Delayed.h
index d7ae67e..d372fa8 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/Delayed.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/Delayed.h
@@ -45,7 +45,7 @@ namespace concurrent {
          * @param unit
          *        The time unit
          *
-         * @returns the remaining delay; zero or negative values indicate that the delay
+         * @return the remaining delay; zero or negative values indicate that the delay
          *          has already elapsed
          */
         virtual long long getDelay( const TimeUnit& unit ) = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h b/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h
index 11369fb..b4ee760 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/ExecutionException.h
@@ -88,7 +88,7 @@ namespace concurrent {
          * to preserve the type of the original exception as well as the message.
          * All subclasses should override.
          *
-         * @returns a new instance of an exception that is a clone of this one.
+         * @return a new instance of an exception that is a clone of this one.
          */
         virtual ExecutionException* clone() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/ExecutorService.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/ExecutorService.h b/activemq-cpp/src/main/decaf/util/concurrent/ExecutorService.h
index 3b2e0fd..4283674 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/ExecutorService.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/ExecutorService.h
@@ -215,7 +215,7 @@ namespace concurrent {
          * @param takeOwnership
          *      Boolean value indicating if the Executor now owns the pointer to the task.
          *
-         * @returns a new Future<?> pointer that is owned by the caller.
+         * @return a new Future<?> pointer that is owned by the caller.
          *
          * @throws RejectedExecutionException if the task cannot be scheduled for execution
          * @throws NullPointerException if the Runnable pointer passed is NULL.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/Executors.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/Executors.h b/activemq-cpp/src/main/decaf/util/concurrent/Executors.h
index 748ce15..fb34d64 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/Executors.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/Executors.h
@@ -97,7 +97,7 @@ namespace concurrent {
          * pool-N-thread-M, where N is the sequence number of this factory, and M is the
          * sequence number of the thread created by this factory.
          *
-         * @returns a new instance of the default thread factory used in Executors, the
+         * @return a new instance of the default thread factory used in Executors, the
          *          caller takes ownership of the returned pointer.
          */
         static ThreadFactory* getDefaultThreadFactory();
@@ -114,7 +114,7 @@ namespace concurrent {
          * @param nThreads
          *      The number of threads to assign as the max for the new ExecutorService.
          *
-         * @returns pointer to a new ExecutorService that is owned by the caller.
+         * @return pointer to a new ExecutorService that is owned by the caller.
          *
          * @throws IllegalArgumentException if nThreads is less than or equal to zero.
          */
@@ -135,7 +135,7 @@ namespace concurrent {
          *      Instance of a ThreadFactory that will be used by the Executor to spawn new
          *      worker threads.  This parameter cannot be NULL.
          *
-         * @returns pointer to a new ExecutorService that is owned by the caller.
+         * @return pointer to a new ExecutorService that is owned by the caller.
          *
          * @throws NullPointerException if threadFactory is NULL.
          * @throws IllegalArgumentException if nThreads is less than or equal to zero.
@@ -150,7 +150,7 @@ namespace concurrent {
          * method is owned by the caller but unlike the Executor returned from the method
          * newFixedThreadPool(1) this one cannot be reconfigurable to use more threads later on.
          *
-         * @returns a new Executor pointer that is owned by the caller.
+         * @return a new Executor pointer that is owned by the caller.
          */
         static ExecutorService* newSingleThreadExecutor();
 
@@ -166,7 +166,7 @@ namespace concurrent {
          *      Instance of a ThreadFactory that will be used by the Executor to spawn new
          *      worker threads.  This parameter cannot be NULL and ownership passes to the Executor.
          *
-         * @returns a new Executor pointer that is owned by the caller.
+         * @return a new Executor pointer that is owned by the caller.
          *
          * @throws NullPointerException if threadFactory is NULL.
          */
@@ -182,7 +182,7 @@ namespace concurrent {
          * @param executor
          *      The ExecutorService pointer to wrap and take ownership of.
          *
-         * @returns a new ExecutorService pointer that is owned by the caller.
+         * @return a new ExecutorService pointer that is owned by the caller.
          *
          * @throws NullPointerException if ExecutorService is NULL.
          */
@@ -199,7 +199,7 @@ namespace concurrent {
          * @param owns
          *      Does the callable instance own the given Runnable task pointer, default is true.
          *
-         * @returns a new Callable<E> pointer that is owned by the caller.
+         * @return a new Callable<E> pointer that is owned by the caller.
          *
          * @throws NullPointerException if the Runnable task is NULL
          */
@@ -225,7 +225,7 @@ namespace concurrent {
          * @param owns
          *      Does the callable instance own the given Runnable task pointer, default is true.
          *
-         * @returns a new Callable<E> pointer that is owned by the caller.
+         * @return a new Callable<E> pointer that is owned by the caller.
          *
          * @throws NullPointerException if the Runnable task is NULL
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/Future.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/Future.h b/activemq-cpp/src/main/decaf/util/concurrent/Future.h
index bf2dcdc..6e9c920 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/Future.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/Future.h
@@ -48,14 +48,14 @@ namespace concurrent {
          *      True if the thread executing this task should be interrupted; otherwise,
          *      in-progress tasks are allowed to complete.
          *
-         * @returns false if the task could not be canceled, typically because it has
+         * @return false if the task could not be canceled, typically because it has
          *          already completed normally; true otherwise
          */
         virtual bool cancel(bool mayInterruptIfRunning) = 0;
 
         /**
          * Returns true if this task was canceled before it completed normally.
-         * @returns true if this task was canceled before it completed
+         * @return true if this task was canceled before it completed
          */
         virtual bool isCancelled() const = 0;
 
@@ -63,7 +63,7 @@ namespace concurrent {
          * Returns true if this task completed. Completion may be due to normal termination,
          * an exception, or cancellation -- in all of these cases, this method will return
          * true.
-         * @returns true if this task completed
+         * @return true if this task completed
          */
         virtual bool isDone() const = 0;
 
@@ -93,7 +93,7 @@ namespace concurrent {
         /**
          * Waits if necessary for the computation to complete, and then retrieves its result.
          *
-         * @returns the computed result.
+         * @return the computed result.
          *
          * @throws CancellationException if the computation was canceled
          * @throws ExecutionException if the computation threw an exception
@@ -110,7 +110,7 @@ namespace concurrent {
          * @param unit
          *      The time unit of the timeout argument.
          *
-         * @returns the computed result
+         * @return the computed result
          *
          * @throws CancellationException if the computation was canceled
          * @throws ExecutionException if the computation threw an exception

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/Semaphore.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/Semaphore.h b/activemq-cpp/src/main/decaf/util/concurrent/Semaphore.h
index 97332b8..ef7de62 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/Semaphore.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/Semaphore.h
@@ -229,7 +229,7 @@ namespace concurrent {
          * though it breaks fairness. If you want to honor the fairness setting, then use
          * tryAcquire(0, TimeUnit.SECONDS) which is almost equivalent (it also detects interruption).
          *
-         * @returns true if a permit was acquired and false otherwise
+         * @return true if a permit was acquired and false otherwise
          *
          * @throw RuntimeException if an unexpected error occurs while acquiring the Semaphore.
          */
@@ -265,7 +265,7 @@ namespace concurrent {
          * @param timeout the maximum time to wait for a permit
          * @param unit the time unit of the timeout argument
          *
-         * @returns true if a permit was acquired and false if the waiting time elapsed before a permit
+         * @return true if a permit was acquired and false if the waiting time elapsed before a permit
          *          was acquired
          *
          * @throw InterruptedException if the current thread is interrupted.
@@ -361,7 +361,7 @@ namespace concurrent {
          *
          * @param permits the number of permits to acquire
          *
-         * @returns true if the permits were acquired and false otherwise.
+         * @return true if the permits were acquired and false otherwise.
          *
          * @throw IllegalArgumentException if the permits argument is negative.
          * @throw RuntimeException if an unexpected error occurs while acquiring the Semaphore.
@@ -404,7 +404,7 @@ namespace concurrent {
          * @param timeout the maximum amount of time to wait to acquire the permits.
          * @param unit the units that the timeout param represents.
          *
-         * @returns true if all permits were acquired and false if the waiting time elapsed before
+         * @return true if all permits were acquired and false if the waiting time elapsed before
          *          all permits were acquired
          *
          * @throw IllegalArgumentException if the permits argument is negative.
@@ -435,21 +435,21 @@ namespace concurrent {
          *
          * This method is typically used for debugging and testing purposes.
          *
-         * @returns the number of permits available in this semaphore
+         * @return the number of permits available in this semaphore
          */
         int availablePermits() const;
 
         /**
          * Acquires and returns all permits that are immediately available.
          *
-         * @returns the number of permits acquired
+         * @return the number of permits acquired
          *
          * @throw RuntimeException if an unexpected error occurs while draining the Semaphore.
          */
         int drainPermits();
 
         /**
-         * @returns true if this semaphore has fairness set true
+         * @return true if this semaphore has fairness set true
          */
         bool isFair() const;
 
@@ -457,7 +457,7 @@ namespace concurrent {
          * Returns a string identifying this semaphore, as well as its state. The state, in
          * brackets, includes the String "Permits =" followed by the number of permits.
          *
-         * @returns a string identifying this semaphore, as well as its state
+         * @return a string identifying this semaphore, as well as its state
          */
         std::string toString() const;
 
@@ -466,12 +466,12 @@ namespace concurrent {
          * value changes dynamically so the result of this method can be invalid immediately after it
          * is called.
          *
-         * @returns an estimate of the number of waiting threads.
+         * @return an estimate of the number of waiting threads.
          */
         int getQueueLength() const;
 
         /**
-         * @returns true if there are threads that are currently waiting to acquire this Semaphore.
+         * @return true if there are threads that are currently waiting to acquire this Semaphore.
          */
         bool hasQueuedThreads() const;
 
@@ -494,7 +494,7 @@ namespace concurrent {
          * Creates and returns a new Collection object that contains a best effort snapshot of the
          * threads that are currently waiting to acquire.
          *
-         * @returns a Collection pointer that contains waiting threads for lock acquisition.
+         * @return a Collection pointer that contains waiting threads for lock acquisition.
          *          The caller owns the returned pointer.
          */
         decaf::util::Collection<decaf::lang::Thread*>* getQueuedThreads() const;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/ThreadFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/ThreadFactory.h b/activemq-cpp/src/main/decaf/util/concurrent/ThreadFactory.h
index 7f3cf43..fc21144 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/ThreadFactory.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/ThreadFactory.h
@@ -63,7 +63,7 @@ namespace concurrent {
          * @param r
          *      A pointer to a Runnable instance to be executed by new Thread instance returned.
          *
-         * @returns constructed thread, or NULL if the request to create a thread is rejected
+         * @return constructed thread, or NULL if the request to create a thread is rejected
          *          the caller owns the returned pointer.
          */
         virtual decaf::lang::Thread* newThread(decaf::lang::Runnable* r) = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/ThreadPoolExecutor.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/ThreadPoolExecutor.h b/activemq-cpp/src/main/decaf/util/concurrent/ThreadPoolExecutor.h
index e77465e..c20d4f1 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/ThreadPoolExecutor.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/ThreadPoolExecutor.h
@@ -311,7 +311,7 @@ namespace concurrent{
          * for debugging and monitoring, care should be taken when using this method.  The executor
          * continues to execute tasks from the Queue.
          *
-         * @returns a pointer to the blocking queue that this executor stores future tasks in.
+         * @return a pointer to the blocking queue that this executor stores future tasks in.
          */
         virtual BlockingQueue<decaf::lang::Runnable*>* getQueue();
 
@@ -346,7 +346,7 @@ namespace concurrent{
          * that are not core threads continue to time out using the set keep alive value
          * regardless of whether this option is enabled.
          *
-         * @returns true if core threads can timeout when idle.
+         * @return true if core threads can timeout when idle.
          */
         virtual bool allowsCoreThreadTimeout() const;
 
@@ -357,7 +357,7 @@ namespace concurrent{
          * @param unit
          *      The unit of time to return the results in.
          *
-         * @returns the configure keep alive time in the requested time units.
+         * @return the configure keep alive time in the requested time units.
          */
         virtual long long getKeepAliveTime(const TimeUnit& unit) const;
 
@@ -393,14 +393,14 @@ namespace concurrent{
          * Gets the currently configured ThreadFactory.  It is considered a programming
          * error to delete the pointer returned by this method.
          *
-         * @returns the currently configured ThreadFactory instance used by this object.
+         * @return the currently configured ThreadFactory instance used by this object.
          */
         virtual ThreadFactory* getThreadFactory() const;
 
         /**
          * Gets the currently configured RejectedExecutionHandler for this Executor.
          *
-         * @returns a pointer to the current RejectedExecutionHandler.
+         * @return a pointer to the current RejectedExecutionHandler.
          */
         virtual RejectedExecutionHandler* getRejectedExecutionHandler() const;
 
@@ -431,7 +431,7 @@ namespace concurrent{
          * new tasks up to the set core thread limit.  When the limit is reached this method returns
          * zero to indicate no more core threads can be created.
          *
-         * @returns the number of core threads created, or zero if the limit has already been met.
+         * @return the number of core threads created, or zero if the limit has already been met.
          */
         virtual int prestartAllCoreThreads();
 
@@ -442,7 +442,7 @@ namespace concurrent{
          * @param task
          *      The task that is to be removed from the work queue.
          *
-         * @returns true if the task was removed from the Queue.
+         * @return true if the task was removed from the Queue.
          */
         bool remove(decaf::lang::Runnable* task);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/TimeUnit.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/TimeUnit.h b/activemq-cpp/src/main/decaf/util/concurrent/TimeUnit.h
index 3c4fb2b..7774415 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/TimeUnit.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/TimeUnit.h
@@ -110,7 +110,7 @@ namespace concurrent {
          * <p>
          * @param sourceDuration - Duration value to convert.
          * @param sourceUnit - Unit type of the source duration.
-         * @returns the converted duration in this unit, or Long.MIN_VALUE if conversion
+         * @return the converted duration in this unit, or Long.MIN_VALUE if conversion
          * would negatively overflow, or Long.MAX_VALUE if it would positively overflow.
          */
         long long convert( long long sourceDuration, const TimeUnit& sourceUnit ) const;
@@ -258,7 +258,7 @@ namespace concurrent {
          *
          * @param name
          *          The Name of the TimeUnit constant to be returned.
-         * @returns
+         * @return
          *          A constant reference to the TimeUnit Constant with the given name.
          * @throws IllegalArgumentException
          *          if this enum type has no constant with the specified name

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicBoolean.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicBoolean.h b/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicBoolean.h
index 7c18985..7180fa0 100644
--- a/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicBoolean.h
+++ b/activemq-cpp/src/main/decaf/util/concurrent/atomic/AtomicBoolean.h
@@ -58,7 +58,7 @@ namespace atomic {
 
         /**
          * Gets the current value of this AtomicBoolean.
-         * @returns the currently set value.
+         * @return the currently set value.
          */
         bool get() const {
             return value == 0 ? false : true;
@@ -78,7 +78,7 @@ namespace atomic {
          *
          * @param expect - the expected value
          * @param update - the new value
-         * @returns true if successful. False return indicates that the actual value
+         * @return true if successful. False return indicates that the actual value
          * was not equal to the expected value.
          */
         bool compareAndSet(bool expect, bool update);
@@ -87,13 +87,13 @@ namespace atomic {
          * Atomically sets to the given value and returns the previous value.
          *
          * @param newValue - the new value
-         * @returns the previous value
+         * @return the previous value
          */
         bool getAndSet(bool newValue);
 
         /**
          * Returns the String representation of the current value.
-         * @returns the String representation of the current value.
+         * @return the String representation of the current value.
          */
         std::string toString() const;
 


[6/9] activemq-cpp git commit: Fix some documentation generation issues.

Posted by ta...@apache.org.
http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Float.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Float.h b/activemq-cpp/src/main/decaf/lang/Float.h
index ca57222..cf9b7d0 100644
--- a/activemq-cpp/src/main/decaf/lang/Float.h
+++ b/activemq-cpp/src/main/decaf/lang/Float.h
@@ -86,7 +86,7 @@ namespace lang {
 
         /**
          * @param f - the Float object to compare against.
-         * @returns true if the two Float Objects have the same value.
+         * @return true if the two Float Objects have the same value.
          */
         bool equals(const Float& f) const {
             return this->value == f.value;
@@ -123,7 +123,7 @@ namespace lang {
 
         /**
          * @param f - the Float object to compare against.
-         * @returns true if the two Float Objects have the same value.
+         * @return true if the two Float Objects have the same value.
          */
         bool equals(const float& f) const {
             return this->value == f;
@@ -149,7 +149,7 @@ namespace lang {
         }
 
         /**
-         * @returns this Float Object as a String Representation
+         * @return this Float Object as a String Representation
          */
         std::string toString() const;
 
@@ -202,12 +202,12 @@ namespace lang {
         }
 
         /**
-         * @returns true if the float is equal to positive infinity.
+         * @return true if the float is equal to positive infinity.
          */
         bool isInfinite() const;
 
         /**
-         * @returns true if the float is equal to NaN.
+         * @return true if the float is equal to NaN.
          */
         bool isNaN() const;
 
@@ -220,7 +220,7 @@ namespace lang {
          * call: Float( f1 ).compareTo( Float( f2) )
          * @param f1 - the first double to compare
          * @param f2 - the second double to compare
-         * @returns the value 0 if d1 is numerically equal to f2; a value less than
+         * @return the value 0 if d1 is numerically equal to f2; a value less than
          * 0 if f1 is numerically less than f2; and a value greater than 0  if f1 is
          * numerically greater than f2.
          */
@@ -245,7 +245,7 @@ namespace lang {
          * same as the argument to floatToIntBits (except all NaN values are
          * collapsed to a single "canonical" NaN value).
          * @param value - the float to convert to int bits
-         * @returns the int that holds the float's value
+         * @return the int that holds the float's value
          */
         static int floatToIntBits(float value);
 
@@ -272,7 +272,7 @@ namespace lang {
          * as the argument to floatToRawIntBits.
          * @param value
          *      The float to convert to a raw int.
-         * @returns the raw int value of the float
+         * @return the raw int value of the float
          */
         static int floatToRawIntBits(float value);
 
@@ -297,7 +297,7 @@ namespace lang {
 
         /**
          * @param value - The float to check.
-         * @returns true if the float is equal to infinity.
+         * @return true if the float is equal to infinity.
          */
         static bool isInfinite(float value);
 
@@ -307,7 +307,7 @@ namespace lang {
          * @param value
          *      The float to check.
          *
-         * @returns true if the float is equal to NaN.
+         * @return true if the float is equal to NaN.
          */
         static bool isNaN(float value);
 
@@ -318,7 +318,7 @@ namespace lang {
          * @param value
          *      The string to parse.
          *
-         * @returns a float parsed from the string
+         * @return a float parsed from the string
          *
          * @throw NumberFormatException if an error occurs parsing the String.
          */
@@ -356,7 +356,7 @@ namespace lang {
          *        there must be at least one nonzero digit in a subnormal significand.
          *
          * @param value - The float to convert to a string
-         * @returns the Hex formatted float string.
+         * @return the Hex formatted float string.
          */
         static std::string toHexString(float value);
 
@@ -392,14 +392,14 @@ namespace lang {
          * @param value
          *      The float to convert to a string
          *
-         * @returns the formatted float string.
+         * @return the formatted float string.
          */
         static std::string toString(float value);
 
         /**
          * Returns a Float instance representing the specified float value.
          * @param value - float to wrap
-         * @returns new Float instance wrapping the primitive value
+         * @return new Float instance wrapping the primitive value
          */
         static Float valueOf(float value);
 
@@ -408,7 +408,7 @@ namespace lang {
          * from the string value passed.
          *
          * @param value - the string to parse
-         * @returns a new Float instance wrapping the float parsed from value
+         * @return a new Float instance wrapping the float parsed from value
          * @throws NumberFormatException on error.
          */
         static Float valueOf(const String& value);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Integer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Integer.h b/activemq-cpp/src/main/decaf/lang/Integer.h
index d74c613..6e47fb1 100644
--- a/activemq-cpp/src/main/decaf/lang/Integer.h
+++ b/activemq-cpp/src/main/decaf/lang/Integer.h
@@ -81,7 +81,7 @@ namespace lang{
 
         /**
          * @param i - the Integer object to compare against.
-         * @returns true if the two Integer Objects have the same value.
+         * @return true if the two Integer Objects have the same value.
          */
         bool equals(const Integer& i) const {
             return this->value == i.value;
@@ -118,7 +118,7 @@ namespace lang{
 
         /**
          * @param i - the Integer object to compare against.
-         * @returns true if the two Integer Objects have the same value.
+         * @return true if the two Integer Objects have the same value.
          */
         bool equals(const int& i) const {
             return this->value == i;
@@ -144,7 +144,7 @@ namespace lang{
         }
 
         /**
-         * @returns this <code>Integer</code> Object as a String Representation
+         * @return this <code>Integer</code> Object as a String Representation
          */
         std::string toString() const;
 
@@ -211,7 +211,7 @@ namespace lang{
          * character of the specified String is the minus sign. No whitespace
          * characters are permitted in the string.
          * @param value - The string to decode
-         * @returns a Integer object containing the decoded value
+         * @return a Integer object containing the decoded value
          * @throws NumberFomatException if the string is not formatted correctly.
          */
         static Integer decode(const String& value);
@@ -228,7 +228,7 @@ namespace lang{
          * Returns the value obtained by reversing the order of the bits in the
          * two's complement binary representation of the specified int  value.
          * @param value - the value whose bits are to be reversed
-         * @returns the reversed bits int.
+         * @return the reversed bits int.
          */
         static int reverse(int value);
 
@@ -268,7 +268,7 @@ namespace lang{
          * @param s
          *      String to convert to a int
          *
-         * @returns the converted int value
+         * @return the converted int value
          * @throws NumberFormatException if the string is not a int.
          */
         static int parseInt(const String& s);
@@ -350,7 +350,7 @@ namespace lang{
          *
          * @param value - the int to convert to a string
          * @param radix - the radix to format the string in
-         * @returns an int formatted to the string value of the radix given.
+         * @return an int formatted to the string value of the radix given.
          */
         static std::string toString(int value, int radix);
 
@@ -371,7 +371,7 @@ namespace lang{
          * If uppercase letters are desired, the toUpperCase() method may be called
          * on the result:
          * @param value - the int to be translated to an Octal string
-         * @returns the unsigned int value as a Octal string
+         * @return the unsigned int value as a Octal string
          */
         static std::string toHexString(int value);
 
@@ -391,7 +391,7 @@ namespace lang{
          *      01234567
          *
          * @param value - the int to be translated to an Octal string
-         * @returns the unsigned int value as a Octal string
+         * @return the unsigned int value as a Octal string
          */
         static std::string toOctalString(int value);
 
@@ -410,7 +410,7 @@ namespace lang{
          * digits.
          *
          * @param value - the int to be translated to a binary string
-         * @returns the unsigned int value as a binary string
+         * @return the unsigned int value as a binary string
          */
         static std::string toBinaryString(int value);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Iterable.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Iterable.h b/activemq-cpp/src/main/decaf/lang/Iterable.h
index b1e02cc..c259e5a 100644
--- a/activemq-cpp/src/main/decaf/lang/Iterable.h
+++ b/activemq-cpp/src/main/decaf/lang/Iterable.h
@@ -35,7 +35,7 @@ namespace lang {
         virtual ~Iterable() {}
 
         /**
-         * @returns an iterator over a set of elements of type T.
+         * @return an iterator over a set of elements of type T.
          */
         virtual decaf::util::Iterator<E>* iterator() = 0;
         virtual decaf::util::Iterator<E>* iterator() const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Long.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Long.h b/activemq-cpp/src/main/decaf/lang/Long.h
index b7bdee5..c8f20ee 100644
--- a/activemq-cpp/src/main/decaf/lang/Long.h
+++ b/activemq-cpp/src/main/decaf/lang/Long.h
@@ -79,7 +79,7 @@ namespace lang {
 
         /**
          * @param l - the Long object to compare against.
-         * @returns true if the two Integer Objects have the same value.
+         * @return true if the two Integer Objects have the same value.
          */
         bool equals(const Long& l) const {
             return this->value == l.value;
@@ -116,7 +116,7 @@ namespace lang {
 
         /**
          * @param l - the Long object to compare against.
-         * @returns true if the two Integer Objects have the same value.
+         * @return true if the two Integer Objects have the same value.
          */
         bool equals(const long long& l) const {
             return this->value == l;
@@ -142,7 +142,7 @@ namespace lang {
         }
 
         /**
-         * @returns this Long Object as a String Representation
+         * @return this Long Object as a String Representation
          */
         std::string toString() const;
 
@@ -218,7 +218,7 @@ namespace lang {
          * character of the specified String is the minus sign. No whitespace
          * characters are permitted in the string.
          * @param value - The string to decode
-         * @returns a Long object containing the decoded value
+         * @return a Long object containing the decoded value
          * @throws NumberFomatException if the string is not formatted correctly.
          */
         static Long decode(const String& value);
@@ -319,7 +319,7 @@ namespace lang {
          * Returns the value obtained by reversing the order of the bits in the
          * two's complement binary representation of the specified long long value.
          * @param value - the value whose bits are to be reversed
-         * @returns the reversed bits long long.
+         * @return the reversed bits long long.
          */
         static long long reverse(long long value);
 
@@ -398,7 +398,7 @@ namespace lang {
          *
          * @param value - the long long to convert to a string
          * @param radix - the radix to format the string in
-         * @returns an long long formatted to the string value of the radix given.
+         * @return an long long formatted to the string value of the radix given.
          */
         static std::string toString(long long value, int radix);
 
@@ -419,7 +419,7 @@ namespace lang {
          * If uppercase letters are desired, the toUpperCase() method may be called
          * on the result:
          * @param value - the long long to be translated to an Octal string
-         * @returns the unsigned long long value as a Octal string
+         * @return the unsigned long long value as a Octal string
          */
         static std::string toHexString(long long value);
 
@@ -439,7 +439,7 @@ namespace lang {
          *      01234567
          *
          * @param value - the long long to be translated to an Octal string
-         * @returns the unsigned long long value as a Octal string
+         * @return the unsigned long long value as a Octal string
          */
         static std::string toOctalString(long long value);
 
@@ -456,7 +456,7 @@ namespace lang {
          * The characters '0' and '1' are used as binary
          * digits.
          * @param value - the long long to be translated to a binary string
-         * @returns the unsigned long long value as a binary string
+         * @return the unsigned long long value as a binary string
          */
         static std::string toBinaryString(long long value);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Math.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Math.h b/activemq-cpp/src/main/decaf/lang/Math.h
index 116420f..5b5a104 100644
--- a/activemq-cpp/src/main/decaf/lang/Math.h
+++ b/activemq-cpp/src/main/decaf/lang/Math.h
@@ -50,7 +50,7 @@ namespace lang{
          * negative, the argument is returned. If the argument is negative, the
          * negation of the argument is returned.
          * @param value - the value to return the abs of
-         * @returns the value if positive, otherwise the negative of value
+         * @return the value if positive, otherwise the negative of value
          */
         static int abs( int value ) {
             return value < 0 ? -value : value;
@@ -61,7 +61,7 @@ namespace lang{
          * negative, the argument is returned. If the argument is negative, the
          * negation of the argument is returned.
          * @param value - the value to return the abs of
-         * @returns the value if positive, otherwise the negative of value
+         * @return the value if positive, otherwise the negative of value
          */
         static long long abs( long long value ) {
             return value < 0 ? -value : value;
@@ -81,7 +81,7 @@ namespace lang{
          *    Float::intBitsToFloat( 0x7fffffff & Float::floatToIntBits( value ) )
          *
          * @param value - the value to return the abs of
-         * @returns the value if positive, otherwise the negative of value
+         * @return the value if positive, otherwise the negative of value
          */
         static float abs( float value );
 
@@ -100,7 +100,7 @@ namespace lang{
          *                              Double::doubleToLongBits( value ) )
          *
          * @param value - the value to return the abs of
-         * @returns the value if positive, otherwise the negative of value
+         * @return the value if positive, otherwise the negative of value
          */
         static double abs( double value );
 
@@ -112,7 +112,7 @@ namespace lang{
          *    the result is NaN.
          *
          * @param value - the value to return the arc cosine of.
-         * @returns arc cosine of value in radians.
+         * @return arc cosine of value in radians.
          */
         //static double acos( double value );
 
@@ -126,7 +126,7 @@ namespace lang{
          *    as the argument.
          *
          * @param value - the value to return the arc cosine of.
-         * @returns arc cosine of value in radians.
+         * @return arc cosine of value in radians.
          */
         //static double asin( double value );
 
@@ -139,7 +139,7 @@ namespace lang{
          *    as the argument.
          *
          * @param value - the value to return the arc cosine of.
-         * @returns arc tangent of value in radians.
+         * @return arc tangent of value in radians.
          */
         //static double atan( double value );
 
@@ -182,7 +182,7 @@ namespace lang{
          *
          * @param y - the ordinate coordinate
          * @param x - the abscissa coordinate
-         * @returns the theta component of the point (r, theta) in polar coordinates
+         * @return the theta component of the point (r, theta) in polar coordinates
          * that corresponds to the point (x, y) in Cartesian coordinates.
          */
         //static double atan2( double x, double y );
@@ -199,7 +199,7 @@ namespace lang{
          *    as the argument.
          *
          * @param value - the double to compute the cube root of
-         * @returns the cube root of value
+         * @return the cube root of value
          */
         //static double cbrt( double value );
 
@@ -209,7 +209,7 @@ namespace lang{
          *   o If the argument is NaN or an infinity, then the result is NaN.
          *
          * @param value - an value in radians
-         * @returns the cosine of the argument.
+         * @return the cosine of the argument.
          */
         //static double cos( double value );
 
@@ -330,7 +330,7 @@ namespace lang{
          *    zero, then the result is the same as the argument.
          *
          * @param value - the value to round to the nearest integer
-         * @returns the rounded value
+         * @return the rounded value
          */
         //static double rint( double value );
 
@@ -490,7 +490,7 @@ namespace lang{
          *    is negative infinity.
          *
          * @param value the value to compute the natural log of.
-         * @returns the natural log of value.
+         * @return the natural log of value.
          */
         //static double log( double value );
 
@@ -505,7 +505,7 @@ namespace lang{
          *   o If the argument is equal to 10n for integer n, then the result is n.
          *
          * @param value - the value to operate on
-         * @returns the long base 10 of value
+         * @return the long base 10 of value
          */
         //static double log10( double value );
 
@@ -524,7 +524,7 @@ namespace lang{
          *     as the argument.
          *
          * @param value - the value to operate on
-         * @returns the the value ln(x + 1), the natural log of x + 1
+         * @return the the value ln(x + 1), the natural log of x + 1
          */
         //static double log1p( double value );
 
@@ -542,7 +542,7 @@ namespace lang{
          *
          * Note that the value of Math.ceil(x) is exactly the value of -Math.floor(-x).
          * @param value - the value to find the ceiling of
-         * @returns the smallest (closest to negative infinity) floating-point value
+         * @return the smallest (closest to negative infinity) floating-point value
          * that is greater than or equal to the argument and is equal to a
          * mathematical integer.
          */
@@ -559,7 +559,7 @@ namespace lang{
          *      zero, then the result is the same as the argument.
          *
          * @param value - the value to find the floor of
-         * @returns the largest (closest to positive infinity) floating-point value
+         * @return the largest (closest to positive infinity) floating-point value
          * that less than or equal to the argument and is equal to a mathematical
          * integer.
          */
@@ -580,7 +580,7 @@ namespace lang{
          *     Integer::MAX_VALUE.
          *
          * @param value - the value to round
-         * @returns the value of the argument rounded to the nearest integral value.
+         * @return the value of the argument rounded to the nearest integral value.
          */
         static int round( float value );
 
@@ -599,7 +599,7 @@ namespace lang{
          *     Long::MAX_VALUE.
          *
          * @param value - the value to round
-         * @returns the value of the argument rounded to the nearest integral value.
+         * @return the value of the argument rounded to the nearest integral value.
          */
         static long long round( double value );
 
@@ -637,7 +637,7 @@ namespace lang{
          * one thread. However, if many threads need to generate pseudorandom numbers
          * at a great rate, it may reduce contention for each thread to have its
          * own pseudorandom-number generator.
-         * @returns a pseudorandom double greater than or equal to 0.0 and
+         * @return a pseudorandom double greater than or equal to 0.0 and
          * less than 1.0.
          */
         static double random();
@@ -651,7 +651,7 @@ namespace lang{
          *  o If the argument is negative infinity, then the result is positive zero.
          *
          * @param value - the exponent to raise e to
-         * @returns the value e^a, where e is the base of the natural logarithms.
+         * @return the value e^a, where e is the base of the natural logarithms.
          */
         //static double exp( double value );
 
@@ -667,7 +667,7 @@ namespace lang{
          *    the argument.
          *
          * @param value - the value to raise e^x - 1
-         * @returns the value ex - 1.
+         * @return the value ex - 1.
          */
         //static double expm1( double value );
 
@@ -681,7 +681,7 @@ namespace lang{
          *
          * @param x - an argument
          * @param y - another argument
-         * @returns the sqrt(x^2 + y^2) without intermediate overflow or underflow
+         * @return the sqrt(x^2 + y^2) without intermediate overflow or underflow
          */
         //static double hypot( double x, double y );
 
@@ -695,7 +695,7 @@ namespace lang{
          *    the same as the argument.
          *
          * @param value - the floating-point value whose signum is to be returned
-         * @returns the signum function of the argument
+         * @return the signum function of the argument
          */
         static float signum( float value );
 
@@ -709,7 +709,7 @@ namespace lang{
          *    the same as the argument.
          *
          * @param value - the floating-point value whose signum is to be returned
-         * @returns the signum function of the argument
+         * @return the signum function of the argument
          */
         static double signum( double value );
 
@@ -745,7 +745,7 @@ namespace lang{
          *  o If the argument is ±Float::MAX_VALUE, then the result is equal to 2^104.
          *
          * @param value - the floating-point value whose ulp is to be returned
-         * @returns the size of an ulp of the argument
+         * @return the size of an ulp of the argument
          */
         //static float ulp( float value );
 
@@ -763,7 +763,7 @@ namespace lang{
          *  o If the argument is ±Float::MAX_VALUE, then the result is equal to 2^971.
          *
          * @param value - the floating-point value whose ulp is to be returned
-         * @returns the size of an ulp of the argument
+         * @return the size of an ulp of the argument
          */
         //static double ulp( double value );
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Pointer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Pointer.h b/activemq-cpp/src/main/decaf/lang/Pointer.h
index fc8ae7f..593a649 100644
--- a/activemq-cpp/src/main/decaf/lang/Pointer.h
+++ b/activemq-cpp/src/main/decaf/lang/Pointer.h
@@ -167,7 +167,7 @@ namespace lang {
          * is not guaranteed to be safe if the Pointer is held by more than one object or this
          * method is called from more than one thread.
          *
-         * @returns The pointer instance that was held by this Pointer object, the pointer is
+         * @return The pointer instance that was held by this Pointer object, the pointer is
          *          no longer owned by this Pointer and won't be freed when this Pointer goes
          *          out of scope.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Runtime.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Runtime.h b/activemq-cpp/src/main/decaf/lang/Runtime.h
index 2994d15..630cd91 100644
--- a/activemq-cpp/src/main/decaf/lang/Runtime.h
+++ b/activemq-cpp/src/main/decaf/lang/Runtime.h
@@ -40,7 +40,7 @@ namespace lang {
         /**
          * Gets the single instance of the Decaf Runtime for this Process.
          *
-         * @returns pointer to the single Decaf Runtime instance that exists
+         * @return pointer to the single Decaf Runtime instance that exists
          *          for this process
          */
         static Runtime* getRuntime();

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Short.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Short.h b/activemq-cpp/src/main/decaf/lang/Short.h
index d1d050b..f7e9bc8 100644
--- a/activemq-cpp/src/main/decaf/lang/Short.h
+++ b/activemq-cpp/src/main/decaf/lang/Short.h
@@ -75,7 +75,7 @@ namespace lang {
         virtual int compareTo(const Short& s) const;
 
         /**
-         * @returns true if the two Short Objects have the same value.
+         * @return true if the two Short Objects have the same value.
          */
         bool equals(const Short& s) const {
             return this->value == s.value;
@@ -111,7 +111,7 @@ namespace lang {
         virtual int compareTo(const short& s) const;
 
         /**
-         * @returns true if the two Short Objects have the same value.
+         * @return true if the two Short Objects have the same value.
          */
         bool equals(const short& s) const {
             return this->value == s;
@@ -137,7 +137,7 @@ namespace lang {
         }
 
         /**
-         * @returns this Short Object as a String Representation
+         * @return this Short Object as a String Representation
          */
         std::string toString() const;
 
@@ -192,7 +192,7 @@ namespace lang {
     public:
 
         /**
-         * @returns a string representing the primitive value as Base 10
+         * @return a string representing the primitive value as Base 10
          */
         static std::string toString(short value);
 
@@ -208,7 +208,7 @@ namespace lang {
          * character of the specified String is the minus sign. No whitespace
          * characters are permitted in the string.
          * @param value - The string to decode
-         * @returns a Short object containing the decoded value
+         * @return a Short object containing the decoded value
          * @throws NumberFomatException if the string is not formatted correctly.
          */
         static Short decode(const String& value);
@@ -261,7 +261,7 @@ namespace lang {
          * @param s
          *      String to convert to a short
          *
-         * @returns the converted short value
+         * @return the converted short value
          *
          * @throws NumberFormatException if the string is not a short.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/String.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/String.h b/activemq-cpp/src/main/decaf/lang/String.h
index 121835c..4432558 100644
--- a/activemq-cpp/src/main/decaf/lang/String.h
+++ b/activemq-cpp/src/main/decaf/lang/String.h
@@ -176,7 +176,7 @@ namespace lang {
          * @param other
          *      The other String to assign to this instance.
          *
-         * @returns a reference to this string with the new contents.
+         * @return a reference to this string with the new contents.
          */
         String& operator= (const String& other);
 
@@ -188,7 +188,7 @@ namespace lang {
          * @param other
          *      The other std::string to assign to this instance.
          *
-         * @returns a reference to this string with the new contents.
+         * @return a reference to this string with the new contents.
          */
         String& operator= (const std::string& other);
 
@@ -200,7 +200,7 @@ namespace lang {
          * @param other
          *      The other C string to assign to this instance.
          *
-         * @returns a reference to this string with the new contents.
+         * @return a reference to this string with the new contents.
          */
         String& operator= (const char* other);
 
@@ -211,7 +211,7 @@ namespace lang {
          * @param other
          *      The string value to compare to this one.
          *
-         * @returns true if the other string is equal to this one, false otherwise.
+         * @return true if the other string is equal to this one, false otherwise.
          */
         bool operator==(const char* other) const;
         bool operator==(const String& other) const;
@@ -224,7 +224,7 @@ namespace lang {
          * @param other
          *      The string value to compare to this one.
          *
-         * @returns true if the other string is not equal to this one, false otherwise.
+         * @return true if the other string is not equal to this one, false otherwise.
          */
         bool operator!=(const char* other) const;
         bool operator!=(const String& other) const;
@@ -237,7 +237,7 @@ namespace lang {
          * @param other
          *      The string value to compare to this one.
          *
-         * @returns true if this string is lexicographically less than the other string.
+         * @return true if this string is lexicographically less than the other string.
          */
         bool operator< (const char* other) const;
         bool operator< (const String& other) const;
@@ -250,7 +250,7 @@ namespace lang {
          * @param other
          *      The string value to compare to this one.
          *
-         * @returns true if this string is lexicographically less than or equal to the other string.
+         * @return true if this string is lexicographically less than or equal to the other string.
          */
         bool operator<=(const char* other) const;
         bool operator<=(const String& other) const;
@@ -263,7 +263,7 @@ namespace lang {
          * @param other
          *      The string value to compare to this one.
          *
-         * @returns true if this string is lexicographically greater than the other string.
+         * @return true if this string is lexicographically greater than the other string.
          */
         bool operator> (const char* other) const;
         bool operator> (const String& other) const;
@@ -276,7 +276,7 @@ namespace lang {
          * @param other
          *      The string value to compare to this one.
          *
-         * @returns true if this string is lexicographically greater than the other string.
+         * @return true if this string is lexicographically greater than the other string.
          */
         bool operator>=(const char* other) const;
         bool operator>=(const String& other) const;
@@ -289,7 +289,7 @@ namespace lang {
          * @param other
          *      The string whose value is to be concatenated with this one.
          *
-         * @returns a new String instance that is the concatenation of the two strings.
+         * @return a new String instance that is the concatenation of the two strings.
          */
         String operator+ (const String& other) const;
         String operator+ (const std::string& other) const;
@@ -303,7 +303,7 @@ namespace lang {
          * new character array in order to return a pointer value that is guaranteed to
          * be NULL terminated.
          *
-         * @returns a const char* value for this String.
+         * @return a const char* value for this String.
          */
         const char* c_str() const;
 
@@ -319,7 +319,7 @@ namespace lang {
          * viewing a small portion of it and the original source String is no longer also
          * maintaining a reference to the backing store.
          *
-         * @returns a new String instance with a compacted backing store.
+         * @return a new String instance with a compacted backing store.
          */
         String compact() const;
 
@@ -515,7 +515,7 @@ namespace lang {
          * @param other
          *      A String instance to compare to this string.
          *
-         * @returns true if this String is equal to the given String instance.
+         * @return true if this String is equal to the given String instance.
          */
         bool equals(const String& other) const;
 
@@ -525,7 +525,7 @@ namespace lang {
          * @param other
          *      A standard string instance to compare to this String.
          *
-         * @returns true if this String is equal to the given std::string instance.
+         * @return true if this String is equal to the given std::string instance.
          */
         bool equals(const std::string& other) const;
 
@@ -537,7 +537,7 @@ namespace lang {
          * @param other
          *      A C string instance to compare to this String.
          *
-         * @returns true if this String is equal to the given C string instance.
+         * @return true if this String is equal to the given C string instance.
          */
         bool equals(const char* other) const;
 
@@ -658,7 +658,7 @@ namespace lang {
          * Returns a hash code for this String instance, the hash code for an empty
          * String will always be zero.
          *
-         * @returns a hash code for this String instance.
+         * @return a hash code for this String instance.
          */
         int hashCode() const;
 
@@ -779,7 +779,7 @@ namespace lang {
         int indexOf(const char* subString, int start) const;
 
         /**
-         * @returns true if the length of this String is zero.
+         * @return true if the length of this String is zero.
          */
         bool isEmpty() const;
 
@@ -1035,7 +1035,7 @@ namespace lang {
         /**
          * Returns a copy of the string, with leading and trailing whitespace omitted.
          *
-         * @returns a copy of the string, with leading and trailing whitespace omitted.
+         * @return a copy of the string, with leading and trailing whitespace omitted.
          */
         String trim() const;
 
@@ -1101,7 +1101,7 @@ namespace lang {
          * Given a C String pointer return true if the value is either NULL or the
          * string contained is empty.
          *
-         * @returns true if the C string is either a NULL or an Empty string.
+         * @return true if the C string is either a NULL or an Empty string.
          */
         static bool isNullOrEmpty(const char*);
 
@@ -1111,7 +1111,7 @@ namespace lang {
          * @param value
          *      The value whose string representation is to be returned.
          *
-         * @returns "true" if the boolean is true, "false" otherwise.
+         * @return "true" if the boolean is true, "false" otherwise.
          */
         static String valueOf(bool value);
 
@@ -1121,7 +1121,7 @@ namespace lang {
          * @param value
          *      The value whose string representation is to be returned.
          *
-         * @returns a String that contains the single character value given.
+         * @return a String that contains the single character value given.
          */
         static String valueOf(char value);
 
@@ -1131,7 +1131,7 @@ namespace lang {
          * @param value
          *      The value whose string representation is to be returned.
          *
-         * @returns a String that contains the string representation of the float value given.
+         * @return a String that contains the string representation of the float value given.
          */
         static String valueOf(float value);
 
@@ -1141,7 +1141,7 @@ namespace lang {
          * @param value
          *      The value whose string representation is to be returned.
          *
-         * @returns a String that contains the string representation of the double value given.
+         * @return a String that contains the string representation of the double value given.
          */
         static String valueOf(double value);
 
@@ -1151,7 +1151,7 @@ namespace lang {
          * @param value
          *      The value whose string representation is to be returned.
          *
-         * @returns a String that contains the string representation of the short value given.
+         * @return a String that contains the string representation of the short value given.
          */
         static String valueOf(short value);
 
@@ -1161,7 +1161,7 @@ namespace lang {
          * @param value
          *      The value whose string representation is to be returned.
          *
-         * @returns a String that contains the string representation of the integer value given.
+         * @return a String that contains the string representation of the integer value given.
          */
         static String valueOf(int value);
 
@@ -1171,7 +1171,7 @@ namespace lang {
          * @param value
          *      The value whose string representation is to be returned.
          *
-         * @returns a String that contains the string representation of the 64 bit long value given.
+         * @return a String that contains the string representation of the 64 bit long value given.
          */
         static String valueOf(long long value);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/StringBuffer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/StringBuffer.h b/activemq-cpp/src/main/decaf/lang/StringBuffer.h
index 639c484..e6be692 100644
--- a/activemq-cpp/src/main/decaf/lang/StringBuffer.h
+++ b/activemq-cpp/src/main/decaf/lang/StringBuffer.h
@@ -140,7 +140,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         template<typename POINTER>
         StringBuffer& append(const POINTER* pointer) {
@@ -161,7 +161,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         template<typename TYPE>
         StringBuffer& append(const Pointer<TYPE> pointer) {
@@ -181,7 +181,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(bool value);
 
@@ -191,7 +191,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(char value);
 
@@ -201,7 +201,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(short value);
 
@@ -211,7 +211,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(int value);
 
@@ -221,7 +221,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(long long value);
 
@@ -231,7 +231,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(float value);
 
@@ -241,7 +241,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(double value);
 
@@ -251,7 +251,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(const char* value);
 
@@ -278,7 +278,7 @@ namespace lang {
          * @param value
          *      The CharSequence value to be appended into this buffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(const CharSequence* value);
 
@@ -305,7 +305,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(const String& value);
 
@@ -315,7 +315,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& append(const StringBuilder& value);
 
@@ -330,7 +330,7 @@ namespace lang {
          * @param end
          *      The ending index (exclusive) to delete from this buffer.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws StringIndexOutOfBoundsException
          *      if start is negative, greater than length(), or greater than end.
@@ -343,7 +343,7 @@ namespace lang {
          * @param index
          *      The index in this buffer where the character to delete is located.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws StringIndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -359,7 +359,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         template<typename POINTER>
         StringBuffer& insert(int index, const POINTER* pointer) {
@@ -382,7 +382,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         template<typename TYPE>
         StringBuffer& insert(int index, const Pointer<TYPE> pointer) {
@@ -405,7 +405,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -421,7 +421,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -437,7 +437,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -453,7 +453,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -469,7 +469,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -485,7 +485,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -501,7 +501,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -516,7 +516,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws NullPointerException if the target C string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -532,7 +532,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws NullPointerException if the target C string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -548,7 +548,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws NullPointerException if the target std::string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -570,7 +570,7 @@ namespace lang {
          * @param length
          *      The number of characters to copy from the given C string.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws NullPointerException if the target C string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -590,7 +590,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -612,7 +612,7 @@ namespace lang {
          * @param length
          *      The number of characters to copy from the given CharSequence.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -634,7 +634,7 @@ namespace lang {
          * @param value
          *      The new string value to replace the older value.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException if start is negative, greater than end or greater than length().
          */
@@ -643,7 +643,7 @@ namespace lang {
         /**
          * Reverses the order of characters in this builder.
          *
-         * @returns a reference to this StringBuffer so that operations can be chained.
+         * @return a reference to this StringBuffer so that operations can be chained.
          */
         StringBuffer& reverse();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/StringBuilder.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/StringBuilder.h b/activemq-cpp/src/main/decaf/lang/StringBuilder.h
index d5d9089..0e9c1a8 100644
--- a/activemq-cpp/src/main/decaf/lang/StringBuilder.h
+++ b/activemq-cpp/src/main/decaf/lang/StringBuilder.h
@@ -102,7 +102,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         template<typename POINTER>
         StringBuilder& append(const POINTER* pointer) {
@@ -123,7 +123,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         template<typename TYPE>
         StringBuilder& append(const Pointer<TYPE> pointer) {
@@ -143,7 +143,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(bool value);
 
@@ -153,7 +153,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(char value);
 
@@ -163,7 +163,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(short value);
 
@@ -173,7 +173,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(int value);
 
@@ -183,7 +183,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(long long value);
 
@@ -193,7 +193,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(float value);
 
@@ -203,7 +203,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(double value);
 
@@ -213,7 +213,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(const char* value);
 
@@ -240,7 +240,7 @@ namespace lang {
          * @param value
          *      The CharSequence value to be appended into this buffer.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(const CharSequence* value);
 
@@ -267,7 +267,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(const String& value);
 
@@ -277,7 +277,7 @@ namespace lang {
          * @param value
          *      The value to append to the contents of the StringBuilder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& append(const StringBuffer& value);
 
@@ -292,7 +292,7 @@ namespace lang {
          * @param end
          *      The ending index (exclusive) to delete from this buffer.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws StringIndexOutOfBoundsException
          *      if start is negative, greater than length(), or greater than end.
@@ -305,7 +305,7 @@ namespace lang {
          * @param index
          *      The index in this buffer where the character to delete is located.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws StringIndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -321,7 +321,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         template<typename POINTER>
         StringBuilder& insert(int index, const POINTER* pointer) {
@@ -344,7 +344,7 @@ namespace lang {
          * @param pointer
          *      A pointer to some object that must define a toString method.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         template<typename TYPE>
         StringBuilder& insert(int index, const Pointer<TYPE> pointer) {
@@ -367,7 +367,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -383,7 +383,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -399,7 +399,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -415,7 +415,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -431,7 +431,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -447,7 +447,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -463,7 +463,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -478,7 +478,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws NullPointerException if the target C string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -494,7 +494,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws NullPointerException if the target C string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -510,7 +510,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws NullPointerException if the target std::string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -532,7 +532,7 @@ namespace lang {
          * @param length
          *      The number of characters to copy from the given C string.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws NullPointerException if the target C string pointer is NULL.
          * @throws IndexOutOfBoundsException
@@ -552,7 +552,7 @@ namespace lang {
          * @param value
          *      The value to insert at the given index.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -574,7 +574,7 @@ namespace lang {
          * @param length
          *      The number of characters to copy from the given CharSequence.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException
          *      if the index is negative or greater than or equal to length().
@@ -596,7 +596,7 @@ namespace lang {
          * @param value
          *      The new string value to replace the older value.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          *
          * @throws IndexOutOfBoundsException if start is negative, greater than end or greater than length().
          */
@@ -605,7 +605,7 @@ namespace lang {
         /**
          * Reverses the order of characters in this builder.
          *
-         * @returns a reference to this StringBuilder so that operations can be chained.
+         * @return a reference to this StringBuilder so that operations can be chained.
          */
         StringBuilder& reverse();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/System.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/System.h b/activemq-cpp/src/main/decaf/lang/System.h
index cdf3430..6567008 100644
--- a/activemq-cpp/src/main/decaf/lang/System.h
+++ b/activemq-cpp/src/main/decaf/lang/System.h
@@ -291,7 +291,7 @@ namespace lang{
          * See the description of the class Date for a discussion of slight discrepancies
          * that may arise between "computer time" and coordinated universal time (UTC).
          *
-         * @returns the difference, measured in milliseconds, between the current time
+         * @return the difference, measured in milliseconds, between the current time
          *          and midnight, January 1, 1970 UTC.
          */
         static long long currentTimeMillis();
@@ -315,7 +315,7 @@ namespace lang{
          *   // ... the code being measured ...
          *   long long estimatedTime = System::nanoTime() - startTime;
          *
-         * @returns
+         * @return
          *     The current value of the system timer, in nanoseconds.
          */
         static long long nanoTime();
@@ -338,7 +338,7 @@ namespace lang{
          * If the Properties has not yet been created or are not yet initialized then they
          * will be on the first call to a Properties accessor.
          *
-         * @returns a reference to the static system Properties object.
+         * @return a reference to the static system Properties object.
          */
         static decaf::util::Properties& getProperties();
 
@@ -351,7 +351,7 @@ namespace lang{
          * @param key
          *      The key name of the desired system property to retrieve.
          *
-         * @returns an empty string if the named property is not set, otherwise returns the value.
+         * @return an empty string if the named property is not set, otherwise returns the value.
          *
          * @throws IllegalArgumentException if key is an empty string.
          */
@@ -368,7 +368,7 @@ namespace lang{
          * @param defaultValue
          *      The default value to return if the key is not set in the System properties.
          *
-         * @returns the value of the named system property or the defaultValue if the property isn't set..
+         * @return the value of the named system property or the defaultValue if the property isn't set..
          *
          * @throws IllegalArgumentException if key is an empty string.
          */
@@ -382,7 +382,7 @@ namespace lang{
          * @param value
          *      The value to assign to the key.
          *
-         * @returns the previous value of the property named by key if there was one, otherwise
+         * @return the previous value of the property named by key if there was one, otherwise
          *          returns an empty string.
          *
          * @throws IllegalArgumentException if key is an empty string.
@@ -395,7 +395,7 @@ namespace lang{
          * @param key
          *      The key name of the system property to clear.
          *
-         * @returns the previous value of the property named by key if there was one, otherwise
+         * @return the previous value of the property named by key if there was one, otherwise
          *          returns an empty string.
          *
          * @throws IllegalArgumentException if key is an empty string.
@@ -409,14 +409,14 @@ namespace lang{
          * with the values.  Caller owns the array.  The array is terminated
          * by an element that holds the value NULL
          *
-         * @returns a vector of environment name / value pairs.
+         * @return a vector of environment name / value pairs.
          */
         static std::vector< std::string > getEnvArray();
 
         /**
          * Gets the one and only APR Pool instance
          *
-         * @returns a reference to the global APR Pool.
+         * @return a reference to the global APR Pool.
          */
         static internal::AprPool& getAprPool();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Thread.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Thread.h b/activemq-cpp/src/main/decaf/lang/Thread.h
index ce36135..e72152e 100644
--- a/activemq-cpp/src/main/decaf/lang/Thread.h
+++ b/activemq-cpp/src/main/decaf/lang/Thread.h
@@ -261,7 +261,7 @@ namespace lang {
 
         /**
          * Returns the Thread's assigned name.
-         * @returns the Name of the Thread.
+         * @return the Name of the Thread.
          */
         std::string getName() const;
 
@@ -292,7 +292,7 @@ namespace lang {
         /**
          * Set the handler invoked when this thread abruptly terminates due to an uncaught exception.
          *
-         * @returns a pointer to the set UncaughtExceptionHandler.
+         * @return a pointer to the set UncaughtExceptionHandler.
          */
         UncaughtExceptionHandler* getUncaughtExceptionHandler() const;
 
@@ -343,7 +343,7 @@ namespace lang {
         /**
          * Returns but does not clear the state of this Thread's interrupted flag.
          *
-         * @returns true if the thread was interrupted, false otherwise.
+         * @return true if the thread was interrupted, false otherwise.
          */
         bool isInterrupted() const;
 
@@ -398,7 +398,7 @@ namespace lang {
          * such that a subsequent call will return false unless an interrupt occurs between
          * the two calls.
          *
-         * @returns true if the thread was interrupted, false otherwise.
+         * @return true if the thread was interrupted, false otherwise.
          */
         static bool interrupted();
 
@@ -409,7 +409,7 @@ namespace lang {
          * is cleared via a call to the setDefaultUncaughtExceptionHandler method will NULL as
          * the value of the handler argument.
          *
-         * @returns a pointer to the default UncaughtExceptionHandler for all Threads.
+         * @return a pointer to the default UncaughtExceptionHandler for all Threads.
          */
         static UncaughtExceptionHandler* getDefaultUncaughtExceptionHandler();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/ThreadLocal.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/ThreadLocal.h b/activemq-cpp/src/main/decaf/lang/ThreadLocal.h
index 0a5f28a..cb59337 100644
--- a/activemq-cpp/src/main/decaf/lang/ThreadLocal.h
+++ b/activemq-cpp/src/main/decaf/lang/ThreadLocal.h
@@ -64,7 +64,7 @@ namespace lang {
          * variable has no value for the current thread, it is first initialized to the value
          * returned by an invocation of the initialValue() method.
          *
-         * @returns the current thread's value for this thread local.
+         * @return the current thread's value for this thread local.
          */
         E& get() {
             void* bytes = getRawValue();

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/lang/Throwable.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/lang/Throwable.h b/activemq-cpp/src/main/decaf/lang/Throwable.h
index de3e534..2329a42 100644
--- a/activemq-cpp/src/main/decaf/lang/Throwable.h
+++ b/activemq-cpp/src/main/decaf/lang/Throwable.h
@@ -62,7 +62,7 @@ namespace lang{
          * a particular exception but wishes to allow for the real causal
          * exception to be passed only in case the caller knows about that
          * type of exception and wishes to respond to it.
-         * @returns a const pointer reference to the causal exception, if there
+         * @return a const pointer reference to the causal exception, if there
          * was no cause associated with this exception then NULL is returned.
          */
         virtual const std::exception* getCause() const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/DatagramPacket.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/DatagramPacket.h b/activemq-cpp/src/main/decaf/net/DatagramPacket.h
index de3ed59..51c2e3c 100644
--- a/activemq-cpp/src/main/decaf/net/DatagramPacket.h
+++ b/activemq-cpp/src/main/decaf/net/DatagramPacket.h
@@ -195,7 +195,7 @@ namespace net {
          * Gets the SocketAddress (usually IP address + port number) of the remote host that this
          * packet is being sent to or is coming from.
          *
-         * @returns the SocketAddress for this datagram packet.
+         * @return the SocketAddress for this datagram packet.
          */
         SocketAddress* getSocketAddress() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/InetAddress.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/InetAddress.h b/activemq-cpp/src/main/decaf/net/InetAddress.h
index 49d5827..f36e904 100644
--- a/activemq-cpp/src/main/decaf/net/InetAddress.h
+++ b/activemq-cpp/src/main/decaf/net/InetAddress.h
@@ -56,14 +56,14 @@ namespace net {
          * Returns the Raw IP address in Network byte order.  The returned address is a copy
          * of the bytes contained in this InetAddress.
          *
-         * @returns and ArrayPointer containing the raw bytes of the network address.
+         * @return and ArrayPointer containing the raw bytes of the network address.
          */
         virtual decaf::lang::ArrayPointer<unsigned char> getAddress() const;
 
         /**
          * Returns a textual representation of the IP Address.
          *
-         * @returns the string form of the IP Address.
+         * @return the string form of the IP Address.
          */
         virtual std::string getHostAddress() const;
 
@@ -75,7 +75,7 @@ namespace net {
          * with the set IP Address.  If the host name cannot be resolved the textual representation
          * of the IP Address is returned instead.
          *
-         * @returns the name of the host associated with this set IP Address.
+         * @return the name of the host associated with this set IP Address.
          */
         virtual std::string getHostName() const;
 
@@ -84,7 +84,7 @@ namespace net {
          *
          * If the hostname is not resolved than it appears as empty.
          *
-         * @returns string value of this InetAddress.
+         * @return string value of this InetAddress.
          */
         virtual std::string toString() const;
 
@@ -220,7 +220,7 @@ namespace net {
          * Gets an InetAddress that is the local host address.  If the localhost value cannot
          * be resolved than the InetAddress for Loopback is returned.
          *
-         * @returns a new InetAddress object that contains the local host address.
+         * @return a new InetAddress object that contains the local host address.
          *
          * @throws UnknownHostException if the address for local host is not found.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/ServerSocket.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/ServerSocket.h b/activemq-cpp/src/main/decaf/net/ServerSocket.h
index aca2864..3581081 100644
--- a/activemq-cpp/src/main/decaf/net/ServerSocket.h
+++ b/activemq-cpp/src/main/decaf/net/ServerSocket.h
@@ -217,7 +217,7 @@ namespace net{
         virtual void close();
 
         /**
-         * @returns true if the close method has been called on the ServerSocket.
+         * @return true if the close method has been called on the ServerSocket.
          */
         virtual bool isClosed() const;
 
@@ -290,12 +290,12 @@ namespace net{
         /**
          * Gets the port number on the Local machine that this ServerSocket is bound to.
          *
-         * @returns the port number of this machine that is bound, if not bound returns -1.
+         * @return the port number of this machine that is bound, if not bound returns -1.
          */
         virtual int getLocalPort() const;
 
         /**
-         * @returns a string representing this ServerSocket.
+         * @return a string representing this ServerSocket.
          */
         virtual std::string toString() const;
 
@@ -330,7 +330,7 @@ namespace net{
         /**
          * Allows a subclass to override what is considered the default backlog.
          *
-         * @returns the default backlog for connections.
+         * @return the default backlog for connections.
          */
         virtual int getDefaultBacklog();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/Socket.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/Socket.h b/activemq-cpp/src/main/decaf/net/Socket.h
index 5b47f03..b3e651f 100644
--- a/activemq-cpp/src/main/decaf/net/Socket.h
+++ b/activemq-cpp/src/main/decaf/net/Socket.h
@@ -229,35 +229,35 @@ namespace net{
         /**
          * Indicates whether or not this socket is connected to am end point.
          *
-         * @returns true if connected, false otherwise.
+         * @return true if connected, false otherwise.
          */
         bool isConnected() const {
             return connected;
         }
 
         /**
-         * @returns true if the Socket has been closed.
+         * @return true if the Socket has been closed.
          */
         bool isClosed() const {
             return closed;
         }
 
         /**
-         * @returns true if this Socket has been bound to a Local address.
+         * @return true if this Socket has been bound to a Local address.
          */
         bool isBound() const {
             return bound;
         }
 
         /**
-         * @returns true if input on this Socket has been shutdown.
+         * @return true if input on this Socket has been shutdown.
          */
         bool isInputShutdown() const {
             return inputShutdown;
         }
 
         /**
-         * @returns true if output on this Socket has been shutdown.
+         * @return true if output on this Socket has been shutdown.
          */
         bool isOutputShutdown() const {
             return outputShutdown;
@@ -310,14 +310,14 @@ namespace net{
         /**
          * Returns the address to which the socket is connected.
          *
-         * @returns the remote IP address to which this socket is connected, or null if the socket is not connected.
+         * @return the remote IP address to which this socket is connected, or null if the socket is not connected.
          */
         std::string getInetAddress() const;
 
         /**
          * Gets the local address to which the socket is bound.
          *
-         * @returns the local address to which the socket is bound or InetAddress.anyLocalAddress() if the socket is not bound yet.
+         * @return the local address to which the socket is bound or InetAddress.anyLocalAddress() if the socket is not bound yet.
          */
         std::string getLocalAddress() const;
 
@@ -466,7 +466,7 @@ namespace net{
         /**
          * Gets the Status of the TCP_NODELAY setting for this socket.
          *
-         * @returns true if TCP_NODELAY is enabled for the socket.
+         * @return true if TCP_NODELAY is enabled for the socket.
          *
          * @throws SocketException Thrown if unable to set the information.
          */
@@ -490,7 +490,7 @@ namespace net{
          *
          * Refer to your platforms network documentation regarding support for this setting.
          *
-         * @returns the bitset result of querying the traffic class setting.
+         * @return the bitset result of querying the traffic class setting.
          *
          * @throws SocketException if an error is encountered while performing this operation.
          */
@@ -541,7 +541,7 @@ namespace net{
         virtual void sendUrgentData(int data);
 
         /**
-         * @returns a string representing this Socket.
+         * @return a string representing this Socket.
          */
         virtual std::string toString() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/SocketFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/SocketFactory.h b/activemq-cpp/src/main/decaf/net/SocketFactory.h
index b65c9a3..982b065 100644
--- a/activemq-cpp/src/main/decaf/net/SocketFactory.h
+++ b/activemq-cpp/src/main/decaf/net/SocketFactory.h
@@ -141,7 +141,7 @@ namespace net{
          * default SocketFactory per application, the pointer returned by this method is owned by
          * the SocketFactory class and in not to be deleted by the caller.
          *
-         * @returns pointer to the applications default SocketFactory.
+         * @return pointer to the applications default SocketFactory.
          *
          * @throws SocketException if an error occurs while getting the default instance.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/net/SocketImpl.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/net/SocketImpl.h b/activemq-cpp/src/main/decaf/net/SocketImpl.h
index c3304cd..34aa432 100644
--- a/activemq-cpp/src/main/decaf/net/SocketImpl.h
+++ b/activemq-cpp/src/main/decaf/net/SocketImpl.h
@@ -138,7 +138,7 @@ namespace net {
         /**
          * Gets the InputStream linked to this Socket.
          *
-         * @returns an InputStream pointer owned by the Socket object.
+         * @return an InputStream pointer owned by the Socket object.
          *
          * @throws IOException if an I/O error occurs while attempting this operation.
          */
@@ -147,7 +147,7 @@ namespace net {
         /**
          * Gets the OutputStream linked to this Socket.
          *
-         * @returns an OutputStream pointer owned by the Socket object.
+         * @return an OutputStream pointer owned by the Socket object.
          *
          * @throws IOException if an I/O error occurs while attempting this operation.
          */
@@ -156,7 +156,7 @@ namespace net {
         /**
          * Gets the number of bytes that can be read from the Socket without blocking.
          *
-         * @returns the number of bytes that can be read from the Socket without blocking.
+         * @return the number of bytes that can be read from the Socket without blocking.
          *
          * @throws IOException if an I/O error occurs while attempting this operation.
          */
@@ -194,7 +194,7 @@ namespace net {
          * @param option
          *      The Socket options whose value is to be retrieved.
          *
-         * @returns the value of the given socket option.
+         * @return the value of the given socket option.
          *
          * @throws IOException if an I/O error occurs while performing this operation.
          */
@@ -224,7 +224,7 @@ namespace net {
          /**
           * Gets the value of this SocketImpl's local port field.
           *
-          * @returns the value of localPort.
+          * @return the value of localPort.
           */
          int getLocalPort() const {
              return this->localPort;
@@ -233,7 +233,7 @@ namespace net {
          /**
           * Gets the value of this SocketImpl's address field.
           *
-          * @returns the value of the address field.
+          * @return the value of the address field.
           */
          std::string getInetAddress() const {
              return this->address;
@@ -243,7 +243,7 @@ namespace net {
           * Gets the FileDescriptor for this Socket, the Object is owned by this Socket and
           * should not be deleted by the caller.
           *
-          * @returns a pointer to this Socket's FileDescriptor object.
+          * @return a pointer to this Socket's FileDescriptor object.
           */
          const decaf::io::FileDescriptor* getFileDescriptor() const {
              return this->fd;
@@ -253,19 +253,19 @@ namespace net {
           * Gets the value of the local Inet address the Socket is bound to if bound, otherwise
           * return the InetAddress ANY value "0.0.0.0".
           *
-          * @returns the local address bound to, or ANY.
+          * @return the local address bound to, or ANY.
           */
          virtual std::string getLocalAddress() const = 0;
 
          /**
           * Returns a string containing the address and port of this Socket instance.
           *
-          * @returns a string containing the address and port of this socket.
+          * @return a string containing the address and port of this socket.
           */
          std::string toString() const;
 
          /**
-          * @returns true if this SocketImpl supports sending Urgent Data.  The default
+          * @return true if this SocketImpl supports sending Urgent Data.  The default
           *          implementation always returns false.
           */
          virtual bool supportsUrgentData() const {


[2/9] activemq-cpp git commit: Formatting cleanup.

Posted by ta...@apache.org.
Formatting cleanup.

Project: http://git-wip-us.apache.org/repos/asf/activemq-cpp/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq-cpp/commit/e058de24
Tree: http://git-wip-us.apache.org/repos/asf/activemq-cpp/tree/e058de24
Diff: http://git-wip-us.apache.org/repos/asf/activemq-cpp/diff/e058de24

Branch: refs/heads/master
Commit: e058de247aa7535faa977812c67a21e58dbfc2b7
Parents: f0b1ff9
Author: Timothy Bish <ta...@gmail.com>
Authored: Wed Aug 5 18:42:58 2015 -0400
Committer: Timothy Bish <ta...@gmail.com>
Committed: Wed Aug 5 18:42:58 2015 -0400

----------------------------------------------------------------------
 activemq-cpp/src/main/decaf/util/Arrays.h       |   4 +-
 .../src/main/decaf/util/zip/Adler32.cpp         |  34 +--
 activemq-cpp/src/main/decaf/util/zip/Adler32.h  |   8 +-
 activemq-cpp/src/main/decaf/util/zip/CRC32.cpp  |  29 +--
 activemq-cpp/src/main/decaf/util/zip/CRC32.h    |   8 +-
 .../main/decaf/util/zip/CheckedInputStream.cpp  |  94 +++----
 .../main/decaf/util/zip/CheckedInputStream.h    |  10 +-
 .../main/decaf/util/zip/CheckedOutputStream.cpp |  61 +++--
 .../main/decaf/util/zip/CheckedOutputStream.h   |  10 +-
 activemq-cpp/src/main/decaf/util/zip/Checksum.h |   8 +-
 .../src/main/decaf/util/zip/Deflater.cpp        | 247 +++++++++----------
 activemq-cpp/src/main/decaf/util/zip/Deflater.h |  28 +--
 .../decaf/util/zip/DeflaterOutputStream.cpp     | 135 +++++-----
 .../main/decaf/util/zip/DeflaterOutputStream.h  |  19 +-
 .../src/main/decaf/util/zip/Inflater.cpp        | 229 +++++++++--------
 activemq-cpp/src/main/decaf/util/zip/Inflater.h |  24 +-
 .../main/decaf/util/zip/InflaterInputStream.cpp | 162 ++++++------
 .../main/decaf/util/zip/InflaterInputStream.h   |  20 +-
 18 files changed, 558 insertions(+), 572 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/Arrays.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/Arrays.h b/activemq-cpp/src/main/decaf/util/Arrays.h
index 5a7a941..d428921 100644
--- a/activemq-cpp/src/main/decaf/util/Arrays.h
+++ b/activemq-cpp/src/main/decaf/util/Arrays.h
@@ -28,8 +28,8 @@ namespace util {
     class Arrays {
     private:
 
-        Arrays( const Arrays& source );
-        Arrays& operator= ( const Arrays& source );
+        Arrays(const Arrays& source);
+        Arrays& operator=(const Arrays& source);
 
     private:
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/Adler32.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Adler32.cpp b/activemq-cpp/src/main/decaf/util/zip/Adler32.cpp
index 517fbb4..761a0a8 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Adler32.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/Adler32.cpp
@@ -36,7 +36,7 @@ Adler32::~Adler32() {
 
 ////////////////////////////////////////////////////////////////////////////////
 void Adler32::reset() {
-    this->value = adler32( (uLong)this->value, NULL, 0 );
+    this->value = adler32((uLong) this->value, NULL, 0);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -45,42 +45,42 @@ long long Adler32::getValue() const {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Adler32::update( const std::vector<unsigned char>& buffer ) {
-    this->update( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+void Adler32::update(const std::vector<unsigned char>& buffer) {
+    this->update(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Adler32::update( const std::vector<unsigned char>& buffer, int offset, int length ) {
-    this->update( &buffer[0], (int)buffer.size(), offset, length );
+void Adler32::update(const std::vector<unsigned char>& buffer, int offset, int length) {
+    this->update(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Adler32::update( int byte ) {
-    this->value = adler32( (uLong)this->value, (const Bytef*)&byte, 1 );
+void Adler32::update(int byte) {
+    this->value = adler32((uLong) this->value, (const Bytef*) &byte, 1);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Adler32::update( const unsigned char* buffer, int size, int offset, int length ) {
+void Adler32::update(const unsigned char* buffer, int size, int offset, int length) {
 
-    if( size < 0 ) {
+    if (size < 0) {
         throw IndexOutOfBoundsException(
-            __FILE__, __LINE__, "size parameter out of Bounds: %d.", size );
+            __FILE__, __LINE__, "size parameter out of Bounds: %d.", size);
     }
 
-    if( offset > size || offset < 0 ) {
+    if (offset > size || offset < 0) {
         throw IndexOutOfBoundsException(
-            __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset );
+            __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset);
     }
 
-    if( length < 0 || length > size - offset ) {
+    if (length < 0 || length > size - offset) {
         throw IndexOutOfBoundsException(
-            __FILE__, __LINE__, "length parameter out of Bounds: %d.", length );
+            __FILE__, __LINE__, "length parameter out of Bounds: %d.", length);
     }
 
-    if( buffer == NULL ) {
+    if (buffer == NULL) {
         throw NullPointerException(
-            __FILE__, __LINE__, "Buffer pointer passed was NULL." );
+            __FILE__, __LINE__, "Buffer pointer passed was NULL.");
     }
 
-    this->value = adler32( (uLong)this->value, (const Bytef*)( buffer + offset ), (uInt)length );
+    this->value = adler32((uLong) this->value, (const Bytef*) (buffer + offset), (uInt) length);
 }

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/Adler32.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Adler32.h b/activemq-cpp/src/main/decaf/util/zip/Adler32.h
index 0ed9580..1d8d2fe 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Adler32.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Adler32.h
@@ -58,7 +58,7 @@ namespace zip {
          * @param buffer
          *      The buffer to read the updated bytes from.
          */
-        virtual void update( const std::vector<unsigned char>& buffer );
+        virtual void update(const std::vector<unsigned char>& buffer);
 
         /**
          * Updates the current checksum with the specified array of bytes.
@@ -72,7 +72,7 @@ namespace zip {
          *
          * @throw IndexOutOfBoundsException if offset + length > size of the buffer.
          */
-        virtual void update( const std::vector<unsigned char>& buffer, int offset, int length );
+        virtual void update(const std::vector<unsigned char>& buffer, int offset, int length);
 
         /**
          * Updates the current checksum with the specified array of bytes.
@@ -89,7 +89,7 @@ namespace zip {
          * @throw NullPointerException if the passed buffer is NULL.
          * @throw IndexOutOfBoundsException if offset + length > size of the buffer.
          */
-        virtual void update( const unsigned char* buffer, int size, int offset, int length );
+        virtual void update(const unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Updates the current checksum with the specified byte value.
@@ -97,7 +97,7 @@ namespace zip {
          * @param byte
          *      The byte value to update the current Checksum with (0..255).
          */
-        virtual void update( int byte );
+        virtual void update(int byte);
 
     };
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/CRC32.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/CRC32.cpp b/activemq-cpp/src/main/decaf/util/zip/CRC32.cpp
index 5d3b308..6b4c3dd 100644
--- a/activemq-cpp/src/main/decaf/util/zip/CRC32.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/CRC32.cpp
@@ -36,7 +36,7 @@ CRC32::~CRC32() {
 
 ////////////////////////////////////////////////////////////////////////////////
 void CRC32::reset() {
-    this->value = crc32( (uLong)this->value, NULL, 0 );
+    this->value = crc32((uLong) this->value, NULL, 0);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
@@ -45,36 +45,33 @@ long long CRC32::getValue() const {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void CRC32::update( const std::vector<unsigned char>& buffer ) {
-    this->update( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+void CRC32::update(const std::vector<unsigned char>& buffer) {
+    this->update(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void CRC32::update( const std::vector<unsigned char>& buffer, int offset, int length ) {
+void CRC32::update(const std::vector<unsigned char>& buffer, int offset, int length) {
 
-    if( offset + length > (int)buffer.size() ) {
+    if (offset + length > (int) buffer.size()) {
         throw IndexOutOfBoundsException(
-            __FILE__, __LINE__, "Given offset + length exceeds the length of the buffer." );
+            __FILE__, __LINE__, "Given offset + length exceeds the length of the buffer.");
     }
 
-    this->update( &buffer[0], (int)buffer.size(), offset, length );
+    this->update(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void CRC32::update( int byte ) {
-    this->value = crc32( (uLong)this->value, (const Bytef*)&byte, 1 );
+void CRC32::update(int byte) {
+    this->value = crc32((uLong) this->value, (const Bytef*) &byte, 1);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void CRC32::update( const unsigned char* buffer, int size, int offset, int length ) {
+void CRC32::update(const unsigned char* buffer, int size, int offset, int length) {
 
-    if( offset + length > size ) {
+    if (offset + length > size) {
         throw IndexOutOfBoundsException(
-            __FILE__, __LINE__, "Given offset + length exceeds the length of the buffer." );
+            __FILE__, __LINE__, "Given offset + length exceeds the length of the buffer.");
     }
 
-    this->value = crc32( (uLong)this->value, (const Bytef*)( buffer + offset ), (uInt)length );
+    this->value = crc32((uLong) this->value, (const Bytef*) (buffer + offset), (uInt) length);
 }
-
-
-

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/CRC32.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/CRC32.h b/activemq-cpp/src/main/decaf/util/zip/CRC32.h
index 6b6ba0d..221b1cf 100644
--- a/activemq-cpp/src/main/decaf/util/zip/CRC32.h
+++ b/activemq-cpp/src/main/decaf/util/zip/CRC32.h
@@ -42,7 +42,7 @@ namespace zip {
         virtual ~CRC32();
 
         /**
-         * @returns the current checksum value.
+         * @return the current checksum value.
          */
         virtual long long getValue() const;
 
@@ -57,7 +57,7 @@ namespace zip {
          * @param buffer
          *      The buffer to read the updated bytes from.
          */
-        virtual void update( const std::vector<unsigned char>& buffer );
+        virtual void update(const std::vector<unsigned char>& buffer);
 
         /**
          * Updates the current checksum with the specified array of bytes.
@@ -88,7 +88,7 @@ namespace zip {
          * @throw NullPointerException if the passed buffer is NULL.
          * @throw IndexOutOfBoundsException if offset + length > size of the buffer.
          */
-        virtual void update( const unsigned char* buffer, int size, int offset, int length );
+        virtual void update(const unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Updates the current checksum with the specified byte value.
@@ -96,7 +96,7 @@ namespace zip {
          * @param byte
          *      The byte value to update the current Checksum with (0..255).
          */
-        virtual void update( int byte );
+        virtual void update(int byte);
 
     };
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.cpp b/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.cpp
index 241278b..b7dfc46 100644
--- a/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.cpp
@@ -27,12 +27,12 @@ using namespace decaf::util;
 using namespace decaf::util::zip;
 
 ////////////////////////////////////////////////////////////////////////////////
-CheckedInputStream::CheckedInputStream( InputStream* inputStream, Checksum* sum, bool own )
- :  FilterInputStream( inputStream, own ), sum( sum ) {
+CheckedInputStream::CheckedInputStream(InputStream* inputStream, Checksum* sum, bool own) :
+    FilterInputStream(inputStream, own), sum(sum) {
 
-    if( sum == NULL ) {
+    if (sum == NULL) {
         throw NullPointerException(
-            __FILE__, __LINE__, "The Checksum instance cannot be NULL." );
+            __FILE__, __LINE__, "The Checksum instance cannot be NULL.");
     }
 }
 
@@ -41,117 +41,117 @@ CheckedInputStream::~CheckedInputStream() {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-long long CheckedInputStream::skip( long long num ) {
+long long CheckedInputStream::skip(long long num) {
 
-    try{
+    try {
 
-        if( num <= 0 ) {
+        if (num <= 0) {
             return 0;
         }
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                __FILE__, __LINE__, "Stream is Closed." );
+                __FILE__, __LINE__, "Stream is Closed.");
         }
 
         // Perform smaller reads then the indicated amount
-        int remaining = Math::min( (int)num, 2048 );
+        int remaining = Math::min((int) num, 2048);
         long long skipped = 0;
 
-        std::vector<unsigned char> buffer( remaining );
+        std::vector<unsigned char> buffer(remaining);
 
-        while( skipped < num ) {
+        while (skipped < num) {
 
-            int result = this->inputStream->read( &buffer[0], remaining );
+            int result = this->inputStream->read(&buffer[0], remaining);
 
-            if( isClosed() ) {
+            if (isClosed()) {
                 throw IOException(
-                    __FILE__, __LINE__, "Stream is Closed." );
+                    __FILE__, __LINE__, "Stream is Closed.");
             }
 
-            if( result == -1 ) {
+            if (result == -1) {
                 return skipped;
             }
 
-            this->sum->update( buffer, 0, remaining );
+            this->sum->update(buffer, 0, remaining);
 
             skipped += result;
-            remaining = ( num - skipped ) > (long long)buffer.size() ? (int)buffer.size() : (int)(num - skipped);
+            remaining = (num - skipped) > (long long) buffer.size() ? (int) buffer.size() : (int) (num - skipped);
         }
 
         return skipped;
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int CheckedInputStream::doReadByte() {
 
-    try{
+    try {
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                __FILE__, __LINE__, "Stream is Closed." );
+                __FILE__, __LINE__, "Stream is Closed.");
         }
 
         int result = this->inputStream->read();
 
-        if( result != -1 ) {
-            this->sum->update( result );
+        if (result != -1) {
+            this->sum->update(result);
         }
 
         return result;
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int CheckedInputStream::doReadArrayBounded( unsigned char* buffer, int size, int offset, int length ) {
+int CheckedInputStream::doReadArrayBounded(unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Buffer passed was NULL" );
+                __FILE__, __LINE__, "Buffer passed was NULL");
         }
 
-        if( size < 0 ) {
+        if (size < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size );
+                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size);
         }
 
-        if( offset > size || offset < 0 ) {
+        if (offset > size || offset < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset );
+                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset);
         }
 
-        if( length < 0 || length > size - offset ) {
+        if (length < 0 || length > size - offset) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length );
+                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length);
         }
 
-        if( length == 0 ) {
+        if (length == 0) {
             return 0;
         }
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                __FILE__, __LINE__, "Stream is Closed." );
+                __FILE__, __LINE__, "Stream is Closed.");
         }
 
-        int result = this->inputStream->read( buffer, size, offset, length );
+        int result = this->inputStream->read(buffer, size, offset, length);
 
-        if( result != -1 ) {
+        if (result != -1) {
             // Only add the amount of bytes actually read to the Checksum.
-            this->sum->update( buffer, size, offset, result );
+            this->sum->update(buffer, size, offset, result);
         }
 
         return result;
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCHALL_THROW(IOException)
 }

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.h b/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.h
index 7f86f92..05839f2 100644
--- a/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.h
+++ b/activemq-cpp/src/main/decaf/util/zip/CheckedInputStream.h
@@ -42,8 +42,8 @@ namespace zip {
 
     private:
 
-        CheckedInputStream( const CheckedInputStream& );
-        CheckedInputStream& operator= ( const CheckedInputStream& );
+        CheckedInputStream(const CheckedInputStream&);
+        CheckedInputStream& operator=(const CheckedInputStream&);
 
     public:
 
@@ -59,7 +59,7 @@ namespace zip {
          *
          * @throws NullPointerException if the Checksum pointer is NULL.
          */
-        CheckedInputStream( InputStream* inputStream, Checksum* sum, bool own = false );
+        CheckedInputStream(InputStream* inputStream, Checksum* sum, bool own = false);
 
         virtual ~CheckedInputStream();
 
@@ -77,13 +77,13 @@ namespace zip {
          *
          * Adds the skipped bytes into the Checksum.
          */
-        virtual long long skip( long long num );
+        virtual long long skip(long long num);
 
     protected:
 
         virtual int doReadByte();
 
-        virtual int doReadArrayBounded( unsigned char* buffer, int size, int offset, int length );
+        virtual int doReadArrayBounded(unsigned char* buffer, int size, int offset, int length);
 
     };
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.cpp b/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.cpp
index 27519e0..2d6f463 100644
--- a/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.cpp
@@ -25,12 +25,12 @@ using namespace decaf::util;
 using namespace decaf::util::zip;
 
 ////////////////////////////////////////////////////////////////////////////////
-CheckedOutputStream::CheckedOutputStream( OutputStream* outputStream, Checksum* sum, bool own )
- :  FilterOutputStream( outputStream, own ), sum( sum ) {
+CheckedOutputStream::CheckedOutputStream(OutputStream* outputStream, Checksum* sum, bool own) :
+    FilterOutputStream(outputStream, own), sum(sum) {
 
-    if( sum == NULL ) {
+    if (sum == NULL) {
         throw NullPointerException(
-            __FILE__, __LINE__, "The Checksum instance cannot be NULL." );
+            __FILE__, __LINE__, "The Checksum instance cannot be NULL.");
     }
 }
 
@@ -39,58 +39,57 @@ CheckedOutputStream::~CheckedOutputStream() {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void CheckedOutputStream::doWriteByte( unsigned char value ) {
+void CheckedOutputStream::doWriteByte(unsigned char value) {
 
-    try{
+    try {
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                 __FILE__, __LINE__, "Stream already closed" );
+                __FILE__, __LINE__, "Stream already closed");
         }
 
-        this->outputStream->write( value );
-        this->sum->update( value );
+        this->outputStream->write(value);
+        this->sum->update(value);
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void CheckedOutputStream::doWriteArrayBounded( const unsigned char* buffer, int size,
-                                               int offset, int length ) {
+void CheckedOutputStream::doWriteArrayBounded(const unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                 __FILE__, __LINE__, "The buffer passed was NULL." );
+                __FILE__, __LINE__, "The buffer passed was NULL.");
         }
 
-        if( size < 0 ) {
+        if (size < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size );
+                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size);
         }
 
-        if( offset > size || offset < 0 ) {
+        if (offset > size || offset < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset );
+                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset);
         }
 
-        if( length < 0 || length > size - offset ) {
+        if (length < 0 || length > size - offset) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length );
+                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length);
         }
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                 __FILE__, __LINE__, "Stream already closed" );
+                __FILE__, __LINE__, "Stream already closed");
         }
 
-        this->outputStream->write( buffer, size, offset, length );
-        this->sum->update( buffer, size, offset, length );
+        this->outputStream->write(buffer, size, offset, length);
+        this->sum->update(buffer, size, offset, length);
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCHALL_THROW(IOException)
 }

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h b/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
index f0175af..870ddf8 100644
--- a/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
+++ b/activemq-cpp/src/main/decaf/util/zip/CheckedOutputStream.h
@@ -41,8 +41,8 @@ namespace zip {
 
     private:
 
-        CheckedOutputStream( const CheckedOutputStream& );
-        CheckedOutputStream& operator= ( const CheckedOutputStream& );
+        CheckedOutputStream(const CheckedOutputStream&);
+        CheckedOutputStream& operator=(const CheckedOutputStream&);
 
     public:
 
@@ -58,7 +58,7 @@ namespace zip {
          *
          * @throws NullPointerException if the Checksum pointer is NULL.
          */
-        CheckedOutputStream( decaf::io::OutputStream* outputStream, Checksum* sum, bool own = false );
+        CheckedOutputStream(decaf::io::OutputStream* outputStream, Checksum* sum, bool own = false);
 
         virtual ~CheckedOutputStream();
 
@@ -71,9 +71,9 @@ namespace zip {
 
     protected:
 
-        virtual void doWriteByte( unsigned char value );
+        virtual void doWriteByte(unsigned char value);
 
-        virtual void doWriteArrayBounded( const unsigned char* buffer, int size, int offset, int length );
+        virtual void doWriteArrayBounded(const unsigned char* buffer, int size, int offset, int length);
 
     };
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/Checksum.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Checksum.h b/activemq-cpp/src/main/decaf/util/zip/Checksum.h
index bb567ac..0cb0d2a 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Checksum.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Checksum.h
@@ -55,7 +55,7 @@ namespace zip {
          * @param buffer
          *      The buffer to read the updated bytes from.
          */
-        virtual void update( const std::vector<unsigned char>& buffer ) = 0;
+        virtual void update(const std::vector<unsigned char>& buffer) = 0;
 
         /**
          * Updates the current checksum with the specified array of bytes.
@@ -69,7 +69,7 @@ namespace zip {
          *
          * @throw IndexOutOfBoundsException if offset + length > size of the buffer.
          */
-        virtual void update( const std::vector<unsigned char>& buffer, int offset, int length ) = 0;
+        virtual void update(const std::vector<unsigned char>& buffer, int offset, int length) = 0;
 
         /**
          * Updates the current checksum with the specified array of bytes.
@@ -86,7 +86,7 @@ namespace zip {
          * @throw NullPointerException if the passed buffer is NULL.
          * @throw IndexOutOfBoundsException if offset + length > size of the buffer.
          */
-        virtual void update( const unsigned char* buffer, int size, int offset, int length ) = 0;
+        virtual void update(const unsigned char* buffer, int size, int offset, int length) = 0;
 
         /**
          * Updates the current checksum with the specified byte value.
@@ -94,7 +94,7 @@ namespace zip {
          * @param byte
          *      The byte value to update the current Checksum with (0..255).
          */
-        virtual void update( int byte ) = 0;
+        virtual void update(int byte) = 0;
 
     };
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/Deflater.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Deflater.cpp b/activemq-cpp/src/main/decaf/util/zip/Deflater.cpp
index 12f4184..4d27edd 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Deflater.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/Deflater.cpp
@@ -30,9 +30,9 @@ using namespace decaf::util;
 using namespace decaf::util::zip;
 
 ////////////////////////////////////////////////////////////////////////////////
-namespace decaf{
-namespace util{
-namespace zip{
+namespace decaf {
+namespace util {
+namespace zip {
 
     class DeflaterData {
     public:
@@ -48,8 +48,8 @@ namespace zip{
 
     private:
 
-        DeflaterData( const DeflaterData& );
-        DeflaterData& operator= ( const DeflaterData& );
+    DeflaterData(const DeflaterData&);
+    DeflaterData& operator=(const DeflaterData&);
 
     public:
 
@@ -64,11 +64,11 @@ namespace zip{
 
     public:
 
-        static void initZLibDeflate( DeflaterData* handle, int level, bool nowrap = false ) {
+        static void initZLibDeflate(DeflaterData* handle, int level, bool nowrap = false) {
 
-            if( handle == NULL ) {
+            if (handle == NULL) {
                 throw NullPointerException(
-                    __FILE__, __LINE__, "Error While initializing the Compression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Compression Library.");
             }
 
             handle->stream = new z_stream;
@@ -87,58 +87,58 @@ namespace zip{
             handle->stream->next_in = Z_NULL;
 
             int result = Z_OK;
-            if( nowrap == false ) {
-                result = deflateInit( handle->stream, handle->level );
+            if (nowrap == false) {
+                result = deflateInit(handle->stream, handle->level);
             } else {
 
                 // Turn off ZLib header wrapping and encode raw.  Attempts
                 // to set all other values to their normal defaults.
-                result = deflateInit2( handle->stream,
-                                       handle->level,
-                                       Z_DEFLATED,
-                                       -15, 8,
-                                       Z_DEFAULT_STRATEGY );
+                result = deflateInit2(handle->stream,
+                                      handle->level,
+                                      Z_DEFLATED,
+                                      -15, 8,
+                                      Z_DEFAULT_STRATEGY);
             }
 
-            if( result != Z_OK ) {
+            if (result != Z_OK) {
                 throw RuntimeException(
-                    __FILE__, __LINE__, "Error While initializing the Compression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Compression Library.");
             }
         }
 
-        static void finishZlibDeflate( DeflaterData* handle ) {
+        static void finishZlibDeflate(DeflaterData* handle) {
 
-            if( handle == NULL ) {
+            if (handle == NULL) {
                 throw NullPointerException(
-                    __FILE__, __LINE__, "Error While initializing the Compression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Compression Library.");
             }
 
             handle->ended = true;
 
-            if( handle->stream != NULL ) {
+            if (handle->stream != NULL) {
 
                 // Shutdown the ZLib stream
-                deflateEnd( handle->stream );
+                deflateEnd(handle->stream);
                 delete handle->stream;
                 handle->stream = NULL;
             }
         }
 
-        static void resetZlibStream( DeflaterData* handle ) {
+        static void resetZlibStream(DeflaterData* handle) {
 
-            if( handle == NULL ) {
+            if (handle == NULL) {
                 throw NullPointerException(
-                    __FILE__, __LINE__, "Error While initializing the Compression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Compression Library.");
             }
 
-            if( handle->stream != NULL ) {
+            if (handle->stream != NULL) {
 
                 handle->finished = false;
                 handle->flush = Z_NO_FLUSH;
                 handle->ended = false;
 
                 // Ask ZLib to do the reset.
-                deflateReset( handle->stream );
+                deflateReset(handle->stream);
 
                 // Clear any old data that might still be around.
                 handle->stream->opaque = Z_NULL;
@@ -163,102 +163,100 @@ const int Deflater::FILTERED = 1;
 const int Deflater::HUFFMAN_ONLY = 2;
 
 ////////////////////////////////////////////////////////////////////////////////
-Deflater::Deflater( int level, bool nowrap ) : data( new DeflaterData() ) {
+Deflater::Deflater(int level, bool nowrap) : data(new DeflaterData()) {
 
-    if( level < DEFAULT_COMPRESSION || level > BEST_COMPRESSION ) {
+    if (level < DEFAULT_COMPRESSION || level > BEST_COMPRESSION) {
         throw IllegalArgumentException(
-            __FILE__, __LINE__, "Compression level passed was Invalid: %d", level );
+            __FILE__, __LINE__, "Compression level passed was Invalid: %d", level);
     }
 
     // Initialize all the ZLib structures.
-    DeflaterData::initZLibDeflate( this->data, level, nowrap );
+    DeflaterData::initZLibDeflate(this->data, level, nowrap);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-Deflater::Deflater() : data( new DeflaterData() ) {
+Deflater::Deflater() : data(new DeflaterData()) {
     // Initialize all the ZLib structures.
-    DeflaterData::initZLibDeflate( this->data, DEFAULT_COMPRESSION );
+    DeflaterData::initZLibDeflate(this->data, DEFAULT_COMPRESSION);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 Deflater::~Deflater() {
-    try{
+    try {
         this->end();
         delete this->data;
     }
-    DECAF_CATCH_NOTHROW( Exception )
+    DECAF_CATCH_NOTHROW(Exception)
     DECAF_CATCHALL_NOTHROW()
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setInput( const unsigned char* buffer, int size, int offset, int length ) {
+void Deflater::setInput(const unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Buffer passed cannot be NULL." );
+                __FILE__, __LINE__, "Buffer passed cannot be NULL.");
         }
 
-        if( this->data->stream == NULL ) {
+        if (this->data->stream == NULL) {
             throw IllegalStateException(
-                __FILE__, __LINE__, "The Deflator has already been ended." );
+                __FILE__, __LINE__, "The Deflator has already been ended.");
         }
 
-        if( offset + length > size ) {
+        if (offset + length > size) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "Given offset + length greater than the size of the buffer." );
+                __FILE__, __LINE__, "Given offset + length greater than the size of the buffer.");
         }
 
-
         // We can only change the level and strategy once an entire block of data is compressed.
-        if( this->data->stream->next_in == NULL ) {
-            deflateParams( this->data->stream, this->data->level, this->data->strategy );
+        if (this->data->stream->next_in == NULL) {
+            deflateParams(this->data->stream, this->data->level, this->data->strategy);
         }
 
-        this->data->stream->avail_in = (uInt)length;
-        this->data->stream->next_in = (Bytef*)( buffer + offset );
+        this->data->stream->avail_in = (uInt) length;
+        this->data->stream->next_in = (Bytef*) (buffer + offset);
     }
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IllegalStateException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCHALL_THROW( IllegalStateException )
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IllegalStateException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCHALL_THROW(IllegalStateException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setInput( const std::vector<unsigned char>& buffer, int offset, int length ) {
-
-    this->setInput( &buffer[0], (int)buffer.size(), offset, length );
+void Deflater::setInput(const std::vector<unsigned char>& buffer, int offset, int length) {
+    this->setInput(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setInput( const std::vector<unsigned char>& buffer ) {
+void Deflater::setInput(const std::vector<unsigned char>& buffer) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return;
     }
 
-    this->setInput( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+    this->setInput(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setDictionary( const unsigned char* buffer, int size, int offset, int length ) {
+void Deflater::setDictionary(const unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Buffer passed cannot be NULL." );
+                __FILE__, __LINE__, "Buffer passed cannot be NULL.");
         }
 
-        if( this->data->stream == NULL ) {
+        if (this->data->stream == NULL) {
             throw IllegalStateException(
-                __FILE__, __LINE__, "The Deflator has already been ended." );
+                __FILE__, __LINE__, "The Deflator has already been ended.");
         }
 
-        if( offset + length > size ) {
+        if (offset + length > size) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "Given offset + length greater than the size of the buffer." );
+                __FILE__, __LINE__, "Given offset + length greater than the size of the buffer.");
         }
 
         // From the ZLib documentation.
@@ -266,60 +264,59 @@ void Deflater::setDictionary( const unsigned char* buffer, int size, int offset,
         // (such as NULL dictionary) or the stream state is inconsistent (for example if deflate has
         // already been called for this stream or if the compression method is bsort).
         // deflateSetDictionary does not perform any compression: this will be done by deflate().
-        if( deflateSetDictionary( this->data->stream, buffer + offset, (uInt)length ) != Z_OK ) {
+        if (deflateSetDictionary(this->data->stream, buffer + offset, (uInt) length) != Z_OK) {
             throw IllegalStateException(
-                __FILE__, __LINE__, "Deflator could not accept the dictionary." );
+                __FILE__, __LINE__, "Deflator could not accept the dictionary.");
         }
     }
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IllegalStateException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCHALL_THROW( IllegalStateException )
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IllegalStateException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCHALL_THROW(IllegalStateException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setDictionary( const std::vector<unsigned char>& buffer, int offset, int length ) {
-
-    this->setDictionary( &buffer[0], (int)buffer.size(), offset, length );
+void Deflater::setDictionary(const std::vector<unsigned char>& buffer, int offset, int length) {
+    this->setDictionary(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setDictionary( const std::vector<unsigned char>& buffer ) {
+void Deflater::setDictionary(const std::vector<unsigned char>& buffer) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return;
     }
 
-    this->setDictionary( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+    this->setDictionary(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setStrategy( int strategy ) {
+void Deflater::setStrategy(int strategy) {
 
-    if( strategy < DEFAULT_STRATEGY || strategy > HUFFMAN_ONLY ) {
+    if (strategy < DEFAULT_STRATEGY || strategy > HUFFMAN_ONLY) {
         throw IllegalArgumentException(
-            __FILE__, __LINE__, "Strategy value {%d} is not valid.", strategy );
+            __FILE__, __LINE__, "Strategy value {%d} is not valid.", strategy);
     }
 
-    if( this->data->stream == NULL && !this->data->ended ) {
+    if (this->data->stream == NULL && !this->data->ended) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Deflator is in an invalid state." );
+            __FILE__, __LINE__, "The Deflator is in an invalid state.");
     }
 
     this->data->strategy = strategy;
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Deflater::setLevel( int level ) {
+void Deflater::setLevel(int level) {
 
-    if( level < DEFAULT_COMPRESSION || level > BEST_COMPRESSION ) {
+    if (level < DEFAULT_COMPRESSION || level > BEST_COMPRESSION) {
         throw IllegalArgumentException(
-            __FILE__, __LINE__, "Strategy value {%d} is not valid.", level );
+            __FILE__, __LINE__, "Strategy value {%d} is not valid.", level);
     }
 
-    if( this->data->stream == NULL && !this->data->ended ) {
+    if (this->data->stream == NULL && !this->data->ended) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Deflator is in an invalid state." );
+            __FILE__, __LINE__, "The Deflator is in an invalid state.");
     }
 
     this->data->level = level;
@@ -327,7 +324,7 @@ void Deflater::setLevel( int level ) {
 
 ////////////////////////////////////////////////////////////////////////////////
 bool Deflater::needsInput() const {
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         return false;
     }
 
@@ -345,72 +342,70 @@ bool Deflater::finished() const {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int Deflater::deflate( unsigned char* buffer, int size, int offset, int length ) {
+int Deflater::deflate(unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Buffer passed cannot be NULL." );
+                __FILE__, __LINE__, "Buffer passed cannot be NULL.");
         }
 
-        if( this->data->stream == NULL ) {
+        if (this->data->stream == NULL) {
             throw IllegalStateException(
-                __FILE__, __LINE__, "The Deflator has already been ended." );
+                __FILE__, __LINE__, "The Deflator has already been ended.");
         }
 
-        if( size < 0 ) {
+        if (size < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size );
+                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size);
         }
 
-        if( offset > size || offset < 0 ) {
+        if (offset > size || offset < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset );
+                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset);
         }
 
-        if( length < 0 || length > size - offset ) {
+        if (length < 0 || length > size - offset) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length );
+                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length);
         }
 
         unsigned long outStart = this->data->stream->total_out;
 
         this->data->stream->next_out = buffer + offset;
-        this->data->stream->avail_out = (uInt)length;
+        this->data->stream->avail_out = (uInt) length;
 
         // Call ZLib and then process the resulting data to figure out what happened.
-        int result = ::deflate( this->data->stream, this->data->flush );
+        int result = ::deflate(this->data->stream, this->data->flush);
 
-        if( result == Z_STREAM_END ) {
+        if (result == Z_STREAM_END) {
             this->data->finished = true;
         }
 
-        return (int)( this->data->stream->total_out - outStart );
+        return (int) (this->data->stream->total_out - outStart);
     }
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IllegalStateException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCHALL_THROW( IllegalStateException )
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IllegalStateException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCHALL_THROW(IllegalStateException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int Deflater::deflate( std::vector<unsigned char>& buffer, int offset, int length ) {
-
-    return this->deflate( &buffer[0], (int)buffer.size(), offset, length );
+int Deflater::deflate(std::vector<unsigned char>& buffer, int offset, int length) {
+    return this->deflate(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int Deflater::deflate( std::vector<unsigned char>& buffer ) {
-
-    return this->deflate( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+int Deflater::deflate(std::vector<unsigned char>& buffer) {
+    return this->deflate(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 long long Deflater::getAdler() const {
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Deflator has already been ended." );
+            __FILE__, __LINE__, "The Deflator has already been ended.");
     }
 
     return this->data->stream->adler;
@@ -418,9 +413,9 @@ long long Deflater::getAdler() const {
 
 ////////////////////////////////////////////////////////////////////////////////
 long long Deflater::getBytesRead() const {
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Deflator has already been ended." );
+            __FILE__, __LINE__, "The Deflator has already been ended.");
     }
 
     return this->data->stream->total_in;
@@ -428,9 +423,9 @@ long long Deflater::getBytesRead() const {
 
 ////////////////////////////////////////////////////////////////////////////////
 long long Deflater::getBytesWritten() const {
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Deflator has already been ended." );
+            __FILE__, __LINE__, "The Deflator has already been ended.");
     }
 
     return this->data->stream->total_out;
@@ -439,18 +434,18 @@ long long Deflater::getBytesWritten() const {
 ////////////////////////////////////////////////////////////////////////////////
 void Deflater::reset() {
 
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Deflator has already been ended." );
+            __FILE__, __LINE__, "The Deflator has already been ended.");
     }
 
-    DeflaterData::resetZlibStream( this->data );
+    DeflaterData::resetZlibStream(this->data);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 void Deflater::end() {
 
-    if( this->data ) {
-        DeflaterData::finishZlibDeflate( this->data );
+    if (this->data) {
+        DeflaterData::finishZlibDeflate(this->data);
     }
 }

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/Deflater.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Deflater.h b/activemq-cpp/src/main/decaf/util/zip/Deflater.h
index 06d74e0..6e0b59e 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Deflater.h
+++ b/activemq-cpp/src/main/decaf/util/zip/Deflater.h
@@ -101,8 +101,8 @@ namespace zip {
 
     private:
 
-        Deflater( const Deflater& );
-        Deflater operator= ( const Deflater& );
+        Deflater(const Deflater&);
+        Deflater operator=(const Deflater&);
 
     public:
 
@@ -116,7 +116,7 @@ namespace zip {
          * @param nowrap
          *      If true uses GZip compatible compression (defaults to false).
          */
-        Deflater( int level, bool nowrap = false );
+        Deflater(int level, bool nowrap = false);
 
         /**
          * Creates a new compressor with the default compression level. Compressed data will be
@@ -143,7 +143,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        void setInput( const unsigned char* buffer, int size, int offset, int length );
+        void setInput(const unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Sets input data for compression. This should be called whenever needsInput() returns
@@ -159,7 +159,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        void setInput( const std::vector<unsigned char>& buffer, int offset, int length );
+        void setInput(const std::vector<unsigned char>& buffer, int offset, int length);
 
         /**
          * Sets input data for compression. This should be called whenever needsInput() returns
@@ -170,7 +170,7 @@ namespace zip {
          *
          * @throws IllegalStateException if in the end state.
          */
-        void setInput( const std::vector<unsigned char>& buffer );
+        void setInput(const std::vector<unsigned char>& buffer);
 
         /**
          * Sets preset dictionary for compression. A preset dictionary is used when the
@@ -191,7 +191,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        void setDictionary( const unsigned char* buffer, int size, int offset, int length );
+        void setDictionary(const unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Sets preset dictionary for compression. A preset dictionary is used when the
@@ -209,7 +209,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        void setDictionary( const std::vector<unsigned char>& buffer, int offset, int length );
+        void setDictionary(const std::vector<unsigned char>& buffer, int offset, int length);
 
         /**
          * Sets preset dictionary for compression. A preset dictionary is used when the
@@ -222,7 +222,7 @@ namespace zip {
          *
          * @throws IllegalStateException if in the end state.
          */
-        void setDictionary( const std::vector<unsigned char>& buffer );
+        void setDictionary(const std::vector<unsigned char>& buffer);
 
         /**
          * Sets the compression strategy to the specified value.
@@ -233,7 +233,7 @@ namespace zip {
          * @throws IllegalArgumentException if the strategy value is invalid.
          * @throws IllegalStateException if in the end state.
          */
-        void setStrategy( int strategy );
+        void setStrategy(int strategy);
 
         /**
          * Sets the compression level to the specified value.
@@ -244,7 +244,7 @@ namespace zip {
          * @throws IllegalArgumentException if the level value is invalid.
          * @throws IllegalStateException if in the end state.
          */
-        void setLevel( int level );
+        void setLevel(int level);
 
         /**
          * @return true if the input data buffer is empty and setInput() should be called in
@@ -283,7 +283,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        int deflate( unsigned char* buffer, int size, int offset, int length );
+        int deflate(unsigned char* buffer, int size, int offset, int length);
 
         /**
          * Fills specified buffer with compressed data. Returns actual number of bytes of
@@ -302,7 +302,7 @@ namespace zip {
          * @throws IndexOutOfBoundsException if the offset + length > size of the buffer.
          * @throws IllegalStateException if in the end state.
          */
-        int deflate( std::vector<unsigned char>& buffer, int offset, int length );
+        int deflate(std::vector<unsigned char>& buffer, int offset, int length);
 
         /**
          * Fills specified buffer with compressed data. Returns actual number of bytes of
@@ -316,7 +316,7 @@ namespace zip {
          *
          * @throws IllegalStateException if in the end state.
          */
-        int deflate( std::vector<unsigned char>& buffer );
+        int deflate(std::vector<unsigned char>& buffer);
 
         /**
          * @returns the ADLER-32 value of the uncompressed data.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.cpp b/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.cpp
index bf9ccfb..379c542 100644
--- a/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.cpp
@@ -28,174 +28,171 @@ using namespace decaf::util::zip;
 const std::size_t DeflaterOutputStream::DEFAULT_BUFFER_SIZE = 512;
 
 ////////////////////////////////////////////////////////////////////////////////
-DeflaterOutputStream::DeflaterOutputStream( OutputStream* outputStream, bool own ) :
-    FilterOutputStream( outputStream, own ), deflater(new Deflater()), buf(), ownDeflater(true), isDone(false) {
+DeflaterOutputStream::DeflaterOutputStream(OutputStream* outputStream, bool own) :
+    FilterOutputStream(outputStream, own), deflater(new Deflater()), buf(), ownDeflater(true), isDone(false) {
 
-    this->buf.resize( DEFAULT_BUFFER_SIZE );
+    this->buf.resize(DEFAULT_BUFFER_SIZE);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DeflaterOutputStream::DeflaterOutputStream( OutputStream* outputStream, Deflater* deflater, bool own, bool ownDeflater )
- :  FilterOutputStream( outputStream, own ), deflater(deflater), buf(), ownDeflater(ownDeflater), isDone(false) {
+DeflaterOutputStream::DeflaterOutputStream(OutputStream* outputStream, Deflater* deflater, bool own, bool ownDeflater) :
+    FilterOutputStream(outputStream, own), deflater(deflater), buf(), ownDeflater(ownDeflater), isDone(false) {
 
-    if( deflater == NULL ) {
+    if (deflater == NULL) {
         throw NullPointerException(
-             __FILE__, __LINE__, "Deflater passed was NULL." );
+            __FILE__, __LINE__, "Deflater passed was NULL.");
     }
 
-    this->buf.resize( DEFAULT_BUFFER_SIZE );
+    this->buf.resize(DEFAULT_BUFFER_SIZE);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-DeflaterOutputStream::DeflaterOutputStream( OutputStream* outputStream, Deflater* deflater,
-                                            int bufferSize, bool own, bool ownDeflater )
- :  FilterOutputStream( outputStream, own ), deflater(deflater), buf(), ownDeflater(ownDeflater), isDone(false) {
+DeflaterOutputStream::DeflaterOutputStream(OutputStream* outputStream, Deflater* deflater, int bufferSize, bool own, bool ownDeflater) :
+    FilterOutputStream(outputStream, own), deflater(deflater), buf(), ownDeflater(ownDeflater), isDone(false) {
 
-    if( deflater == NULL ) {
+    if (deflater == NULL) {
         throw NullPointerException(
-             __FILE__, __LINE__, "Deflater passed was NULL." );
+            __FILE__, __LINE__, "Deflater passed was NULL.");
     }
 
-    if( bufferSize == 0 ) {
+    if (bufferSize == 0) {
         throw IllegalArgumentException(
-             __FILE__, __LINE__, "Cannot create a zero sized buffer." );
+            __FILE__, __LINE__, "Cannot create a zero sized buffer.");
     }
 
-    this->buf.resize( bufferSize );
+    this->buf.resize(bufferSize);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 DeflaterOutputStream::~DeflaterOutputStream() {
-    try{
+    try {
 
         this->close();
 
-        if( ownDeflater ) {
+        if (ownDeflater) {
             delete this->deflater;
         }
     }
-    DECAF_CATCH_NOTHROW( Exception )
-    DECAF_CATCHALL_NOTHROW()
-}
+    DECAF_CATCH_NOTHROW(Exception)
+    DECAF_CATCHALL_NOTHROW()}
 
 ////////////////////////////////////////////////////////////////////////////////
 void DeflaterOutputStream::finish() {
 
-    try{
+    try {
 
-        if( isDone ) {
+        if (isDone) {
             return;
         }
 
         int result;
         this->deflater->finish();
 
-        while( !this->deflater->finished() ) {
+        while (!this->deflater->finished()) {
 
-            if( this->deflater->needsInput() ) {
-                this->deflater->setInput( buf, 0, 0 );
+            if (this->deflater->needsInput()) {
+                this->deflater->setInput(buf, 0, 0);
             }
-            result = this->deflater->deflate( &buf[0], (int)buf.size(), 0, (int)buf.size() );
-            this->outputStream->write( &buf[0], (int)buf.size(), 0, result );
+            result = this->deflater->deflate(&buf[0], (int) buf.size(), 0, (int) buf.size());
+            this->outputStream->write(&buf[0], (int) buf.size(), 0, result);
         }
 
         this->isDone = true;
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 void DeflaterOutputStream::close() {
 
-    try{
+    try {
 
-        if( !this->deflater->finished() ) {
+        if (!this->deflater->finished()) {
             this->finish();
         }
         this->deflater->end();
         FilterOutputStream::close();
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void DeflaterOutputStream::doWriteByte( unsigned char value ) {
+void DeflaterOutputStream::doWriteByte(unsigned char value) {
 
-    try{
-        this->doWriteArrayBounded( &value, 1, 0, 1 );
+    try {
+        this->doWriteArrayBounded(&value, 1, 0, 1);
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void DeflaterOutputStream::doWriteArrayBounded( const unsigned char* buffer, int size,
-                                                int offset, int length ) {
+void DeflaterOutputStream::doWriteArrayBounded(const unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( isDone ) {
+        if (isDone) {
             throw IOException(
-                __FILE__, __LINE__, "Finish was already called on this DeflaterOutputStream." );
+                __FILE__, __LINE__, "Finish was already called on this DeflaterOutputStream.");
         }
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Buffer passed was NULL." );
+                __FILE__, __LINE__, "Buffer passed was NULL.");
         }
 
-        if( size < 0 ) {
+        if (size < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size );
+                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size);
         }
 
-        if( offset > size || offset < 0 ) {
+        if (offset > size || offset < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset );
+                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset);
         }
 
-        if( length < 0 || length > size - offset ) {
+        if (length < 0 || length > size - offset) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length );
+                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length);
         }
 
-        if( length == 0 ) {
+        if (length == 0) {
             return;
         }
 
-        if( isClosed() ) {
+        if (isClosed()) {
             throw IOException(
-                __FILE__, __LINE__, "The stream is already closed." );
+                __FILE__, __LINE__, "The stream is already closed.");
         }
 
-        if( !this->deflater->needsInput() ) {
+        if (!this->deflater->needsInput()) {
             throw IOException(
-                __FILE__, __LINE__, "The Deflater is in an Invalid State." );
+                __FILE__, __LINE__, "The Deflater is in an Invalid State.");
         }
 
-        this->deflater->setInput( buffer, size, offset, length );
+        this->deflater->setInput(buffer, size, offset, length);
 
         this->deflate();
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCHALL_THROW(IOException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 void DeflaterOutputStream::deflate() {
 
-    try{
+    try {
 
         int result;
-        do{
-            result = this->deflater->deflate( &buf[0], (int)buf.size(), 0, (int)buf.size() );
-            this->outputStream->write( &buf[0], (int)buf.size(), 0, result );
-        } while( !this->deflater->needsInput() );
+        do {
+            result = this->deflater->deflate(&buf[0], (int) buf.size(), 0, (int) buf.size());
+            this->outputStream->write(&buf[0], (int) buf.size(), 0, result);
+        } while (!this->deflater->needsInput());
     }
-    DECAF_CATCH_RETHROW( IOException )
-    DECAF_CATCHALL_THROW( IOException )
+    DECAF_CATCH_RETHROW(IOException)
+    DECAF_CATCHALL_THROW(IOException)
 }

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.h b/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.h
index 08f751e..8e953e6 100644
--- a/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.h
+++ b/activemq-cpp/src/main/decaf/util/zip/DeflaterOutputStream.h
@@ -56,8 +56,8 @@ namespace zip {
 
     private:
 
-        DeflaterOutputStream( const DeflaterOutputStream& );
-        DeflaterOutputStream& operator= ( const DeflaterOutputStream& );
+        DeflaterOutputStream(const DeflaterOutputStream&);
+        DeflaterOutputStream& operator=(const DeflaterOutputStream&);
 
     public:
 
@@ -69,7 +69,7 @@ namespace zip {
          * @param own
          *      Should this filter take ownership of the OutputStream pointer (default is false).
          */
-        DeflaterOutputStream( decaf::io::OutputStream* outputStream, bool own = false );
+        DeflaterOutputStream(decaf::io::OutputStream* outputStream, bool own = false);
 
         /**
          * Creates a new DeflateOutputStream with a user supplied Deflater and a default buffer size.
@@ -88,8 +88,8 @@ namespace zip {
          *
          * @throws NullPointerException if the Deflater given is NULL.
          */
-        DeflaterOutputStream( decaf::io::OutputStream* outputStream, Deflater* deflater,
-                              bool own = false, bool ownDeflater = false );
+        DeflaterOutputStream(decaf::io::OutputStream* outputStream, Deflater* deflater,
+                             bool own = false, bool ownDeflater = false);
 
         /**
          * Creates a new DeflateOutputStream with a user supplied Deflater and specified buffer size.
@@ -111,8 +111,8 @@ namespace zip {
          * @throws NullPointerException if the Deflater given is NULL.
          * @throws IllegalArgumentException if bufferSize is 0.
          */
-        DeflaterOutputStream( decaf::io::OutputStream* outputStream, Deflater* deflater,
-                              int bufferSize, bool own = false, bool ownDeflater = false );
+        DeflaterOutputStream(decaf::io::OutputStream* outputStream, Deflater* deflater,
+                             int bufferSize, bool own = false, bool ownDeflater = false);
 
         virtual ~DeflaterOutputStream();
 
@@ -133,10 +133,9 @@ namespace zip {
 
     protected:
 
-        virtual void doWriteByte( unsigned char value );
+        virtual void doWriteByte(unsigned char value);
 
-        virtual void doWriteArrayBounded( const unsigned char* buffer, int size,
-                                          int offset, int length );
+        virtual void doWriteArrayBounded(const unsigned char* buffer, int size, int offset, int length);
 
     protected:
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/e058de24/activemq-cpp/src/main/decaf/util/zip/Inflater.cpp
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/util/zip/Inflater.cpp b/activemq-cpp/src/main/decaf/util/zip/Inflater.cpp
index bb0923f..48dff4f 100644
--- a/activemq-cpp/src/main/decaf/util/zip/Inflater.cpp
+++ b/activemq-cpp/src/main/decaf/util/zip/Inflater.cpp
@@ -47,8 +47,8 @@ namespace zip{
 
     private:
 
-        InflaterData( const InflaterData& );
-        InflaterData& operator= ( const InflaterData& );
+        InflaterData(const InflaterData&);
+        InflaterData& operator=(const InflaterData&);
 
     public:
 
@@ -56,11 +56,11 @@ namespace zip{
 
     public:
 
-        static void initZlibInflate( InflaterData* handle, bool nowrap = false ) {
+        static void initZlibInflate(InflaterData* handle, bool nowrap = false) {
 
-            if( handle == NULL ) {
+            if (handle == NULL) {
                 throw NullPointerException(
-                    __FILE__, __LINE__, "Error While initializing the Decompression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Decompression Library.");
             }
 
             handle->stream = new z_stream;
@@ -77,50 +77,50 @@ namespace zip{
             handle->stream->next_in = Z_NULL;
 
             int result = Z_OK;
-            if( nowrap == false ) {
-                result = inflateInit( handle->stream );
+            if (nowrap == false) {
+                result = inflateInit(handle->stream);
             } else {
                 // Disable the ZLib header.
-                result = inflateInit2( handle->stream, -15 );
+                result = inflateInit2(handle->stream, -15);
             }
 
-            if( result != Z_OK ) {
+            if (result != Z_OK) {
                 throw RuntimeException(
-                    __FILE__, __LINE__, "Error While initializing the Decompression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Decompression Library.");
             }
         }
 
-        static void finishZlibDeflate( InflaterData* handle ) {
+        static void finishZlibDeflate(InflaterData* handle) {
 
-            if( handle == NULL ) {
+            if (handle == NULL) {
                 throw NullPointerException(
-                    __FILE__, __LINE__, "Error While initializing the Decompression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Decompression Library.");
             }
 
-            if( handle->stream != NULL ) {
+            if (handle->stream != NULL) {
 
                 // Shutdown the ZLib stream
-                inflateEnd( handle->stream );
+                inflateEnd(handle->stream);
                 delete handle->stream;
                 handle->stream = NULL;
             }
         }
 
-        static void resetZlibStream( InflaterData* handle ) {
+        static void resetZlibStream(InflaterData* handle) {
 
-            if( handle == NULL ) {
+            if (handle == NULL) {
                 throw NullPointerException(
-                    __FILE__, __LINE__, "Error While initializing the Decompression Library." );
+                    __FILE__, __LINE__, "Error While initializing the Decompression Library.");
             }
 
-            if( handle->stream != NULL ) {
+            if (handle->stream != NULL) {
 
                 handle->finished = false;
                 handle->needDictionary = false;
                 handle->flush = Z_NO_FLUSH;
 
                 // Ask ZLib to do the reset.
-                inflateReset( handle->stream );
+                inflateReset(handle->stream);
 
                 // clear any old data
                 handle->stream->opaque = Z_NULL;
@@ -133,78 +133,77 @@ namespace zip{
 }}}
 
 ////////////////////////////////////////////////////////////////////////////////
-Inflater::Inflater( bool nowrap ) : data( new InflaterData() ) {
-    InflaterData::initZlibInflate( this->data, nowrap );
+Inflater::Inflater(bool nowrap) : data(new InflaterData()) {
+    InflaterData::initZlibInflate(this->data, nowrap);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-Inflater::Inflater() : data( new InflaterData() ) {
-    InflaterData::initZlibInflate( this->data );
+Inflater::Inflater() : data(new InflaterData()) {
+    InflaterData::initZlibInflate(this->data);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 Inflater::~Inflater() {
-    try{
+    try {
         this->end();
         delete data;
     }
-    DECAF_CATCH_NOTHROW( Exception )
-    DECAF_CATCHALL_NOTHROW()
-}
+    DECAF_CATCH_NOTHROW(Exception)
+    DECAF_CATCHALL_NOTHROW()}
 
 ////////////////////////////////////////////////////////////////////////////////
-void Inflater::setInput( const unsigned char* buffer, int size, int offset, int length ) {
+void Inflater::setInput(const unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Passed Buffer was NULL." );
+                __FILE__, __LINE__, "Passed Buffer was NULL.");
         }
 
-        if( this->data->stream == NULL ) {
+        if (this->data->stream == NULL) {
             throw IllegalStateException(
-                __FILE__, __LINE__, "The Inflater end method has already been called." );
+                __FILE__, __LINE__, "The Inflater end method has already been called.");
         }
 
-        if( offset + length > size ) {
+        if (offset + length > size) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "The offset + length given is greater than the specified buffer size." );
+                __FILE__, __LINE__, "The offset + length given is greater than the specified buffer size.");
         }
 
-        this->data->stream->avail_in = (uInt)length;
-        this->data->stream->next_in = (Bytef*)( buffer + offset );
+        this->data->stream->avail_in = (uInt) length;
+        this->data->stream->next_in = (Bytef*) (buffer + offset);
     }
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCH_RETHROW( IllegalStateException )
-    DECAF_CATCHALL_THROW( IllegalStateException )
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCH_RETHROW(IllegalStateException)
+    DECAF_CATCHALL_THROW(IllegalStateException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Inflater::setInput( const std::vector<unsigned char>& buffer, int offset, int length ) {
+void Inflater::setInput(const std::vector<unsigned char>& buffer, int offset, int length) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return;
     }
 
-    this->setInput( &buffer[0], (int)buffer.size(), offset, length );
+    this->setInput(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Inflater::setInput( const std::vector<unsigned char>& buffer ) {
+void Inflater::setInput(const std::vector<unsigned char>& buffer) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return;
     }
 
-    this->setInput( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+    this->setInput(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 int Inflater::getRemaining() const {
 
-    if( this->data->stream != NULL ) {
+    if (this->data->stream != NULL) {
         return this->data->stream->avail_in;
     }
 
@@ -212,23 +211,23 @@ int Inflater::getRemaining() const {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Inflater::setDictionary( const unsigned char* buffer, int size, int offset, int length ) {
+void Inflater::setDictionary(const unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Passed Buffer was NULL." );
+                __FILE__, __LINE__, "Passed Buffer was NULL.");
         }
 
-        if( this->data->stream == NULL ) {
+        if (this->data->stream == NULL) {
             throw IllegalStateException(
-                __FILE__, __LINE__, "The Inflater end method has already been called." );
+                __FILE__, __LINE__, "The Inflater end method has already been called.");
         }
 
-        if( offset + length > size ) {
+        if (offset + length > size) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "The offset + length given is greater than the specified buffer size." );
+                __FILE__, __LINE__, "The offset + length given is greater than the specified buffer size.");
         }
 
         // From the ZLib documentation
@@ -236,43 +235,43 @@ void Inflater::setDictionary( const unsigned char* buffer, int size, int offset,
         // as NULL dictionary) or the stream state is inconsistent, Z_DATA_ERROR if the given dictionary
         // doesn't match the expected one (incorrect adler32 value). inflateSetDictionary does not
         // perform any decompression: this will be done by subsequent calls of inflate().
-        int result = inflateSetDictionary( this->data->stream, buffer + offset, (uInt)length );
-        if( result != Z_OK ) {
+        int result = inflateSetDictionary(this->data->stream, buffer + offset, (uInt) length);
+        if (result != Z_OK) {
             throw IllegalArgumentException(
-                __FILE__, __LINE__, "Dictionary given does not match required checksum value." );
+                __FILE__, __LINE__, "Dictionary given does not match required checksum value.");
         }
     }
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCH_RETHROW( IllegalStateException )
-    DECAF_CATCH_RETHROW( IllegalArgumentException )
-    DECAF_CATCHALL_THROW( IllegalStateException )
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCH_RETHROW(IllegalStateException)
+    DECAF_CATCH_RETHROW(IllegalArgumentException)
+    DECAF_CATCHALL_THROW(IllegalStateException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Inflater::setDictionary( const std::vector<unsigned char>& buffer, int offset, int length ) {
+void Inflater::setDictionary(const std::vector<unsigned char>& buffer, int offset, int length) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return;
     }
 
-    this->setDictionary( &buffer[0], (int)buffer.size(), offset, length );
+    this->setDictionary(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-void Inflater::setDictionary( const std::vector<unsigned char>& buffer ) {
+void Inflater::setDictionary(const std::vector<unsigned char>& buffer) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return;
     }
 
-    this->setDictionary( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+    this->setDictionary(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 bool Inflater::needsInput() const {
 
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         return false;
     }
 
@@ -295,93 +294,93 @@ bool Inflater::finished() const {
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int Inflater::inflate( unsigned char* buffer, int size, int offset, int length ) {
+int Inflater::inflate(unsigned char* buffer, int size, int offset, int length) {
 
-    try{
+    try {
 
-        if( buffer == NULL ) {
+        if (buffer == NULL) {
             throw NullPointerException(
-                __FILE__, __LINE__, "Passed Buffer was NULL." );
+                __FILE__, __LINE__, "Passed Buffer was NULL.");
         }
 
-        if( this->data->stream == NULL ) {
+        if (this->data->stream == NULL) {
             throw IllegalStateException(
-                __FILE__, __LINE__, "The Inflater end method has already been called." );
+                __FILE__, __LINE__, "The Inflater end method has already been called.");
         }
 
-        if( size < 0 ) {
+        if (size < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size );
+                __FILE__, __LINE__, "size parameter out of Bounds: %d.", size);
         }
 
-        if( offset > size || offset < 0 ) {
+        if (offset > size || offset < 0) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset );
+                __FILE__, __LINE__, "offset parameter out of Bounds: %d.", offset);
         }
 
-        if( length < 0 || length > size - offset ) {
+        if (length < 0 || length > size - offset) {
             throw IndexOutOfBoundsException(
-                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length );
+                __FILE__, __LINE__, "length parameter out of Bounds: %d.", length);
         }
 
         unsigned long outStart = this->data->stream->total_out;
 
         this->data->stream->next_out = buffer + offset;
-        this->data->stream->avail_out = (uInt)length;
+        this->data->stream->avail_out = (uInt) length;
 
         // Call ZLib and then process the resulting data to figure out what happened.
-        int result = ::inflate( this->data->stream, this->data->flush );
+        int result = ::inflate(this->data->stream, this->data->flush);
 
-        if( result == Z_STREAM_END ) {
+        if (result == Z_STREAM_END) {
             this->data->finished = true;
-        } else if( result == Z_NEED_DICT ) {
+        } else if (result == Z_NEED_DICT) {
 
-            if( this->needsDictionary() ) {
+            if (this->needsDictionary()) {
                 throw DataFormatException(
-                    __FILE__, __LINE__, "Inflate cannot proceed until a Dictionary is set." );
+                    __FILE__, __LINE__, "Inflate cannot proceed until a Dictionary is set.");
             }
 
             this->data->needDictionary = true;
-        } else if( result == Z_DATA_ERROR ) {
+        } else if (result == Z_DATA_ERROR) {
             throw DataFormatException(
-                __FILE__, __LINE__, "Inflate failed because a block of invalid data was found." );
+                __FILE__, __LINE__, "Inflate failed because a block of invalid data was found.");
         }
 
-        return (int)( this->data->stream->total_out - outStart );
+        return (int) (this->data->stream->total_out - outStart);
     }
-    DECAF_CATCH_RETHROW( NullPointerException )
-    DECAF_CATCH_RETHROW( IndexOutOfBoundsException )
-    DECAF_CATCH_RETHROW( DataFormatException )
-    DECAF_CATCH_RETHROW( IllegalStateException )
-    DECAF_CATCHALL_THROW( IllegalStateException )
+    DECAF_CATCH_RETHROW(NullPointerException)
+    DECAF_CATCH_RETHROW(IndexOutOfBoundsException)
+    DECAF_CATCH_RETHROW(DataFormatException)
+    DECAF_CATCH_RETHROW(IllegalStateException)
+    DECAF_CATCHALL_THROW(IllegalStateException)
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int Inflater::inflate( std::vector<unsigned char>& buffer, int offset, int length ) {
+int Inflater::inflate(std::vector<unsigned char>& buffer, int offset, int length) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return 0;
     }
 
-    return this->inflate( &buffer[0], (int)buffer.size(), offset, length );
+    return this->inflate(&buffer[0], (int) buffer.size(), offset, length);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
-int Inflater::inflate( std::vector<unsigned char>& buffer ) {
+int Inflater::inflate(std::vector<unsigned char>& buffer) {
 
-    if( buffer.empty() ) {
+    if (buffer.empty()) {
         return 0;
     }
 
-    return this->inflate( &buffer[0], (int)buffer.size(), 0, (int)buffer.size() );
+    return this->inflate(&buffer[0], (int) buffer.size(), 0, (int) buffer.size());
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 long long Inflater::getAdler() const {
 
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Inflater has already been ended." );
+            __FILE__, __LINE__, "The Inflater has already been ended.");
     }
 
     return this->data->stream->adler;
@@ -390,9 +389,9 @@ long long Inflater::getAdler() const {
 ////////////////////////////////////////////////////////////////////////////////
 long long Inflater::getBytesRead() const {
 
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Inflater has already been ended." );
+            __FILE__, __LINE__, "The Inflater has already been ended.");
     }
 
     return this->data->stream->total_in;
@@ -401,9 +400,9 @@ long long Inflater::getBytesRead() const {
 ////////////////////////////////////////////////////////////////////////////////
 long long Inflater::getBytesWritten() const {
 
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Inflater has already been ended." );
+            __FILE__, __LINE__, "The Inflater has already been ended.");
     }
 
     return this->data->stream->total_out;
@@ -412,18 +411,18 @@ long long Inflater::getBytesWritten() const {
 ////////////////////////////////////////////////////////////////////////////////
 void Inflater::reset() {
 
-    if( this->data->stream == NULL ) {
+    if (this->data->stream == NULL) {
         throw IllegalStateException(
-            __FILE__, __LINE__, "The Inflater has already been ended." );
+            __FILE__, __LINE__, "The Inflater has already been ended.");
     }
 
-    InflaterData::resetZlibStream( this->data );
+    InflaterData::resetZlibStream(this->data);
 }
 
 ////////////////////////////////////////////////////////////////////////////////
 void Inflater::end() {
 
-    if( this->data ) {
-        InflaterData::finishZlibDeflate( this->data );
+    if (this->data) {
+        InflaterData::finishZlibDeflate(this->data);
     }
 }


[8/9] activemq-cpp git commit: Fix some documentation generation issues.

Posted by ta...@apache.org.
http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/util/AdvisorySupport.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/util/AdvisorySupport.h b/activemq-cpp/src/main/activemq/util/AdvisorySupport.h
index 15ac6ba..5cfc27e 100644
--- a/activemq-cpp/src/main/activemq/util/AdvisorySupport.h
+++ b/activemq-cpp/src/main/activemq/util/AdvisorySupport.h
@@ -419,152 +419,152 @@ namespace util {
     public:
 
         /**
-         * @returns true if the specified destination is a Destination advisory topic.
+         * @return true if the specified destination is a Destination advisory topic.
          */
         static bool isDestinationAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is a Destination advisory topic.
+         * @return true if the specified destination is a Destination advisory topic.
          */
         static bool isDestinationAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is a Temporary Destination advisory topic.
+         * @return true if the specified destination is a Temporary Destination advisory topic.
          */
         static bool isTempDestinationAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is a Temporary Destination advisory topic.
+         * @return true if the specified destination is a Temporary Destination advisory topic.
          */
         static bool isTempDestinationAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an advisory topic.
+         * @return true if the specified destination is an advisory topic.
          */
         static bool isAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an advisory topic.
+         * @return true if the specified destination is an advisory topic.
          */
         static bool isAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Connection advisory topic.
+         * @return true if the specified destination is an Connection advisory topic.
          */
         static bool isConnectionAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Connection advisory topic.
+         * @return true if the specified destination is an Connection advisory topic.
          */
         static bool isConnectionAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Producer advisory topic.
+         * @return true if the specified destination is an Producer advisory topic.
          */
         static bool isProducerAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Producer advisory topic.
+         * @return true if the specified destination is an Producer advisory topic.
          */
         static bool isProducerAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Consumer advisory topic.
+         * @return true if the specified destination is an Consumer advisory topic.
          */
         static bool isConsumerAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Consumer advisory topic.
+         * @return true if the specified destination is an Consumer advisory topic.
          */
         static bool isConsumerAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Slow Consumer advisory topic.
+         * @return true if the specified destination is an Slow Consumer advisory topic.
          */
         static bool isSlowConsumerAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Slow Consumer advisory topic.
+         * @return true if the specified destination is an Slow Consumer advisory topic.
          */
         static bool isSlowConsumerAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Fast Producer advisory topic.
+         * @return true if the specified destination is an Fast Producer advisory topic.
          */
         static bool isFastProducerAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Fast Producer advisory topic.
+         * @return true if the specified destination is an Fast Producer advisory topic.
          */
         static bool isFastProducerAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Message Consumed advisory topic.
+         * @return true if the specified destination is an Message Consumed advisory topic.
          */
         static bool isMessageConsumedAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Message Consumed advisory topic.
+         * @return true if the specified destination is an Message Consumed advisory topic.
          */
         static bool isMessageConsumedAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Master Broker advisory topic.
+         * @return true if the specified destination is an Master Broker advisory topic.
          */
         static bool isMasterBrokerAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Master Broker Consumed advisory topic.
+         * @return true if the specified destination is an Master Broker Consumed advisory topic.
          */
         static bool isMasterBrokerAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Message Delivered advisory topic.
+         * @return true if the specified destination is an Message Delivered advisory topic.
          */
         static bool isMessageDeliveredAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Message Delivered advisory topic.
+         * @return true if the specified destination is an Message Delivered advisory topic.
          */
         static bool isMessageDeliveredAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Message Discarded advisory topic.
+         * @return true if the specified destination is an Message Discarded advisory topic.
          */
         static bool isMessageDiscardedAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Message Discarded advisory topic.
+         * @return true if the specified destination is an Message Discarded advisory topic.
          */
         static bool isMessageDiscardedAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Message DLQ'd advisory topic.
+         * @return true if the specified destination is an Message DLQ'd advisory topic.
          */
         static bool isMessageDLQdAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Message DLQ'd advisory topic.
+         * @return true if the specified destination is an Message DLQ'd advisory topic.
          */
         static bool isMessageDLQdAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Destination Full advisory topic.
+         * @return true if the specified destination is an Destination Full advisory topic.
          */
         static bool isFullAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Destination Full advisory topic.
+         * @return true if the specified destination is an Destination Full advisory topic.
          */
         static bool isFullAdvisoryTopic(const commands::ActiveMQDestination* destination);
 
         /**
-         * @returns true if the specified destination is an Network Bridge advisory topic.
+         * @return true if the specified destination is an Network Bridge advisory topic.
          */
         static bool isNetworkBridgeAdvisoryTopic(const cms::Destination* destination);
 
         /**
-         * @returns true if the specified destination is an Network Bridge advisory topic.
+         * @return true if the specified destination is an Network Bridge advisory topic.
          */
         static bool isNetworkBridgeAdvisoryTopic(const commands::ActiveMQDestination* destination);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/util/IdGenerator.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/util/IdGenerator.h b/activemq-cpp/src/main/activemq/util/IdGenerator.h
index bdcfef8..2d6ad61 100644
--- a/activemq-cpp/src/main/activemq/util/IdGenerator.h
+++ b/activemq-cpp/src/main/activemq/util/IdGenerator.h
@@ -55,7 +55,7 @@ namespace util {
     public:
 
         /**
-         * @returns a newly generated unique id.
+         * @return a newly generated unique id.
          */
         std::string generateId() const;
 
@@ -72,14 +72,14 @@ namespace util {
         /**
          * Gets the seed value from a Generated Id, the count portion is removed.
          *
-         * @returns the seed portion of the Id, minus the count value.
+         * @return the seed portion of the Id, minus the count value.
          */
         static std::string getSeedFromId(const std::string& id);
 
         /**
          * Gets the count value from a Generated Id, the seed portion is removed.
          *
-         * @returns the sequence count portion of the id, minus the seed value.
+         * @return the sequence count portion of the id, minus the seed value.
          */
         static long long getSequenceFromId(const std::string& id);
 
@@ -91,7 +91,7 @@ namespace util {
          * @param id2
          *      The second id to compare, or right hand side.
          *
-         * @returns zero if ids are equal or positove if id1 > id2...
+         * @return zero if ids are equal or positove if id1 > id2...
          */
         static int compare(const std::string& id1, const std::string& id2);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/util/LongSequenceGenerator.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/util/LongSequenceGenerator.h b/activemq-cpp/src/main/activemq/util/LongSequenceGenerator.h
index f7db187..cb15b32 100644
--- a/activemq-cpp/src/main/activemq/util/LongSequenceGenerator.h
+++ b/activemq-cpp/src/main/activemq/util/LongSequenceGenerator.h
@@ -41,12 +41,12 @@ namespace util {
         virtual ~LongSequenceGenerator();
 
         /**
-         * @returns the next id in the sequence.
+         * @return the next id in the sequence.
          */
         long long getNextSequenceId();
 
         /**
-         * @returns the last id that was generated.
+         * @return the last id that was generated.
          */
         long long getLastSequenceId();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/util/MarshallingSupport.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/util/MarshallingSupport.h b/activemq-cpp/src/main/activemq/util/MarshallingSupport.h
index a3c66df..598509c 100644
--- a/activemq-cpp/src/main/activemq/util/MarshallingSupport.h
+++ b/activemq-cpp/src/main/activemq/util/MarshallingSupport.h
@@ -94,7 +94,7 @@ namespace util {
          * @param dataIn
          *      The DataInputStream to read the String data from.
          *
-         * @returns the String value.
+         * @return the String value.
          *
          * @throws IOException if an I/O error occurs while writing the string.
          */
@@ -111,7 +111,7 @@ namespace util {
          * @param dataIn
          *      The DataInputStream to read the String data from.
          *
-         * @returns the String value.
+         * @return the String value.
          *
          * @throws IOException if an I/O error occurs while writing the string.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/util/PrimitiveList.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/util/PrimitiveList.h b/activemq-cpp/src/main/activemq/util/PrimitiveList.h
index 68f5150..be09e3b 100644
--- a/activemq-cpp/src/main/activemq/util/PrimitiveList.h
+++ b/activemq-cpp/src/main/activemq/util/PrimitiveList.h
@@ -62,7 +62,7 @@ namespace util{
         /**
          * Converts the contents into a formatted string that can be output
          * in a Log File or other debugging tool.
-         * @returns formatted String of all elements in the list.
+         * @return formatted String of all elements in the list.
          */
         std::string toString() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/util/PrimitiveMap.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/util/PrimitiveMap.h b/activemq-cpp/src/main/activemq/util/PrimitiveMap.h
index 9ec7c4c..d289de5 100644
--- a/activemq-cpp/src/main/activemq/util/PrimitiveMap.h
+++ b/activemq-cpp/src/main/activemq/util/PrimitiveMap.h
@@ -67,12 +67,12 @@ namespace util {
          * Converts the contents into a formatted string that can be output
          * in a Log File or other debugging tool.
          *
-         * @returns formatted String of all elements in the map.
+         * @return formatted String of all elements in the map.
          */
         std::string toString() const;
 
         /**
-         * @returns the numeric type value for the given key if it exists.
+         * @return the numeric type value for the given key if it exists.
          * @throws NoSuchElementException if the key is not present in the map.
          */
         virtual PrimitiveValueNode::PrimitiveType getValueType(const std::string& key) const;
@@ -83,7 +83,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -104,7 +104,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -125,7 +125,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -146,7 +146,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -167,7 +167,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -188,7 +188,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -209,7 +209,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -230,7 +230,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -251,7 +251,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns
@@ -272,7 +272,7 @@ namespace util {
          * an exception of type NoSuchElementException is thrown.
          *
          * @param key - the location to return the value from.
-         * @returns the value at key in the type requested.
+         * @return the value at key in the type requested.
          * @throw NoSuchElementException if key is not in the map.
          * @throw UnSupportedOperationException if the value cannot be converted
          *                                      to the type this method returns

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/util/URISupport.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/util/URISupport.h b/activemq-cpp/src/main/activemq/util/URISupport.h
index d1ccf8f..739f49c 100644
--- a/activemq-cpp/src/main/activemq/util/URISupport.h
+++ b/activemq-cpp/src/main/activemq/util/URISupport.h
@@ -69,7 +69,7 @@ namespace util {
          * @param query
          *      The query string to parse and extract the encoded properties.
          *
-         * @returns Properties object with the parsed output.
+         * @return Properties object with the parsed output.
          *
          * @throw IllegalArgumentException if the Query string is not well formed.
          */
@@ -226,7 +226,7 @@ namespace util {
          * If so the we attempt to replace the value with what is stored in that
          * env var, if the var is not set then we throw an IllegalArgumentException.
          * @param value - the value to check for env
-         * @returns the env var if value points to an env var else returns value
+         * @return the env var if value points to an env var else returns value
          * @throws IllegalArgumentException if the var is not set or has bad syntax
          */
         static std::string replaceEnvValues(const std::string& value);

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/MarshalAware.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/MarshalAware.h b/activemq-cpp/src/main/activemq/wireformat/MarshalAware.h
index 7b63631..eced66b 100644
--- a/activemq-cpp/src/main/activemq/wireformat/MarshalAware.h
+++ b/activemq-cpp/src/main/activemq/wireformat/MarshalAware.h
@@ -39,7 +39,7 @@ namespace wireformat {
          * but since this is C++ and we don't have true interfaces we need
          * a flat inheritance hierarchy, so we always implement this.
          *
-         * @returns true if this class cares about marshaling.
+         * @return true if this class cares about marshaling.
          */
         virtual bool isMarshalAware() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/WireFormat.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/WireFormat.h b/activemq-cpp/src/main/activemq/wireformat/WireFormat.h
index ec0b604..061b60f 100644
--- a/activemq-cpp/src/main/activemq/wireformat/WireFormat.h
+++ b/activemq-cpp/src/main/activemq/wireformat/WireFormat.h
@@ -72,7 +72,7 @@ namespace wireformat {
          * @param in
          *      The input stream to read the command from.
          *
-         * @returns the newly marshaled Command, caller owns the pointer
+         * @return the newly marshaled Command, caller owns the pointer
          *
          * @throws IOException if an I/O error occurs.
          */
@@ -97,7 +97,7 @@ namespace wireformat {
         /**
          * Returns true if this WireFormat has a Negotiator that needs to wrap the
          * Transport that uses it.
-         * @returns true if the WireFormat provides a Negotiator.
+         * @return true if the WireFormat provides a Negotiator.
          */
         virtual bool hasNegotiator() const = 0;
 
@@ -108,7 +108,7 @@ namespace wireformat {
          * can query the WireFormat instance to determine if its busy or not and not mark the
          * connection as inactive if so.
          *
-         * @returns true if the WireFormat object is unmarshaling a message.
+         * @return true if the WireFormat object is unmarshaling a message.
          */
         virtual bool inReceive() const = 0;
 
@@ -119,7 +119,7 @@ namespace wireformat {
          * @param transport
          *      The Transport to Wrap the Negotiator around.
          *
-         * @returns new instance of a WireFormatNegotiator as a Pointer<Transport>.
+         * @return new instance of a WireFormatNegotiator as a Pointer<Transport>.
          *
          * @throws UnsupportedOperationException if the WireFormat doesn't have a Negotiator.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/WireFormatRegistry.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/WireFormatRegistry.h b/activemq-cpp/src/main/activemq/wireformat/WireFormatRegistry.h
index 655c7ff..d4bd3da 100644
--- a/activemq-cpp/src/main/activemq/wireformat/WireFormatRegistry.h
+++ b/activemq-cpp/src/main/activemq/wireformat/WireFormatRegistry.h
@@ -70,7 +70,7 @@ namespace wireformat {
          * @param name
          *        The name of the Factory to find in the Registry.
          *
-         * @returns the Factory registered under the given name.
+         * @return the Factory registered under the given name.
          *
          * @throws NoSuchElementException if no factory is registered with that name.
          */
@@ -110,7 +110,7 @@ namespace wireformat {
          * Retrieves a list of the names of all the Registered WireFormat's in this
          * Registry.
          *
-         * @returns stl vector of strings with all the WireFormat names registered.
+         * @return stl vector of strings with all the WireFormat names registered.
          */
         std::vector<std::string> getWireFormatNames() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/openwire/OpenWireFormat.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/openwire/OpenWireFormat.h b/activemq-cpp/src/main/activemq/wireformat/openwire/OpenWireFormat.h
index e9e76bd..1512459 100644
--- a/activemq-cpp/src/main/activemq/wireformat/openwire/OpenWireFormat.h
+++ b/activemq-cpp/src/main/activemq/wireformat/openwire/OpenWireFormat.h
@@ -126,7 +126,7 @@ namespace marshal {
          * stream passed.
          * @param object - The DataStructure to marshal
          * @param bs - the BooleanStream to write to
-         * @returns size of the data returned.
+         * @return size of the data returned.
          */
         virtual int tightMarshalNestedObject1(commands::DataStructure* object, utils::BooleanStream* bs);
 
@@ -147,7 +147,7 @@ namespace marshal {
          * returned is now the property of the caller.
          * @param dis - DataInputStream to read from
          * @param bs - BooleanStream to read from
-         * @returns Newly allocated DataStructure Object
+         * @return Newly allocated DataStructure Object
          * @throws IOException if an error occurs.
          */
         commands::DataStructure* tightUnmarshalNestedObject(decaf::io::DataInputStream* dis, utils::BooleanStream* bs);
@@ -158,7 +158,7 @@ namespace marshal {
          * the Data and construct a new DataStructure based Object, the
          * pointer to the Object returned is now owned by the caller.
          * @param dis - the DataInputStream to read the data from
-         * @returns a new DataStructure derived Object pointer
+         * @return a new DataStructure derived Object pointer
          * @throws IOException if an error occurs.
          */
         commands::DataStructure* looseUnmarshalNestedObject(decaf::io::DataInputStream* dis);
@@ -368,7 +368,7 @@ namespace marshal {
          * @param dis
          *      The DataInputStream to read from.
          *
-         * @returns new DataStructure* that the caller owns.
+         * @return new DataStructure* that the caller owns.
          *
          * @throws IOException if an error occurs during the unmarshal.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/BaseDataStreamMarshaller.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/BaseDataStreamMarshaller.h b/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/BaseDataStreamMarshaller.h
index 825fdb4..81e0214 100644
--- a/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/BaseDataStreamMarshaller.h
+++ b/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/BaseDataStreamMarshaller.h
@@ -111,21 +111,21 @@ namespace marshal{
         /**
          * Converts the object to a String
          * @param id - MessageId pointer
-         * @returns string representing the id
+         * @return string representing the id
          */
         static std::string toString(const commands::MessageId* id);
 
         /**
          * Converts the object to a String
          * @param id - ProducerId pointer
-         * @returns string representing the id
+         * @return string representing the id
          */
         static std::string toString(const commands::ProducerId* id);
 
         /**
          * Converts the given transaction ID into a String
          * @param txnId - TransactionId poitner
-         * @returns string representation of the id
+         * @return string representation of the id
          */
         static std::string toString(const commands::TransactionId* txnId);
 
@@ -133,7 +133,7 @@ namespace marshal{
          * given an array of bytes, convert that array to a Hexidecimal
          * coded string that represents that data.
          * @param data - unsigned char data array pointer
-         * @returns a string coded in hex that represents the data
+         * @return a string coded in hex that represents the data
          */
         static std::string toHexFromBytes(const std::vector<unsigned char>& data);
 
@@ -144,7 +144,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshaled form from
          * @param bs - boolean stream to marshal to.
-         * @returns pointer to a new DataStructure Object
+         * @return pointer to a new DataStructure Object
          * @throws IOException if an error occurs.
          */
         virtual commands::DataStructure* tightUnmarshalCachedObject(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn, utils::BooleanStream* bs);
@@ -155,7 +155,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param data - DataStructure Object Pointer to marshal
          * @param bs - boolean stream to marshal to.
-         * @returns size of data written.
+         * @return size of data written.
          * @throws IOException if an error occurs.
          */
         virtual int tightMarshalCachedObject1(OpenWireFormat* wireFormat, commands::DataStructure* data, utils::BooleanStream* bs);
@@ -185,7 +185,7 @@ namespace marshal{
          * Loose Unmarshal the cached object
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshaled form from
-         * @returns pointer to a new DataStructure Object
+         * @return pointer to a new DataStructure Object
          * @throws IOException if an error occurs.
          */
         virtual commands::DataStructure* looseUnmarshalCachedObject(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn);
@@ -196,7 +196,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param object - DataStructure Object Pointer to marshal
          * @param bs - boolean stream to marshal to.
-         * @returns size of data written.
+         * @return size of data written.
          * @throws IOException if an error occurs.
          */
         virtual int tightMarshalNestedObject1(OpenWireFormat* wireFormat, commands::DataStructure* object, utils::BooleanStream* bs);
@@ -218,7 +218,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshaled form from
          * @param bs - boolean stream to marshal to.
-         * @returns pointer to a new DataStructure Object
+         * @return pointer to a new DataStructure Object
          * @throws IOException if an error occurs.
          */
         virtual commands::DataStructure* tightUnmarshalNestedObject(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn, utils::BooleanStream* bs);
@@ -227,7 +227,7 @@ namespace marshal{
          * Loose Unmarshal the nested object
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshaled form from
-         * @returns pointer to a new DataStructure Object
+         * @return pointer to a new DataStructure Object
          * @throws IOException if an error occurs.
          */
         virtual commands::DataStructure* looseUnmarshalNestedObject(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn);
@@ -245,7 +245,7 @@ namespace marshal{
          * Performs Tight Unmarshaling of String Objects
          * @param dataIn - the DataInputStream to Un-Marshal from
          * @param bs - boolean stream to unmarshal from.
-         * @returns the unmarshaled string.
+         * @return the unmarshaled string.
          * @throws IOException if an error occurs.
          */
         virtual std::string tightUnmarshalString(decaf::io::DataInputStream* dataIn, utils::BooleanStream* bs);
@@ -255,7 +255,7 @@ namespace marshal{
          * the marshaled size.
          * @param value - string to marshal
          * @param bs - BooleanStream to use.
-         * @returns size of marshaled string.
+         * @return size of marshaled string.
          * @throws IOException if an error occurs.
          */
         virtual int tightMarshalString1(const std::string& value, utils::BooleanStream* bs);
@@ -290,7 +290,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param value - long long to marshal
          * @param bs - boolean stream to marshal to.
-         * @returns size of data written.
+         * @return size of data written.
          * @throws IOException if an error occurs.
          */
         virtual int tightMarshalLong1(OpenWireFormat* wireFormat, long long value, utils::BooleanStream* bs);
@@ -310,7 +310,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshaled form from
          * @param bs - boolean stream to marshal to.
-         * @returns the unmarshaled long long
+         * @return the unmarshaled long long
          * @throws IOException if an error occurs.
          */
         virtual long long tightUnmarshalLong(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn, utils::BooleanStream* bs);
@@ -328,7 +328,7 @@ namespace marshal{
          * Loose marshal the long long type.
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshaled form from
-         * @returns the unmarshaled long long
+         * @return the unmarshaled long long
          * @throws IOException if an error occurs.
          */
         virtual long long looseUnmarshalLong(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn);
@@ -337,7 +337,7 @@ namespace marshal{
          * Tight Unmarshal an array of char
          * @param dataIn - the DataInputStream to Un-Marshal from
          * @param bs - boolean stream to unmarshal from.
-         * @returns the unmarshaled vector of chars.
+         * @return the unmarshaled vector of chars.
          * @throws IOException if an error occurs.
          */
         virtual std::vector<unsigned char> tightUnmarshalByteArray(decaf::io::DataInputStream* dataIn, utils::BooleanStream* bs);
@@ -345,7 +345,7 @@ namespace marshal{
         /**
          * Loose Unmarshal an array of char
          * @param dataIn - the DataInputStream to Un-Marshal from
-         * @returns the unmarshalled vector of chars.
+         * @return the unmarshalled vector of chars.
          * @throws IOException if an error occurs.
          */
         virtual std::vector<unsigned char> looseUnmarshalByteArray(decaf::io::DataInputStream* dataIn);
@@ -356,7 +356,7 @@ namespace marshal{
          * @param dataIn - the DataInputStream to Un-Marshal from
          * @param bs - boolean stream to unmarshal from.
          * @param size - size of the const array to unmarshal
-         * @returns the unmarshaled vector of chars.
+         * @return the unmarshaled vector of chars.
          * @throws IOException if an error occurs.
          */
         virtual std::vector<unsigned char> tightUnmarshalConstByteArray(decaf::io::DataInputStream* dataIn, utils::BooleanStream* bs, int size);
@@ -366,7 +366,7 @@ namespace marshal{
          * and return an stl vector of char as the resultant.
          * @param dataIn - the DataInputStream to Un-Marshal from
          * @param size - size of the const array to unmarshal
-         * @returns the unmarshaled vector of chars.
+         * @return the unmarshaled vector of chars.
          * @throws IOException if an error occurs.
          */
         virtual std::vector<unsigned char> looseUnmarshalConstByteArray(decaf::io::DataInputStream* dataIn, int size);
@@ -376,7 +376,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshalled form from
          * @param bs - boolean stream to marshal to.
-         * @returns pointer to a new DataStructure Object
+         * @return pointer to a new DataStructure Object
          * @throws IOException if an error occurs.
          */
         virtual commands::DataStructure* tightUnmarshalBrokerError(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn, utils::BooleanStream* bs);
@@ -386,7 +386,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param data - Error to Marshal
          * @param bs - boolean stream to marshal to.
-         * @returns size of the marshalled data
+         * @return size of the marshalled data
          * @throws IOException if an error occurs.
          */
         virtual int tightMarshalBrokerError1(OpenWireFormat* wireFormat, commands::DataStructure* data, utils::BooleanStream* bs);
@@ -405,7 +405,7 @@ namespace marshal{
          * Loose Unarshal the Error object
          * @param wireFormat - The OpenwireFormat properties
          * @param dataIn - stream to read marshalled form from
-         * @returns pointer to a new DataStructure Object
+         * @return pointer to a new DataStructure Object
          * @throws IOException if an error occurs.
          */
         virtual commands::DataStructure* looseUnmarshalBrokerError(OpenWireFormat* wireFormat, decaf::io::DataInputStream* dataIn);
@@ -426,7 +426,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param objects - array of DataStructure object pointers.
          * @param bs - boolean stream to marshal to.
-         * @returns size of the marshalled data
+         * @return size of the marshalled data
          * @throws IOException if an error occurs.
          */
         template<typename T>
@@ -459,7 +459,7 @@ namespace marshal{
          * @param objects - array of DataStructure object pointers.
          * @param dataOut - stream to write marshalled data to
          * @param bs - boolean stream to marshal to.
-         * @returns size of the marshalled data
+         * @return size of the marshalled data
          * @throws IOException if an error occurs.
          */
         template<typename T>
@@ -486,7 +486,7 @@ namespace marshal{
          * @param wireFormat - The OpenwireFormat properties
          * @param objects - array of DataStructure object pointers.
          * @param dataOut - stream to write marshalled data to
-         * @returns size of the marshalled data
+         * @return size of the marshalled data
          * @throws IOException if an error occurs.
          */
         template<typename T>

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/DataStreamMarshaller.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/DataStreamMarshaller.h b/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/DataStreamMarshaller.h
index 1b7171c..5515f42 100644
--- a/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/DataStreamMarshaller.h
+++ b/activemq-cpp/src/main/activemq/wireformat/openwire/marshal/DataStreamMarshaller.h
@@ -41,14 +41,14 @@ namespace marshal {
 
         /**
          * Gets the DataStructureType that this class marshals/unmarshals
-         * @returns byte Id of this classes DataStructureType
+         * @return byte Id of this classes DataStructureType
          */
         virtual unsigned char getDataStructureType() const = 0;
 
         /**
          * Creates a new instance of the class that this class is a marshaling
          * director for.
-         * @returns newly allocated Command
+         * @return newly allocated Command
          */
         virtual commands::DataStructure* createObject() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/openwire/utils/BooleanStream.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/openwire/utils/BooleanStream.h b/activemq-cpp/src/main/activemq/wireformat/openwire/utils/BooleanStream.h
index c92da47..a4d0169 100644
--- a/activemq-cpp/src/main/activemq/wireformat/openwire/utils/BooleanStream.h
+++ b/activemq-cpp/src/main/activemq/wireformat/openwire/utils/BooleanStream.h
@@ -70,7 +70,7 @@ namespace utils{
         /**
          * Read a boolean data element from the internal data buffer
          *
-         * @returns boolean from the stream
+         * @return boolean from the stream
          *
          * @throws IOException if an I/O error occurs during this operation.
          */
@@ -115,7 +115,7 @@ namespace utils{
 
         /**
          * Calc the size that data is marshalled to
-         * @returns int size of marshalled data.
+         * @return int size of marshalled data.
          */
         int marshalledSize();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/openwire/utils/HexTable.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/openwire/utils/HexTable.h b/activemq-cpp/src/main/activemq/wireformat/openwire/utils/HexTable.h
index e6de44d..b9b359f 100644
--- a/activemq-cpp/src/main/activemq/wireformat/openwire/utils/HexTable.h
+++ b/activemq-cpp/src/main/activemq/wireformat/openwire/utils/HexTable.h
@@ -52,7 +52,7 @@ namespace utils{
          * @param index
          *      The index of the value in the table to fetch.
          *
-         * @returns string containing the hex value if the index
+         * @return string containing the hex value if the index
          *
          * @throws IndexOutOfBoundsException if the index exceeds the table size.
          */
@@ -62,7 +62,7 @@ namespace utils{
         /**
          * Returns the max size of this Table.
          *
-         * @returns an integer size value for the table.
+         * @return an integer size value for the table.
          */
         virtual std::size_t size() const{
             return table.size();

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/stomp/StompHelper.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/stomp/StompHelper.h b/activemq-cpp/src/main/activemq/wireformat/stomp/StompHelper.h
index b2b7fec..e103199 100644
--- a/activemq-cpp/src/main/activemq/wireformat/stomp/StompHelper.h
+++ b/activemq-cpp/src/main/activemq/wireformat/stomp/StompHelper.h
@@ -89,7 +89,7 @@ namespace stomp {
          * Converts from a Stomp Destination to an ActiveMQDestination
          *
          * @param destination - The Stomp Destination name string.
-         * @returns Pointer to a new ActiveMQDestination.
+         * @return Pointer to a new ActiveMQDestination.
          */
         Pointer<ActiveMQDestination> convertDestination(const std::string& destination);
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/activemq/wireformat/stomp/StompWireFormat.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/activemq/wireformat/stomp/StompWireFormat.h b/activemq-cpp/src/main/activemq/wireformat/stomp/StompWireFormat.h
index c08846c..c55ebe5 100644
--- a/activemq-cpp/src/main/activemq/wireformat/stomp/StompWireFormat.h
+++ b/activemq-cpp/src/main/activemq/wireformat/stomp/StompWireFormat.h
@@ -91,7 +91,7 @@ namespace stomp {
          *
          * @param transport - Pointer to the transport that is making this request.
          * @param in - the input stream to read the command from.
-         * @returns the newly marshaled Command, caller owns the pointer
+         * @return the newly marshaled Command, caller owns the pointer
          * @throws IOException
          */
         virtual Pointer<commands::Command> unmarshal(const activemq::transport::Transport* transport,
@@ -183,7 +183,7 @@ namespace stomp {
         /**
          * Returns true if this WireFormat has a Negotiator that needs to wrap the
          * Transport that uses it.
-         * @returns true if the WireFormat provides a Negotiator.
+         * @return true if the WireFormat provides a Negotiator.
          */
         virtual bool hasNegotiator() const {
             return false;
@@ -192,7 +192,7 @@ namespace stomp {
         /**
          * If the Transport Provides a Negotiator this method will create and return
          * a news instance of the Negotiator.
-         * @returns new instance of a WireFormatNegotiator.
+         * @return new instance of a WireFormatNegotiator.
          * @throws UnsupportedOperationException if the WireFormat doesn't have a Negotiator.
          */
         virtual Pointer<transport::Transport> createNegotiator(

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/BytesMessage.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/BytesMessage.h b/activemq-cpp/src/main/cms/BytesMessage.h
index 0858c3f..aeb541c 100644
--- a/activemq-cpp/src/main/cms/BytesMessage.h
+++ b/activemq-cpp/src/main/cms/BytesMessage.h
@@ -116,7 +116,7 @@ namespace cms {
 
         /**
          * Reads a Boolean from the Bytes message stream
-         * @returns boolean value from stream
+         * @return boolean value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -142,7 +142,7 @@ namespace cms {
         /**
          * Reads a Byte from the Bytes message stream
          *
-         * @returns unsigned char value from stream
+         * @return unsigned char value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -178,7 +178,7 @@ namespace cms {
          *
          * @param value
          *      buffer to place data in
-         * @returns the total number of bytes read into the buffer, or -1 if
+         * @return the total number of bytes read into the buffer, or -1 if
          *          there is no more data because the end of the stream has
          *          been reached
          *
@@ -224,7 +224,7 @@ namespace cms {
          * @param length
          *      the number of bytes to read; must be less than or equal to
          *      value.length
-         * @returns the total number of bytes read into the buffer, or -1 if
+         * @return the total number of bytes read into the buffer, or -1 if
          *          there is no more data because the end of the stream has
          *          been reached
          *
@@ -255,7 +255,7 @@ namespace cms {
         /**
          * Reads a Char from the Bytes message stream
          *
-         * @returns char value from stream
+         * @return char value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -279,7 +279,7 @@ namespace cms {
         /**
          * Reads a 32 bit float from the Bytes message stream
          *
-         * @returns double value from stream
+         * @return double value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -302,7 +302,7 @@ namespace cms {
         /**
          * Reads a 64 bit double from the Bytes message stream
          *
-         * @returns double value from stream
+         * @return double value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -325,7 +325,7 @@ namespace cms {
         /**
          * Reads a 16 bit signed short from the Bytes message stream
          *
-         * @returns short value from stream
+         * @return short value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -349,7 +349,7 @@ namespace cms {
         /**
          * Reads a 16 bit unsigned short from the Bytes message stream
          *
-         * @returns unsigned short value from stream
+         * @return unsigned short value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -373,7 +373,7 @@ namespace cms {
         /**
          * Reads a 32 bit signed integer from the Bytes message stream
          *
-         * @returns int value from stream
+         * @return int value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -397,7 +397,7 @@ namespace cms {
         /**
          * Reads a 64 bit long from the Bytes message stream
          *
-         * @returns long long value from stream
+         * @return long long value from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -421,7 +421,7 @@ namespace cms {
         /**
          * Reads an ASCII String from the Bytes message stream
          *
-         * @returns String from stream
+         * @return String from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.
@@ -445,7 +445,7 @@ namespace cms {
         /**
          * Reads an UTF String from the BytesMessage stream
          *
-         * @returns String from stream
+         * @return String from stream
          *
          * @throws CMSException - if the CMS provider fails to read the message due to
          *                        some internal error.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/CMSException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/CMSException.h b/activemq-cpp/src/main/cms/CMSException.h
index ef9afea..3bf2240 100644
--- a/activemq-cpp/src/main/cms/CMSException.h
+++ b/activemq-cpp/src/main/cms/CMSException.h
@@ -81,7 +81,7 @@ namespace cms {
          * a particular exception but wishes to allow for the real causal
          * exception to be passed only in case the caller knows about that
          * type of exception and wishes to respond to it.
-         * @returns a const pointer reference to the causal exception, if there
+         * @return a const pointer reference to the causal exception, if there
          * was no cause associated with this exception then NULL is returned.
          */
         virtual const std::exception* getCause() const;
@@ -133,7 +133,7 @@ namespace cms {
          * This method passes on ownership of the contained cause exception pointer to
          * the clone.  This method is mainly useful to the CMS provider.
          *
-         * @returns new pointer that is a clone of this Exception, caller owns.
+         * @return new pointer that is a clone of this Exception, caller owns.
          */
         virtual CMSException* clone();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/CMSProperties.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/CMSProperties.h b/activemq-cpp/src/main/cms/CMSProperties.h
index b00ca11..5f6060e 100644
--- a/activemq-cpp/src/main/cms/CMSProperties.h
+++ b/activemq-cpp/src/main/cms/CMSProperties.h
@@ -101,7 +101,7 @@ namespace cms {
          * @param name
          *      the name of the property to be removed.
          *
-         * @returns the value that was removed from the Properties, or empty string.
+         * @return the value that was removed from the Properties, or empty string.
          */
         virtual std::string remove(const std::string& name) = 0;
 
@@ -109,7 +109,7 @@ namespace cms {
          * Returns a vector containing all the names of the properties currently stored
          * in the Properties object.
          *
-         * @returns an STL std::vector<std::string> with all the currently stored property names.
+         * @return an STL std::vector<std::string> with all the currently stored property names.
          */
         virtual std::vector<std::string> propertyNames() const = 0;
 
@@ -133,7 +133,7 @@ namespace cms {
         /**
          * Clones this object.
          *
-         * @returns a replica of this object.
+         * @return a replica of this object.
          */
         virtual CMSProperties* clone() const = 0;
 
@@ -146,7 +146,7 @@ namespace cms {
          * Formats the contents of the Properties Object into a string
          * that can be logged, etc.
          *
-         * @returns string value of this object.
+         * @return string value of this object.
          */
         virtual std::string toString() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/Connection.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/Connection.h b/activemq-cpp/src/main/cms/Connection.h
index bb9f5fd..a7c2eee 100644
--- a/activemq-cpp/src/main/cms/Connection.h
+++ b/activemq-cpp/src/main/cms/Connection.h
@@ -83,7 +83,7 @@ namespace cms {
         /**
          * Gets the metadata for this connection.
          *
-         * @returns the connection MetaData pointer ( caller does not own it ).
+         * @return the connection MetaData pointer ( caller does not own it ).
          *
          * @throws CMSException
          *         if the provider fails to get the connection metadata for this connection.
@@ -172,7 +172,7 @@ namespace cms {
         /**
          * Gets the currently configured MessageTransformer for this Connection.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/ConnectionFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/ConnectionFactory.h b/activemq-cpp/src/main/cms/ConnectionFactory.h
index b1db082..4541a41 100644
--- a/activemq-cpp/src/main/cms/ConnectionFactory.h
+++ b/activemq-cpp/src/main/cms/ConnectionFactory.h
@@ -115,7 +115,7 @@ namespace cms {
          * the client code must ensure that the object remains valid for the lifetime of the CMS
          * object to which the ExceptionListener has been assigned.
          *
-         * @returns the pointer to the currently set cms::ExceptionListener.
+         * @return the pointer to the currently set cms::ExceptionListener.
          */
         virtual cms::ExceptionListener* getExceptionListener() const = 0;
 
@@ -135,7 +135,7 @@ namespace cms {
         /**
          * Gets the currently configured MessageTransformer for this ConnectionFactory.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/ConnectionMetaData.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/ConnectionMetaData.h b/activemq-cpp/src/main/cms/ConnectionMetaData.h
index bd4ed0d..f5ac054 100644
--- a/activemq-cpp/src/main/cms/ConnectionMetaData.h
+++ b/activemq-cpp/src/main/cms/ConnectionMetaData.h
@@ -46,7 +46,7 @@ namespace cms {
         /**
          * Gets the CMS major version number.
          *
-         * @returns the CMS API major version number
+         * @return the CMS API major version number
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.
@@ -56,7 +56,7 @@ namespace cms {
         /**
          * Gets the CMS minor version number.
          *
-         * @returns the CMS API minor version number
+         * @return the CMS API minor version number
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.
@@ -66,7 +66,7 @@ namespace cms {
         /**
          * Gets the CMS provider name.
          *
-         * @returns the CMS provider name
+         * @return the CMS provider name
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.
@@ -76,7 +76,7 @@ namespace cms {
         /**
          * Gets the CMS provider version.
          *
-         * @returns the CMS provider version
+         * @return the CMS provider version
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.
@@ -86,7 +86,7 @@ namespace cms {
         /**
          * Gets the CMS provider major version number.
          *
-         * @returns the CMS provider major version number
+         * @return the CMS provider major version number
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.
@@ -96,7 +96,7 @@ namespace cms {
         /**
          * Gets the CMS provider minor version number.
          *
-         * @returns the CMS provider minor version number
+         * @return the CMS provider minor version number
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.
@@ -106,7 +106,7 @@ namespace cms {
         /**
          * Gets the CMS provider patch version number.
          *
-         * @returns the CMS provider patch version number
+         * @return the CMS provider patch version number
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.
@@ -116,7 +116,7 @@ namespace cms {
         /**
          * Gets an Vector of the CMSX property names.
          *
-         * @returns an Vector of CMSX property names
+         * @return an Vector of CMSX property names
          *
          * @throw CMSException
          *        If the CMS Provider fails to retrieve the metadata due to some internal error.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/Destination.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/Destination.h b/activemq-cpp/src/main/cms/Destination.h
index 1f4d87e..0fc47c5 100644
--- a/activemq-cpp/src/main/cms/Destination.h
+++ b/activemq-cpp/src/main/cms/Destination.h
@@ -61,7 +61,7 @@ namespace cms {
          * Creates a new instance of this destination type that is a
          * copy of this one, and returns it.
          *
-         * @returns cloned copy of this object
+         * @return cloned copy of this object
          */
         virtual cms::Destination* clone() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/DestinationEvent.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/DestinationEvent.h b/activemq-cpp/src/main/cms/DestinationEvent.h
index 4b272e6..a2dc585 100644
--- a/activemq-cpp/src/main/cms/DestinationEvent.h
+++ b/activemq-cpp/src/main/cms/DestinationEvent.h
@@ -40,21 +40,21 @@ namespace cms {
          * if the caller wishes to store it beyond the lifetime of this event
          * object.
          *
-         * @returns a cms::Destination instance that this event relates to.
+         * @return a cms::Destination instance that this event relates to.
          */
         virtual const cms::Destination* getDestination() const = 0;
 
         /**
          * Returns true if this events represents the addition of a Destination.
          *
-         * @returns true if this events represents the addition of a Destination.
+         * @return true if this events represents the addition of a Destination.
          */
         virtual bool isAddOperation() const = 0;
 
         /**
          * Returns true if this events represents the removal of a Destination.
          *
-         * @returns true if this events represents the removal of a Destination.
+         * @return true if this events represents the removal of a Destination.
          */
         virtual bool isRemoveOperation() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/DestinationSource.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/DestinationSource.h b/activemq-cpp/src/main/cms/DestinationSource.h
index d27b8e7..a03823a 100644
--- a/activemq-cpp/src/main/cms/DestinationSource.h
+++ b/activemq-cpp/src/main/cms/DestinationSource.h
@@ -58,7 +58,7 @@ namespace cms {
          * it is removed via a call to setListener(null) and should not be deleted
          * until the client is sure it will not receive any future events.
          *
-         * @returns the configured DestinationListener for this event source or null if none.
+         * @return the configured DestinationListener for this event source or null if none.
          */
         virtual cms::DestinationListener* getListener() const = 0;
 
@@ -70,7 +70,7 @@ namespace cms {
          * The destinations are cloned and placed into the returned vector, the caller is
          * responsible for deleting these cloned objects.
          *
-         * @returns an STL vector containing the current list of known Queues.
+         * @return an STL vector containing the current list of known Queues.
          */
         virtual std::vector<cms::Queue*> getQueues() const = 0;
 
@@ -82,7 +82,7 @@ namespace cms {
          * The destinations are cloned and placed into the returned vector, the caller is
          * responsible for deleting these cloned objects.
          *
-         * @returns an STL vector containing the current list of known Queues.
+         * @return an STL vector containing the current list of known Queues.
          */
         virtual std::vector<cms::Topic*> getTopics() const = 0;
 
@@ -94,7 +94,7 @@ namespace cms {
          * The destinations are cloned and placed into the returned vector, the caller is
          * responsible for deleting these cloned objects.
          *
-         * @returns an STL vector containing the current list of known Queues.
+         * @return an STL vector containing the current list of known Queues.
          */
         virtual std::vector<cms::TemporaryQueue*> getTemporaryQueues() const = 0;
 
@@ -106,7 +106,7 @@ namespace cms {
          * The destinations are cloned and placed into the returned vector, the caller is
          * responsible for deleting these cloned objects.
          *
-         * @returns an STL vector containing the current list of known Queues.
+         * @return an STL vector containing the current list of known Queues.
          */
         virtual std::vector<cms::TemporaryTopic*> getTemporaryTopics() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/MapMessage.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/MapMessage.h b/activemq-cpp/src/main/cms/MapMessage.h
index f973e9e..f4d8c5d 100644
--- a/activemq-cpp/src/main/cms/MapMessage.h
+++ b/activemq-cpp/src/main/cms/MapMessage.h
@@ -76,7 +76,7 @@ namespace cms {
         /**
          * Returns true if there are no values stored in the MapMessage body.
          *
-         * @returns true if the body of the MapMessage contains no elements.
+         * @return true if the body of the MapMessage contains no elements.
          *
          * @throws CMSException if the operation fails due to an internal error.
          */
@@ -113,7 +113,7 @@ namespace cms {
          * @param key
          *      The string key used to look up the value type mapping.
          *
-         * @returns The ValueType contained in the given mapping.
+         * @return The ValueType contained in the given mapping.
          *
          * @throws CMSException if no mapping exists that matches the requested key.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/Message.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/Message.h b/activemq-cpp/src/main/cms/Message.h
index 6c8dc18..b18901c 100644
--- a/activemq-cpp/src/main/cms/Message.h
+++ b/activemq-cpp/src/main/cms/Message.h
@@ -213,7 +213,7 @@ namespace cms {
          * @param name
          *      The string property name key used to look up the value type.
          *
-         * @returns The ValueType contained in the given property.
+         * @return The ValueType contained in the given property.
          *
          * @throws CMSException if no property exists that matches the requested key.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/MessageConsumer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/MessageConsumer.h b/activemq-cpp/src/main/cms/MessageConsumer.h
index e806ead..6ae878b 100644
--- a/activemq-cpp/src/main/cms/MessageConsumer.h
+++ b/activemq-cpp/src/main/cms/MessageConsumer.h
@@ -139,7 +139,7 @@ namespace cms {
         /**
          * Gets the currently configured MessageTransformer for this MessageConsumer.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/MessageProducer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/MessageProducer.h b/activemq-cpp/src/main/cms/MessageProducer.h
index 9213f36..127399d 100644
--- a/activemq-cpp/src/main/cms/MessageProducer.h
+++ b/activemq-cpp/src/main/cms/MessageProducer.h
@@ -364,7 +364,7 @@ namespace cms {
         /**
          * Gets the currently configured MessageTransformer for this MessageProducer.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/MessageTransformer.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/MessageTransformer.h b/activemq-cpp/src/main/cms/MessageTransformer.h
index cf3ec8c..7529b69 100644
--- a/activemq-cpp/src/main/cms/MessageTransformer.h
+++ b/activemq-cpp/src/main/cms/MessageTransformer.h
@@ -57,7 +57,7 @@ namespace cms {
          * @param transformed
          *      A pointer to the location in memory where the newly transformed Message has been allocated.
          *
-         * @returns true if the MessageProducer should handle deleting the transformed Message once sent.
+         * @return true if the MessageProducer should handle deleting the transformed Message once sent.
          *
          * @throws cms::CMSException if an error occurs during the transform operation.
          */
@@ -81,7 +81,7 @@ namespace cms {
          * @param transformed
          *      A pointer to the location in memory where the newly transformed Message has been allocated.
          *
-         * @returns true if the MessageConsumer should handle deleting the transformed Message once sent.
+         * @return true if the MessageConsumer should handle deleting the transformed Message once sent.
          *
          * @throws cms::CMSException if an error occurs during the transform operation.
          */

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/ObjectMessage.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/ObjectMessage.h b/activemq-cpp/src/main/cms/ObjectMessage.h
index c978927..36de0ed 100644
--- a/activemq-cpp/src/main/cms/ObjectMessage.h
+++ b/activemq-cpp/src/main/cms/ObjectMessage.h
@@ -52,7 +52,7 @@ namespace cms {
         /**
          * Returns the byte array containing the serialized form of the transmitted Object.
          *
-         * @returns a byte vector containing the serialized Object.
+         * @return a byte vector containing the serialized Object.
          *
          * @throws CMSException - if the operation fails due to an internal error.
          * @throws MessageNotReadableException - if the message is in write only mode.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/QueueBrowser.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/QueueBrowser.h b/activemq-cpp/src/main/cms/QueueBrowser.h
index 5ceaf53..b6f4473 100644
--- a/activemq-cpp/src/main/cms/QueueBrowser.h
+++ b/activemq-cpp/src/main/cms/QueueBrowser.h
@@ -56,14 +56,14 @@ namespace cms {
         virtual ~QueueBrowser();
 
         /**
-         * @returns the Queue that this browser is listening on.
+         * @return the Queue that this browser is listening on.
          *
          * @throws CMSException if an internal error occurs.
          */
         virtual const Queue* getQueue() const = 0;
 
         /**
-         * @returns the MessageSelector that is used on when this browser was
+         * @return the MessageSelector that is used on when this browser was
          * created or empty string if no selector was present.
          *
          * @throws CMSException if an internal error occurs.
@@ -75,7 +75,7 @@ namespace cms {
          * the Queue in the order that a client would receive them.  The pointer returned is
          * owned by the browser and should not be deleted by the client application.
          *
-         * @returns a pointer to a Queue Enumeration, this Pointer is owned by the QueueBrowser
+         * @return a pointer to a Queue Enumeration, this Pointer is owned by the QueueBrowser
          *          and should not be deleted by the client.
          *
          * @throws CMSException if an internal error occurs.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/Session.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/Session.h b/activemq-cpp/src/main/cms/Session.h
index a86d0e8..a201251 100644
--- a/activemq-cpp/src/main/cms/Session.h
+++ b/activemq-cpp/src/main/cms/Session.h
@@ -461,7 +461,7 @@ namespace cms {
         /**
          * Gets the currently configured MessageTransformer for this Session.
          *
-         * @returns the pointer to the currently set cms::MessageTransformer.
+         * @return the pointer to the currently set cms::MessageTransformer.
          */
         virtual cms::MessageTransformer* getMessageTransformer() const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/StreamMessage.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/StreamMessage.h b/activemq-cpp/src/main/cms/StreamMessage.h
index 14d7c32..7036bc5 100644
--- a/activemq-cpp/src/main/cms/StreamMessage.h
+++ b/activemq-cpp/src/main/cms/StreamMessage.h
@@ -70,7 +70,7 @@ namespace cms {
          * The call can fail if the StreamMessage is currently in the middle of a ready of
          * a Byte array.
          *
-         * @returns The ValueType contained in the next message element.
+         * @return The ValueType contained in the next message element.
          *
          * @throws CMSException if no property exists that matches the requested key.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -81,7 +81,7 @@ namespace cms {
 
         /**
          * Reads a Boolean from the Stream message stream
-         * @returns boolean value from stream
+         * @return boolean value from stream
          *
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
@@ -107,7 +107,7 @@ namespace cms {
         /**
          * Reads a Byte from the Stream message stream
          *
-         * @returns unsigned char value from stream
+         * @return unsigned char value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -142,7 +142,7 @@ namespace cms {
          *
          * @param value
          *      buffer to place data in
-         * @returns the total number of bytes read into the buffer, or -1 if
+         * @return the total number of bytes read into the buffer, or -1 if
          *          there is no more data because the end of the stream has
          *          been reached
          * @throw CMSException - if the CMS provider fails to read the message
@@ -187,7 +187,7 @@ namespace cms {
          * @param length
          *      the number of bytes to read; must be less than or equal to
          *      value.length
-         * @returns the total number of bytes read into the buffer, or -1 if
+         * @return the total number of bytes read into the buffer, or -1 if
          *          there is no more data because the end of the stream has
          *          been reached
          * @throw CMSException - if the CMS provider fails to read the message
@@ -217,7 +217,7 @@ namespace cms {
         /**
          * Reads a Char from the Stream message stream
          *
-         * @returns char value from stream
+         * @return char value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -240,7 +240,7 @@ namespace cms {
         /**
          * Reads a 32 bit float from the Stream message stream
          *
-         * @returns double value from stream
+         * @return double value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -262,7 +262,7 @@ namespace cms {
         /**
          * Reads a 64 bit double from the Stream message stream
          *
-         * @returns double value from stream
+         * @return double value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -284,7 +284,7 @@ namespace cms {
         /**
          * Reads a 16 bit signed short from the Stream message stream
          *
-         * @returns short value from stream
+         * @return short value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -307,7 +307,7 @@ namespace cms {
         /**
          * Reads a 16 bit unsigned short from the Stream message stream
          *
-         * @returns unsigned short value from stream
+         * @return unsigned short value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -330,7 +330,7 @@ namespace cms {
         /**
          * Reads a 32 bit signed integer from the Stream message stream
          *
-         * @returns int value from stream
+         * @return int value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -353,7 +353,7 @@ namespace cms {
         /**
          * Reads a 64 bit long from the Stream message stream
          *
-         * @returns long long value from stream
+         * @return long long value from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.
@@ -376,7 +376,7 @@ namespace cms {
         /**
          * Reads an ASCII String from the Stream message stream
          *
-         * @returns String from stream
+         * @return String from stream
          * @throw CMSException - if the CMS provider fails to read the message
          *                       due to some internal error.
          * @throw MessageEOFException - if unexpected end of message stream has been reached.

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/XAConnection.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/XAConnection.h b/activemq-cpp/src/main/cms/XAConnection.h
index c239c3a..6cc94c8 100644
--- a/activemq-cpp/src/main/cms/XAConnection.h
+++ b/activemq-cpp/src/main/cms/XAConnection.h
@@ -42,7 +42,7 @@ namespace cms {
         /**
          * Creates an XASession object.
          *
-         * @returns a newly created XASession instance, caller owns the pointer.
+         * @return a newly created XASession instance, caller owns the pointer.
          *
          * @throws CMSException
          *      If the XAConnection object fails to create the XASession instance due to

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/XAConnectionFactory.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/XAConnectionFactory.h b/activemq-cpp/src/main/cms/XAConnectionFactory.h
index 870d188..20b66c2 100644
--- a/activemq-cpp/src/main/cms/XAConnectionFactory.h
+++ b/activemq-cpp/src/main/cms/XAConnectionFactory.h
@@ -54,7 +54,7 @@ namespace cms {
          * in stopped mode just as the standard Connection object is created from the ConnectionFactory.
          * No messages will be delivered until the Connection.start method is explicitly called.
          *
-         * @returns a new XAConnectionFactory instance, the caller owns the returned pointer.
+         * @return a new XAConnectionFactory instance, the caller owns the returned pointer.
          *
          * @throws CMSException if an internal error occurs while creating the Connection.
          * @throws CMSSecurityException if the client authentication fails because the user name or
@@ -67,7 +67,7 @@ namespace cms {
          * created in stopped mode just as the standard ConnectionFactory creates a new Connection.
          * No messages will be delivered until the Connection.start method is explicitly called.
          *
-         * @returns a new XAConnectionFactory instance, the caller owns the returned pointer.
+         * @return a new XAConnectionFactory instance, the caller owns the returned pointer.
          *
          * @throws CMSException if an internal error occurs while creating the Connection.
          * @throws CMSSecurityException if the client authentication fails because the user name or

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/XAException.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/XAException.h b/activemq-cpp/src/main/cms/XAException.h
index daa3c52..aa0097f 100644
--- a/activemq-cpp/src/main/cms/XAException.h
+++ b/activemq-cpp/src/main/cms/XAException.h
@@ -206,7 +206,7 @@ namespace cms {
         /**
          * Gets the error code that was assigned to this XAException.
          *
-         * @returns the assigned error code.
+         * @return the assigned error code.
          */
         int getErrorCode() const {
             return this->errorCode;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/XASession.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/XASession.h b/activemq-cpp/src/main/cms/XASession.h
index 4402b75..7a7e17d 100644
--- a/activemq-cpp/src/main/cms/XASession.h
+++ b/activemq-cpp/src/main/cms/XASession.h
@@ -62,7 +62,7 @@ namespace cms {
          * The client can use the provided XA resource to interact with the XA Transaction
          * Manager in use in the client application.
          *
-         * @returns an XAResouce instance to the caller, the caller does not own this
+         * @return an XAResouce instance to the caller, the caller does not own this
          *          pointer and should not delete it.
          */
         virtual XAResource* getXAResource() const = 0;

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/cms/Xid.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/cms/Xid.h b/activemq-cpp/src/main/cms/Xid.h
index 61d2e92..1dc5bfa 100644
--- a/activemq-cpp/src/main/cms/Xid.h
+++ b/activemq-cpp/src/main/cms/Xid.h
@@ -63,14 +63,14 @@ namespace cms {
         /**
          * Creates a Copy of this Xid instance that contains the same id values.
          *
-         * @returns a new Xid instance that is equal to this one when compared.
+         * @return a new Xid instance that is equal to this one when compared.
          */
         virtual Xid* clone() const = 0;
 
         /**
          * Compares this Xid to another and returns true if they are the same.
          *
-         * @returns true if both Xid's represent that same id value.
+         * @return true if both Xid's represent that same id value.
          */
         virtual bool equals(const Xid* other) const = 0;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/AprPool.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/AprPool.h b/activemq-cpp/src/main/decaf/internal/AprPool.h
index c94ef93..da8aa93 100644
--- a/activemq-cpp/src/main/decaf/internal/AprPool.h
+++ b/activemq-cpp/src/main/decaf/internal/AprPool.h
@@ -50,7 +50,7 @@ namespace internal{
 
         /**
          * Gets the internal APR Pool.
-         * @returns the internal APR pool
+         * @return the internal APR pool
          */
         apr_pool_t* getAprPool() const;
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/DecafRuntime.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/DecafRuntime.h b/activemq-cpp/src/main/decaf/internal/DecafRuntime.h
index 410b1fc..b686bb8 100644
--- a/activemq-cpp/src/main/decaf/internal/DecafRuntime.h
+++ b/activemq-cpp/src/main/decaf/internal/DecafRuntime.h
@@ -62,7 +62,7 @@ namespace internal {
          * The pointer returned is owned by the Decaf runtime and should not be
          * deleted or copied by the caller.
          *
-         * @returns a pointer to the Decaf Runtime's global Lock instance.
+         * @return a pointer to the Decaf Runtime's global Lock instance.
          */
         decaf::util::concurrent::Mutex* getGlobalLock();
 

http://git-wip-us.apache.org/repos/asf/activemq-cpp/blob/cb372c07/activemq-cpp/src/main/decaf/internal/net/Network.h
----------------------------------------------------------------------
diff --git a/activemq-cpp/src/main/decaf/internal/net/Network.h b/activemq-cpp/src/main/decaf/internal/net/Network.h
index 277677a..f03b14d 100644
--- a/activemq-cpp/src/main/decaf/internal/net/Network.h
+++ b/activemq-cpp/src/main/decaf/internal/net/Network.h
@@ -64,7 +64,7 @@ namespace net {
          * The pointer returned is owned by the Network runtime and should not be
          * deleted or copied by the caller.
          *
-         * @returns a pointer to the Network Runtime's single Lock instance.
+         * @return a pointer to the Network Runtime's single Lock instance.
          */
         decaf::util::concurrent::Mutex* getRuntimeLock();