You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mina.apache.org by el...@apache.org on 2023/06/01 21:48:57 UTC

[mina] branch 2.1.X updated: Replaced the xxx by {@code xxx} in javadoc

This is an automated email from the ASF dual-hosted git repository.

elecharny pushed a commit to branch 2.1.X
in repository https://gitbox.apache.org/repos/asf/mina.git


The following commit(s) were added to refs/heads/2.1.X by this push:
     new 99e43919b Replaced the <tt>xxx</tt> by {@code xxx} in javadoc
99e43919b is described below

commit 99e43919b7238e930778d3e23be14253d2a7ba24
Author: emmanuel lecharny <el...@apache.org>
AuthorDate: Thu Jun 1 23:48:47 2023 +0200

    Replaced the <tt>xxx</tt> by {@code xxx} in javadoc
---
 .../src/main/java/org/apache/mina/core/IoUtil.java |  8 +-
 .../apache/mina/core/buffer/AbstractIoBuffer.java  |  4 +-
 .../mina/core/buffer/CachedBufferAllocator.java    |  8 +-
 .../java/org/apache/mina/core/buffer/IoBuffer.java | 96 +++++++++++-----------
 .../apache/mina/core/buffer/IoBufferAllocator.java |  8 +-
 .../apache/mina/core/buffer/IoBufferHexDumper.java |  6 +-
 .../java/org/apache/mina/core/file/FileRegion.java |  6 +-
 .../filterchain/DefaultIoFilterChainBuilder.java   |  6 +-
 .../org/apache/mina/core/filterchain/IoFilter.java | 26 +++---
 .../mina/core/filterchain/IoFilterChain.java       | 40 ++++-----
 .../core/filterchain/IoFilterChainBuilder.java     |  2 +-
 .../org/apache/mina/core/future/CloseFuture.java   |  2 +-
 .../org/apache/mina/core/future/ConnectFuture.java |  2 +-
 .../apache/mina/core/future/DefaultIoFuture.java   |  2 +-
 .../java/org/apache/mina/core/future/IoFuture.java | 16 ++--
 .../org/apache/mina/core/future/ReadFuture.java    |  8 +-
 .../org/apache/mina/core/future/WriteFuture.java   |  4 +-
 .../core/polling/AbstractPollingIoConnector.java   |  2 +-
 .../core/polling/AbstractPollingIoProcessor.java   | 18 ++--
 .../mina/core/service/AbstractIoConnector.java     |  6 +-
 .../org/apache/mina/core/service/IoAcceptor.java   | 20 ++---
 .../org/apache/mina/core/service/IoProcessor.java  |  6 +-
 .../org/apache/mina/core/service/IoService.java    | 10 +--
 .../mina/core/service/IoServiceStatistics.java     | 12 +--
 .../mina/core/service/TransportMetadata.java       |  2 +-
 .../org/apache/mina/core/session/DummySession.java |  4 +-
 .../org/apache/mina/core/session/IdleStatus.java   |  6 +-
 .../mina/core/session/IdleStatusChecker.java       |  2 +-
 .../org/apache/mina/core/session/IoSession.java    | 90 ++++++++++----------
 .../mina/core/session/IoSessionAttributeMap.java   | 12 +--
 .../apache/mina/core/session/IoSessionConfig.java  | 12 +--
 .../session/IoSessionDataStructureFactory.java     |  4 +-
 .../org/apache/mina/core/write/WriteRequest.java   |  2 +-
 .../apache/mina/core/write/WriteRequestQueue.java  |  2 +-
 .../filter/codec/CumulativeProtocolDecoder.java    | 20 ++---
 .../apache/mina/filter/codec/ProtocolDecoder.java  |  4 +-
 .../mina/filter/codec/ProtocolEncoderOutput.java   |  2 +-
 .../codec/RecoverableProtocolDecoderException.java |  2 +-
 .../filter/codec/SynchronizedProtocolDecoder.java  |  2 +-
 .../filter/codec/SynchronizedProtocolEncoder.java  |  2 +-
 .../codec/demux/DemuxingProtocolEncoder.java       |  2 +-
 .../mina/filter/codec/demux/MessageDecoder.java    |  6 +-
 .../mina/filter/codec/demux/MessageEncoder.java    |  2 +-
 .../ObjectSerializationCodecFactory.java           |  4 +-
 .../serialization/ObjectSerializationDecoder.java  |  4 +-
 .../ObjectSerializationInputStream.java            |  4 +-
 .../ConsumeToDynamicTerminatorDecodingState.java   |  4 +-
 .../ConsumeToLinearWhitespaceDecodingState.java    |  2 +-
 .../codec/statemachine/CrLfDecodingState.java      |  6 +-
 .../filter/codec/statemachine/DecodingState.java   |  2 +-
 .../filter/codec/statemachine/SkippingState.java   |  4 +-
 .../mina/filter/codec/textline/LineDelimiter.java  | 18 ++--
 .../codec/textline/TextLineCodecFactory.java       |  4 +-
 .../filter/codec/textline/TextLineDecoder.java     | 18 ++--
 .../filter/codec/textline/TextLineEncoder.java     | 14 ++--
 .../executor/DefaultIoEventSizeEstimator.java      |  2 +-
 .../mina/filter/executor/ExecutorFilter.java       |  4 +-
 .../mina/filter/executor/IoEventQueueHandler.java  | 10 +--
 .../mina/filter/keepalive/KeepAliveFilter.java     | 54 ++++++------
 .../filter/keepalive/KeepAliveMessageFactory.java  |  8 +-
 .../apache/mina/filter/ssl/KeyStoreFactory.java    |  2 +-
 .../apache/mina/filter/ssl/SslContextFactory.java  | 18 ++--
 .../org/apache/mina/filter/ssl/SslHandler.java     |  2 +-
 .../util/SessionAttributeInitializingFilter.java   | 14 ++--
 .../mina/handler/chain/ChainedIoHandler.java       |  8 +-
 .../apache/mina/handler/chain/IoHandlerChain.java  |  6 +-
 .../mina/handler/demux/DemuxingIoHandler.java      | 12 +--
 .../apache/mina/handler/demux/MessageHandler.java  |  2 +-
 .../mina/handler/stream/StreamIoHandler.java       |  8 +-
 .../mina/proxy/AbstractProxyLogicHandler.java      |  2 +-
 .../org/apache/mina/proxy/ProxyLogicHandler.java   |  2 +-
 .../apache/mina/proxy/utils/IoBufferDecoder.java   |  8 +-
 .../apache/mina/proxy/utils/StringUtilities.java   |  2 +-
 .../socket/AbstractDatagramSessionConfig.java      | 30 +++----
 .../socket/AbstractSocketSessionConfig.java        | 48 +++++------
 .../mina/transport/socket/DatagramAcceptor.java    |  2 +-
 .../transport/socket/DatagramSessionConfig.java    |  6 +-
 .../mina/transport/socket/SocketAcceptor.java      |  4 +-
 .../mina/transport/socket/SocketSessionConfig.java | 26 +++---
 .../socket/nio/NioDatagramSessionConfig.java       |  4 +-
 .../transport/socket/nio/NioSocketAcceptor.java    |  2 +-
 .../org/apache/mina/util/AvailablePortFinder.java  |  2 +-
 .../org/apache/mina/util/ExceptionMonitor.java     |  4 +-
 .../apache/mina/util/LazyInitializedCacheMap.java  |  2 +-
 .../org/apache/mina/util/byteaccess/ByteArray.java |  2 +-
 .../mina/util/byteaccess/IoAbsoluteReader.java     | 16 ++--
 .../mina/util/byteaccess/IoRelativeReader.java     |  2 +-
 .../sumup/codec/AbstractMessageDecoder.java        |  2 +-
 .../mina/filter/compression/CompressionFilter.java | 16 ++--
 .../org/apache/mina/filter/compression/Zlib.java   |  8 +-
 .../java/org/apache/mina/http/api/HttpMessage.java |  6 +-
 .../java/org/apache/mina/http/api/HttpRequest.java |  2 +-
 .../apache/mina/integration/beans/NullEditor.java  |  2 +-
 .../mina/integration/ognl/IoSessionFinder.java     |  2 +-
 .../integration/ognl/PropertyTypeConverter.java    |  2 +-
 .../statemachine/StateMachineProxyBuilder.java     |  4 +-
 .../context/AbstractStateContextLookup.java        | 10 +--
 .../transition/AbstractSelfTransition.java         |  2 +-
 .../transition/AbstractTransition.java             |  4 +-
 .../statemachine/transition/SelfTransition.java    |  2 +-
 .../mina/statemachine/transition/Transition.java   |  8 +-
 .../mina/transport/serial/SerialAddressEditor.java |  2 +-
 102 files changed, 483 insertions(+), 483 deletions(-)

diff --git a/mina-core/src/main/java/org/apache/mina/core/IoUtil.java b/mina-core/src/main/java/org/apache/mina/core/IoUtil.java
index b9711bd27..72510e4d9 100644
--- a/mina-core/src/main/java/org/apache/mina/core/IoUtil.java
+++ b/mina-core/src/main/java/org/apache/mina/core/IoUtil.java
@@ -158,7 +158,7 @@ public final class IoUtil {
      * @param futures The {@link IoFuture}s we are waiting on 
      * @param timeout The maximum time we wait for the {@link IoFuture}s to complete
      * @param unit The Time unit to use for the timeout
-     * @return <tt>TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE</tt> if
+     * @return {@code TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE} if
      * at least one {@link IoFuture} haas been interrupted
      * @throws InterruptedException If one of the {@link IoFuture} is interrupted
      */
@@ -172,7 +172,7 @@ public final class IoUtil {
      *  
      * @param futures The {@link IoFuture}s we are waiting on 
      * @param timeoutMillis The maximum milliseconds we wait for the {@link IoFuture}s to complete
-     * @return <tt>TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE</tt> if
+     * @return {@code TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE} if
      * at least one {@link IoFuture} has been interrupted
      * @throws InterruptedException If one of the {@link IoFuture} is interrupted
      */
@@ -186,7 +186,7 @@ public final class IoUtil {
      * @param futures The {@link IoFuture}s we are waiting on 
      * @param timeout The maximum time we wait for the {@link IoFuture}s to complete
      * @param unit The Time unit to use for the timeout
-     * @return <tt>TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE</tt> if
+     * @return {@code TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE} if
      * at least one {@link IoFuture} has been interrupted
      */
     public static boolean awaitUninterruptibly(Iterable<? extends IoFuture> futures, long timeout, TimeUnit unit) {
@@ -198,7 +198,7 @@ public final class IoUtil {
      *  
      * @param futures The {@link IoFuture}s we are waiting on 
      * @param timeoutMillis The maximum milliseconds we wait for the {@link IoFuture}s to complete
-     * @return <tt>TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE</tt> if
+     * @return {@code TRUE</TT> if all the {@link IoFuture} have been completed, <tt>FALSE} if
      * at least one {@link IoFuture} has been interrupted
      */
     public static boolean awaitUninterruptibly(Iterable<? extends IoFuture> futures, long timeoutMillis) {
diff --git a/mina-core/src/main/java/org/apache/mina/core/buffer/AbstractIoBuffer.java b/mina-core/src/main/java/org/apache/mina/core/buffer/AbstractIoBuffer.java
index 6f6e00426..b16e75f0f 100644
--- a/mina-core/src/main/java/org/apache/mina/core/buffer/AbstractIoBuffer.java
+++ b/mina-core/src/main/java/org/apache/mina/core/buffer/AbstractIoBuffer.java
@@ -2720,7 +2720,7 @@ public abstract class AbstractIoBuffer extends IoBuffer {
 
     /**
      * This method forwards the call to {@link #expand(int)} only when
-     * <tt>autoExpand</tt> property is <tt>true</tt>.
+     * {@code autoExpand</tt> property is <tt>true}.
      */
     private IoBuffer autoExpand(int expectedRemaining) {
         if (isAutoExpand()) {
@@ -2731,7 +2731,7 @@ public abstract class AbstractIoBuffer extends IoBuffer {
 
     /**
      * This method forwards the call to {@link #expand(int)} only when
-     * <tt>autoExpand</tt> property is <tt>true</tt>.
+     * {@code autoExpand</tt> property is <tt>true}.
      */
     private IoBuffer autoExpand(int pos, int expectedRemaining) {
         if (isAutoExpand()) {
diff --git a/mina-core/src/main/java/org/apache/mina/core/buffer/CachedBufferAllocator.java b/mina-core/src/main/java/org/apache/mina/core/buffer/CachedBufferAllocator.java
index 991a8720c..e3a3244c2 100644
--- a/mina-core/src/main/java/org/apache/mina/core/buffer/CachedBufferAllocator.java
+++ b/mina-core/src/main/java/org/apache/mina/core/buffer/CachedBufferAllocator.java
@@ -83,10 +83,10 @@ public class CachedBufferAllocator implements IoBufferAllocator {
      * Creates a new instance.
      * 
      * @param maxPoolSize the maximum number of buffers with the same capacity per thread.
-     *                    <tt>0</tt> disables this limitation.
+     *                    {@code 0} disables this limitation.
      * @param maxCachedBufferSize the maximum capacity of a cached buffer.
      *                            A buffer whose capacity is bigger than this value is
-     *                            not pooled. <tt>0</tt> disables this limitation.
+     *                            not pooled. {@code 0} disables this limitation.
      */
     public CachedBufferAllocator(int maxPoolSize, int maxCachedBufferSize) {
         if (maxPoolSize < 0) {
@@ -117,7 +117,7 @@ public class CachedBufferAllocator implements IoBufferAllocator {
 
     /**
      * @return the maximum number of buffers with the same capacity per thread.
-     * <tt>0</tt> means 'no limitation'.
+     * {@code 0} means 'no limitation'.
      */
     public int getMaxPoolSize() {
         return maxPoolSize;
@@ -125,7 +125,7 @@ public class CachedBufferAllocator implements IoBufferAllocator {
 
     /**
      * @return the maximum capacity of a cached buffer.  A buffer whose
-     * capacity is bigger than this value is not pooled.  <tt>0</tt> means
+     * capacity is bigger than this value is not pooled.  {@code 0} means
      * 'no limitation'.
      */
     public int getMaxCachedBufferSize() {
diff --git a/mina-core/src/main/java/org/apache/mina/core/buffer/IoBuffer.java b/mina-core/src/main/java/org/apache/mina/core/buffer/IoBuffer.java
index db5e47726..7927a4383 100644
--- a/mina-core/src/main/java/org/apache/mina/core/buffer/IoBuffer.java
+++ b/mina-core/src/main/java/org/apache/mina/core/buffer/IoBuffer.java
@@ -78,14 +78,14 @@ import org.apache.mina.core.session.IoSession;
  * 
  * <h2>Wrapping existing NIO buffers and arrays</h2>
  * <p>
- * This class provides a few <tt>wrap(...)</tt> methods that wraps any NIO
+ * This class provides a few {@code wrap(...)} methods that wraps any NIO
  * buffers and byte arrays.
  * 
  * <h2>AutoExpand</h2>
  * <p>
- * Writing variable-length data using NIO <tt>ByteBuffers</tt> is not really
+ * Writing variable-length data using NIO {@code ByteBuffers} is not really
  * easy, and it is because its size is fixed at allocation. {@link IoBuffer}
- * introduces the <tt>autoExpand</tt> property. If <tt>autoExpand</tt> property
+ * introduces the {@code autoExpand</tt> property. If <tt>autoExpand} property
  * is set to true, you never get a {@link BufferOverflowException} or an
  * {@link IndexOutOfBoundsException} (except when index is negative). It
  * automatically expands its capacity. For instance:
@@ -107,8 +107,8 @@ import org.apache.mina.core.session.IoSession;
  * <p>
  * You might also want to decrease the capacity of the buffer when most of the
  * allocated memory area is not being used. {@link IoBuffer} provides
- * <tt>autoShrink</tt> property to take care of this issue. If
- * <tt>autoShrink</tt> is turned on, {@link IoBuffer} halves the capacity of the
+ * {@code autoShrink} property to take care of this issue. If
+ * {@code autoShrink} is turned on, {@link IoBuffer} halves the capacity of the
  * buffer when {@link #compact()} is invoked and only 1/4 or less of the current
  * capacity is being used.
  * <p>
@@ -130,7 +130,7 @@ import org.apache.mina.core.session.IoSession;
  * multiple {@link IoSession}s. Please note that the buffer derived from and its
  * derived buffers are not auto-expandable nor auto-shrinkable. Trying to call
  * {@link #setAutoExpand(boolean)} or {@link #setAutoShrink(boolean)} with
- * <tt>true</tt> parameter will raise an {@link IllegalStateException}.
+ * {@code true} parameter will raise an {@link IllegalStateException}.
  * 
  * <h2>Changing Buffer Allocation Policy</h2>
  * <p>
@@ -187,9 +187,9 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     }
 
     /**
-     * @return <tt>true</tt> if and only if a direct buffer is allocated by default
+     * @return {@code true} if and only if a direct buffer is allocated by default
      *         when the type of the new buffer is not specified. The default value
-     *         is <tt>false</tt>.
+     *         is {@code false}.
      */
     public static boolean isUseDirectBuffer() {
         return useDirectBuffer;
@@ -197,7 +197,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
 
     /**
      * Sets if a direct buffer should be allocated by default when the type of the
-     * new buffer is not specified. The default value is <tt>false</tt>.
+     * new buffer is not specified. The default value is {@code false}.
      * 
      * @param useDirectBuffer Tells if direct buffers should be allocated
      */
@@ -223,7 +223,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * bytes.
      * 
      * @param capacity        the capacity of the buffer
-     * @param useDirectBuffer <tt>true</tt> to get a direct buffer, <tt>false</tt>
+     * @param useDirectBuffer {@code true</tt> to get a direct buffer, <tt>false}
      *                        to get a heap buffer.
      * @return a direct or heap IoBuffer which can hold up to capacity bytes
      */
@@ -308,12 +308,12 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * @see ByteBuffer#isDirect()
      * 
-     * @return <tt>True</tt> if this is a direct buffer
+     * @return {@code True} if this is a direct buffer
      */
     public abstract boolean isDirect();
 
     /**
-     * @return <tt>true</tt> if and only if this buffer is derived from another
+     * @return {@code true} if and only if this buffer is derived from another
      *         buffer via one of the {@link #duplicate()}, {@link #slice()} or
      *         {@link #asReadOnlyBuffer()} methods.
      */
@@ -322,7 +322,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * @see ByteBuffer#isReadOnly()
      * 
-     * @return <tt>true</tt> if the buffer is readOnly
+     * @return {@code true} if the buffer is readOnly
      */
     public abstract boolean isReadOnly();
 
@@ -403,12 +403,12 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract IoBuffer capacity(int newCapacity);
 
     /**
-     * @return <tt>true</tt> if and only if <tt>autoExpand</tt> is turned on.
+     * @return {@code true</tt> if and only if <tt>autoExpand} is turned on.
      */
     public abstract boolean isAutoExpand();
 
     /**
-     * Turns on or off <tt>autoExpand</tt>.
+     * Turns on or off {@code autoExpand}.
      * 
      * @param autoExpand The flag value to set
      * @return The modified IoBuffer instance
@@ -416,12 +416,12 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract IoBuffer setAutoExpand(boolean autoExpand);
 
     /**
-     * @return <tt>true</tt> if and only if <tt>autoShrink</tt> is turned on.
+     * @return {@code true</tt> if and only if <tt>autoShrink} is turned on.
      */
     public abstract boolean isAutoShrink();
 
     /**
-     * Turns on or off <tt>autoShrink</tt>.
+     * Turns on or off {@code autoShrink}.
      * 
      * @param autoShrink The flag value to set
      * @return The modified IoBuffer instance
@@ -430,8 +430,8 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
 
     /**
      * Changes the capacity and limit of this buffer so this buffer get the
-     * specified <tt>expectedRemaining</tt> room from the current position. This
-     * method works even if you didn't set <tt>autoExpand</tt> to <tt>true</tt>.
+     * specified {@code expectedRemaining} room from the current position. This
+     * method works even if you didn't set {@code autoExpand</tt> to <tt>true}.
      * <br>
      * Assuming a buffer contains N bytes, its position is P and its current
      * capacity is C, here are the resulting buffer if we call the expand method
@@ -499,9 +499,9 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
 
     /**
      * Changes the capacity and limit of this buffer so this buffer get the
-     * specified <tt>expectedRemaining</tt> room from the specified
-     * <tt>position</tt>. This method works even if you didn't set
-     * <tt>autoExpand</tt> to <tt>true</tt>. Assuming a buffer contains N bytes, its
+     * specified {@code expectedRemaining} room from the specified
+     * {@code position}. This method works even if you didn't set
+     * {@code autoExpand</tt> to <tt>true}. Assuming a buffer contains N bytes, its
      * position is P and its current capacity is C, here are the resulting buffer if
      * we call the expand method with a expectedRemaining value V :
      * 
@@ -653,7 +653,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract IoBuffer mark();
 
     /**
-     * @return the position of the current mark. This method returns <tt>-1</tt> if
+     * @return the position of the current mark. This method returns {@code -1} if
      *         no mark is set.
      */
     public abstract int markValue();
@@ -675,7 +675,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract IoBuffer clear();
 
     /**
-     * Clears this buffer and fills its content with <tt>NUL</tt>. The position is
+     * Clears this buffer and fills its content with {@code NUL}. The position is
      * set to zero, the limit is set to the capacity, and the mark is discarded.
      * 
      * @return the modified IoBuffer
@@ -684,7 +684,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract IoBuffer sweep();
 
     /**
-     * double Clears this buffer and fills its content with <tt>value</tt>. The
+     * double Clears this buffer and fills its content with {@code value}. The
      * position is set to zero, the limit is set to the capacity, and the mark is
      * discarded.
      *
@@ -720,7 +720,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * @see java.nio.Buffer#hasRemaining()
      * 
-     * @return <tt>true</tt> if there are some remaining bytes in the buffer
+     * @return {@code true} if there are some remaining bytes in the buffer
      */
     public abstract boolean hasRemaining();
 
@@ -751,7 +751,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * @see ByteBuffer#hasArray()
      * 
-     * @return <tt>true</tt> if the {@link #array()} method will return a byte[]
+     * @return {@code true} if the {@link #array()} method will return a byte[]
      */
     public abstract boolean hasArray();
 
@@ -855,7 +855,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract IoBuffer getSlice(int length);
 
     /**
-     * Writes the content of the specified <tt>src</tt> into this buffer.
+     * Writes the content of the specified {@code src} into this buffer.
      * 
      * @param src The source ByteBuffer
      * @return the modified IoBuffer
@@ -863,7 +863,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract IoBuffer put(ByteBuffer src);
 
     /**
-     * Writes the content of the specified <tt>src</tt> into this buffer.
+     * Writes the content of the specified {@code src} into this buffer.
      * 
      * @param src The source IoBuffer
      * @return the modified IoBuffer
@@ -1052,7 +1052,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * @param index The index from which the medium int will be read
      * @return The medium int value at the given index
      * 
-     * @throws IndexOutOfBoundsException If <tt>index</tt> is negative or not
+     * @throws IndexOutOfBoundsException If {@code index} is negative or not
      *                                   smaller than the buffer's limit
      */
     public abstract int getMediumInt(int index);
@@ -1067,7 +1067,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * @param index The index from which the unsigned medium int will be read
      * @return The unsigned medium int value at the given index
      * 
-     * @throws IndexOutOfBoundsException If <tt>index</tt> is negative or not
+     * @throws IndexOutOfBoundsException If {@code index} is negative or not
      *                                   smaller than the buffer's limit
      */
     public abstract int getUnsignedMediumInt(int index);
@@ -1099,7 +1099,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * 
      * @return the modified IoBuffer
      * 
-     * @throws IndexOutOfBoundsException If <tt>index</tt> is negative or not
+     * @throws IndexOutOfBoundsException If {@code index} is negative or not
      *                                   smaller than the buffer's limit, minus
      *                                   three
      */
@@ -1491,7 +1491,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
 
     /**
      * @return an {@link InputStream} that reads the data from this buffer.
-     *         {@link InputStream#read()} returns <tt>-1</tt> if the buffer position
+     *         {@link InputStream#read()} returns {@code -1} if the buffer position
      *         reaches to the limit.
      */
     public abstract InputStream asInputStream();
@@ -1500,7 +1500,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * @return an {@link OutputStream} that appends the data into this buffer.
      *         Please note that the {@link OutputStream#write(int)} will throw a
      *         {@link BufferOverflowException} instead of an {@link IOException} in
-     *         case of buffer overflow. Please set <tt>autoExpand</tt> property by
+     *         case of buffer overflow. Please set {@code autoExpand} property by
      *         calling {@link #setAutoExpand(boolean)} to prevent the unexpected
      *         runtime exception.
      */
@@ -1556,7 +1556,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * Reads a <code>NUL</code>-terminated string from this buffer using the
      * specified <code>decoder</code> and returns it. This method reads until the
-     * limit of this buffer if no <tt>NUL</tt> is found.
+     * limit of this buffer if no {@code NUL} is found.
      * 
      * @param decoder The {@link CharsetDecoder} to use
      * @return the read String
@@ -1579,7 +1579,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
 
     /**
      * Writes the content of <code>in</code> into this buffer using the specified
-     * <code>encoder</code>. This method doesn't terminate string with <tt>NUL</tt>.
+     * <code>encoder</code>. This method doesn't terminate string with {@code NUL}.
      * You have to do it by yourself.
      * 
      * @param val     The CharSequence to put in the IoBuffer
@@ -1599,7 +1599,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * a terminator.
      * <p>
      * Please note that this method doesn't terminate with <code>NUL</code> if the
-     * input string is longer than <tt>fieldSize</tt>.
+     * input string is longer than {@code fieldSize}.
      * 
      * @param val       The CharSequence to put in the IoBuffer
      * @param fieldSize the maximum number of bytes to write
@@ -1614,7 +1614,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * Reads a string which has a 16-bit length field before the actual encoded
      * string, using the specified <code>decoder</code> and returns it. This method
-     * is a shortcut for <tt>getPrefixedString(2, decoder)</tt>.
+     * is a shortcut for {@code getPrefixedString(2, decoder)}.
      * 
      * @param decoder The CharsetDecoder to use
      * @return The read String
@@ -1641,7 +1641,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * Writes the content of <code>in</code> into this buffer as a string which has
      * a 16-bit length field before the actual encoded string, using the specified
      * <code>encoder</code>. This method is a shortcut for
-     * <tt>putPrefixedString(in, 2, 0, encoder)</tt>.
+     * {@code putPrefixedString(in, 2, 0, encoder)}.
      * 
      * @param in      The CharSequence to put in the IoBuffer
      * @param encoder The CharsetEncoder to use
@@ -1656,7 +1656,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * Writes the content of <code>in</code> into this buffer as a string which has
      * a 16-bit length field before the actual encoded string, using the specified
      * <code>encoder</code>. This method is a shortcut for
-     * <tt>putPrefixedString(in, prefixLength, 0, encoder)</tt>.
+     * {@code putPrefixedString(in, prefixLength, 0, encoder)}.
      * 
      * @param in           The CharSequence to put in the IoBuffer
      * @param prefixLength the length of the length field (1, 2, or 4)
@@ -1673,11 +1673,11 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * Writes the content of <code>in</code> into this buffer as a string which has
      * a 16-bit length field before the actual encoded string, using the specified
      * <code>encoder</code>. This method is a shortcut for
-     * <tt>putPrefixedString(in, prefixLength, padding, ( byte ) 0, encoder)</tt>
+     * {@code putPrefixedString(in, prefixLength, padding, ( byte ) 0, encoder)}
      * 
      * @param in           The CharSequence to put in the IoBuffer
      * @param prefixLength the length of the length field (1, 2, or 4)
-     * @param padding      the number of padded <tt>NUL</tt>s (1 (or 0), 2, or 4)
+     * @param padding      the number of padded {@code NUL}s (1 (or 0), 2, or 4)
      * @param encoder      The CharsetEncoder to use
      * @return The modified IoBuffer
      * 
@@ -1714,7 +1714,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     public abstract Object getObject() throws ClassNotFoundException;
 
     /**
-     * Reads a Java object from the buffer using the specified <tt>classLoader</tt>.
+     * Reads a Java object from the buffer using the specified {@code classLoader}.
      * 
      * @param classLoader The classLoader to use to read an Object from the IoBuffer
      * @return The read Object
@@ -1733,10 +1733,10 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * 
      * @param prefixLength the length of the prefix field (1, 2, or 4)
-     * @return <tt>true</tt> if this buffer contains a data which has a data length
+     * @return {@code true} if this buffer contains a data which has a data length
      *         as a prefix and the buffer has remaining data as enough as specified
      *         in the data length field. This method is identical with
-     *         <tt>prefixedDataAvailable( prefixLength, Integer.MAX_VALUE )</tt>.
+     *         {@code prefixedDataAvailable( prefixLength, Integer.MAX_VALUE )}.
      *         Please not that using this method can allow DoS (Denial of Service)
      *         attack in case the remote peer sends too big data length value. It is
      *         recommended to use {@link #prefixedDataAvailable(int, int)} instead.
@@ -1748,12 +1748,12 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
     /**
      * @param prefixLength  the length of the prefix field (1, 2, or 4)
      * @param maxDataLength the allowed maximum of the read data length
-     * @return <tt>true</tt> if this buffer contains a data which has a data length
+     * @return {@code true} if this buffer contains a data which has a data length
      *         as a prefix and the buffer has remaining data as enough as specified
      *         in the data length field.
      * @throws IllegalArgumentException if prefixLength is wrong
      * @throws BufferDataException      if data length is negative or greater then
-     *                                  <tt>maxDataLength</tt>
+     *                                  {@code maxDataLength}
      */
     public abstract boolean prefixedDataAvailable(int prefixLength, int maxDataLength);
 
@@ -1766,7 +1766,7 @@ public abstract class IoBuffer implements Comparable<IoBuffer> {
      * position to the current limit.
      *
      * @param b The byte we are looking for
-     * @return <tt>-1</tt> if the specified byte is not found
+     * @return {@code -1} if the specified byte is not found
      */
     public abstract int indexOf(byte b);
 
diff --git a/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferAllocator.java b/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferAllocator.java
index d7b347e23..25dcb0797 100644
--- a/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferAllocator.java
+++ b/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferAllocator.java
@@ -32,8 +32,8 @@ public interface IoBufferAllocator {
      * Returns the buffer which is capable of the specified size.
      *
      * @param capacity the capacity of the buffer
-     * @param direct <tt>true</tt> to get a direct buffer,
-     *               <tt>false</tt> to get a heap buffer.
+     * @param direct {@code true} to get a direct buffer,
+     *               {@code false} to get a heap buffer.
      * @return The allocated {@link IoBuffer}
      */
     IoBuffer allocate(int capacity, boolean direct);
@@ -42,8 +42,8 @@ public interface IoBufferAllocator {
      * Returns the NIO buffer which is capable of the specified size.
      *
      * @param capacity the capacity of the buffer
-     * @param direct <tt>true</tt> to get a direct buffer,
-     *               <tt>false</tt> to get a heap buffer.
+     * @param direct {@code true} to get a direct buffer,
+     *               {@code false} to get a heap buffer.
      * @return The allocated {@link ByteBuffer}
      */
     ByteBuffer allocateNioBuffer(int capacity, boolean direct);
diff --git a/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferHexDumper.java b/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferHexDumper.java
index 02f75c4f9..44cbd2ebd 100644
--- a/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferHexDumper.java
+++ b/mina-core/src/main/java/org/apache/mina/core/buffer/IoBufferHexDumper.java
@@ -163,13 +163,13 @@ class IoBufferHexDumper {
      *
      * @param pos  index position to begin reading
      *
-     * @param len  number of bytes to read; this can be less than the <tt>line</tt>
+     * @param len  number of bytes to read; this can be less than the {@code line}
      *             width
      *
      * @param col  number of bytes in a column
      *
-     * @param line line width in bytes which pads the output if <tt>len</tt> is less
-     *             than <tt>line</tt>
+     * @param line line width in bytes which pads the output if {@code len} is less
+     *             than {@code line}
      *
      * @return string hex dump
      */
diff --git a/mina-core/src/main/java/org/apache/mina/core/file/FileRegion.java b/mina-core/src/main/java/org/apache/mina/core/file/FileRegion.java
index a338be9dc..1c14ac782 100644
--- a/mina-core/src/main/java/org/apache/mina/core/file/FileRegion.java
+++ b/mina-core/src/main/java/org/apache/mina/core/file/FileRegion.java
@@ -29,10 +29,10 @@ import java.nio.channels.FileChannel;
 public interface FileRegion {
 
     /**
-     * The open <tt>FileChannel</tt> from which data will be read to send to
+     * The open {@code FileChannel} from which data will be read to send to
      * remote host.
      *
-     * @return  An open <tt>FileChannel</tt>.
+     * @return  An open {@code FileChannel}.
      */
     FileChannel getFileChannel();
 
@@ -71,7 +71,7 @@ public interface FileRegion {
     /**
      * Provides an absolute filename for the underlying FileChannel.
      * 
-     * @return  the absolute filename, or <tt>null</tt> if the FileRegion
+     * @return  the absolute filename, or {@code null} if the FileRegion
      *   does not know the filename
      */
     String getFilename();
diff --git a/mina-core/src/main/java/org/apache/mina/core/filterchain/DefaultIoFilterChainBuilder.java b/mina-core/src/main/java/org/apache/mina/core/filterchain/DefaultIoFilterChainBuilder.java
index 69473557c..a225179c5 100644
--- a/mina-core/src/main/java/org/apache/mina/core/filterchain/DefaultIoFilterChainBuilder.java
+++ b/mina-core/src/main/java/org/apache/mina/core/filterchain/DefaultIoFilterChainBuilder.java
@@ -190,7 +190,7 @@ public class DefaultIoFilterChainBuilder implements IoFilterChainBuilder {
      * @see IoFilterChain#contains(String)
      * 
      * @param name The Filter's name we want to check if it's in the chain
-     * @return <tt>true</tt> if the chain contains the given filter name
+     * @return {@code true} if the chain contains the given filter name
      */
     public boolean contains(String name) {
         return getEntry(name) != null;
@@ -200,7 +200,7 @@ public class DefaultIoFilterChainBuilder implements IoFilterChainBuilder {
      * @see IoFilterChain#contains(IoFilter)
      * 
      * @param filter The Filter we want to check if it's in the chain
-     * @return <tt>true</tt> if the chain contains the given filter
+     * @return {@code true} if the chain contains the given filter
      */
     public boolean contains(IoFilter filter) {
         return getEntry(filter) != null;
@@ -210,7 +210,7 @@ public class DefaultIoFilterChainBuilder implements IoFilterChainBuilder {
      * @see IoFilterChain#contains(Class)
      * 
      * @param filterType The FilterType we want to check if it's in the chain
-     * @return <tt>true</tt> if the chain contains the given filterType
+     * @return {@code true} if the chain contains the given filterType
      */
     public boolean contains(Class<? extends IoFilter> filterType) {
         return getEntry(filterType) != null;
diff --git a/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilter.java b/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilter.java
index 1ec041286..b1c794c83 100644
--- a/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilter.java
+++ b/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilter.java
@@ -99,7 +99,7 @@ public interface IoFilter {
     void destroy() throws Exception;
 
     /**
-     * Invoked before this filter is added to the specified <tt>parent</tt>.
+     * Invoked before this filter is added to the specified {@code parent}.
      * Please note that this method can be invoked more than once if
      * this filter is added to more than one parents.  This method is not
      * invoked before {@link #init()} is invoked.
@@ -113,7 +113,7 @@ public interface IoFilter {
     void onPreAdd(IoFilterChain parent, String name, NextFilter nextFilter) throws Exception;
 
     /**
-     * Invoked after this filter is added to the specified <tt>parent</tt>.
+     * Invoked after this filter is added to the specified {@code parent}.
      * Please note that this method can be invoked more than once if
      * this filter is added to more than one parents.  This method is not
      * invoked before {@link #init()} is invoked.
@@ -127,7 +127,7 @@ public interface IoFilter {
     void onPostAdd(IoFilterChain parent, String name, NextFilter nextFilter) throws Exception;
 
     /**
-     * Invoked before this filter is removed from the specified <tt>parent</tt>.
+     * Invoked before this filter is removed from the specified {@code parent}.
      * Please note that this method can be invoked more than once if
      * this filter is removed from more than one parents.
      * This method is always invoked before {@link #destroy()} is invoked.
@@ -141,7 +141,7 @@ public interface IoFilter {
     void onPreRemove(IoFilterChain parent, String name, NextFilter nextFilter) throws Exception;
 
     /**
-     * Invoked after this filter is removed from the specified <tt>parent</tt>.
+     * Invoked after this filter is removed from the specified {@code parent}.
      * Please note that this method can be invoked more than once if
      * this filter is removed from more than one parents.
      * This method is always invoked before {@link #destroy()} is invoked.
@@ -288,28 +288,28 @@ public interface IoFilter {
      */
     interface NextFilter {
         /**
-         * Forwards <tt>sessionCreated</tt> event to next filter.
+         * Forwards {@code sessionCreated} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          */
         void sessionCreated(IoSession session);
 
         /**
-         * Forwards <tt>sessionOpened</tt> event to next filter.
+         * Forwards {@code sessionOpened} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          */
         void sessionOpened(IoSession session);
 
         /**
-         * Forwards <tt>sessionClosed</tt> event to next filter.
+         * Forwards {@code sessionClosed} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          */
         void sessionClosed(IoSession session);
 
         /**
-         * Forwards <tt>sessionIdle</tt> event to next filter.
+         * Forwards {@code sessionIdle} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          * @param status The {@link IdleStatus} type
@@ -317,7 +317,7 @@ public interface IoFilter {
         void sessionIdle(IoSession session, IdleStatus status);
 
         /**
-         * Forwards <tt>exceptionCaught</tt> event to next filter.
+         * Forwards {@code exceptionCaught} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          * @param cause The exception that cause this event to be received
@@ -331,7 +331,7 @@ public interface IoFilter {
         void inputClosed(IoSession session);
 
         /**
-         * Forwards <tt>messageReceived</tt> event to next filter.
+         * Forwards {@code messageReceived} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          * @param message The received message
@@ -339,7 +339,7 @@ public interface IoFilter {
         void messageReceived(IoSession session, Object message);
 
         /**
-         * Forwards <tt>messageSent</tt> event to next filter.
+         * Forwards {@code messageSent} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          * @param writeRequest The {@link WriteRequest} to process
@@ -347,7 +347,7 @@ public interface IoFilter {
         void messageSent(IoSession session, WriteRequest writeRequest);
 
         /**
-         * Forwards <tt>filterWrite</tt> event to next filter.
+         * Forwards {@code filterWrite} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          * @param writeRequest The {@link WriteRequest} to process
@@ -355,7 +355,7 @@ public interface IoFilter {
         void filterWrite(IoSession session, WriteRequest writeRequest);
 
         /**
-         * Forwards <tt>filterClose</tt> event to next filter.
+         * Forwards {@code filterClose} event to next filter.
          * 
          * @param session The {@link IoSession} which has to process this invocation
          */
diff --git a/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChain.java b/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChain.java
index fefa995f1..250e2fb83 100644
--- a/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChain.java
+++ b/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChain.java
@@ -42,55 +42,55 @@ public interface IoFilterChain {
     IoSession getSession();
 
     /**
-     * Returns the {@link Entry} with the specified <tt>name</tt> in this chain.
+     * Returns the {@link Entry} with the specified {@code name} in this chain.
      * 
      * @param name The filter's name we are looking for
-     * @return <tt>null</tt> if there's no such name in this chain
+     * @return {@code null} if there's no such name in this chain
      */
     Entry getEntry(String name);
 
     /**
-     * Returns the {@link Entry} with the specified <tt>filter</tt> in this chain.
+     * Returns the {@link Entry} with the specified {@code filter} in this chain.
      * 
      * @param filter  The Filter we are looking for
-     * @return <tt>null</tt> if there's no such filter in this chain
+     * @return {@code null} if there's no such filter in this chain
      */
     Entry getEntry(IoFilter filter);
 
     /**
-     * Returns the {@link Entry} with the specified <tt>filterType</tt>
+     * Returns the {@link Entry} with the specified {@code filterType}
      * in this chain. If there's more than one filter with the specified
      * type, the first match will be chosen.
      * 
      * @param filterType The filter class we are looking for
-     * @return <tt>null</tt> if there's no such name in this chain
+     * @return {@code null} if there's no such name in this chain
      */
     Entry getEntry(Class<? extends IoFilter> filterType);
 
     /**
-     * Returns the {@link IoFilter} with the specified <tt>name</tt> in this chain.
+     * Returns the {@link IoFilter} with the specified {@code name} in this chain.
      * 
      * @param name the filter's name
-     * @return <tt>null</tt> if there's no such name in this chain
+     * @return {@code null} if there's no such name in this chain
      */
     IoFilter get(String name);
 
     /**
-     * Returns the {@link IoFilter} with the specified <tt>filterType</tt>
+     * Returns the {@link IoFilter} with the specified {@code filterType}
      * in this chain. If there's more than one filter with the specified
      * type, the first match will be chosen.
      * 
      * @param filterType The filter class
-     * @return <tt>null</tt> if there's no such name in this chain
+     * @return {@code null} if there's no such name in this chain
      */
     IoFilter get(Class<? extends IoFilter> filterType);
 
     /**
      * Returns the {@link NextFilter} of the {@link IoFilter} with the
-     * specified <tt>name</tt> in this chain.
+     * specified {@code name} in this chain.
      * 
      * @param name The filter's name we want the next filter
-     * @return <tt>null</tt> if there's no such name in this chain
+     * @return {@code null} if there's no such name in this chain
      */
     NextFilter getNextFilter(String name);
 
@@ -99,17 +99,17 @@ public interface IoFilterChain {
      * in this chain.
      * 
      * @param filter The filter for which we want the next filter
-     * @return <tt>null</tt> if there's no such name in this chain
+     * @return {@code null} if there's no such name in this chain
      */
     NextFilter getNextFilter(IoFilter filter);
 
     /**
-     * Returns the {@link NextFilter} of the specified <tt>filterType</tt>
+     * Returns the {@link NextFilter} of the specified {@code filterType}
      * in this chain.  If there's more than one filter with the specified
      * type, the first match will be chosen.
      * 
      * @param filterType The Filter class for which we want the next filter
-     * @return <tt>null</tt> if there's no such name in this chain
+     * @return {@code null} if there's no such name in this chain
      */
     NextFilter getNextFilter(Class<? extends IoFilter> filterType);
 
@@ -126,23 +126,23 @@ public interface IoFilterChain {
     /**
      * @param name The filter's name we are looking for
      * 
-     * @return <tt>true</tt> if this chain contains an {@link IoFilter} with the
-     * specified <tt>name</tt>.
+     * @return {@code true} if this chain contains an {@link IoFilter} with the
+     * specified {@code name}.
      */
     boolean contains(String name);
 
     /**
      * @param filter The filter we are looking for
      * 
-     * @return <tt>true</tt> if this chain contains the specified <tt>filter</tt>.
+     * @return {@code true</tt> if this chain contains the specified <tt>filter}.
      */
     boolean contains(IoFilter filter);
 
     /**
      * @param  filterType The filter's class we are looking for
      * 
-     * @return <tt>true</tt> if this chain contains an {@link IoFilter} of the
-     * specified <tt>filterType</tt>.
+     * @return {@code true} if this chain contains an {@link IoFilter} of the
+     * specified {@code filterType}.
      */
     boolean contains(Class<? extends IoFilter> filterType);
 
diff --git a/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChainBuilder.java b/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChainBuilder.java
index 50b3b2cf0..cffc2cdfa 100644
--- a/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChainBuilder.java
+++ b/mina-core/src/main/java/org/apache/mina/core/filterchain/IoFilterChainBuilder.java
@@ -58,7 +58,7 @@ public interface IoFilterChainBuilder {
     };
 
     /**
-     * Modifies the specified <tt>chain</tt>.
+     * Modifies the specified {@code chain}.
      * 
      * @param chain The chain to modify
      * @throws Exception If the chain modification failed
diff --git a/mina-core/src/main/java/org/apache/mina/core/future/CloseFuture.java b/mina-core/src/main/java/org/apache/mina/core/future/CloseFuture.java
index 7afa4bf6b..de7f71213 100644
--- a/mina-core/src/main/java/org/apache/mina/core/future/CloseFuture.java
+++ b/mina-core/src/main/java/org/apache/mina/core/future/CloseFuture.java
@@ -38,7 +38,7 @@ package org.apache.mina.core.future;
  */
 public interface CloseFuture extends IoFuture {
     /**
-     * @return <tt>true</tt> if the close request is finished and the session is closed.
+     * @return {@code true} if the close request is finished and the session is closed.
      */
     boolean isClosed();
 
diff --git a/mina-core/src/main/java/org/apache/mina/core/future/ConnectFuture.java b/mina-core/src/main/java/org/apache/mina/core/future/ConnectFuture.java
index 0376af91c..a653565a7 100644
--- a/mina-core/src/main/java/org/apache/mina/core/future/ConnectFuture.java
+++ b/mina-core/src/main/java/org/apache/mina/core/future/ConnectFuture.java
@@ -48,7 +48,7 @@ public interface ConnectFuture extends IoFuture {
     /**
      * Returns the cause of the connection failure.
      *
-     * @return <tt>null</tt> if the connect operation is not finished yet,
+     * @return {@code null} if the connect operation is not finished yet,
      *         or if the connection attempt is successful, otherwise returns
      *         the cause of the exception
      */
diff --git a/mina-core/src/main/java/org/apache/mina/core/future/DefaultIoFuture.java b/mina-core/src/main/java/org/apache/mina/core/future/DefaultIoFuture.java
index c764fbeff..96baeabdd 100644
--- a/mina-core/src/main/java/org/apache/mina/core/future/DefaultIoFuture.java
+++ b/mina-core/src/main/java/org/apache/mina/core/future/DefaultIoFuture.java
@@ -186,7 +186,7 @@ public class DefaultIoFuture implements IoFuture {
      * 
      * @param timeoutMillis The delay we will wait for the Future to be ready
      * @param interruptable Tells if the wait can be interrupted or not
-     * @return <tt>true</tt> if the Future is ready
+     * @return {@code true} if the Future is ready
      * @throws InterruptedException If the thread has been interrupted
      * when it's not allowed.
      */
diff --git a/mina-core/src/main/java/org/apache/mina/core/future/IoFuture.java b/mina-core/src/main/java/org/apache/mina/core/future/IoFuture.java
index 76e534604..42a090e9f 100644
--- a/mina-core/src/main/java/org/apache/mina/core/future/IoFuture.java
+++ b/mina-core/src/main/java/org/apache/mina/core/future/IoFuture.java
@@ -51,7 +51,7 @@ public interface IoFuture {
      *
      * @param timeout The maximum delay to wait before getting out
      * @param unit the type of unit for the delay (seconds, minutes...)
-     * @return <tt>true</tt> if the operation is completed. 
+     * @return {@code true} if the operation is completed. 
      * @exception InterruptedException If the thread is interrupted while waiting
      */
     boolean await(long timeout, TimeUnit unit) throws InterruptedException;
@@ -60,7 +60,7 @@ public interface IoFuture {
      * Wait for the asynchronous operation to complete with the specified timeout.
      *
      * @param timeoutMillis The maximum milliseconds to wait before getting out
-     * @return <tt>true</tt> if the operation is completed.
+     * @return {@code true} if the operation is completed.
      * @exception InterruptedException If the thread is interrupted while waiting
      */
     boolean await(long timeoutMillis) throws InterruptedException;
@@ -80,7 +80,7 @@ public interface IoFuture {
      *
      * @param timeout The maximum delay to wait before getting out
      * @param unit the type of unit for the delay (seconds, minutes...)
-     * @return <tt>true</tt> if the operation is completed.
+     * @return {@code true} if the operation is completed.
      */
     boolean awaitUninterruptibly(long timeout, TimeUnit unit);
 
@@ -89,7 +89,7 @@ public interface IoFuture {
      * uninterruptibly.
      *
      * @param timeoutMillis The maximum milliseconds to wait before getting out
-     * @return <tt>true</tt> if the operation is finished.
+     * @return {@code true} if the operation is finished.
      */
     boolean awaitUninterruptibly(long timeoutMillis);
 
@@ -103,18 +103,18 @@ public interface IoFuture {
      * @deprecated Replaced with {@link #awaitUninterruptibly(long)}.
      * 
      * @param timeoutMillis The time to wait for the join before bailing out
-     * @return <tt>true</tt> if the join was successful
+     * @return {@code true} if the join was successful
      */
     @Deprecated
     boolean join(long timeoutMillis);
 
     /**
-     * @return <tt>true</tt> if the operation is completed.
+     * @return {@code true} if the operation is completed.
      */
     boolean isDone();
 
     /**
-     * Adds an event <tt>listener</tt> which is notified when
+     * Adds an event {@code listener} which is notified when
      * this future is completed. If the listener is added
      * after the completion, the listener is directly notified.
      * 
@@ -124,7 +124,7 @@ public interface IoFuture {
     IoFuture addListener(IoFutureListener<?> listener);
 
     /**
-     * Removes an existing event <tt>listener</tt> so it won't be notified when
+     * Removes an existing event {@code listener} so it won't be notified when
      * the future is completed.
      * 
      * @param listener The listener to remove
diff --git a/mina-core/src/main/java/org/apache/mina/core/future/ReadFuture.java b/mina-core/src/main/java/org/apache/mina/core/future/ReadFuture.java
index 62221a047..0129bd704 100644
--- a/mina-core/src/main/java/org/apache/mina/core/future/ReadFuture.java
+++ b/mina-core/src/main/java/org/apache/mina/core/future/ReadFuture.java
@@ -50,18 +50,18 @@ public interface ReadFuture extends IoFuture {
     /**
      * Get the read message.
      * 
-     * @return the received message.  It returns <tt>null</tt> if this
+     * @return the received message.  It returns {@code null} if this
      * future is not ready or the associated {@link IoSession} has been closed. 
      */
     Object getMessage();
 
     /**
-     * @return <tt>true</tt> if a message was received successfully.
+     * @return {@code true} if a message was received successfully.
      */
     boolean isRead();
 
     /**
-     * @return <tt>true</tt> if the {@link IoSession} associated with this
+     * @return {@code true} if the {@link IoSession} associated with this
      * future has been closed.
      */
     boolean isClosed();
@@ -69,7 +69,7 @@ public interface ReadFuture extends IoFuture {
     /**
      * @return the cause of the read failure if and only if the read
      * operation has failed due to an {@link Exception}.  Otherwise,
-     * <tt>null</tt> is returned.
+     * {@code null} is returned.
      */
     Throwable getException();
 
diff --git a/mina-core/src/main/java/org/apache/mina/core/future/WriteFuture.java b/mina-core/src/main/java/org/apache/mina/core/future/WriteFuture.java
index 2b653929a..d8c638a27 100644
--- a/mina-core/src/main/java/org/apache/mina/core/future/WriteFuture.java
+++ b/mina-core/src/main/java/org/apache/mina/core/future/WriteFuture.java
@@ -45,14 +45,14 @@ package org.apache.mina.core.future;
  */
 public interface WriteFuture extends IoFuture {
     /**
-     * @return <tt>true</tt> if the write operation is finished successfully.
+     * @return {@code true} if the write operation is finished successfully.
      */
     boolean isWritten();
 
     /**
      * @return the cause of the write failure if and only if the write
      * operation has failed due to an {@link Exception}.  Otherwise,
-     * <tt>null</tt> is returned.
+     * {@code null} is returned.
      */
     Throwable getException();
 
diff --git a/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoConnector.java b/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoConnector.java
index 32a395631..c19c5dd76 100644
--- a/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoConnector.java
+++ b/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoConnector.java
@@ -248,7 +248,7 @@ public abstract class AbstractPollingIoConnector<S extends AbstractIoSession, H>
      * 
      * @param handle the client socket handle
      * @param remoteAddress the remote address where to connect
-     * @return <tt>true</tt> if a connection was established, <tt>false</tt> if
+     * @return {@code true</tt> if a connection was established, <tt>false} if
      *         this client socket is in non-blocking mode and the connection
      *         operation is in progress
      * @throws Exception If the connect failed
diff --git a/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoProcessor.java b/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoProcessor.java
index 105013e9b..aeeb99ac1 100644
--- a/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoProcessor.java
+++ b/mina-core/src/main/java/org/apache/mina/core/polling/AbstractPollingIoProcessor.java
@@ -223,7 +223,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * Say if the list of {@link IoSession} polled by this {@link IoProcessor}
      * is empty
      * 
-     * @return <tt>true</tt> if at least a session is managed by this
+     * @return {@code true} if at least a session is managed by this
      *         {@link IoProcessor}
      */
     protected abstract boolean isSelectorEmpty();
@@ -270,7 +270,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * 
      * @param session
      *            the queried session
-     * @return <tt>true</tt> is ready, <tt>false</tt> if not ready
+     * @return {@code true</tt> is ready, <tt>false} if not ready
      */
     protected abstract boolean isWritable(S session);
 
@@ -279,7 +279,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * 
      * @param session
      *            the queried session
-     * @return <tt>true</tt> is ready, <tt>false</tt> if not ready
+     * @return {@code true</tt> is ready, <tt>false} if not ready
      */
     protected abstract boolean isReadable(S session);
 
@@ -289,7 +289,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * @param session
      *            the session for which we want to be interested in write events
      * @param isInterested
-     *            <tt>true</tt> for registering, <tt>false</tt> for removing
+     *            {@code true</tt> for registering, <tt>false} for removing
      * @throws Exception
      *             If there was a problem while registering the session
      */
@@ -301,7 +301,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * @param session
      *            the session for which we want to be interested in read events
      * @param isInterested
-     *            <tt>true</tt> for registering, <tt>false</tt> for removing
+     *            {@code true</tt> for registering, <tt>false} for removing
      * @throws Exception
      *             If there was a problem while registering the session
      */
@@ -312,7 +312,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * 
      * @param session
      *            the queried session
-     * @return <tt>true</tt> is registered for reading
+     * @return {@code true} is registered for reading
      */
     protected abstract boolean isInterestedInRead(S session);
 
@@ -321,7 +321,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * 
      * @param session
      *            the queried session
-     * @return <tt>true</tt> is registered for writing
+     * @return {@code true} is registered for writing
      */
     protected abstract boolean isInterestedInWrite(S session);
 
@@ -496,7 +496,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
      * broken connection. In this case, this is a standard case, and we just
      * have to loop.
      * 
-     * @return <tt>true</tt> if a connection has been brutally closed.
+     * @return {@code true} if a connection has been brutally closed.
      * @throws IOException
      *             If we got an exception
      */
@@ -818,7 +818,7 @@ public abstract class AbstractPollingIoProcessor<S extends AbstractIoSession> im
          * 
          * @param session
          *            The session to create
-         * @return <tt>true</tt> if the session has been registered
+         * @return {@code true} if the session has been registered
          */
         private boolean addNow(S session) {
             boolean registered = false;
diff --git a/mina-core/src/main/java/org/apache/mina/core/service/AbstractIoConnector.java b/mina-core/src/main/java/org/apache/mina/core/service/AbstractIoConnector.java
index dde38134c..cb78e5b53 100644
--- a/mina-core/src/main/java/org/apache/mina/core/service/AbstractIoConnector.java
+++ b/mina-core/src/main/java/org/apache/mina/core/service/AbstractIoConnector.java
@@ -92,7 +92,7 @@ public abstract class AbstractIoConnector extends AbstractIoService implements I
     }
 
     /**
-     * @deprecated Take a look at <tt>getConnectTimeoutMillis()</tt>
+     * @deprecated Take a look at {@code getConnectTimeoutMillis()}
      */
     @Deprecated
     @Override
@@ -110,7 +110,7 @@ public abstract class AbstractIoConnector extends AbstractIoService implements I
 
     /**
      * @deprecated
-     *  Take a look at <tt>setConnectTimeoutMillis(long)</tt>
+     *  Take a look at {@code setConnectTimeoutMillis(long)}
      */
     @Deprecated
     @Override
@@ -335,7 +335,7 @@ public abstract class AbstractIoConnector extends AbstractIoService implements I
      * Implement this method to perform the actual connect operation.
      *
      * @param remoteAddress The remote address to connect from
-     * @param localAddress <tt>null</tt> if no local address is specified
+     * @param localAddress {@code null} if no local address is specified
      * @param sessionInitializer The IoSessionInitializer to use when the connection s successful
      * @return The ConnectFuture associated with this asynchronous operation
      * 
diff --git a/mina-core/src/main/java/org/apache/mina/core/service/IoAcceptor.java b/mina-core/src/main/java/org/apache/mina/core/service/IoAcceptor.java
index b40a5e747..9ce62102c 100644
--- a/mina-core/src/main/java/org/apache/mina/core/service/IoAcceptor.java
+++ b/mina-core/src/main/java/org/apache/mina/core/service/IoAcceptor.java
@@ -117,20 +117,20 @@ public interface IoAcceptor extends IoService {
     void setDefaultLocalAddresses(List<? extends SocketAddress> localAddresses);
 
     /**
-     * Returns <tt>true</tt> if and only if all clients are closed when this
+     * Returns {@code true} if and only if all clients are closed when this
      * acceptor unbinds from all the related local address (i.e. when the
      * service is deactivated).
      * 
-     * @return <tt>true</tt> if the service sets the closeOnDeactivation flag
+     * @return {@code true} if the service sets the closeOnDeactivation flag
      */
     boolean isCloseOnDeactivation();
 
     /**
      * Sets whether all client sessions are closed when this acceptor unbinds
      * from all the related local addresses (i.e. when the service is
-     * deactivated).  The default value is <tt>true</tt>.
+     * deactivated).  The default value is {@code true}.
      * 
-     * @param closeOnDeactivation <tt>true</tt> if we should close on deactivation
+     * @param closeOnDeactivation {@code true} if we should close on deactivation
      */
     void setCloseOnDeactivation(boolean closeOnDeactivation);
 
@@ -186,7 +186,7 @@ public interface IoAcceptor extends IoService {
      * Unbinds from all local addresses that this service is bound to and stops
      * to accept incoming connections.  All managed connections will be closed
      * if {@link #setCloseOnDeactivation(boolean) disconnectOnUnbind} property
-     * is <tt>true</tt>.  This method returns silently if no local address is
+     * is {@code true}.  This method returns silently if no local address is
      * bound yet.
      */
     void unbind();
@@ -195,7 +195,7 @@ public interface IoAcceptor extends IoService {
      * Unbinds from the specified local address and stop to accept incoming
      * connections.  All managed connections will be closed if
      * {@link #setCloseOnDeactivation(boolean) disconnectOnUnbind} property is
-     * <tt>true</tt>.  This method returns silently if the default local
+     * {@code true}.  This method returns silently if the default local
      * address is not bound yet.
      * 
      * @param localAddress The local address we will be unbound from
@@ -206,7 +206,7 @@ public interface IoAcceptor extends IoService {
      * Unbinds from the specified local addresses and stop to accept incoming
      * connections.  All managed connections will be closed if
      * {@link #setCloseOnDeactivation(boolean) disconnectOnUnbind} property is
-     * <tt>true</tt>.  This method returns silently if the default local
+     * {@code true}.  This method returns silently if the default local
      * addresses are not bound yet.
      * 
      * @param firstLocalAddress The first local address to be unbound from
@@ -218,7 +218,7 @@ public interface IoAcceptor extends IoService {
      * Unbinds from the specified local addresses and stop to accept incoming
      * connections.  All managed connections will be closed if
      * {@link #setCloseOnDeactivation(boolean) disconnectOnUnbind} property is
-     * <tt>true</tt>.  This method returns silently if the default local
+     * {@code true}.  This method returns silently if the default local
      * addresses are not bound yet.
      * 
      * @param localAddresses The local address we will be unbound from
@@ -227,7 +227,7 @@ public interface IoAcceptor extends IoService {
 
     /**
      * (Optional) Returns an {@link IoSession} that is bound to the specified
-     * <tt>localAddress</tt> and the specified <tt>remoteAddress</tt> which
+     * {@code localAddress</tt> and the specified <tt>remoteAddress} which
      * reuses the local address that is already bound by this service.
      * <p>
      * This operation is optional.  Please throw {@link UnsupportedOperationException}
@@ -239,7 +239,7 @@ public interface IoAcceptor extends IoService {
      * @throws UnsupportedOperationException if this operation is not supported
      * @throws IllegalStateException if this service is not running.
      * @throws IllegalArgumentException if this service is not bound to the
-     *                                  specified <tt>localAddress</tt>.
+     *                                  specified {@code localAddress}.
      * @return The session bound to the the given localAddress and remote address
      */
     IoSession newSession(SocketAddress remoteAddress, SocketAddress localAddress);
diff --git a/mina-core/src/main/java/org/apache/mina/core/service/IoProcessor.java b/mina-core/src/main/java/org/apache/mina/core/service/IoProcessor.java
index fd63a675e..41ac04c3e 100644
--- a/mina-core/src/main/java/org/apache/mina/core/service/IoProcessor.java
+++ b/mina-core/src/main/java/org/apache/mina/core/service/IoProcessor.java
@@ -35,14 +35,14 @@ import org.apache.mina.core.write.WriteRequest;
 public interface IoProcessor<S extends IoSession> {
 
     /**
-     * @return <tt>true</tt> if and if only {@link #dispose()} method has
-     * been called.  Please note that this method will return <tt>true</tt>
+     * @return {@code true} if and if only {@link #dispose()} method has
+     * been called.  Please note that this method will return {@code true}
      * even after all the related resources are released.
      */
     boolean isDisposing();
 
     /**
-     * @return <tt>true</tt> if and if only all resources of this processor
+     * @return {@code true} if and if only all resources of this processor
      * have been disposed.
      */
     boolean isDisposed();
diff --git a/mina-core/src/main/java/org/apache/mina/core/service/IoService.java b/mina-core/src/main/java/org/apache/mina/core/service/IoService.java
index 31be6f70d..4c2f39bf2 100644
--- a/mina-core/src/main/java/org/apache/mina/core/service/IoService.java
+++ b/mina-core/src/main/java/org/apache/mina/core/service/IoService.java
@@ -60,14 +60,14 @@ public interface IoService {
     void removeListener(IoServiceListener listener);
 
     /**
-     * @return <tt>true</tt> if and if only {@link #dispose()} method has
-     * been called.  Please note that this method will return <tt>true</tt>
+     * @return {@code true} if and if only {@link #dispose()} method has
+     * been called.  Please note that this method will return {@code true}
      * even after all the related resources are released.
      */
     boolean isDisposing();
 
     /**
-     * @return <tt>true</tt> if and if only all resources of this processor
+     * @return {@code true} if and if only all resources of this processor
      * have been disposed.
      */
     boolean isDisposed();
@@ -133,7 +133,7 @@ public interface IoService {
      * Sets the {@link IoFilterChainBuilder} which will build the
      * {@link IoFilterChain} of all {@link IoSession}s which is created
      * by this service.
-     * If you specify <tt>null</tt> this property will be set to
+     * If you specify {@code null} this property will be set to
      * an empty {@link DefaultIoFilterChainBuilder}.
      * 
      * @param builder The filter chain builder to use
@@ -141,7 +141,7 @@ public interface IoService {
     void setFilterChainBuilder(IoFilterChainBuilder builder);
 
     /**
-     * A shortcut for <tt>( ( DefaultIoFilterChainBuilder ) </tt>{@link #getFilterChainBuilder()}<tt> )</tt>.
+     * A shortcut for {@code ( ( DefaultIoFilterChainBuilder ) </tt>{@link #getFilterChainBuilder()}<tt> )}.
      * Please note that the returned object is not a <b>real</b> {@link IoFilterChain}
      * but a {@link DefaultIoFilterChainBuilder}.  Modifying the returned builder
      * won't affect the existing {@link IoSession}s at all, because
diff --git a/mina-core/src/main/java/org/apache/mina/core/service/IoServiceStatistics.java b/mina-core/src/main/java/org/apache/mina/core/service/IoServiceStatistics.java
index 0971612f0..f6d69c08a 100644
--- a/mina-core/src/main/java/org/apache/mina/core/service/IoServiceStatistics.java
+++ b/mina-core/src/main/java/org/apache/mina/core/service/IoServiceStatistics.java
@@ -389,7 +389,7 @@ public class IoServiceStatistics {
 
     /**
      * @return the interval (seconds) between each throughput calculation. The
-     *         default value is <tt>3</tt> seconds.
+     *         default value is {@code 3} seconds.
      */
     public final int getThroughputCalculationInterval() {
         return config.getThroughputCalculationInterval();
@@ -397,7 +397,7 @@ public class IoServiceStatistics {
 
     /**
      * @return the interval (milliseconds) between each throughput calculation.
-     * The default value is <tt>3</tt> seconds.
+     * The default value is {@code 3} seconds.
      */
     public final long getThroughputCalculationIntervalInMillis() {
         return config.getThroughputCalculationIntervalInMillis();
@@ -405,7 +405,7 @@ public class IoServiceStatistics {
 
     /**
      * Sets the interval (seconds) between each throughput calculation.  The
-     * default value is <tt>3</tt> seconds.
+     * default value is {@code 3} seconds.
      * 
      * @param throughputCalculationInterval The interval between two calculation
      */
@@ -914,7 +914,7 @@ public class IoServiceStatistics {
 
         /**
          * @return the interval (seconds) between each throughput calculation. The
-         *         default value is <tt>3</tt> seconds.
+         *         default value is {@code 3} seconds.
          */
         public int getThroughputCalculationInterval() {
             return throughputCalculationInterval.get();
@@ -922,7 +922,7 @@ public class IoServiceStatistics {
 
         /**
          * @return the interval (milliseconds) between each throughput calculation.
-         * The default value is <tt>3</tt> seconds.
+         * The default value is {@code 3} seconds.
          */
         public long getThroughputCalculationIntervalInMillis() {
             return throughputCalculationInterval.get() * 1000L;
@@ -930,7 +930,7 @@ public class IoServiceStatistics {
 
         /**
          * Sets the interval (seconds) between each throughput calculation.  The
-         * default value is <tt>3</tt> seconds.
+         * default value is {@code 3} seconds.
          *
          * @param throughputCalculationInterval The interval between two calculation
          */
diff --git a/mina-core/src/main/java/org/apache/mina/core/service/TransportMetadata.java b/mina-core/src/main/java/org/apache/mina/core/service/TransportMetadata.java
index 58e958ca3..f4692d28a 100644
--- a/mina-core/src/main/java/org/apache/mina/core/service/TransportMetadata.java
+++ b/mina-core/src/main/java/org/apache/mina/core/service/TransportMetadata.java
@@ -43,7 +43,7 @@ public interface TransportMetadata {
     String getName();
 
     /**
-     * @return <tt>true</tt> if the session of this transport type is
+     * @return {@code true} if the session of this transport type is
      * <a href="http://en.wikipedia.org/wiki/Connectionless">connectionless</a>.
      */
     boolean isConnectionless();
diff --git a/mina-core/src/main/java/org/apache/mina/core/session/DummySession.java b/mina-core/src/main/java/org/apache/mina/core/session/DummySession.java
index c28e18772..e5bb3da33 100644
--- a/mina-core/src/main/java/org/apache/mina/core/session/DummySession.java
+++ b/mina-core/src/main/java/org/apache/mina/core/session/DummySession.java
@@ -412,10 +412,10 @@ public class DummySession extends AbstractIoSession {
      * this method returns silently without updating the throughput properties
      * if they were calculated already within last
      * {@link IoSessionConfig#getThroughputCalculationInterval() calculation interval}.
-     * If, however, <tt>force</tt> is specified as <tt>true</tt>, this method
+     * If, however, {@code force</tt> is specified as <tt>true}, this method
      * updates the throughput properties immediately.
      * 
-     * @param force the flag that forces the update of properties immediately if <tt>true</tt>
+     * @param force the flag that forces the update of properties immediately if {@code true}
      */
     public void updateThroughput(boolean force) {
         super.updateThroughput(System.currentTimeMillis(), force);
diff --git a/mina-core/src/main/java/org/apache/mina/core/session/IdleStatus.java b/mina-core/src/main/java/org/apache/mina/core/session/IdleStatus.java
index cba39d633..adbeb8f44 100644
--- a/mina-core/src/main/java/org/apache/mina/core/session/IdleStatus.java
+++ b/mina-core/src/main/java/org/apache/mina/core/session/IdleStatus.java
@@ -62,9 +62,9 @@ public class IdleStatus {
     /**
      * @return the string representation of this status.
      * <ul>
-     *   <li>{@link #READER_IDLE} - <tt>"reader idle"</tt></li>
-     *   <li>{@link #WRITER_IDLE} - <tt>"writer idle"</tt></li>
-     *   <li>{@link #BOTH_IDLE} - <tt>"both idle"</tt></li>
+     *   <li>{@link #READER_IDLE} - {@code "reader idle"}</li>
+     *   <li>{@link #WRITER_IDLE} - {@code "writer idle"}</li>
+     *   <li>{@link #BOTH_IDLE} - {@code "both idle"}</li>
      * </ul>
      */
     @Override
diff --git a/mina-core/src/main/java/org/apache/mina/core/session/IdleStatusChecker.java b/mina-core/src/main/java/org/apache/mina/core/session/IdleStatusChecker.java
index b9215309b..1f57fa494 100644
--- a/mina-core/src/main/java/org/apache/mina/core/session/IdleStatusChecker.java
+++ b/mina-core/src/main/java/org/apache/mina/core/session/IdleStatusChecker.java
@@ -29,7 +29,7 @@ import org.apache.mina.core.service.IoService;
 import org.apache.mina.util.ConcurrentHashSet;
 
 /**
- * Detects idle sessions and fires <tt>sessionIdle</tt> events to them.
+ * Detects idle sessions and fires {@code sessionIdle} events to them.
  * To be used for service unable to trigger idle events alone, like VmPipe
  * or SerialTransport. Polling base transport are advised to trigger idle 
  * events alone, using the poll/select timeout. 
diff --git a/mina-core/src/main/java/org/apache/mina/core/session/IoSession.java b/mina-core/src/main/java/org/apache/mina/core/session/IoSession.java
index 9abdf01a9..4477eaf1a 100644
--- a/mina-core/src/main/java/org/apache/mina/core/session/IoSession.java
+++ b/mina-core/src/main/java/org/apache/mina/core/session/IoSession.java
@@ -125,7 +125,7 @@ public interface IoSession {
      * queued somewhere to support this operation, possibly leading to memory
      * leak.  This means you have to keep calling {@link #read()} once you
      * enabled this operation.  To enable this operation, please call
-     * {@link IoSessionConfig#setUseReadOperation(boolean)} with <tt>true</tt>.
+     * {@link IoSessionConfig#setUseReadOperation(boolean)} with {@code true}.
      *
      * @throws IllegalStateException if
      * {@link IoSessionConfig#setUseReadOperation(boolean) useReadOperation}
@@ -146,7 +146,7 @@ public interface IoSession {
     WriteFuture write(Object message);
 
     /**
-     * (Optional) Writes the specified <tt>message</tt> to the specified <tt>destination</tt>.
+     * (Optional) Writes the specified {@code message</tt> to the specified <tt>destination}.
      * This operation is asynchronous; {@link IoHandler#messageSent(IoSession, Object)}
      * will be invoked when the message is actually sent to remote peer. You can
      * also wait for the returned {@link WriteFuture} if you want to wait for
@@ -161,7 +161,7 @@ public interface IoSession {
      * can specify the destination.
      * 
      * @param message The message to write
-     * @param destination <tt>null</tt> if you want the message sent to the
+     * @param destination {@code null} if you want the message sent to the
      *                    default remote address
      * @return The associated WriteFuture
      */
@@ -213,7 +213,7 @@ public interface IoSession {
 
     /**
      * Returns an attachment of this session.
-     * This method is identical with <tt>getAttribute( "" )</tt>.
+     * This method is identical with {@code getAttribute( "" )}.
      *
      * @return The attachment
      * @deprecated Use {@link #getAttribute(Object)} instead.
@@ -223,10 +223,10 @@ public interface IoSession {
 
     /**
      * Sets an attachment of this session.
-     * This method is identical with <tt>setAttribute( "", attachment )</tt>.
+     * This method is identical with {@code setAttribute( "", attachment )}.
      *
      * @param attachment The attachment
-     * @return Old attachment. <tt>null</tt> if it is new.
+     * @return Old attachment. {@code null} if it is new.
      * @deprecated Use {@link #setAttribute(Object, Object)} instead.
      */
     @Deprecated
@@ -236,7 +236,7 @@ public interface IoSession {
      * Returns the value of the user-defined attribute of this session.
      *
      * @param key the key of the attribute
-     * @return <tt>null</tt> if there is no attribute with the specified key
+     * @return {@code null} if there is no attribute with the specified key
      */
     Object getAttribute(Object key);
 
@@ -257,7 +257,7 @@ public interface IoSession {
      * 
      * @param key the key of the attribute we want to retreive
      * @param defaultValue the default value of the attribute
-     * @return The retrieved attribute or <tt>null</tt> if not found
+     * @return The retrieved attribute or {@code null} if not found
      */
     Object getAttribute(Object key, Object defaultValue);
 
@@ -266,7 +266,7 @@ public interface IoSession {
      *
      * @param key the key of the attribute
      * @param value the value of the attribute
-     * @return The old value of the attribute.  <tt>null</tt> if it is new.
+     * @return The old value of the attribute.  {@code null} if it is new.
      */
     Object setAttribute(Object key, Object value);
 
@@ -276,7 +276,7 @@ public interface IoSession {
      * {@link Boolean#TRUE}.
      *
      * @param key the key of the attribute
-     * @return The old value of the attribute.  <tt>null</tt> if it is new.
+     * @return The old value of the attribute.  {@code null} if it is new.
      */
     Object setAttribute(Object key);
 
@@ -294,7 +294,7 @@ public interface IoSession {
      * 
      * @param key The key of the attribute we want to set
      * @param value The value we want to set
-     * @return The old value of the attribute.  <tt>null</tt> if not found.
+     * @return The old value of the attribute.  {@code null} if not found.
      */
     Object setAttributeIfAbsent(Object key, Object value);
 
@@ -313,7 +313,7 @@ public interface IoSession {
      * </pre>
      * 
      * @param key The key of the attribute we want to set
-     * @return The old value of the attribute.  <tt>null</tt> if not found.
+     * @return The old value of the attribute.  {@code null} if not found.
      */
     Object setAttributeIfAbsent(Object key);
 
@@ -321,7 +321,7 @@ public interface IoSession {
      * Removes a user-defined attribute with the specified key.
      *
      * @param key The key of the attribute we want to remove
-     * @return The old value of the attribute.  <tt>null</tt> if not found.
+     * @return The old value of the attribute.  {@code null} if not found.
      */
     Object removeAttribute(Object key);
 
@@ -341,7 +341,7 @@ public interface IoSession {
      * 
      * @param key The key we want to remove
      * @param value The value we want to remove
-     * @return <tt>true</tt> if the removal was successful
+     * @return {@code true} if the removal was successful
      */
     boolean removeAttribute(Object key, Object value);
 
@@ -362,14 +362,14 @@ public interface IoSession {
      * @param key The key we want to replace
      * @param oldValue The previous value
      * @param newValue The new value
-     * @return <tt>true</tt> if the replacement was successful
+     * @return {@code true} if the replacement was successful
      */
     boolean replaceAttribute(Object key, Object oldValue, Object newValue);
 
     /**
      * @param key The key of the attribute we are looking for in the session 
-     * @return <tt>true</tt> if this session contains the attribute with
-     * the specified <tt>key</tt>.
+     * @return {@code true} if this session contains the attribute with
+     * the specified {@code key}.
      */
     boolean containsAttribute(Object key);
 
@@ -379,24 +379,24 @@ public interface IoSession {
     Set<Object> getAttributeKeys();
 
     /**
-     * @return <tt>true</tt> if this session is connected with remote peer.
+     * @return {@code true} if this session is connected with remote peer.
      */
     boolean isConnected();
     
     /**
-     * @return <tt>true</tt> if this session is active.
+     * @return {@code true} if this session is active.
      */
     boolean isActive();
 
     /**
-     * @return <tt>true</tt> if and only if this session is being closed
+     * @return {@code true} if and only if this session is being closed
      * (but not disconnected yet) or is closed.
      */
     boolean isClosing();
     
     /**
-     * @return <tt>true</tt> if the session has started and initialized a SslEngine,
-     * <tt>false</tt> if the session is not yet secured (the handshake is not completed)
+     * @return {@code true} if the session has started and initialized a SslEngine,
+     * {@code false} if the session is not yet secured (the handshake is not completed)
      * or if SSL is not set for this session, or if SSL is not even an option.
      */
     boolean isSecured();
@@ -459,14 +459,14 @@ public interface IoSession {
     /**
      * Is read operation is suspended for this session. 
      * 
-     * @return <tt>true</tt> if suspended
+     * @return {@code true} if suspended
      */
     boolean isReadSuspended();
 
     /**
      * Is write operation is suspended for this session.
      * 
-     * @return <tt>true</tt> if suspended
+     * @return {@code true} if suspended
      */
     boolean isWriteSuspended();
 
@@ -476,11 +476,11 @@ public interface IoSession {
      * silently without updating the throughput properties if they were
      * calculated already within last
      * {@link IoSessionConfig#getThroughputCalculationInterval() calculation interval}.
-     * If, however, <tt>force</tt> is specified as <tt>true</tt>, this method
+     * If, however, {@code force</tt> is specified as <tt>true}, this method
      * updates the throughput properties immediately.
 
      * @param currentTime the current time in milliseconds
-     * @param force Force the update if <tt>true</tt>
+     * @param force Force the update if {@code true}
      */
     void updateThroughput(long currentTime, boolean force);
 
@@ -537,7 +537,7 @@ public interface IoSession {
 
     /**
      * Returns the message which is being written by {@link IoService}.
-     * @return <tt>null</tt> if and if only no message is being written
+     * @return {@code null} if and if only no message is being written
      */
     Object getCurrentWriteMessage();
 
@@ -545,7 +545,7 @@ public interface IoSession {
      * Returns the {@link WriteRequest} which is being processed by
      * {@link IoService}.
      *
-     * @return <tt>null</tt> if and if only no message is being written
+     * @return {@code null} if and if only no message is being written
      */
     WriteRequest getCurrentWriteRequest();
 
@@ -571,58 +571,58 @@ public interface IoSession {
 
     /**
      * @param status The researched idle status
-     * @return <tt>true</tt> if this session is idle for the specified
+     * @return {@code true} if this session is idle for the specified
      * {@link IdleStatus}.
      */
     boolean isIdle(IdleStatus status);
 
     /**
-     * @return <tt>true</tt> if this session is {@link IdleStatus#READER_IDLE}.
+     * @return {@code true} if this session is {@link IdleStatus#READER_IDLE}.
      * @see #isIdle(IdleStatus)
      */
     boolean isReaderIdle();
 
     /**
-     * @return <tt>true</tt> if this session is {@link IdleStatus#WRITER_IDLE}.
+     * @return {@code true} if this session is {@link IdleStatus#WRITER_IDLE}.
      * @see #isIdle(IdleStatus)
      */
     boolean isWriterIdle();
 
     /**
-     * @return <tt>true</tt> if this session is {@link IdleStatus#BOTH_IDLE}.
+     * @return {@code true} if this session is {@link IdleStatus#BOTH_IDLE}.
      * @see #isIdle(IdleStatus)
      */
     boolean isBothIdle();
 
     /**
      * @param status The researched idle status
-     * @return the number of the fired continuous <tt>sessionIdle</tt> events
+     * @return the number of the fired continuous {@code sessionIdle} events
      * for the specified {@link IdleStatus}.
      * <p>
-     * If <tt>sessionIdle</tt> event is fired first after some time after I/O,
-     * <tt>idleCount</tt> becomes <tt>1</tt>.  <tt>idleCount</tt> resets to
-     * <tt>0</tt> if any I/O occurs again, otherwise it increases to
-     * <tt>2</tt> and so on if <tt>sessionIdle</tt> event is fired again without
-     * any I/O between two (or more) <tt>sessionIdle</tt> events.
+     * If {@code sessionIdle} event is fired first after some time after I/O,
+     * {@code idleCount</tt> becomes <tt>1</tt>.  <tt>idleCount} resets to
+     * {@code 0} if any I/O occurs again, otherwise it increases to
+     * {@code 2</tt> and so on if <tt>sessionIdle} event is fired again without
+     * any I/O between two (or more) {@code sessionIdle} events.
      */
     int getIdleCount(IdleStatus status);
 
     /**
-     * @return the number of the fired continuous <tt>sessionIdle</tt> events
+     * @return the number of the fired continuous {@code sessionIdle} events
      * for {@link IdleStatus#READER_IDLE}.
      * @see #getIdleCount(IdleStatus)
      */
     int getReaderIdleCount();
 
     /**
-     * @return the number of the fired continuous <tt>sessionIdle</tt> events
+     * @return the number of the fired continuous {@code sessionIdle} events
      * for {@link IdleStatus#WRITER_IDLE}.
      * @see #getIdleCount(IdleStatus)
      */
     int getWriterIdleCount();
 
     /**
-     * @return the number of the fired continuous <tt>sessionIdle</tt> events
+     * @return the number of the fired continuous {@code sessionIdle} events
      * for {@link IdleStatus#BOTH_IDLE}.
      * @see #getIdleCount(IdleStatus)
      */
@@ -630,27 +630,27 @@ public interface IoSession {
 
     /**
      * @param status The researched idle status
-     * @return the time in milliseconds when the last <tt>sessionIdle</tt> event
+     * @return the time in milliseconds when the last {@code sessionIdle} event
      * is fired for the specified {@link IdleStatus}.
      */
     long getLastIdleTime(IdleStatus status);
 
     /**
-     * @return the time in milliseconds when the last <tt>sessionIdle</tt> event
+     * @return the time in milliseconds when the last {@code sessionIdle} event
      * is fired for {@link IdleStatus#READER_IDLE}.
      * @see #getLastIdleTime(IdleStatus)
      */
     long getLastReaderIdleTime();
 
     /**
-     * @return the time in milliseconds when the last <tt>sessionIdle</tt> event
+     * @return the time in milliseconds when the last {@code sessionIdle} event
      * is fired for {@link IdleStatus#WRITER_IDLE}.
      * @see #getLastIdleTime(IdleStatus)
      */
     long getLastWriterIdleTime();
 
     /**
-     * @return the time in milliseconds when the last <tt>sessionIdle</tt> event
+     * @return the time in milliseconds when the last {@code sessionIdle} event
      * is fired for {@link IdleStatus#BOTH_IDLE}.
      * @see #getLastIdleTime(IdleStatus)
      */
diff --git a/mina-core/src/main/java/org/apache/mina/core/session/IoSessionAttributeMap.java b/mina-core/src/main/java/org/apache/mina/core/session/IoSessionAttributeMap.java
index 0892a316b..af3e9a6b8 100644
--- a/mina-core/src/main/java/org/apache/mina/core/session/IoSessionAttributeMap.java
+++ b/mina-core/src/main/java/org/apache/mina/core/session/IoSessionAttributeMap.java
@@ -56,7 +56,7 @@ public interface IoSessionAttributeMap {
      * @param session the session for which we want to set an attribute
      * @param key the key of the attribute
      * @param value the value of the attribute
-     * @return The old value of the attribute.  <tt>null</tt> if it is new.
+     * @return The old value of the attribute.  {@code null} if it is new.
      */
     Object setAttribute(IoSession session, Object key, Object value);
 
@@ -82,7 +82,7 @@ public interface IoSessionAttributeMap {
     /**
      * Removes a user-defined attribute with the specified key.
      *
-     * @return The old value of the attribute.  <tt>null</tt> if not found.
+     * @return The old value of the attribute.  {@code null} if not found.
      * @param session the session for which we want to remove an attribute
      * @param key The key we are looking for
      */
@@ -105,7 +105,7 @@ public interface IoSessionAttributeMap {
      * @param session the session for which we want to remove a value
      * @param key The key we are looking for
      * @param value The value to remove
-     * @return <tt>true</tt> if the value has been removed, <tt>false</tt> if the key was
+     * @return {@code true</tt> if the value has been removed, <tt>false} if the key was
      * not found of the value not removed
      */
     boolean removeAttribute(IoSession session, Object key, Object value);
@@ -128,14 +128,14 @@ public interface IoSessionAttributeMap {
      * @param key The key we are looking for
      * @param oldValue The old value to replace
      * @param newValue The new value to set
-     * @return <tt>true</tt> if the value has been replaced, <tt>false</tt> if the key was
+     * @return {@code true</tt> if the value has been replaced, <tt>false} if the key was
      * not found of the value not replaced
      */
     boolean replaceAttribute(IoSession session, Object key, Object oldValue, Object newValue);
 
     /**
-     * @return <tt>true</tt> if this session contains the attribute with
-     * the specified <tt>key</tt>.
+     * @return {@code true} if this session contains the attribute with
+     * the specified {@code key}.
      * 
      * @param session the session for which wa want to check if an attribute is present
      * @param key The key we are looking for
diff --git a/mina-core/src/main/java/org/apache/mina/core/session/IoSessionConfig.java b/mina-core/src/main/java/org/apache/mina/core/session/IoSessionConfig.java
index cc951b9e2..324961f1a 100644
--- a/mina-core/src/main/java/org/apache/mina/core/session/IoSessionConfig.java
+++ b/mina-core/src/main/java/org/apache/mina/core/session/IoSessionConfig.java
@@ -78,19 +78,19 @@ public interface IoSessionConfig {
 
     /**
      * @return the interval (seconds) between each throughput calculation.
-     * The default value is <tt>3</tt> seconds.
+     * The default value is {@code 3} seconds.
      */
     int getThroughputCalculationInterval();
 
     /**
      * @return the interval (milliseconds) between each throughput calculation.
-     * The default value is <tt>3</tt> seconds.
+     * The default value is {@code 3} seconds.
      */
     long getThroughputCalculationIntervalInMillis();
 
     /**
      * Sets the interval (seconds) between each throughput calculation.  The
-     * default value is <tt>3</tt> seconds.
+     * default value is {@code 3} seconds.
      * 
      * @param throughputCalculationInterval The interval
      */
@@ -189,7 +189,7 @@ public interface IoSessionConfig {
     void setWriteTimeout(int writeTimeout);
 
     /**
-     * @return <tt>true</tt> if and only if {@link IoSession#read()} operation
+     * @return {@code true} if and only if {@link IoSession#read()} operation
      * is enabled.  If enabled, all received messages are stored in an internal
      * {@link BlockingQueue} so you can read received messages in more
      * convenient way for client applications.  Enabling this option is not
@@ -206,13 +206,13 @@ public interface IoSessionConfig {
      * and can cause unintended memory leak, and therefore it's disabled by
      * default.
      * 
-     * @param useReadOperation <tt>true</tt> if the read operation is enabled, <tt>false</tt> otherwise
+     * @param useReadOperation {@code true</tt> if the read operation is enabled, <tt>false} otherwise
      */
     void setUseReadOperation(boolean useReadOperation);
 
     /**
      * Sets all configuration properties retrieved from the specified
-     * <tt>config</tt>.
+     * {@code config}.
      * 
      * @param config The configuration to use
      */
diff --git a/mina-core/src/main/java/org/apache/mina/core/session/IoSessionDataStructureFactory.java b/mina-core/src/main/java/org/apache/mina/core/session/IoSessionDataStructureFactory.java
index 79c477f5f..c90331848 100644
--- a/mina-core/src/main/java/org/apache/mina/core/session/IoSessionDataStructureFactory.java
+++ b/mina-core/src/main/java/org/apache/mina/core/session/IoSessionDataStructureFactory.java
@@ -32,7 +32,7 @@ import org.apache.mina.core.write.WriteRequestQueue;
 public interface IoSessionDataStructureFactory {
     /**
      * @return an {@link IoSessionAttributeMap} which is going to be associated
-     * with the specified <tt>session</tt>.  Please note that the returned
+     * with the specified {@code session}.  Please note that the returned
      * implementation must be thread-safe.
      * 
      * @param session The session for which we want the Attribute Map
@@ -42,7 +42,7 @@ public interface IoSessionDataStructureFactory {
 
     /**
      * @return an {@link WriteRequest} which is going to be associated with
-     * the specified <tt>session</tt>.  Please note that the returned
+     * the specified {@code session}.  Please note that the returned
      * implementation must be thread-safe and robust enough to deal
      * with various messages types (even what you didn't expect at all),
      * especially when you are going to implement a priority queue which
diff --git a/mina-core/src/main/java/org/apache/mina/core/write/WriteRequest.java b/mina-core/src/main/java/org/apache/mina/core/write/WriteRequest.java
index 17953c566..43737f5c3 100644
--- a/mina-core/src/main/java/org/apache/mina/core/write/WriteRequest.java
+++ b/mina-core/src/main/java/org/apache/mina/core/write/WriteRequest.java
@@ -56,7 +56,7 @@ public interface WriteRequest {
     /**
      * Returns the destination of this write request.
      *
-     * @return <tt>null</tt> for the default destination
+     * @return {@code null} for the default destination
      */
     SocketAddress getDestination();
 
diff --git a/mina-core/src/main/java/org/apache/mina/core/write/WriteRequestQueue.java b/mina-core/src/main/java/org/apache/mina/core/write/WriteRequestQueue.java
index 13ef9727e..72d2bffb0 100644
--- a/mina-core/src/main/java/org/apache/mina/core/write/WriteRequestQueue.java
+++ b/mina-core/src/main/java/org/apache/mina/core/write/WriteRequestQueue.java
@@ -45,7 +45,7 @@ public interface WriteRequestQueue {
     /**
      * Tells if the WriteRequest queue is empty or not for a session
      * @param session The session to check
-     * @return <tt>true</tt> if the writeRequest is empty
+     * @return {@code true} if the writeRequest is empty
      */
     boolean isEmpty(IoSession session);
 
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/CumulativeProtocolDecoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/CumulativeProtocolDecoder.java
index fc3ace994..e32ee4be8 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/CumulativeProtocolDecoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/CumulativeProtocolDecoder.java
@@ -115,14 +115,14 @@ public abstract class CumulativeProtocolDecoder extends ProtocolDecoderAdapter {
     }
 
     /**
-     * Cumulates content of <tt>in</tt> into internal buffer and forwards
+     * Cumulates content of {@code in} into internal buffer and forwards
      * decoding request to
      * doDecode(IoSession, IoBuffer, ProtocolDecoderOutput).
-     * <tt>doDecode()</tt> is invoked repeatedly until it returns <tt>false</tt>
+     * {@code doDecode()</tt> is invoked repeatedly until it returns <tt>false}
      * and the cumulative buffer is compacted after decoding ends.
      *
      * @throws IllegalStateException
-     *             if your <tt>doDecode()</tt> returned <tt>true</tt> not
+     *             if your {@code doDecode()</tt> returned <tt>true} not
      *             consuming the cumulative buffer.
      */
     @Override
@@ -214,18 +214,18 @@ public abstract class CumulativeProtocolDecoder extends ProtocolDecoderAdapter {
      * @param session The current Session
      * @param in the cumulative buffer
      * @param out The {@link ProtocolDecoderOutput} that will receive the decoded message
-     * @return <tt>true</tt> if and only if there's more to decode in the buffer
-     *         and you want to have <tt>doDecode</tt> method invoked again.
-     *         Return <tt>false</tt> if remaining data is not enough to decode,
+     * @return {@code true} if and only if there's more to decode in the buffer
+     *         and you want to have {@code doDecode} method invoked again.
+     *         Return {@code false} if remaining data is not enough to decode,
      *         then this method will be invoked again when more data is
      *         cumulated.
-     * @throws Exception if cannot decode <tt>in</tt>.
+     * @throws Exception if cannot decode {@code in}.
      */
     protected abstract boolean doDecode(IoSession session, IoBuffer in, ProtocolDecoderOutput out) throws Exception;
 
     /**
-     * Releases the cumulative buffer used by the specified <tt>session</tt>.
-     * Please don't forget to call <tt>super.dispose( session )</tt> when you
+     * Releases the cumulative buffer used by the specified {@code session}.
+     * Please don't forget to call {@code super.dispose( session )} when you
      * override this method.
      */
     @Override
@@ -247,7 +247,7 @@ public abstract class CumulativeProtocolDecoder extends ProtocolDecoderAdapter {
     }
     
     /**
-     * Let the user change the way we handle fragmentation. If set to <tt>false</tt>, the 
+     * Let the user change the way we handle fragmentation. If set to {@code false}, the 
      * decode() method will not check the TransportMetadata fragmentation capability
      *  
      * @param transportMetadataFragmentation The flag to set.
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolDecoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolDecoder.java
index b59a601be..97703cd5d 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolDecoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolDecoder.java
@@ -52,9 +52,9 @@ public interface ProtocolDecoder {
     void decode(IoSession session, IoBuffer in, ProtocolDecoderOutput out) throws Exception;
 
     /**
-     * Invoked when the specified <tt>session</tt> is closed.  This method is useful
+     * Invoked when the specified {@code session} is closed.  This method is useful
      * when you deal with the protocol which doesn't specify the length of a message
-     * such as HTTP response without <tt>content-length</tt> header. Implement this
+     * such as HTTP response without {@code content-length} header. Implement this
      * method to process the remaining data that {@link #decode(IoSession, IoBuffer, ProtocolDecoderOutput)}
      * method didn't process completely.
      *
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolEncoderOutput.java b/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolEncoderOutput.java
index 0fc847ce3..5a239323c 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolEncoderOutput.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/ProtocolEncoderOutput.java
@@ -58,7 +58,7 @@ public interface ProtocolEncoderOutput {
      * the returned {@link WriteFuture} if you want to wait for
      * the buffers flushed.
      *
-     * @return <tt>null</tt> if there is nothing to flush at all.
+     * @return {@code null} if there is nothing to flush at all.
      */
     WriteFuture flush();
 }
\ No newline at end of file
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/RecoverableProtocolDecoderException.java b/mina-core/src/main/java/org/apache/mina/filter/codec/RecoverableProtocolDecoderException.java
index f4030d2ce..4d581733c 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/RecoverableProtocolDecoderException.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/RecoverableProtocolDecoderException.java
@@ -27,7 +27,7 @@ package org.apache.mina.filter.codec;
  * than {@link RecoverableProtocolDecoderException}, it stops calling
  * the {@link ProtocolDecoder#decode(org.apache.mina.core.session.IoSession,
  *        org.apache.mina.core.buffer.IoBuffer, ProtocolDecoderOutput)}
- * immediately and fires an <tt>exceptionCaught</tt> event.
+ * immediately and fires an {@code exceptionCaught} event.
  * <p>
  * On the other hand, if {@link RecoverableProtocolDecoderException} is thrown,
  * it doesn't stop immediately but keeps calling the {@link ProtocolDecoder}
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolDecoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolDecoder.java
index eda5dbeb2..b4076057f 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolDecoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolDecoder.java
@@ -37,7 +37,7 @@ public class SynchronizedProtocolDecoder implements ProtocolDecoder {
     private final ProtocolDecoder decoder;
 
     /**
-     * Creates a new instance which decorates the specified <tt>decoder</tt>.
+     * Creates a new instance which decorates the specified {@code decoder}.
      * 
      * @param decoder The decorated decoder
      */
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolEncoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolEncoder.java
index 21d40cf8e..2539fca31 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolEncoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/SynchronizedProtocolEncoder.java
@@ -35,7 +35,7 @@ public class SynchronizedProtocolEncoder implements ProtocolEncoder {
     private final ProtocolEncoder encoder;
 
     /**
-     * Creates a new instance which decorates the specified <tt>encoder</tt>.
+     * Creates a new instance which decorates the specified {@code encoder}.
      * @param encoder The decorated encoder
      */
     public SynchronizedProtocolEncoder(ProtocolEncoder encoder) {
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/demux/DemuxingProtocolEncoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/demux/DemuxingProtocolEncoder.java
index 4e0ca3de4..b473d6ae1 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/demux/DemuxingProtocolEncoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/demux/DemuxingProtocolEncoder.java
@@ -38,7 +38,7 @@ import org.apache.mina.util.IdentityHashSet;
  * <h2>Disposing resources acquired by {@link MessageEncoder}</h2>
  * <p>
  * Override {@link #dispose(IoSession)} method. Please don't forget to call
- * <tt>super.dispose()</tt>.
+ * {@code super.dispose()}.
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>
  *
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageDecoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageDecoder.java
index 66b3605c8..33be3b481 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageDecoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageDecoder.java
@@ -26,7 +26,7 @@ import org.apache.mina.filter.codec.ProtocolDecoderOutput;
 /**
  * Decodes a certain type of messages.
  * <p>
- * We didn't provide any <tt>dispose</tt> method for {@link MessageDecoder}
+ * We didn't provide any {@code dispose} method for {@link MessageDecoder}
  * because it can give you  performance penalty in case you have a lot of
  * message types to handle.
  *
@@ -87,9 +87,9 @@ public interface MessageDecoder {
     MessageDecoderResult decode(IoSession session, IoBuffer in, ProtocolDecoderOutput out) throws Exception;
 
     /**
-     * Invoked when the specified <tt>session</tt> is closed while this decoder was
+     * Invoked when the specified {@code session} is closed while this decoder was
      * parsing the data.  This method is useful when you deal with the protocol which doesn't
-     * specify the length of a message such as HTTP response without <tt>content-length</tt>
+     * specify the length of a message such as HTTP response without {@code content-length}
      * header. Implement this method to process the remaining data that
      * {@link #decode(IoSession, IoBuffer, ProtocolDecoderOutput)} method didn't process
      * completely.
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageEncoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageEncoder.java
index 631db60bf..c02ff3c1e 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageEncoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/demux/MessageEncoder.java
@@ -26,7 +26,7 @@ import org.apache.mina.filter.codec.ProtocolEncoderOutput;
 /**
  * Encodes a certain type of messages.
  * <p>
- * We didn't provide any <tt>dispose</tt> method for {@link MessageEncoder}
+ * We didn't provide any {@code dispose} method for {@link MessageEncoder}
  * because it can give you  performance penalty in case you have a lot of
  * message types to handle.
  * 
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationCodecFactory.java b/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationCodecFactory.java
index ac91cad28..d48dddab5 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationCodecFactory.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationCodecFactory.java
@@ -101,7 +101,7 @@ public class ObjectSerializationCodecFactory implements ProtocolCodecFactory {
      * @return the allowed maximum size of the object to be decoded.
      * If the size of the object to be decoded exceeds this value, the
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1048576</tt> (1MB).
+     * value is {@code 1048576} (1MB).
      * <p>
      * This method does the same job with {@link ObjectSerializationDecoder#getMaxObjectSize()}.
      */
@@ -113,7 +113,7 @@ public class ObjectSerializationCodecFactory implements ProtocolCodecFactory {
      * Sets the allowed maximum size of the object to be decoded.
      * If the size of the object to be decoded exceeds this value, the
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1048576</tt> (1MB).
+     * value is {@code 1048576} (1MB).
      * <p>
      * This method does the same job with {@link ObjectSerializationDecoder#setMaxObjectSize(int)}.
      * 
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationDecoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationDecoder.java
index caf9468e7..542fb422e 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationDecoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationDecoder.java
@@ -63,7 +63,7 @@ public class ObjectSerializationDecoder extends CumulativeProtocolDecoder {
      * @return the allowed maximum size of the object to be decoded.
      * If the size of the object to be decoded exceeds this value, this
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1048576</tt> (1MB).
+     * value is {@code 1048576} (1MB).
      */
     public int getMaxObjectSize() {
         return maxObjectSize;
@@ -73,7 +73,7 @@ public class ObjectSerializationDecoder extends CumulativeProtocolDecoder {
      * Sets the allowed maximum size of the object to be decoded.
      * If the size of the object to be decoded exceeds this value, this
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1048576</tt> (1MB).
+     * value is {@code 1048576} (1MB).
      * 
      * @param maxObjectSize The maximum size for an object to be decoded
      */
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationInputStream.java b/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationInputStream.java
index 5da80cf06..fdf328648 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationInputStream.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/serialization/ObjectSerializationInputStream.java
@@ -78,7 +78,7 @@ public class ObjectSerializationInputStream extends InputStream implements Objec
      * @return the allowed maximum size of the object to be decoded.
      * If the size of the object to be decoded exceeds this value, this
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1048576</tt> (1MB).
+     * value is {@code 1048576} (1MB).
      */
     public int getMaxObjectSize() {
         return maxObjectSize;
@@ -88,7 +88,7 @@ public class ObjectSerializationInputStream extends InputStream implements Objec
      * Sets the allowed maximum size of the object to be decoded.
      * If the size of the object to be decoded exceeds this value, this
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1048576</tt> (1MB).
+     * value is {@code 1048576} (1MB).
      * 
      * @param maxObjectSize The maximum decoded object size
      */
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToDynamicTerminatorDecodingState.java b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToDynamicTerminatorDecodingState.java
index 06f990394..0e54edb4a 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToDynamicTerminatorDecodingState.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToDynamicTerminatorDecodingState.java
@@ -105,8 +105,8 @@ public abstract class ConsumeToDynamicTerminatorDecodingState implements Decodin
      * Determines whether the specified <code>byte</code> is a terminator.
      * 
      * @param b the <code>byte</code> to check.
-     * @return <tt>true</tt> if <code>b</code> is a terminator, 
-     *         <tt>false</tt> otherwise.
+     * @return {@code true} if <code>b</code> is a terminator, 
+     *         {@code false} otherwise.
      */
     protected abstract boolean isTerminator(byte b);
 
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToLinearWhitespaceDecodingState.java b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToLinearWhitespaceDecodingState.java
index aa3bb6084..f521cda56 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToLinearWhitespaceDecodingState.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/ConsumeToLinearWhitespaceDecodingState.java
@@ -28,7 +28,7 @@ package org.apache.mina.filter.codec.statemachine;
 public abstract class ConsumeToLinearWhitespaceDecodingState extends ConsumeToDynamicTerminatorDecodingState {
 
     /**
-     * @return <tt>true</tt> if the given byte is a space or a tab
+     * @return {@code true} if the given byte is a space or a tab
      */
     @Override
     protected boolean isTerminator(byte b) {
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/CrLfDecodingState.java b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/CrLfDecodingState.java
index 0d9ce1aa5..56bb1e128 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/CrLfDecodingState.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/CrLfDecodingState.java
@@ -25,9 +25,9 @@ import org.apache.mina.filter.codec.ProtocolDecoderOutput;
 
 /**
  * {@link DecodingState} which decodes a single <code>CRLF</code>.
- * If it is found, the bytes are consumed and <tt>true</tt>
+ * If it is found, the bytes are consumed and {@code true}
  * is provided as the product. Otherwise, read bytes are pushed back
- * to the stream, and <tt>false</tt> is provided as the
+ * to the stream, and {@code false} is provided as the
  * product.
  * Note that if we find a CR but do not find a following LF, we raise
  * an error.
@@ -99,7 +99,7 @@ public abstract class CrLfDecodingState implements DecodingState {
     /**
      * Invoked when this state has found a <code>CRLF</code>.
      * 
-     * @param foundCRLF <tt>true</tt> if <code>CRLF</code> was found.
+     * @param foundCRLF {@code true} if <code>CRLF</code> was found.
      * @param out the current {@link ProtocolDecoderOutput} used to write 
      *        decoded messages.
      * @return the next state if a state transition was triggered (use 
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/DecodingState.java b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/DecodingState.java
index bde345a8c..1dd9b7bd7 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/DecodingState.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/DecodingState.java
@@ -45,7 +45,7 @@ public interface DecodingState {
     /**
      * Invoked when the associated {@link IoSession} is closed. This method is 
      * useful when you deal with protocols which don't specify the length of a 
-     * message (e.g. HTTP responses without <tt>content-length</tt> header). 
+     * message (e.g. HTTP responses without {@code content-length} header). 
      * Implement this method to process the remaining data that 
      * {@link #decode(IoBuffer, ProtocolDecoderOutput)} method didn't process 
      * completely.
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/SkippingState.java b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/SkippingState.java
index ed45dec05..ce4520fb7 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/SkippingState.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/statemachine/SkippingState.java
@@ -24,7 +24,7 @@ import org.apache.mina.filter.codec.ProtocolDecoderOutput;
 
 /**
  * {@link DecodingState} which skips data until canSkip(byte) returns 
- * <tt>false</tt>.
+ * {@code false}.
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>
  */
@@ -70,7 +70,7 @@ public abstract class SkippingState implements DecodingState {
      * Called to determine whether the specified byte can be skipped.
      * 
      * @param b the byte to check.
-     * @return <tt>true</tt> if the byte can be skipped.
+     * @return {@code true} if the byte can be skipped.
      */
     protected abstract boolean canSkip(byte b);
 
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/LineDelimiter.java b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/LineDelimiter.java
index 9910f99c1..e1ab83998 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/LineDelimiter.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/LineDelimiter.java
@@ -24,7 +24,7 @@ import java.io.PrintWriter;
 
 /**
  * A delimiter which is appended to the end of a text line, such as
- * <tt>CR/LF</tt>. This class defines default delimiters for various
+ * {@code CR/LF}. This class defines default delimiters for various
  * OS :
  * <ul>
  * <li><b>Unix/Linux</b> : LineDelimiter.UNIX ("\n")</li>
@@ -49,34 +49,34 @@ public class LineDelimiter {
     /**
      * A special line delimiter which is used for auto-detection of
      * EOL in {@link TextLineDecoder}.  If this delimiter is used,
-     * {@link TextLineDecoder} will consider both  <tt>'\r'</tt> and
-     * <tt>'\n'</tt> as a delimiter.
+     * {@link TextLineDecoder} will consider both  {@code '\r'} and
+     * {@code '\n'} as a delimiter.
      */
     public static final LineDelimiter AUTO = new LineDelimiter("");
 
     /**
-     * The CRLF line delimiter constant (<tt>"\r\n"</tt>)
+     * The CRLF line delimiter constant ({@code "\r\n"})
      */
     public static final LineDelimiter CRLF = new LineDelimiter("\r\n");
 
     /**
-     * The line delimiter constant of UNIX (<tt>"\n"</tt>)
+     * The line delimiter constant of UNIX ({@code "\n"})
      */
     public static final LineDelimiter UNIX = new LineDelimiter("\n");
 
     /**
-     * The line delimiter constant of MS Windows/DOS (<tt>"\r\n"</tt>)
+     * The line delimiter constant of MS Windows/DOS ({@code "\r\n"})
      */
     public static final LineDelimiter WINDOWS = CRLF;
 
     /**
-     * The line delimiter constant of Mac OS (<tt>"\r"</tt>)
+     * The line delimiter constant of Mac OS ({@code "\r"})
      */
     public static final LineDelimiter MAC = new LineDelimiter("\r");
 
     /**
      * The line delimiter constant for NUL-terminated text protocols
-     * such as Flash XML socket (<tt>"\0"</tt>)
+     * such as Flash XML socket ({@code "\0"})
      */
     public static final LineDelimiter NUL = new LineDelimiter("\0");
 
@@ -84,7 +84,7 @@ public class LineDelimiter {
     private final String value;
 
     /**
-     * Creates a new line delimiter with the specified <tt>value</tt>.
+     * Creates a new line delimiter with the specified {@code value}.
      * 
      * @param value The new Line Delimiter
      */
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineCodecFactory.java b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineCodecFactory.java
index 9858f3e4a..e3d8f1eeb 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineCodecFactory.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineCodecFactory.java
@@ -137,7 +137,7 @@ public class TextLineCodecFactory implements ProtocolCodecFactory {
      * @return the allowed maximum size of the line to be decoded.
      * If the size of the line to be decoded exceeds this value, the
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1024</tt> (1KB).
+     * value is {@code 1024} (1KB).
      * <p>
      * This method does the same job with {@link TextLineDecoder#getMaxLineLength()}.
      */
@@ -149,7 +149,7 @@ public class TextLineCodecFactory implements ProtocolCodecFactory {
      * Sets the allowed maximum size of the line to be decoded.
      * If the size of the line to be decoded exceeds this value, the
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1024</tt> (1KB).
+     * value is {@code 1024} (1KB).
      * <p>
      * This method does the same job with {@link TextLineDecoder#setMaxLineLength(int)}.
      * 
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineDecoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineDecoder.java
index ad43b382d..1b4439c41 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineDecoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineDecoder.java
@@ -66,7 +66,7 @@ public class TextLineDecoder implements ProtocolDecoder {
 
     /**
      * Creates a new instance with the current default {@link Charset}
-     * and the specified <tt>delimiter</tt>.
+     * and the specified {@code delimiter}.
      * 
      * @param delimiter The line delimiter to use
      */
@@ -76,7 +76,7 @@ public class TextLineDecoder implements ProtocolDecoder {
 
     /**
      * Creates a new instance with the current default {@link Charset}
-     * and the specified <tt>delimiter</tt>.
+     * and the specified {@code delimiter}.
      * 
      * @param delimiter The line delimiter to use
      */
@@ -85,7 +85,7 @@ public class TextLineDecoder implements ProtocolDecoder {
     }
 
     /**
-     * Creates a new instance with the spcified <tt>charset</tt>
+     * Creates a new instance with the spcified {@code charset}
      * and {@link LineDelimiter#AUTO} delimiter.
      * 
      * @param charset The {@link Charset} to use
@@ -95,8 +95,8 @@ public class TextLineDecoder implements ProtocolDecoder {
     }
 
     /**
-     * Creates a new instance with the spcified <tt>charset</tt>
-     * and the specified <tt>delimiter</tt>.
+     * Creates a new instance with the spcified {@code charset}
+     * and the specified {@code delimiter}.
      * 
      * @param charset The {@link Charset} to use
      * @param delimiter The line delimiter to use
@@ -106,8 +106,8 @@ public class TextLineDecoder implements ProtocolDecoder {
     }
 
     /**
-     * Creates a new instance with the specified <tt>charset</tt>
-     * and the specified <tt>delimiter</tt>.
+     * Creates a new instance with the specified {@code charset}
+     * and the specified {@code delimiter}.
      * 
      * @param charset The {@link Charset} to use
      * @param delimiter The line delimiter to use
@@ -143,7 +143,7 @@ public class TextLineDecoder implements ProtocolDecoder {
      * @return the allowed maximum size of the line to be decoded.
      * If the size of the line to be decoded exceeds this value, the
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1024</tt> (1KB).
+     * value is {@code 1024} (1KB).
      */
     public int getMaxLineLength() {
         return maxLineLength;
@@ -153,7 +153,7 @@ public class TextLineDecoder implements ProtocolDecoder {
      * Sets the allowed maximum size of the line to be decoded.
      * If the size of the line to be decoded exceeds this value, the
      * decoder will throw a {@link BufferDataException}.  The default
-     * value is <tt>1024</tt> (1KB).
+     * value is {@code 1024} (1KB).
      * 
      * @param maxLineLength The maximum line length
      */
diff --git a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineEncoder.java b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineEncoder.java
index bd19c4d3b..121897ccc 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineEncoder.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/codec/textline/TextLineEncoder.java
@@ -54,7 +54,7 @@ public class TextLineEncoder extends ProtocolEncoderAdapter {
 
     /**
      * Creates a new instance with the current default {@link Charset}
-     * and the specified <tt>delimiter</tt>.
+     * and the specified {@code delimiter}.
      * 
      * @param delimiter The line delimiter to use
      */
@@ -64,7 +64,7 @@ public class TextLineEncoder extends ProtocolEncoderAdapter {
 
     /**
      * Creates a new instance with the current default {@link Charset}
-     * and the specified <tt>delimiter</tt>.
+     * and the specified {@code delimiter}.
      * 
      * @param delimiter The line delimiter to use
      */
@@ -73,7 +73,7 @@ public class TextLineEncoder extends ProtocolEncoderAdapter {
     }
 
     /**
-     * Creates a new instance with the specified <tt>charset</tt>
+     * Creates a new instance with the specified {@code charset}
      * and {@link LineDelimiter#UNIX} delimiter.
      * 
      * @param charset The {@link Charset} to use
@@ -83,8 +83,8 @@ public class TextLineEncoder extends ProtocolEncoderAdapter {
     }
 
     /**
-     * Creates a new instance with the specified <tt>charset</tt>
-     * and the specified <tt>delimiter</tt>.
+     * Creates a new instance with the specified {@code charset}
+     * and the specified {@code delimiter}.
      * 
      * @param charset The {@link Charset} to use
      * @param delimiter The line delimiter to use
@@ -94,8 +94,8 @@ public class TextLineEncoder extends ProtocolEncoderAdapter {
     }
 
     /**
-     * Creates a new instance with the specified <tt>charset</tt>
-     * and the specified <tt>delimiter</tt>.
+     * Creates a new instance with the specified {@code charset}
+     * and the specified {@code delimiter}.
      * 
      * @param charset The {@link Charset} to use
      * @param delimiter The line delimiter to use
diff --git a/mina-core/src/main/java/org/apache/mina/filter/executor/DefaultIoEventSizeEstimator.java b/mina-core/src/main/java/org/apache/mina/filter/executor/DefaultIoEventSizeEstimator.java
index 858e0a163..a3628a600 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/executor/DefaultIoEventSizeEstimator.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/executor/DefaultIoEventSizeEstimator.java
@@ -36,7 +36,7 @@ import org.apache.mina.core.write.WriteRequest;
  * <a href="http://martin.nobilitas.com/java/sizeof.html">Martin's Java Notes</a>
  * was used for estimation.  For unknown types, it inspects declaring fields of the
  * class of the specified event and the parameter of the event.  The size of unknown
- * declaring fields are approximated to the specified <tt>averageSizePerField</tt>
+ * declaring fields are approximated to the specified {@code averageSizePerField}
  * (default: 64).
  * <p>
  * All the estimated sizes of classes are cached for performance improvement.
diff --git a/mina-core/src/main/java/org/apache/mina/filter/executor/ExecutorFilter.java b/mina-core/src/main/java/org/apache/mina/filter/executor/ExecutorFilter.java
index 273d805ac..2b950b704 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/executor/ExecutorFilter.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/executor/ExecutorFilter.java
@@ -80,8 +80,8 @@ import org.apache.mina.core.write.WriteRequest;
  * 
  * <h2>Selective Filtering</h2>
  * 
- * By default, all event types but <tt>sessionCreated</tt>, <tt>filterWrite</tt>,
- * <tt>filterClose</tt> and <tt>filterSetTrafficMask</tt> are submitted to the
+ * By default, all event types but {@code sessionCreated</tt>, <tt>filterWrite},
+ * {@code filterClose</tt> and <tt>filterSetTrafficMask} are submitted to the
  * underlying executor, which is most common setting.
  * <p>
  * If you want to submit only a certain set of event types, you can specify them
diff --git a/mina-core/src/main/java/org/apache/mina/filter/executor/IoEventQueueHandler.java b/mina-core/src/main/java/org/apache/mina/filter/executor/IoEventQueueHandler.java
index ceba8045c..59be99189 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/executor/IoEventQueueHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/executor/IoEventQueueHandler.java
@@ -61,9 +61,9 @@ public interface IoEventQueueHandler extends EventListener {
     };
 
     /**
-     * @return <tt>true</tt> if and only if the specified <tt>event</tt> is
-     * allowed to be offered to the event queue.  The <tt>event</tt> is dropped
-     * if <tt>false</tt> is returned.
+     * @return {@code true</tt> if and only if the specified <tt>event} is
+     * allowed to be offered to the event queue.  The {@code event} is dropped
+     * if {@code false} is returned.
      * 
      * @param source The source of event
      * @param event The received event
@@ -71,7 +71,7 @@ public interface IoEventQueueHandler extends EventListener {
     boolean accept(Object source, IoEvent event);
 
     /**
-     * Invoked after the specified <tt>event</tt> has been offered to the
+     * Invoked after the specified {@code event} has been offered to the
      * event queue.
      * 
      * @param source The source of event
@@ -80,7 +80,7 @@ public interface IoEventQueueHandler extends EventListener {
     void offered(Object source, IoEvent event);
 
     /**
-     * Invoked after the specified <tt>event</tt> has been polled from the
+     * Invoked after the specified {@code event} has been polled from the
      * event queue.
      * 
      * @param source The source of event
diff --git a/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveFilter.java b/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveFilter.java
index 3b5aa758c..7ee3aafeb 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveFilter.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveFilter.java
@@ -39,14 +39,14 @@ import org.apache.mina.core.write.WriteRequest;
  *
  * <h2>Interference with {@link IoSessionConfig#setIdleTime(IdleStatus, int)}</h2>
  *
- * This filter adjusts <tt>idleTime</tt> of the {@link IdleStatus}s that
+ * This filter adjusts {@code idleTime} of the {@link IdleStatus}s that
  * this filter is interested in automatically (e.g. {@link IdleStatus#READER_IDLE}
- * and {@link IdleStatus#WRITER_IDLE}.)  Changing the <tt>idleTime</tt>
+ * and {@link IdleStatus#WRITER_IDLE}.)  Changing the {@code idleTime}
  * of the {@link IdleStatus}s can lead this filter to a unexpected behavior.
  * Please also note that any {@link IoFilter} and {@link IoHandler} behind
  * {@link KeepAliveFilter} will not get any {@link IoEventType#SESSION_IDLE}
  * event.  To receive the internal {@link IoEventType#SESSION_IDLE} event,
- * you can call {@link #setForwardEvent(boolean)} with <tt>true</tt>.
+ * you can call {@link #setForwardEvent(boolean)} with {@code true}.
  *
  * <h2>Implementing {@link KeepAliveMessageFactory}</h2>
  *
@@ -65,14 +65,14 @@ import org.apache.mina.core.write.WriteRequest;
  *     <td>
  *       You want a keep-alive request is sent when the reader is idle.
  *       Once the request is sent, the response for the request should be
- *       received within <tt>keepAliveRequestTimeout</tt> seconds.  Otherwise,
+ *       received within {@code keepAliveRequestTimeout} seconds.  Otherwise,
  *       the specified {@link KeepAliveRequestTimeoutHandler} will be invoked.
  *       If a keep-alive request is received, its response also should be sent back.
  *     </td>
  *     <td>
  *       Both {@link KeepAliveMessageFactory#getRequest(IoSession)} and
  *       {@link KeepAliveMessageFactory#getResponse(IoSession, Object)} must
- *       return a non-<tt>null</tt>.
+ *       return a non-{@code null}.
  *     </td>
  *   </tr>
  *   <tr valign="top">
@@ -86,7 +86,7 @@ import org.apache.mina.core.write.WriteRequest;
  *     <td>
  *       Both {@link KeepAliveMessageFactory#getRequest(IoSession)} and
  *       {@link KeepAliveMessageFactory#getResponse(IoSession, Object)} must
- *       return a non-<tt>null</tt>, and the <tt>timeoutHandler</tt> property
+ *       return a non-{@code null</tt>, and the <tt>timeoutHandler} property
  *       should be set to {@link KeepAliveRequestTimeoutHandler#NOOP},
  *       {@link KeepAliveRequestTimeoutHandler#LOG} or the custom {@link KeepAliveRequestTimeoutHandler}
  *       implementation that doesn't affect the session state nor throw an exception.
@@ -100,8 +100,8 @@ import org.apache.mina.core.write.WriteRequest;
  *     </td>
  *     <td>
  *       {@link KeepAliveMessageFactory#getRequest(IoSession)} must return
- *       <tt>null</tt> and {@link KeepAliveMessageFactory#getResponse(IoSession, Object)}
- *       must return a non-<tt>null</tt>.
+ *       {@code null} and {@link KeepAliveMessageFactory#getResponse(IoSession, Object)}
+ *       must return a non-{@code null}.
  *     </td>
  *   </tr>
  *   <tr valign="top">
@@ -112,9 +112,9 @@ import org.apache.mina.core.write.WriteRequest;
  *     </td>
  *     <td>
  *       {@link KeepAliveMessageFactory#getRequest(IoSession)} must return
- *       a non-<tt>null</tt>,
+ *       a non-{@code null},
  *       {@link KeepAliveMessageFactory#getResponse(IoSession, Object)} must
- *       return <tt>null</tt> and the <tt>timeoutHandler</tt> must be set to
+ *       return {@code null</tt> and the <tt>timeoutHandler} must be set to
  *       {@link KeepAliveRequestTimeoutHandler#DEAF_SPEAKER}.
  *     </td>
  *   </tr>
@@ -127,7 +127,7 @@ import org.apache.mina.core.write.WriteRequest;
  *     <td>
  *       Both {@link KeepAliveMessageFactory#getRequest(IoSession)} and
  *       {@link KeepAliveMessageFactory#getResponse(IoSession, Object)} must
- *       return <tt>null</tt>.
+ *       return {@code null}.
  *     </td>
  *   </tr>
  * </table>
@@ -150,7 +150,7 @@ import org.apache.mina.core.write.WriteRequest;
  *
  * {@link KeepAliveRequestTimeoutHandler#DEAF_SPEAKER} is a special handler which is
  * dedicated for the 'deaf speaker' mode mentioned above.  Setting the
- * <tt>timeoutHandler</tt> property to {@link KeepAliveRequestTimeoutHandler#DEAF_SPEAKER}
+ * {@code timeoutHandler} property to {@link KeepAliveRequestTimeoutHandler#DEAF_SPEAKER}
  * stops this filter from waiting for response messages and therefore disables
  * response timeout detection.
  *
@@ -179,10 +179,10 @@ public class KeepAliveFilter extends IoFilterAdapter {
      * Creates a new instance with the default properties.
      * The default property values are:
      * <ul>
-     * <li><tt>interestedIdleStatus</tt> - {@link IdleStatus#READER_IDLE}</li>
-     * <li><tt>policy</tt> = {@link KeepAliveRequestTimeoutHandler#CLOSE}</li>
-     * <li><tt>keepAliveRequestInterval</tt> - 60 (seconds)</li>
-     * <li><tt>keepAliveRequestTimeout</tt> - 30 (seconds)</li>
+     * <li>{@code interestedIdleStatus} - {@link IdleStatus#READER_IDLE}</li>
+     * <li>{@code policy} = {@link KeepAliveRequestTimeoutHandler#CLOSE}</li>
+     * <li>{@code keepAliveRequestInterval} - 60 (seconds)</li>
+     * <li>{@code keepAliveRequestTimeout} - 30 (seconds)</li>
      * </ul>
      * 
      * @param messageFactory The message factory to use 
@@ -195,9 +195,9 @@ public class KeepAliveFilter extends IoFilterAdapter {
      * Creates a new instance with the default properties.
      * The default property values are:
      * <ul>
-     * <li><tt>policy</tt> = {@link KeepAliveRequestTimeoutHandler#CLOSE}</li>
-     * <li><tt>keepAliveRequestInterval</tt> - 60 (seconds)</li>
-     * <li><tt>keepAliveRequestTimeout</tt> - 30 (seconds)</li>
+     * <li>{@code policy} = {@link KeepAliveRequestTimeoutHandler#CLOSE}</li>
+     * <li>{@code keepAliveRequestInterval} - 60 (seconds)</li>
+     * <li>{@code keepAliveRequestTimeout} - 30 (seconds)</li>
      * </ul>
      * 
      * @param messageFactory The message factory to use 
@@ -211,9 +211,9 @@ public class KeepAliveFilter extends IoFilterAdapter {
      * Creates a new instance with the default properties.
      * The default property values are:
      * <ul>
-     * <li><tt>interestedIdleStatus</tt> - {@link IdleStatus#READER_IDLE}</li>
-     * <li><tt>keepAliveRequestInterval</tt> - 60 (seconds)</li>
-     * <li><tt>keepAliveRequestTimeout</tt> - 30 (seconds)</li>
+     * <li>{@code interestedIdleStatus} - {@link IdleStatus#READER_IDLE}</li>
+     * <li>{@code keepAliveRequestInterval} - 60 (seconds)</li>
+     * <li>{@code keepAliveRequestTimeout} - 30 (seconds)</li>
      * </ul>
      * 
      * @param messageFactory The message factory to use 
@@ -227,8 +227,8 @@ public class KeepAliveFilter extends IoFilterAdapter {
      * Creates a new instance with the default properties.
      * The default property values are:
      * <ul>
-     * <li><tt>keepAliveRequestInterval</tt> - 60 (seconds)</li>
-     * <li><tt>keepAliveRequestTimeout</tt> - 30 (seconds)</li>
+     * <li>{@code keepAliveRequestInterval} - 60 (seconds)</li>
+     * <li>{@code keepAliveRequestTimeout} - 30 (seconds)</li>
      * </ul>
      * 
      * @param messageFactory The message factory to use 
@@ -347,9 +347,9 @@ public class KeepAliveFilter extends IoFilterAdapter {
     }
 
     /**
-     * @return <tt>true</tt> if and only if this filter forwards
+     * @return {@code true} if and only if this filter forwards
      * a {@link IoEventType#SESSION_IDLE} event to the next filter.
-     * By default, the value of this property is <tt>false</tt>.
+     * By default, the value of this property is {@code false}.
      */
     public boolean isForwardEvent() {
         return forwardEvent;
@@ -358,7 +358,7 @@ public class KeepAliveFilter extends IoFilterAdapter {
     /**
      * Sets if this filter needs to forward a
      * {@link IoEventType#SESSION_IDLE} event to the next filter.
-     * By default, the value of this property is <tt>false</tt>.
+     * By default, the value of this property is {@code false}.
      * 
      * @param forwardEvent a flag set to tell if the filter has to forward a {@link IoEventType#SESSION_IDLE} event
      */
diff --git a/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveMessageFactory.java b/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveMessageFactory.java
index 34d2e8d6a..2428d21cf 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveMessageFactory.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/keepalive/KeepAliveMessageFactory.java
@@ -29,7 +29,7 @@ import org.apache.mina.core.session.IoSession;
 public interface KeepAliveMessageFactory {
 
     /**
-     * @return <tt>true</tt> if and only if the specified message is a
+     * @return {@code true} if and only if the specified message is a
      * keep-alive request message.
      * 
      * @param session The current session
@@ -38,7 +38,7 @@ public interface KeepAliveMessageFactory {
     boolean isRequest(IoSession session, Object message);
 
     /**
-     * @return <tt>true</tt> if and only if the specified message is a 
+     * @return {@code true} if and only if the specified message is a 
      * keep-alive response message;
      * 
      * @param session The current session
@@ -47,14 +47,14 @@ public interface KeepAliveMessageFactory {
     boolean isResponse(IoSession session, Object message);
 
     /**
-     * @return a (new) keep-alive request message or <tt>null</tt> if no request is required.
+     * @return a (new) keep-alive request message or {@code null} if no request is required.
      * 
      * @param session The current session
      */
     Object getRequest(IoSession session);
 
     /**
-     * @return a (new) response message for the specified keep-alive request, or <tt>null</tt> if no response is required.
+     * @return a (new) response message for the specified keep-alive request, or {@code null} if no response is required.
      * 
      * @param session The current session
      * @param request The request we are lookig for
diff --git a/mina-core/src/main/java/org/apache/mina/filter/ssl/KeyStoreFactory.java b/mina-core/src/main/java/org/apache/mina/filter/ssl/KeyStoreFactory.java
index b0903fa54..b0319371e 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/ssl/KeyStoreFactory.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/ssl/KeyStoreFactory.java
@@ -121,7 +121,7 @@ public class KeyStoreFactory {
      * Sets the name of the provider to use when creating the key store. The
      * default is to use the platform default provider.
      *
-     * @param provider the name of the provider, e.g. <tt>"SUN"</tt>.
+     * @param provider the name of the provider, e.g. {@code "SUN"}.
      */
     public void setProvider(String provider) {
         this.provider = provider;
diff --git a/mina-core/src/main/java/org/apache/mina/filter/ssl/SslContextFactory.java b/mina-core/src/main/java/org/apache/mina/filter/ssl/SslContextFactory.java
index e05d3d61d..8cef40952 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/ssl/SslContextFactory.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/ssl/SslContextFactory.java
@@ -181,7 +181,7 @@ public class SslContextFactory {
 
     /**
      * Sets the provider of the new {@link SSLContext}. The default value is
-     * <tt>null</tt>, which means the default provider will be used.
+     * {@code null}, which means the default provider will be used.
      * 
      * @param provider the name of the {@link SSLContext} provider
      */
@@ -204,28 +204,28 @@ public class SslContextFactory {
     }
 
     /**
-     * If this is set to <tt>true</tt> while no {@link KeyManagerFactory}
+     * If this is set to {@code true} while no {@link KeyManagerFactory}
      * has been set using {@link #setKeyManagerFactory(KeyManagerFactory)} and
      * no algorithm has been set using
      * {@link #setKeyManagerFactoryAlgorithm(String)} the default algorithm
      * return by {@link KeyManagerFactory#getDefaultAlgorithm()} will be used.
-     * The default value of this property is <tt>true</tt>.
+     * The default value of this property is {@code true}.
      *
-     * @param useDefault <tt>true</tt> or <tt>false</tt>.
+     * @param useDefault {@code true</tt> or <tt>false}.
      */
     public void setKeyManagerFactoryAlgorithmUseDefault(boolean useDefault) {
         this.keyManagerFactoryAlgorithmUseDefault = useDefault;
     }
 
     /**
-     * If this is set to <tt>true</tt> while no {@link TrustManagerFactory}
+     * If this is set to {@code true} while no {@link TrustManagerFactory}
      * has been set using {@link #setTrustManagerFactory(TrustManagerFactory)} and
      * no algorithm has been set using
      * {@link #setTrustManagerFactoryAlgorithm(String)} the default algorithm
      * return by {@link TrustManagerFactory#getDefaultAlgorithm()} will be used.
-     * The default value of this property is <tt>true</tt>.
+     * The default value of this property is {@code true}.
      *
-     * @param useDefault <tt>true</tt> or <tt>false</tt>.
+     * @param useDefault {@code true</tt> or <tt>false}.
      */
     public void setTrustManagerFactoryAlgorithmUseDefault(boolean useDefault) {
         this.trustManagerFactoryAlgorithmUseDefault = useDefault;
@@ -253,7 +253,7 @@ public class SslContextFactory {
      * If this property isn't set while no {@link KeyManagerFactory} has been
      * set using {@link #setKeyManagerFactory(KeyManagerFactory)} and
      * {@link #setKeyManagerFactoryAlgorithmUseDefault(boolean)} has been set to
-     * <tt>true</tt> the value returned
+     * {@code true} the value returned
      * by {@link KeyManagerFactory#getDefaultAlgorithm()} will be used instead.
      *
      * @param algorithm the algorithm to use.
@@ -330,7 +330,7 @@ public class SslContextFactory {
      * If this property isn't set while no {@link TrustManagerFactory} has been
      * set using {@link #setTrustManagerFactory(TrustManagerFactory)} and
      * {@link #setTrustManagerFactoryAlgorithmUseDefault(boolean)} has been set to
-     * <tt>true</tt> the value returned
+     * {@code true} the value returned
      * by {@link TrustManagerFactory#getDefaultAlgorithm()} will be used instead.
      *
      * @param algorithm the algorithm to use.
diff --git a/mina-core/src/main/java/org/apache/mina/filter/ssl/SslHandler.java b/mina-core/src/main/java/org/apache/mina/filter/ssl/SslHandler.java
index 9dbeda409..39ff9ddd3 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/ssl/SslHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/ssl/SslHandler.java
@@ -475,7 +475,7 @@ class SslHandler {
     /**
      * Start SSL shutdown process.
      * 
-     * @return <tt>true</tt> if shutdown process is started. <tt>false</tt> if
+     * @return {@code true</tt> if shutdown process is started. <tt>false} if
      *         shutdown process is already finished.
      * @throws SSLException
      *             on errors
diff --git a/mina-core/src/main/java/org/apache/mina/filter/util/SessionAttributeInitializingFilter.java b/mina-core/src/main/java/org/apache/mina/filter/util/SessionAttributeInitializingFilter.java
index d8e9fc611..ed48820f3 100644
--- a/mina-core/src/main/java/org/apache/mina/filter/util/SessionAttributeInitializingFilter.java
+++ b/mina-core/src/main/java/org/apache/mina/filter/util/SessionAttributeInitializingFilter.java
@@ -32,7 +32,7 @@ import org.apache.mina.core.session.IoSession;
  * {@link IoSession} is created.  By default, the attribute map is empty when
  * an {@link IoSession} is newly created.  Inserting this filter will make
  * the pre-configured attributes available after this filter executes the
- * <tt>sessionCreated</tt> event.
+ * {@code sessionCreated} event.
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>
  * @org.apache.xbean.XBean
@@ -64,7 +64,7 @@ public class SessionAttributeInitializingFilter extends IoFilterAdapter {
      * Returns the value of user-defined attribute.
      *
      * @param key the key of the attribute
-     * @return <tt>null</tt> if there is no attribute with the specified key
+     * @return {@code null} if there is no attribute with the specified key
      */
     public Object getAttribute(String key) {
         return attributes.get(key);
@@ -75,7 +75,7 @@ public class SessionAttributeInitializingFilter extends IoFilterAdapter {
      *
      * @param key the key of the attribute
      * @param value the value of the attribute
-     * @return The old value of the attribute.  <tt>null</tt> if it is new.
+     * @return The old value of the attribute.  {@code null} if it is new.
      */
     public Object setAttribute(String key, Object value) {
         if (value == null) {
@@ -91,7 +91,7 @@ public class SessionAttributeInitializingFilter extends IoFilterAdapter {
      * {@link Boolean#TRUE}.
      *
      * @param key the key of the attribute
-     * @return The old value of the attribute.  <tt>null</tt> if it is new.
+     * @return The old value of the attribute.  {@code null} if it is new.
      */
     public Object setAttribute(String key) {
         return attributes.put(key, Boolean.TRUE);
@@ -101,15 +101,15 @@ public class SessionAttributeInitializingFilter extends IoFilterAdapter {
      * Removes a user-defined attribute with the specified key.
      *
      * @param key The attribut's key we want to removee
-     * @return The old value of the attribute.  <tt>null</tt> if not found.
+     * @return The old value of the attribute.  {@code null} if not found.
      */
     public Object removeAttribute(String key) {
         return attributes.remove(key);
     }
 
     /**
-     * @return <tt>true</tt> if this session contains the attribute with
-     * the specified <tt>key</tt>.
+     * @return {@code true} if this session contains the attribute with
+     * the specified {@code key}.
      */
     boolean containsAttribute(String key) {
         return attributes.containsKey(key);
diff --git a/mina-core/src/main/java/org/apache/mina/handler/chain/ChainedIoHandler.java b/mina-core/src/main/java/org/apache/mina/handler/chain/ChainedIoHandler.java
index 19ce3dcfb..eab30fcb8 100644
--- a/mina-core/src/main/java/org/apache/mina/handler/chain/ChainedIoHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/handler/chain/ChainedIoHandler.java
@@ -25,7 +25,7 @@ import org.apache.mina.core.session.IoSession;
 
 /**
  * An {@link IoHandler} which executes an {@link IoHandlerChain}
- * on a <tt>messageReceived</tt> event.
+ * on a {@code messageReceived} event.
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>
  */
@@ -41,7 +41,7 @@ public class ChainedIoHandler extends IoHandlerAdapter {
 
     /**
      * Creates a new instance which executes the specified
-     * {@link IoHandlerChain} on a <tt>messageReceived</tt> event.
+     * {@link IoHandlerChain} on a {@code messageReceived} event.
      *
      * @param chain an {@link IoHandlerChain} to execute
      */
@@ -55,14 +55,14 @@ public class ChainedIoHandler extends IoHandlerAdapter {
 
     /**
      * @return the {@link IoHandlerCommand} this handler will use to
-     * handle <tt>messageReceived</tt> events.
+     * handle {@code messageReceived} events.
      */
     public IoHandlerChain getChain() {
         return chain;
     }
 
     /**
-     * Handles the specified <tt>messageReceived</tt> event with the
+     * Handles the specified {@code messageReceived} event with the
      * {@link IoHandlerCommand} or {@link IoHandlerChain} you specified
      * in the constructor.
      */
diff --git a/mina-core/src/main/java/org/apache/mina/handler/chain/IoHandlerChain.java b/mina-core/src/main/java/org/apache/mina/handler/chain/IoHandlerChain.java
index ca54758ae..1c6021200 100644
--- a/mina-core/src/main/java/org/apache/mina/handler/chain/IoHandlerChain.java
+++ b/mina-core/src/main/java/org/apache/mina/handler/chain/IoHandlerChain.java
@@ -300,7 +300,7 @@ public class IoHandlerChain implements IoHandlerCommand {
      * Checks if the chain of {@link IoHandlerCommand} contains a {@link IoHandlerCommand} by its name
      * 
      * @param name The {@link IoHandlerCommand} name
-     * @return <tt>TRUE</tt> if the {@link IoHandlerCommand} is found in the chain
+     * @return {@code TRUE} if the {@link IoHandlerCommand} is found in the chain
      */
     public boolean contains(String name) {
         return getEntry(name) != null;
@@ -310,7 +310,7 @@ public class IoHandlerChain implements IoHandlerCommand {
      * Checks if the chain of {@link IoHandlerCommand} contains a specific {@link IoHandlerCommand}
      * 
      * @param command The {@link IoHandlerCommand} we are looking for
-     * @return <tt>TRUE</tt> if the {@link IoHandlerCommand} is found in the chain
+     * @return {@code TRUE} if the {@link IoHandlerCommand} is found in the chain
      */
     public boolean contains(IoHandlerCommand command) {
         Entry e = head.nextEntry;
@@ -327,7 +327,7 @@ public class IoHandlerChain implements IoHandlerCommand {
      * Checks if the chain of {@link IoHandlerCommand} contains a specific {@link IoHandlerCommand}
      * 
      * @param commandType The type of {@link IoHandlerCommand} we are looking for
-     * @return <tt>TRUE</tt> if the {@link IoHandlerCommand} is found in the chain
+     * @return {@code TRUE} if the {@link IoHandlerCommand} is found in the chain
      */
     public boolean contains(Class<? extends IoHandlerCommand> commandType) {
         Entry e = head.nextEntry;
diff --git a/mina-core/src/main/java/org/apache/mina/handler/demux/DemuxingIoHandler.java b/mina-core/src/main/java/org/apache/mina/handler/demux/DemuxingIoHandler.java
index 2ff2a581c..89f7e85d0 100644
--- a/mina-core/src/main/java/org/apache/mina/handler/demux/DemuxingIoHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/handler/demux/DemuxingIoHandler.java
@@ -101,7 +101,7 @@ public class DemuxingIoHandler extends IoHandlerAdapter {
      * @param type The message's type
      * @param handler The message handler
      * @return the old handler if there is already a registered handler for
-     *         the specified <tt>type</tt>.  <tt>null</tt> otherwise.
+     *         the specified {@code type</tt>.  <tt>null} otherwise.
      */
     @SuppressWarnings("unchecked")
     public <E> MessageHandler<? super E> addReceivedMessageHandler(Class<E> type, MessageHandler<? super E> handler) {
@@ -116,7 +116,7 @@ public class DemuxingIoHandler extends IoHandlerAdapter {
      *
      * @param <E> The message handler's type
      * @param type The message's type
-     * @return the removed handler if successfully removed.  <tt>null</tt> otherwise.
+     * @return the removed handler if successfully removed.  {@code null} otherwise.
      */
     @SuppressWarnings("unchecked")
     public <E> MessageHandler<? super E> removeReceivedMessageHandler(Class<E> type) {
@@ -133,7 +133,7 @@ public class DemuxingIoHandler extends IoHandlerAdapter {
      * @param type The message's type
      * @param handler The message handler
      * @return the old handler if there is already a registered handler for
-     *         the specified <tt>type</tt>.  <tt>null</tt> otherwise.
+     *         the specified {@code type</tt>.  <tt>null} otherwise.
      */
     @SuppressWarnings("unchecked")
     public <E> MessageHandler<? super E> addSentMessageHandler(Class<E> type, MessageHandler<? super E> handler) {
@@ -148,7 +148,7 @@ public class DemuxingIoHandler extends IoHandlerAdapter {
      *
      * @param <E> The message handler's type
      * @param type The message's type
-     * @return the removed handler if successfully removed.  <tt>null</tt> otherwise.
+     * @return the removed handler if successfully removed.  {@code null} otherwise.
      */
     @SuppressWarnings("unchecked")
     public <E> MessageHandler<? super E> removeSentMessageHandler(Class<E> type) {
@@ -165,7 +165,7 @@ public class DemuxingIoHandler extends IoHandlerAdapter {
      * @param type The message's type
      * @param handler The Exception handler
      * @return the old handler if there is already a registered handler for
-     *         the specified <tt>type</tt>.  <tt>null</tt> otherwise.
+     *         the specified {@code type</tt>.  <tt>null} otherwise.
      */
     @SuppressWarnings("unchecked")
     public <E extends Throwable> ExceptionHandler<? super E> addExceptionHandler(Class<E> type,
@@ -181,7 +181,7 @@ public class DemuxingIoHandler extends IoHandlerAdapter {
      *
      * @param <E> The Exception Handler's type
      * @param type The message's type
-     * @return the removed handler if successfully removed.  <tt>null</tt> otherwise.
+     * @return the removed handler if successfully removed.  {@code null} otherwise.
      */
     @SuppressWarnings("unchecked")
     public <E extends Throwable> ExceptionHandler<? super E> removeExceptionHandler(Class<E> type) {
diff --git a/mina-core/src/main/java/org/apache/mina/handler/demux/MessageHandler.java b/mina-core/src/main/java/org/apache/mina/handler/demux/MessageHandler.java
index dec14fc31..139b7711b 100644
--- a/mina-core/src/main/java/org/apache/mina/handler/demux/MessageHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/handler/demux/MessageHandler.java
@@ -23,7 +23,7 @@ import org.apache.mina.core.session.IoSession;
 
 /**
  * A handler interface that {@link DemuxingIoHandler} forwards
- * <tt>messageReceived</tt> or <tt>messageSent</tt> events to.  You have to
+ * {@code messageReceived</tt> or <tt>messageSent} events to.  You have to
  * register your handler with the type of the message you want to get notified
  * using {@link DemuxingIoHandler#addReceivedMessageHandler(Class, MessageHandler)}
  * or {@link DemuxingIoHandler#addSentMessageHandler(Class, MessageHandler)}.
diff --git a/mina-core/src/main/java/org/apache/mina/handler/stream/StreamIoHandler.java b/mina-core/src/main/java/org/apache/mina/handler/stream/StreamIoHandler.java
index 724952444..58da7df31 100644
--- a/mina-core/src/main/java/org/apache/mina/handler/stream/StreamIoHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/handler/stream/StreamIoHandler.java
@@ -71,7 +71,7 @@ public abstract class StreamIoHandler extends IoHandlerAdapter {
 
     /**
      * @return read timeout in seconds.
-     * The default value is <tt>0</tt> (disabled).
+     * The default value is {@code 0} (disabled).
      */
     public int getReadTimeout() {
         return readTimeout;
@@ -79,7 +79,7 @@ public abstract class StreamIoHandler extends IoHandlerAdapter {
 
     /**
      * Sets read timeout in seconds.
-     * The default value is <tt>0</tt> (disabled).
+     * The default value is {@code 0} (disabled).
      * @param readTimeout The Read timeout
      */
     public void setReadTimeout(int readTimeout) {
@@ -88,7 +88,7 @@ public abstract class StreamIoHandler extends IoHandlerAdapter {
 
     /**
      * @return write timeout in seconds.
-     * The default value is <tt>0</tt> (disabled).
+     * The default value is {@code 0} (disabled).
      */
     public int getWriteTimeout() {
         return writeTimeout;
@@ -96,7 +96,7 @@ public abstract class StreamIoHandler extends IoHandlerAdapter {
 
     /**
      * Sets write timeout in seconds.
-     * The default value is <tt>0</tt> (disabled).
+     * The default value is {@code 0} (disabled).
      * 
      * @param writeTimeout The Write timeout
      */
diff --git a/mina-core/src/main/java/org/apache/mina/proxy/AbstractProxyLogicHandler.java b/mina-core/src/main/java/org/apache/mina/proxy/AbstractProxyLogicHandler.java
index 2c1a0b5be..6a8074e4f 100644
--- a/mina-core/src/main/java/org/apache/mina/proxy/AbstractProxyLogicHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/proxy/AbstractProxyLogicHandler.java
@@ -115,7 +115,7 @@ public abstract class AbstractProxyLogicHandler implements ProxyLogicHandler {
     }
 
     /**
-     * @return <tt>true</tt> if handshaking is complete and
+     * @return {@code true} if handshaking is complete and
      * data can be sent through the proxy.
      */
     public boolean isHandshakeComplete() {
diff --git a/mina-core/src/main/java/org/apache/mina/proxy/ProxyLogicHandler.java b/mina-core/src/main/java/org/apache/mina/proxy/ProxyLogicHandler.java
index b57db9749..24ade36d2 100644
--- a/mina-core/src/main/java/org/apache/mina/proxy/ProxyLogicHandler.java
+++ b/mina-core/src/main/java/org/apache/mina/proxy/ProxyLogicHandler.java
@@ -34,7 +34,7 @@ public interface ProxyLogicHandler {
     /**
      * Tests if handshake process is complete.
      * 
-     * @return <tt>true</tt> if handshaking is complete and
+     * @return {@code true} if handshaking is complete and
      * data can be sent through the proxy, false otherwise.
      */
     boolean isHandshakeComplete();
diff --git a/mina-core/src/main/java/org/apache/mina/proxy/utils/IoBufferDecoder.java b/mina-core/src/main/java/org/apache/mina/proxy/utils/IoBufferDecoder.java
index e7a8da4b2..47fcfc45b 100644
--- a/mina-core/src/main/java/org/apache/mina/proxy/utils/IoBufferDecoder.java
+++ b/mina-core/src/main/java/org/apache/mina/proxy/utils/IoBufferDecoder.java
@@ -140,7 +140,7 @@ public class IoBufferDecoder {
     private DecodingContext ctx = new DecodingContext();
 
     /**
-     * Creates a new instance that uses specified <tt>delimiter</tt> byte array as a
+     * Creates a new instance that uses specified {@code delimiter} byte array as a
      * message delimiter.
      * 
      * @param delimiter an array of characters which delimits messages
@@ -150,7 +150,7 @@ public class IoBufferDecoder {
     }
 
     /**
-     * Creates a new instance that will read messages of <tt>contentLength</tt> bytes.
+     * Creates a new instance that will read messages of {@code contentLength} bytes.
      * 
      * @param contentLength the exact length to read
      */
@@ -162,7 +162,7 @@ public class IoBufferDecoder {
      * Sets the the length of the content line to be decoded.
      * When set, it overrides the dynamic delimiter setting and content length 
      * method will be used for decoding on the next decodeOnce call.
-     * The default value is <tt>-1</tt>.
+     * The default value is {@code -1}.
      * 
      * @param contentLength the content length to match
      * @param resetMatchCount delimiter matching is reset if true
@@ -181,7 +181,7 @@ public class IoBufferDecoder {
     /**
      * Dynamically sets a new delimiter. Next time 
      * {@link #decodeFully(IoBuffer)} will be called it will use the new 
-     * delimiter. Delimiter matching is reset only if <tt>resetMatchCount</tt> is true but 
+     * delimiter. Delimiter matching is reset only if {@code resetMatchCount} is true but 
      * decoding will continue from current position.
      * 
      * NB : Delimiter {@link LineDelimiter#AUTO} is not allowed.
diff --git a/mina-core/src/main/java/org/apache/mina/proxy/utils/StringUtilities.java b/mina-core/src/main/java/org/apache/mina/proxy/utils/StringUtilities.java
index efd0b4da2..18b3cbb5e 100644
--- a/mina-core/src/main/java/org/apache/mina/proxy/utils/StringUtilities.java
+++ b/mina-core/src/main/java/org/apache/mina/proxy/utils/StringUtilities.java
@@ -242,7 +242,7 @@ public class StringUtilities {
      * Note that we're checking individual bytes instead of CRLF
      * 
      * @param b the byte to check
-     * @return <tt>true</tt> if it's a linear white space
+     * @return {@code true} if it's a linear white space
      */
     public static boolean isLws(byte b) {
         switch (b) {
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractDatagramSessionConfig.java b/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractDatagramSessionConfig.java
index 0ef1b9f4b..7b465051e 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractDatagramSessionConfig.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractDatagramSessionConfig.java
@@ -79,10 +79,10 @@ public abstract class AbstractDatagramSessionConfig extends AbstractIoSessionCon
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>broadcast</tt> property
+     * @return {@code true</tt> if and only if the <tt>broadcast} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isBroadcastChanged() {
@@ -90,10 +90,10 @@ public abstract class AbstractDatagramSessionConfig extends AbstractIoSessionCon
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>receiveBufferSize</tt> property
+     * @return {@code true</tt> if and only if the <tt>receiveBufferSize} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isReceiveBufferSizeChanged() {
@@ -101,10 +101,10 @@ public abstract class AbstractDatagramSessionConfig extends AbstractIoSessionCon
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>reuseAddress</tt> property
+     * @return {@code true</tt> if and only if the <tt>reuseAddress} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isReuseAddressChanged() {
@@ -112,10 +112,10 @@ public abstract class AbstractDatagramSessionConfig extends AbstractIoSessionCon
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>sendBufferSize</tt> property
+     * @return {@code true</tt> if and only if the <tt>sendBufferSize} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isSendBufferSizeChanged() {
@@ -123,10 +123,10 @@ public abstract class AbstractDatagramSessionConfig extends AbstractIoSessionCon
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>trafficClass</tt> property
+     * @return {@code true</tt> if and only if the <tt>trafficClass} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isTrafficClassChanged() {
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractSocketSessionConfig.java b/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractSocketSessionConfig.java
index fcfc96f40..b87b979e2 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractSocketSessionConfig.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/AbstractSocketSessionConfig.java
@@ -82,10 +82,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>keepAlive</tt> property
+     * @return {@code true</tt> if and only if the <tt>keepAlive} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isKeepAliveChanged() {
@@ -93,10 +93,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>oobInline</tt> property
+     * @return {@code true</tt> if and only if the <tt>oobInline} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isOobInlineChanged() {
@@ -104,10 +104,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>receiveBufferSize</tt> property
+     * @return {@code true</tt> if and only if the <tt>receiveBufferSize} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isReceiveBufferSizeChanged() {
@@ -115,10 +115,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>reuseAddress</tt> property
+     * @return {@code true</tt> if and only if the <tt>reuseAddress} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isReuseAddressChanged() {
@@ -126,10 +126,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>sendBufferSize</tt> property
+     * @return {@code true</tt> if and only if the <tt>sendBufferSize} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isSendBufferSizeChanged() {
@@ -137,10 +137,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>soLinger</tt> property
+     * @return {@code true</tt> if and only if the <tt>soLinger} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isSoLingerChanged() {
@@ -148,10 +148,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>tcpNoDelay</tt> property
+     * @return {@code true</tt> if and only if the <tt>tcpNoDelay} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isTcpNoDelayChanged() {
@@ -159,10 +159,10 @@ public abstract class AbstractSocketSessionConfig extends AbstractIoSessionConfi
     }
 
     /**
-     * @return <tt>true</tt> if and only if the <tt>trafficClass</tt> property
+     * @return {@code true</tt> if and only if the <tt>trafficClass} property
      * has been changed by its setter method.  The system call related with
-     * the property is made only when this method returns <tt>true</tt>.  By
-     * default, this method always returns <tt>true</tt> to simplify implementation
+     * the property is made only when this method returns {@code true}.  By
+     * default, this method always returns {@code true} to simplify implementation
      * of subclasses, but overriding the default behavior is always encouraged.
      */
     protected boolean isTrafficClassChanged() {
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramAcceptor.java b/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramAcceptor.java
index bc0c6872f..4756c0926 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramAcceptor.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramAcceptor.java
@@ -66,7 +66,7 @@ public interface DatagramAcceptor extends IoAcceptor {
     /**
      * Sets the {@link IoSessionRecycler} for this service.
      *
-     * @param sessionRecycler <tt>null</tt> to use the default recycler
+     * @param sessionRecycler {@code null} to use the default recycler
      */
     void setSessionRecycler(IoSessionRecycler sessionRecycler);
 
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramSessionConfig.java b/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramSessionConfig.java
index a17d29532..47dab2e53 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramSessionConfig.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/DatagramSessionConfig.java
@@ -33,7 +33,7 @@ public interface DatagramSessionConfig extends IoSessionConfig {
     /**
      * @see DatagramSocket#getBroadcast()
      * 
-     * @return <tt>true</tt> if SO_BROADCAST is enabled.
+     * @return {@code true} if SO_BROADCAST is enabled.
      */
     boolean isBroadcast();
 
@@ -47,7 +47,7 @@ public interface DatagramSessionConfig extends IoSessionConfig {
     /**
      * @see DatagramSocket#getReuseAddress()
      * 
-     * @return <tt>true</tt> if SO_REUSEADDR is enabled.
+     * @return {@code true} if SO_REUSEADDR is enabled.
      */
     boolean isReuseAddress();
 
@@ -113,7 +113,7 @@ public interface DatagramSessionConfig extends IoSessionConfig {
      * Sets if the session should be closed if an {@link PortUnreachableException} 
      * occurs.
      * 
-     * @param closeOnPortUnreachable <tt>true</tt> if we should close if the port is unreachable
+     * @param closeOnPortUnreachable {@code true} if we should close if the port is unreachable
      */
     void setCloseOnPortUnreachable(boolean closeOnPortUnreachable);
 }
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/SocketAcceptor.java b/mina-core/src/main/java/org/apache/mina/transport/socket/SocketAcceptor.java
index b21f79c8b..9f976c0cc 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/SocketAcceptor.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/SocketAcceptor.java
@@ -61,14 +61,14 @@ public interface SocketAcceptor extends IoAcceptor {
     /**
      * @see ServerSocket#getReuseAddress()
      * 
-     * @return <tt>true</tt> if the <tt>SO_REUSEADDR</tt> is enabled
+     * @return {@code true</tt> if the <tt>SO_REUSEADDR} is enabled
      */
     boolean isReuseAddress();
 
     /**
      * @see ServerSocket#setReuseAddress(boolean)
      * 
-     * @param reuseAddress tells if the <tt>SO_REUSEADDR</tt> is to be enabled
+     * @param reuseAddress tells if the {@code SO_REUSEADDR} is to be enabled
      */
     void setReuseAddress(boolean reuseAddress);
 
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/SocketSessionConfig.java b/mina-core/src/main/java/org/apache/mina/transport/socket/SocketSessionConfig.java
index 24bc41e79..bdcc0284f 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/SocketSessionConfig.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/SocketSessionConfig.java
@@ -32,7 +32,7 @@ public interface SocketSessionConfig extends IoSessionConfig {
     /**
      * @see Socket#getReuseAddress()
      * 
-     * @return <tt>true</tt> if SO_REUSEADDR is enabled.
+     * @return {@code true} if SO_REUSEADDR is enabled.
      */
     boolean isReuseAddress();
 
@@ -81,55 +81,55 @@ public interface SocketSessionConfig extends IoSessionConfig {
     /**
      * @see Socket#setTrafficClass(int)
      * 
-     * @param trafficClass The traffic class to set, one of <tt>IPTOS_LOWCOST</tt> (0x02)
-     * <tt>IPTOS_RELIABILITY</tt> (0x04), <tt>IPTOS_THROUGHPUT</tt> (0x08) or <tt>IPTOS_LOWDELAY</tt> (0x10)
+     * @param trafficClass The traffic class to set, one of {@code IPTOS_LOWCOST} (0x02)
+     * {@code IPTOS_RELIABILITY</tt> (0x04), <tt>IPTOS_THROUGHPUT</tt> (0x08) or <tt>IPTOS_LOWDELAY} (0x10)
      */
     void setTrafficClass(int trafficClass);
 
     /**
      * @see Socket#getKeepAlive()
      * 
-     * @return <tt>true</tt> if <tt>SO_KEEPALIVE</tt> is enabled.
+     * @return {@code true</tt> if <tt>SO_KEEPALIVE} is enabled.
      */
     boolean isKeepAlive();
 
     /**
      * @see Socket#setKeepAlive(boolean)
      * 
-     * @param keepAlive if <tt>SO_KEEPALIVE</tt> is to be enabled
+     * @param keepAlive if {@code SO_KEEPALIVE} is to be enabled
      */
     void setKeepAlive(boolean keepAlive);
 
     /**
      * @see Socket#getOOBInline()
      * 
-     * @return <tt>true</tt> if <tt>SO_OOBINLINE</tt> is enabled.
+     * @return {@code true</tt> if <tt>SO_OOBINLINE} is enabled.
      */
     boolean isOobInline();
 
     /**
      * @see Socket#setOOBInline(boolean)
      * 
-     * @param oobInline if <tt>SO_OOBINLINE</tt> is to be enabled
+     * @param oobInline if {@code SO_OOBINLINE} is to be enabled
      */
     void setOobInline(boolean oobInline);
 
     /**
-     * Please note that enabling <tt>SO_LINGER</tt> in Java NIO can result
+     * Please note that enabling {@code SO_LINGER} in Java NIO can result
      * in platform-dependent behavior and unexpected blocking of I/O thread.
      *
      * @see Socket#getSoLinger()
      * @see <a href="http://bugs.sun.com/bugdatabase/view_bug.do?bug_id=6179351">Sun Bug Database</a>
      * 
-     * @return The value for <tt>SO_LINGER</tt>
+     * @return The value for {@code SO_LINGER}
      */
     int getSoLinger();
 
     /**
-     * Please note that enabling <tt>SO_LINGER</tt> in Java NIO can result
+     * Please note that enabling {@code SO_LINGER} in Java NIO can result
      * in platform-dependent behavior and unexpected blocking of I/O thread.
      *
-     * @param soLinger Please specify a negative value to disable <tt>SO_LINGER</tt>.
+     * @param soLinger Please specify a negative value to disable {@code SO_LINGER}.
      *
      * @see Socket#setSoLinger(boolean, int)
      * @see <a href="http://bugs.sun.com/bugdatabase/view_bug.do?bug_id=6179351">Sun Bug Database</a>
@@ -139,14 +139,14 @@ public interface SocketSessionConfig extends IoSessionConfig {
     /**
      * @see Socket#getTcpNoDelay()
      * 
-     * @return <tt>true</tt> if <tt>TCP_NODELAY</tt> is enabled.
+     * @return {@code true</tt> if <tt>TCP_NODELAY} is enabled.
      */
     boolean isTcpNoDelay();
 
     /**
      * @see Socket#setTcpNoDelay(boolean)
      * 
-     * @param tcpNoDelay <tt>true</tt> if <tt>TCP_NODELAY</tt> is to be enabled
+     * @param tcpNoDelay {@code true</tt> if <tt>TCP_NODELAY} is to be enabled
      */
     void setTcpNoDelay(boolean tcpNoDelay);
 }
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java b/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java
index 94df01e46..e676e6917 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java
@@ -87,7 +87,7 @@ class NioDatagramSessionConfig extends AbstractDatagramSessionConfig {
     /**
      * Tells if SO_BROADCAST is enabled.
      * 
-     * @return <tt>true</tt> if SO_BROADCAST is enabled
+     * @return {@code true} if SO_BROADCAST is enabled
      * @throws RuntimeIoException If the socket is closed or if we get an
      * {@link SocketException} 
      */
@@ -140,7 +140,7 @@ class NioDatagramSessionConfig extends AbstractDatagramSessionConfig {
     /**
      * Tells if SO_REUSEADDR is enabled.
      * 
-     * @return <tt>true</tt> if SO_REUSEADDR is enabled
+     * @return {@code true} if SO_REUSEADDR is enabled
      * @throws RuntimeIoException If the socket is closed or if we get an
      * {@link SocketException} 
      */
diff --git a/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioSocketAcceptor.java b/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioSocketAcceptor.java
index 836326609..dcf576091 100644
--- a/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioSocketAcceptor.java
+++ b/mina-core/src/main/java/org/apache/mina/transport/socket/nio/NioSocketAcceptor.java
@@ -396,7 +396,7 @@ implements SocketAcceptor {
 
         /**
          * Tells if there are more SockectChannel left in the iterator
-         * @return <tt>true</tt> if there is at least one more
+         * @return {@code true} if there is at least one more
          * SockectChannel object to read
          */
         @Override
diff --git a/mina-core/src/main/java/org/apache/mina/util/AvailablePortFinder.java b/mina-core/src/main/java/org/apache/mina/util/AvailablePortFinder.java
index 4147066b1..9d44431bb 100644
--- a/mina-core/src/main/java/org/apache/mina/util/AvailablePortFinder.java
+++ b/mina-core/src/main/java/org/apache/mina/util/AvailablePortFinder.java
@@ -99,7 +99,7 @@ public class AvailablePortFinder {
      * Checks to see if a specific port is available.
      *
      * @param port the port to check for availability
-     * @return <tt>true</tt> if the port is available
+     * @return {@code true} if the port is available
      */
     public static boolean available(int port) {
         if (port < MIN_PORT_NUMBER || port > MAX_PORT_NUMBER) {
diff --git a/mina-core/src/main/java/org/apache/mina/util/ExceptionMonitor.java b/mina-core/src/main/java/org/apache/mina/util/ExceptionMonitor.java
index da5b644bb..e002dcca0 100644
--- a/mina-core/src/main/java/org/apache/mina/util/ExceptionMonitor.java
+++ b/mina-core/src/main/java/org/apache/mina/util/ExceptionMonitor.java
@@ -25,7 +25,7 @@ package org.apache.mina.util;
  * <p>
  * You can monitor any uncaught exceptions by setting {@link ExceptionMonitor}
  * by calling {@link #setInstance(ExceptionMonitor)}.  The default
- * monitor logs all caught exceptions in <tt>WARN</tt> level using
+ * monitor logs all caught exceptions in {@code WARN} level using
  * SLF4J.
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>
@@ -47,7 +47,7 @@ public abstract class ExceptionMonitor {
      * the default monitor will be set.
      *
      * @param monitor A new instance of {@link DefaultExceptionMonitor} is set
-     *                if <tt>null</tt> is specified.
+     *                if {@code null} is specified.
      */
     public static void setInstance(ExceptionMonitor monitor) {
         if (monitor == null) {
diff --git a/mina-core/src/main/java/org/apache/mina/util/LazyInitializedCacheMap.java b/mina-core/src/main/java/org/apache/mina/util/LazyInitializedCacheMap.java
index d38fc61b2..24b36b4e4 100644
--- a/mina-core/src/main/java/org/apache/mina/util/LazyInitializedCacheMap.java
+++ b/mina-core/src/main/java/org/apache/mina/util/LazyInitializedCacheMap.java
@@ -132,7 +132,7 @@ public class LazyInitializedCacheMap<K, V> implements Map<K, V> {
      * @param value a lazy initialized value object.
      * 
      * @return the previous value associated with the specified key,
-     *         or <tt>null</tt> if there was no mapping for the key
+     *         or {@code null} if there was no mapping for the key
      */
     public V putIfAbsent(K key, LazyInitializer<V> value) {
         LazyInitializer<V> v = cache.get(key);
diff --git a/mina-core/src/main/java/org/apache/mina/util/byteaccess/ByteArray.java b/mina-core/src/main/java/org/apache/mina/util/byteaccess/ByteArray.java
index f81357797..0a4ea6260 100644
--- a/mina-core/src/main/java/org/apache/mina/util/byteaccess/ByteArray.java
+++ b/mina-core/src/main/java/org/apache/mina/util/byteaccess/ByteArray.java
@@ -83,7 +83,7 @@ public interface ByteArray extends IoAbsoluteReader, IoAbsoluteWriter {
      * index.
      * 
      * @param other The ByteArray we want to compare with
-     * @return <tt>true</tt> if both ByteArray are equals
+     * @return {@code true} if both ByteArray are equals
      */
     @Override
     boolean equals(Object other);
diff --git a/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoAbsoluteReader.java b/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoAbsoluteReader.java
index c1c17e18f..f27d314c7 100644
--- a/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoAbsoluteReader.java
+++ b/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoAbsoluteReader.java
@@ -61,12 +61,12 @@ public interface IoAbsoluteReader {
 
     /**
      * @param index The starting position
-     * @return a <tt>byte</tt> from the given index.
+     * @return a {@code byte} from the given index.
      */
     byte get(int index);
 
     /**
-     * Gets enough bytes to fill the <tt>IoBuffer</tt> from the given index.
+     * Gets enough bytes to fill the {@code IoBuffer} from the given index.
      * 
      * @param index The starting position
      * @param bb The IoBuffer that will be filled with the bytes
@@ -75,37 +75,37 @@ public interface IoAbsoluteReader {
 
     /**
      * @param index The starting position
-     * @return a <tt>short</tt> from the given index.
+     * @return a {@code short} from the given index.
      */
     short getShort(int index);
 
     /**
      * @param index The starting position
-     * @return an <tt>int</tt> from the given index.
+     * @return an {@code int} from the given index.
      */
     int getInt(int index);
 
     /**
      * @param index The starting position
-     * @return a <tt>long</tt> from the given index.
+     * @return a {@code long} from the given index.
      */
     long getLong(int index);
 
     /**
      * @param index The starting position
-     * @return a <tt>float</tt> from the given index.
+     * @return a {@code float} from the given index.
      */
     float getFloat(int index);
 
     /**
      * @param index The starting position
-     * @return a <tt>double</tt> from the given index.
+     * @return a {@code double} from the given index.
      */
     double getDouble(int index);
 
     /**
      * @param index The starting position
-     * @return a <tt>char</tt> from the given index.
+     * @return a {@code char} from the given index.
      */
     char getChar(int index);
 }
diff --git a/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoRelativeReader.java b/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoRelativeReader.java
index 51aab6281..1c72a088d 100644
--- a/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoRelativeReader.java
+++ b/mina-core/src/main/java/org/apache/mina/util/byteaccess/IoRelativeReader.java
@@ -38,7 +38,7 @@ public interface IoRelativeReader {
     /**
      * Checks if there are any remaining bytes that can be read.
      * 
-     * @return <tt>true</tt> if there are some remaining bytes in the buffer
+     * @return {@code true} if there are some remaining bytes in the buffer
      */
     boolean hasRemaining();
 
diff --git a/mina-example/src/main/java/org/apache/mina/example/sumup/codec/AbstractMessageDecoder.java b/mina-example/src/main/java/org/apache/mina/example/sumup/codec/AbstractMessageDecoder.java
index 779327a60..5330ebc41 100644
--- a/mina-example/src/main/java/org/apache/mina/example/sumup/codec/AbstractMessageDecoder.java
+++ b/mina-example/src/main/java/org/apache/mina/example/sumup/codec/AbstractMessageDecoder.java
@@ -84,7 +84,7 @@ public abstract class AbstractMessageDecoder implements MessageDecoder {
     /**
      * @param session The current session
      * @param in The incoming buffer
-     * @return <tt>null</tt> if the whole body is not read yet
+     * @return {@code null} if the whole body is not read yet
      */
     protected abstract AbstractMessage decodeBody(IoSession session,
             IoBuffer in);
diff --git a/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/CompressionFilter.java b/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/CompressionFilter.java
index 60252d91e..b74271a7f 100644
--- a/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/CompressionFilter.java
+++ b/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/CompressionFilter.java
@@ -34,7 +34,7 @@ import org.apache.mina.core.write.WriteRequest;
  * <a href="http://www.jcraft.com/jzlib/">JZlib</a>.
  * Support for the LZW (DLCZ) algorithm is also planned.
  * <p>
- * This filter only supports compression using the <tt>PARTIAL FLUSH</tt> method,
+ * This filter only supports compression using the {@code PARTIAL FLUSH} method,
  * since that is the only method useful when doing stream level compression.
  * <p>
  * This filter supports compression/decompression of the input and output
@@ -109,7 +109,7 @@ public class CompressionFilter extends IoFilterAdapter {
 
     /**
      * Creates a new instance which compresses outboud data and decompresses
-     * inbound data with the specified <tt>compressionLevel</tt>.
+     * inbound data with the specified {@code compressionLevel}.
      *
      * @param compressionLevel the level of compression to be used. Must
      *                         be one of {@link #COMPRESSION_DEFAULT},
@@ -124,8 +124,8 @@ public class CompressionFilter extends IoFilterAdapter {
     /**
      * Creates a new instance.
      *
-     * @param compressInbound <tt>true</tt> if data read is to be decompressed
-     * @param compressOutbound <tt>true</tt> if data written is to be compressed
+     * @param compressInbound {@code true} if data read is to be decompressed
+     * @param compressOutbound {@code true} if data written is to be compressed
      * @param compressionLevel the level of compression to be used. Must
      *                         be one of {@link #COMPRESSION_DEFAULT},
      *                         {@link #COMPRESSION_MAX},
@@ -216,7 +216,7 @@ public class CompressionFilter extends IoFilterAdapter {
     }
 
     /**
-     * @return <tt>true</tt> if incoming data is being compressed.
+     * @return {@code true} if incoming data is being compressed.
      */
     public boolean isCompressInbound() {
         return compressInbound;
@@ -225,14 +225,14 @@ public class CompressionFilter extends IoFilterAdapter {
     /**
      * Sets if incoming data has to be compressed.
      * 
-     * @param compressInbound <tt>true</tt> if the incoming data has to be compressed
+     * @param compressInbound {@code true} if the incoming data has to be compressed
      */
     public void setCompressInbound(boolean compressInbound) {
         this.compressInbound = compressInbound;
     }
 
     /**
-     * @return <tt>true</tt> if the filter is compressing data being written.
+     * @return {@code true} if the filter is compressing data being written.
      */
     public boolean isCompressOutbound() {
         return compressOutbound;
@@ -241,7 +241,7 @@ public class CompressionFilter extends IoFilterAdapter {
     /**
      * Set if outgoing data has to be compressed.
      * 
-     * @param compressOutbound <tt>true</tt> if the outgoing data has to be compressed
+     * @param compressOutbound {@code true} if the outgoing data has to be compressed
      */
     public void setCompressOutbound(boolean compressOutbound) {
         this.compressOutbound = compressOutbound;
diff --git a/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/Zlib.java b/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/Zlib.java
index 3908b9183..7bb09a354 100644
--- a/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/Zlib.java
+++ b/mina-filter-compression/src/main/java/org/apache/mina/filter/compression/Zlib.java
@@ -29,7 +29,7 @@ import com.jcraft.jzlib.ZStream;
 /**
  * A helper class for interfacing with the JZlib library. This class acts both
  * as a compressor and decompressor, but only as one at a time.  The only
- * flush method supported is <tt>Z_SYNC_FLUSH</tt> also known as <tt>Z_PARTIAL_FLUSH</tt>
+ * flush method supported is {@code Z_SYNC_FLUSH</tt> also known as <tt>Z_PARTIAL_FLUSH}
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>
  */
@@ -65,10 +65,10 @@ class Zlib {
      * Creates an instance of the ZLib class.
      * 
      * @param compressionLevel the level of compression that should be used. One of
-     * <tt>COMPRESSION_MAX</tt>, <tt>COMPRESSION_MIN</tt>,
-     * <tt>COMPRESSION_NONE</tt> or <tt>COMPRESSION_DEFAULT</tt>
+     * {@code COMPRESSION_MAX</tt>, <tt>COMPRESSION_MIN},
+     * {@code COMPRESSION_NONE</tt> or <tt>COMPRESSION_DEFAULT}
      * @param mode the mode in which the instance will operate. Can be either
-     * of <tt>MODE_DEFLATER</tt> or <tt>MODE_INFLATER</tt>
+     * of {@code MODE_DEFLATER</tt> or <tt>MODE_INFLATER}
      * @throws IllegalArgumentException if the mode is incorrect
      */
     public Zlib(int compressionLevel, int mode) {
diff --git a/mina-http/src/main/java/org/apache/mina/http/api/HttpMessage.java b/mina-http/src/main/java/org/apache/mina/http/api/HttpMessage.java
index c215beda8..8a5a23dc1 100644
--- a/mina-http/src/main/java/org/apache/mina/http/api/HttpMessage.java
+++ b/mina-http/src/main/java/org/apache/mina/http/api/HttpMessage.java
@@ -37,14 +37,14 @@ public interface HttpMessage {
     HttpVersion getProtocolVersion();
 
     /**
-     * Gets the <tt>Content-Type</tt> header of the message.
+     * Gets the {@code Content-Type} header of the message.
      * 
      * @return The content type.
      */
     String getContentType();
 
     /**
-     * @return <tt>true</tt> if this message enables keep-alive connection.
+     * @return {@code true} if this message enables keep-alive connection.
      */
     boolean isKeepAlive();
 
@@ -61,7 +61,7 @@ public interface HttpMessage {
      * Tells if the message contains some header
      * 
      * @param name the Header's name we are looking for
-     * @return <tt>true</tt> if the HTTP header with the specified name exists in this request.
+     * @return {@code true} if the HTTP header with the specified name exists in this request.
      */
     boolean containsHeader(String name);
 
diff --git a/mina-http/src/main/java/org/apache/mina/http/api/HttpRequest.java b/mina-http/src/main/java/org/apache/mina/http/api/HttpRequest.java
index 4976907f7..31d7111fa 100644
--- a/mina-http/src/main/java/org/apache/mina/http/api/HttpRequest.java
+++ b/mina-http/src/main/java/org/apache/mina/http/api/HttpRequest.java
@@ -34,7 +34,7 @@ public interface HttpRequest extends HttpMessage {
      * Determines whether this request contains at least one parameter with the specified name
      * 
      * @param name The parameter name
-     * @return <tt>true</tt> if this request contains at least one parameter with the specified name
+     * @return {@code true} if this request contains at least one parameter with the specified name
      */
     boolean containsParameter(String name);
 
diff --git a/mina-integration-beans/src/main/java/org/apache/mina/integration/beans/NullEditor.java b/mina-integration-beans/src/main/java/org/apache/mina/integration/beans/NullEditor.java
index 0b9d72195..831e951fb 100644
--- a/mina-integration-beans/src/main/java/org/apache/mina/integration/beans/NullEditor.java
+++ b/mina-integration-beans/src/main/java/org/apache/mina/integration/beans/NullEditor.java
@@ -22,7 +22,7 @@ package org.apache.mina.integration.beans;
 import java.beans.PropertyEditor;
 
 /**
- * A dummy {@link PropertyEditor} for <tt>null</tt>.
+ * A dummy {@link PropertyEditor} for {@code null}.
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>
  */
diff --git a/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/IoSessionFinder.java b/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/IoSessionFinder.java
index 7f95bc32a..5d7cd13f4 100644
--- a/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/IoSessionFinder.java
+++ b/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/IoSessionFinder.java
@@ -41,7 +41,7 @@ public class IoSessionFinder {
 
     /**
      * Creates a new instance with the specified OGNL expression that returns
-     * a boolean value (e.g. <tt>"id == 0x12345678"</tt>).
+     * a boolean value (e.g. {@code "id == 0x12345678"}).
      * 
      * @param query The OGNL expression 
      */
diff --git a/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/PropertyTypeConverter.java b/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/PropertyTypeConverter.java
index b98e4c94c..c07e768e8 100644
--- a/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/PropertyTypeConverter.java
+++ b/mina-integration-ognl/src/main/java/org/apache/mina/integration/ognl/PropertyTypeConverter.java
@@ -28,7 +28,7 @@ import org.apache.mina.integration.beans.PropertyEditorFactory;
 /**
  * {@link PropertyEditor}-based implementation of OGNL {@link TypeConverter}.
  * This converter uses the {@link PropertyEditor} implementations in
- * <tt>mina-integration-beans</tt> module to perform conversion.  To use this
+ * {@code mina-integration-beans} module to perform conversion.  To use this
  * converter:
  * <pre><code>
  * OgnlContext ctx = Ognl.createDefaultContext(root);
diff --git a/mina-statemachine/src/main/java/org/apache/mina/statemachine/StateMachineProxyBuilder.java b/mina-statemachine/src/main/java/org/apache/mina/statemachine/StateMachineProxyBuilder.java
index 5e7d40038..77132147a 100644
--- a/mina-statemachine/src/main/java/org/apache/mina/statemachine/StateMachineProxyBuilder.java
+++ b/mina-statemachine/src/main/java/org/apache/mina/statemachine/StateMachineProxyBuilder.java
@@ -123,7 +123,7 @@ public class StateMachineProxyBuilder {
      * an exception or be silently ignored. The default is to raise an 
      * exception. 
      * 
-     * @param b <tt>true</tt> to ignore context lookup failures.
+     * @param b {@code true} to ignore context lookup failures.
      * @return this {@link StateMachineProxyBuilder} for method chaining. 
      */
     public StateMachineProxyBuilder setIgnoreUnhandledEvents(boolean b) {
@@ -136,7 +136,7 @@ public class StateMachineProxyBuilder {
      * to a method call on the proxy produced by this builder will raise an
      * exception or be silently ignored. The default is to raise an exception.
      * 
-     * @param b <tt>true</tt> to ignore context lookup failures.
+     * @param b {@code true} to ignore context lookup failures.
      * @return this {@link StateMachineProxyBuilder} for method chaining. 
      */
     public StateMachineProxyBuilder setIgnoreStateContextLookupFailure(boolean b) {
diff --git a/mina-statemachine/src/main/java/org/apache/mina/statemachine/context/AbstractStateContextLookup.java b/mina-statemachine/src/main/java/org/apache/mina/statemachine/context/AbstractStateContextLookup.java
index cebfd1813..42cf1b13d 100644
--- a/mina-statemachine/src/main/java/org/apache/mina/statemachine/context/AbstractStateContextLookup.java
+++ b/mina-statemachine/src/main/java/org/apache/mina/statemachine/context/AbstractStateContextLookup.java
@@ -23,7 +23,7 @@ package org.apache.mina.statemachine.context;
  * Abstract {@link StateContextLookup} implementation. The {@link #lookup(Object[])}
  * method will loop through the event arguments and call the supports(Class)
  * method for each of them. The first argument that this method returns 
- * <tt>true</tt> for will be passed to the abstract lookup(Object)
+ * {@code true} for will be passed to the abstract lookup(Object)
  * method which should try to extract a {@link StateContext} from the argument.
  * If none is found a new {@link StateContext} will be created and stored in the
  * event argument using the store(Object, StateContext) method.
@@ -63,7 +63,7 @@ public abstract class AbstractStateContextLookup implements StateContextLookup {
     /**
      * Extracts a {@link StateContext} from the specified event argument which
      * is an instance of a class {@link #supports(Class)} returns 
-     * <tt>true</tt> for.
+     * {@code true} for.
      * 
      * @param eventArg the event argument.
      * @return the {@link StateContext}.
@@ -73,7 +73,7 @@ public abstract class AbstractStateContextLookup implements StateContextLookup {
     /**
      * Stores a new {@link StateContext} in the specified event argument which
      * is an instance of a class {@link #supports(Class)} returns 
-     * <tt>true</tt> for.
+     * {@code true} for.
      * 
      * @param eventArg the event argument.
      * @param context the {@link StateContext} to be stored.
@@ -81,12 +81,12 @@ public abstract class AbstractStateContextLookup implements StateContextLookup {
     protected abstract void store(Object eventArg, StateContext context);
 
     /**
-     * Must return <tt>true</tt> for any {@link Class} that this
+     * Must return {@code true} for any {@link Class} that this
      * {@link StateContextLookup} can use to store and lookup 
      * {@link StateContext} objects.
      * 
      * @param c the class.
-     * @return <tt>true</tt> or <tt>false</tt>.
+     * @return {@code true</tt> or <tt>false}.
      */
     protected abstract boolean supports(Class<?> c);
 }
diff --git a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractSelfTransition.java b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractSelfTransition.java
index a28441302..85a82927c 100644
--- a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractSelfTransition.java
+++ b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractSelfTransition.java
@@ -41,7 +41,7 @@ public abstract class AbstractSelfTransition implements SelfTransition {
      * 
      * @param stateContext the context in which the execution should occur
      * @param state the current state
-     * @return <tt>true</tt> if the {@link SelfTransition} has been executed
+     * @return {@code true} if the {@link SelfTransition} has been executed
      *         successfully
      */
     protected abstract boolean doExecute(StateContext stateContext, State state);
diff --git a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractTransition.java b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractTransition.java
index df1ae695d..3f98490f1 100644
--- a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractTransition.java
+++ b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/AbstractTransition.java
@@ -106,9 +106,9 @@ public abstract class AbstractTransition implements Transition {
      * already made sure that that is the case.
      * 
      * @param event the current {@link Event}.
-     * @return <tt>true</tt> if the {@link Transition} has been executed 
+     * @return {@code true} if the {@link Transition} has been executed 
      *         successfully and the {@link StateMachine} should move to the 
-     *         next {@link State}. <tt>false</tt> otherwise.
+     *         next {@link State}. {@code false} otherwise.
      */
     protected abstract boolean doExecute(Event event);
     
diff --git a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/SelfTransition.java b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/SelfTransition.java
index 7df1dd493..68c16633a 100644
--- a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/SelfTransition.java
+++ b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/SelfTransition.java
@@ -34,7 +34,7 @@ public interface SelfTransition {
      * 
      * @param stateContext The context in which we are executing the transition
      * @param state The current state
-     * @return <tt>true</tt> if the execution succeeded, <tt>false</tt> otherwise.
+     * @return {@code true</tt> if the execution succeeded, <tt>false} otherwise.
      */
     boolean execute(StateContext stateContext, State state);
 }
diff --git a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/Transition.java b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/Transition.java
index c7f1abfde..26ab45270 100644
--- a/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/Transition.java
+++ b/mina-statemachine/src/main/java/org/apache/mina/statemachine/transition/Transition.java
@@ -49,22 +49,22 @@ public interface Transition {
      * Executes this {@link Transition}. It is the responsibility of this
      * {@link Transition} to determine whether it actually applies for the
      * specified {@link Event}. If this {@link Transition} doesn't apply
-     * nothing should be executed and <tt>false</tt> must be returned.
+     * nothing should be executed and {@code false} must be returned.
      * The method will accept any {@link Event} if it is registered with the 
      * wild card event ID ('*'), and the event ID it is declared for (ie,
      * the event ID that has been passed as a parameter to this transition 
      * constructor.)
      * 
      * @param event the current {@link Event}.
-     * @return <tt>true</tt> if the {@link Transition} was executed, 
-     *         <tt>false</tt> otherwise.
+     * @return {@code true} if the {@link Transition} was executed, 
+     *         {@code false} otherwise.
      */
     boolean execute(Event event);
 
     /**
      * @return the {@link State} which the {@link StateMachine} should move to 
      * if this {@link Transition} is taken and {@link #execute(Event)} returns
-     * <tt>true</tt>. <code>null</code> if this {@link Transition} is a loopback 
+     * {@code true}. <code>null</code> if this {@link Transition} is a loopback 
      * {@link Transition}.
      */
     State getNextState();
diff --git a/mina-transport-serial/src/main/java/org/apache/mina/transport/serial/SerialAddressEditor.java b/mina-transport-serial/src/main/java/org/apache/mina/transport/serial/SerialAddressEditor.java
index 39698db07..eeeaa899d 100644
--- a/mina-transport-serial/src/main/java/org/apache/mina/transport/serial/SerialAddressEditor.java
+++ b/mina-transport-serial/src/main/java/org/apache/mina/transport/serial/SerialAddressEditor.java
@@ -30,7 +30,7 @@ import org.apache.mina.transport.serial.SerialAddress.StopBits;
 /**
  * A {@link PropertyEditor} which converts a {@link String} into a
  * {@link SerialAddress} and vice versa.  Valid values specify 6 address
- * components separated by colon (e.g. <tt>COM1:9600:7:1:even:rtscts-in</tt>);
+ * components separated by colon (e.g. {@code COM1:9600:7:1:even:rtscts-in});
  * port name, bauds, data bits, stop bits, parity and flow control respectively.
  *
  * @author <a href="http://mina.apache.org">Apache MINA Project</a>