You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flex.apache.org by cd...@apache.org on 2015/07/30 13:19:40 UTC

[3/4] flex-blazeds git commit: Removed all "exclude" javadoc annotations

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/client/FlexClient.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/client/FlexClient.java b/modules/core/src/flex/messaging/client/FlexClient.java
index f6a4b59..9c6e4fe 100644
--- a/modules/core/src/flex/messaging/client/FlexClient.java
+++ b/modules/core/src/flex/messaging/client/FlexClient.java
@@ -65,7 +65,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     /**
      * This value is passed to the server in an initial client connect to
      * indicate that the client needs a server-assigned FlexClient Id.
-     * @exclude
+     *
      */
     public static final String NULL_FLEXCLIENT_ID = "nil";
 
@@ -134,7 +134,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     //--------------------------------------------------------------------------
 
     /**
-     * @exclude
+     *
      * Constructs a new FlexClient instance.
      *
      * @param manager The FlexClientManager managing this instance.
@@ -145,7 +145,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Constructs a new FlexClient instance having the specified Id.
      *
      * @param manager The FlexClientManager managing this instance.
@@ -338,7 +338,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Returns the push handler registered with the FlexClient with the supplied
      * endpoint id, or null if no push handler was registered with the FlexClient
      * for that endpoint.
@@ -358,7 +358,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Returns the queue processor registered with the FlexClient with the supplied
      * endpoint id, or null if no queue processor was registered with the FlexClient
      * for that endpoint.
@@ -373,7 +373,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
     
     /**
-     * @exclude
+     *
      * Returns the endpoint queue registered with the FlexClient with the supplied
      * endpoint id, or null if no endpoint queue was registered with the FlexClient
      * for that endpoint.
@@ -475,7 +475,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      *
      * Returns the principal associated with this client.  If the client has not
      * authenticated the principal will be null.  Should only be called from FlexContext
@@ -493,7 +493,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      *
      * Should only be called from FlexContext and only if perClientAuthentication is used.
      * Not available to users.
@@ -710,7 +710,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Implements TimeoutCapable.
      * Determine the time, in milliseconds, that this object is allowed to idle
      * before having its timeout method invoked.
@@ -722,7 +722,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Implements MessageClientListener.
      * Handling created events is a no-op.
      *
@@ -731,7 +731,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     public void messageClientCreated(MessageClient messageClient) {}
 
     /**
-     * @exclude
+     *
      * Implements MessageClientListener.
      * Notification that an associated FlexSession was destroyed.
      *
@@ -743,7 +743,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Poll for outbound messages for the FlexClient.
      * This method is only invoked by internal code while processing a client poll request; it
      * is not intended for general public use.
@@ -778,7 +778,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Poll for outbound messages for the FlexClient and if no messages are available
      * immediately, store a reference to the passed async handler and call back when messages arrive.
      *
@@ -856,7 +856,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Poll for outbound messages for the FlexClient and if no messages are available
      * immediately, put processing into a wait state until messages arrive.
      * This method is only invoked by internal code while processing a client poll request; it
@@ -1024,7 +1024,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Poll for outbound messages for a specific MessageClient/Consumer.
      * This overload of poll() is only invoked when handling a Consumer.receive() request.
      *
@@ -1067,7 +1067,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Push a message to the FlexClient.
      * The message is added to the outbound queue of messages for the client and
      * will be pushed if possible or retrieved via a client poll request.
@@ -1154,7 +1154,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Registers an <tt>EndpointPushHandler</tt> for the specified endpoint to handle pushing messages
      * to remote clients.
      *
@@ -1180,7 +1180,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Used internally to associate a FlexSession with this FlexClient.
      *
      * @param session The FlexSession to associate with this FlexClient.
@@ -1195,7 +1195,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Used internally to associate a MessageClient with this FlexClient.
      *
      * @param messageClient The MessageClient to associate with this FlexClient.
@@ -1294,7 +1294,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Implements FlexSessionListener interface.
      * Notification that a FlexSession was created.
      * This is a no-op because the FlexClient is never added as a static FlexSession created listener
@@ -1306,7 +1306,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     public void sessionCreated(FlexSession session) {}
 
     /**
-     * @exclude
+     *
      * Implements FlexSessionListener interface.
      * Notification that an associated FlexSession was destroyed.
      *
@@ -1378,7 +1378,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Implements TimeoutCapable.
      * Inform the object that it has timed out.
      */
@@ -1388,7 +1388,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Unregisters an <tt>EndpointPushHandler</tt> from the specified endpoint.
      *
      * @param handler The <tt>EndpointPushHandler</tt> to unregister.
@@ -1407,7 +1407,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Used internally to disassociate a FlexSession from this FlexClient.
      *
      * @param session The FlexSession to disassociate from this FlexClient.
@@ -1425,7 +1425,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Used internally to disassociate a MessageClient (subscription) from a FlexClient.
      *
      * @param messageClient The MessageClient to disassociate from the FlexClient.
@@ -2199,7 +2199,7 @@ public class FlexClient extends TimeoutAbstractObject implements FlexSessionList
     }
 
     /**
-     * @exclude
+     *
      * Helper class that stores per-endpoint outbound queue state including:
      * <ul>
      *   <li>flexClient - The <tt>FlexClient</tt> the queue is used by.</li>

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/client/FlexClientManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/client/FlexClientManager.java b/modules/core/src/flex/messaging/client/FlexClientManager.java
index 05c7d2c..943956d 100644
--- a/modules/core/src/flex/messaging/client/FlexClientManager.java
+++ b/modules/core/src/flex/messaging/client/FlexClientManager.java
@@ -36,7 +36,7 @@ import flex.messaging.util.TimeoutAbstractObject;
 import flex.messaging.util.TimeoutManager;
 
 /**
- * @exclude
+ *
  * Manages FlexClient instances for a MessageBroker.
  */
 public class FlexClientManager extends ManageableComponent
@@ -50,7 +50,7 @@ public class FlexClientManager extends ManageableComponent
     //--------------------------------------------------------------------------
 
     /**
-     * @exclude
+     *
      */
     public FlexClientManager()
     {
@@ -67,7 +67,7 @@ public class FlexClientManager extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      */
     public FlexClientManager(boolean enableManagement, MessageBroker mbroker)
     {
@@ -305,7 +305,7 @@ public class FlexClientManager extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      * Monitors an async poll for a FlexClient for timeout.
      *
      * @param asyncPollTimeout The async poll task to monitor for timeout.
@@ -316,7 +316,7 @@ public class FlexClientManager extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      * Monitors a scheduled flush for a FlexClient for timeout.
      *
      * @param scheduledFlushTimeout The schedule flush task to monitor for timeout.
@@ -395,7 +395,7 @@ public class FlexClientManager extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      * Removes a FlexClient from being managed by this manager.
      * This method is invoked by FlexClients when they are invalidated.
      *

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/client/FlexClientNotSubscribedException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/client/FlexClientNotSubscribedException.java b/modules/core/src/flex/messaging/client/FlexClientNotSubscribedException.java
index 54d7a33..f5ffe18 100644
--- a/modules/core/src/flex/messaging/client/FlexClientNotSubscribedException.java
+++ b/modules/core/src/flex/messaging/client/FlexClientNotSubscribedException.java
@@ -20,12 +20,12 @@ import flex.messaging.MessageException;
 import flex.messaging.log.LogEvent;
 
 /**
- * @exclude
+ *
  */
 public class FlexClientNotSubscribedException extends MessageException
 {
     /**
-     * @exclude
+     *
      */
     private static final long serialVersionUID = 773524927178340950L;
 

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/client/FlexClientOutboundQueueProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/client/FlexClientOutboundQueueProcessor.java b/modules/core/src/flex/messaging/client/FlexClientOutboundQueueProcessor.java
index dd7df44..19cf19e 100644
--- a/modules/core/src/flex/messaging/client/FlexClientOutboundQueueProcessor.java
+++ b/modules/core/src/flex/messaging/client/FlexClientOutboundQueueProcessor.java
@@ -71,7 +71,7 @@ public class FlexClientOutboundQueueProcessor
     //--------------------------------------------------------------------------
 
     /**
-     * @exclude
+     *
      * Stores the Id for the outbound queue's endpoint.
      *
      * @param value The Id for the outbound queue's endpoint.
@@ -92,7 +92,7 @@ public class FlexClientOutboundQueueProcessor
     }
 
     /**
-     * @exclude
+     *
      * Sets the associated FlexClient.
      *
      * @param value The associated FlexClient.

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/cluster/BroadcastHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/cluster/BroadcastHandler.java b/modules/core/src/flex/messaging/cluster/BroadcastHandler.java
index c8a5db4..f036622 100644
--- a/modules/core/src/flex/messaging/cluster/BroadcastHandler.java
+++ b/modules/core/src/flex/messaging/cluster/BroadcastHandler.java
@@ -19,7 +19,7 @@ package flex.messaging.cluster;
 import java.util.List;
 
 /**
- * @exclude
+ *
  * This interface represents a handler for a message broadcast by a Cluster.
  * Clusters broadcast messages across their physical nodes, and when they
  * receive those messages they locate a BroadcastHandler capable of handling

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/cluster/Cluster.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/cluster/Cluster.java b/modules/core/src/flex/messaging/cluster/Cluster.java
index 506bb19..eab1890 100644
--- a/modules/core/src/flex/messaging/cluster/Cluster.java
+++ b/modules/core/src/flex/messaging/cluster/Cluster.java
@@ -26,7 +26,7 @@ import flex.messaging.config.ConfigMap;
 import flex.messaging.log.LogCategories;
 
 /**
- * @exclude
+ *
  * Base interface for cluster implementations.
  */
 public abstract class Cluster

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/cluster/ClusterException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/cluster/ClusterException.java b/modules/core/src/flex/messaging/cluster/ClusterException.java
index a7e1fe2..c0dc41d 100644
--- a/modules/core/src/flex/messaging/cluster/ClusterException.java
+++ b/modules/core/src/flex/messaging/cluster/ClusterException.java
@@ -19,7 +19,7 @@ package flex.messaging.cluster;
 import flex.messaging.MessageException;
 
 /**
- * @exclude
+ *
  * Exception type for cluster errors.
  */
 public class ClusterException extends MessageException

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/cluster/ClusterManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/cluster/ClusterManager.java b/modules/core/src/flex/messaging/cluster/ClusterManager.java
index 0e88fe1..07ef180 100644
--- a/modules/core/src/flex/messaging/cluster/ClusterManager.java
+++ b/modules/core/src/flex/messaging/cluster/ClusterManager.java
@@ -42,7 +42,7 @@ import flex.messaging.endpoints.Endpoint;
 import flex.messaging.util.ClassUtil;
 
 /**
- * @exclude
+ *
  * The manager of all clusters defined in services-config.xml, and the broker
  * for the clusters created for clustered destinations.
  */
@@ -578,7 +578,7 @@ public class ClusterManager
         Constructor clusterConstructor = null;
         try
         {
-            clusterConstructor = clusterClass.getConstructor(new Class[] {ClusterManager.class});
+            clusterConstructor = clusterClass.getConstructor(ClusterManager.class);
         }
         catch (Exception e)
         {
@@ -589,7 +589,7 @@ public class ClusterManager
         }
         try
         {
-            cluster = (Cluster)clusterConstructor.newInstance(new Object[] {this});
+            cluster = (Cluster)clusterConstructor.newInstance(this);
             cluster.setClusterPropertiesFile(propsFile);
             cluster.setURLLoadBalancing(cls.getURLLoadBalancing());
             cluster.initialize(clusterId, cls.getProperties());

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/cluster/ClusterMembershipListener.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/cluster/ClusterMembershipListener.java b/modules/core/src/flex/messaging/cluster/ClusterMembershipListener.java
index fd5b70d..302163e 100644
--- a/modules/core/src/flex/messaging/cluster/ClusterMembershipListener.java
+++ b/modules/core/src/flex/messaging/cluster/ClusterMembershipListener.java
@@ -25,7 +25,7 @@ import org.jgroups.MembershipListener;
 import org.jgroups.View;
 
 /**
- * @exclude
+ *
  * Clusters employ this Listener in order to respond to nodes which
  * join and abandon it. This class bridges the low-level protocol layer
  * to the more abstract logical cluster.

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/cluster/ClusterNode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/cluster/ClusterNode.java b/modules/core/src/flex/messaging/cluster/ClusterNode.java
index 6fdd67e..6a0b64c 100644
--- a/modules/core/src/flex/messaging/cluster/ClusterNode.java
+++ b/modules/core/src/flex/messaging/cluster/ClusterNode.java
@@ -21,7 +21,7 @@ import java.util.Iterator;
 import java.util.Map;
 
 /**
- * @exclude
+ *
  * ClusterNode is an encapsulation for pairing a physical host and a logical
  * software group, which is in effect a mapping between a physical address used
  * by the cluster infrastructure and a service destination used by the message

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/cluster/RemoveNodeListener.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/cluster/RemoveNodeListener.java b/modules/core/src/flex/messaging/cluster/RemoveNodeListener.java
index fd8778d..05583c3 100644
--- a/modules/core/src/flex/messaging/cluster/RemoveNodeListener.java
+++ b/modules/core/src/flex/messaging/cluster/RemoveNodeListener.java
@@ -18,7 +18,7 @@ package flex.messaging.cluster;
 
 
 /**
- * @exclude
+ *
  * Called when a node leaves the cluster.  Note that for JGroups at least, this
  * callback should not execute any "long running" operations.  This is indirectly
  * called from the MembershipListener interface in JGroups.

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/ApacheXPathServerConfigurationParser.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/ApacheXPathServerConfigurationParser.java b/modules/core/src/flex/messaging/config/ApacheXPathServerConfigurationParser.java
index cb93f8e..29dd222 100644
--- a/modules/core/src/flex/messaging/config/ApacheXPathServerConfigurationParser.java
+++ b/modules/core/src/flex/messaging/config/ApacheXPathServerConfigurationParser.java
@@ -29,7 +29,7 @@ import javax.xml.transform.TransformerException;
  * sections of the document need to be parsed first.
  * </p>
  *
- * @exclude
+ *
  */
 public class ApacheXPathServerConfigurationParser extends ServerConfigurationParser
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/ConfigurationManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/ConfigurationManager.java b/modules/core/src/flex/messaging/config/ConfigurationManager.java
index 86a83d3..8f3f463 100644
--- a/modules/core/src/flex/messaging/config/ConfigurationManager.java
+++ b/modules/core/src/flex/messaging/config/ConfigurationManager.java
@@ -28,7 +28,7 @@ import flex.messaging.log.LogCategories;
  * a servlet init-param &quot;services.configuration.manager&quot;
  * to the MessageBrokerServlet.
  *
- * @exclude
+ *
  */
 public interface ConfigurationManager
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/FactorySettings.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/FactorySettings.java b/modules/core/src/flex/messaging/config/FactorySettings.java
index 65634fa..aec365e 100644
--- a/modules/core/src/flex/messaging/config/FactorySettings.java
+++ b/modules/core/src/flex/messaging/config/FactorySettings.java
@@ -23,7 +23,7 @@ import flex.messaging.util.ClassUtil;
  * The factory configuration defines a single factory in the flex
  * configuration file.
  *
- * @exclude
+ *
  */
 public class FactorySettings extends PropertiesSettings
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/FlexConfigurationManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/FlexConfigurationManager.java b/modules/core/src/flex/messaging/config/FlexConfigurationManager.java
index cdf4184..313cb87 100644
--- a/modules/core/src/flex/messaging/config/FlexConfigurationManager.java
+++ b/modules/core/src/flex/messaging/config/FlexConfigurationManager.java
@@ -40,7 +40,7 @@ import java.io.File;
  * </p>
  *
  * @see ConfigurationParser
- * @exclude
+ *
  */
 public class FlexConfigurationManager implements ConfigurationManager
 {
@@ -205,7 +205,7 @@ public class FlexConfigurationManager implements ConfigurationManager
                         boolean available = resolver.isAvailable(configurationPath, isServletResource);
                         if (available) {
                             // it's available via the servlet resource loader
-                            configurationResolver = (ConfigurationFileResolver) resolver;
+                            configurationResolver = resolver;
                         } else {
                             // it wasn't available via the servlet resource loader
                             configurationResolver = new LocalFileResolver(LocalFileResolver.SERVER);

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/MessageFilterSettings.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/MessageFilterSettings.java b/modules/core/src/flex/messaging/config/MessageFilterSettings.java
index c58bc25..34ed523 100644
--- a/modules/core/src/flex/messaging/config/MessageFilterSettings.java
+++ b/modules/core/src/flex/messaging/config/MessageFilterSettings.java
@@ -19,7 +19,7 @@ package flex.messaging.config;
 /**
  * Settings class for message filters.
  * 
- * @exclude
+ *
  */
 public class MessageFilterSettings extends PropertiesSettings
 {
@@ -27,8 +27,8 @@ public class MessageFilterSettings extends PropertiesSettings
      * Filters belong to one of two types; those that filter messages
      * asynchronously and those that filter messages synchronously.
      */
-    public enum FilterType { ASYNC, SYNC };
-    
+    public enum FilterType { ASYNC, SYNC }
+
     private String id;
 
     /**

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/MessagingConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/MessagingConfiguration.java b/modules/core/src/flex/messaging/config/MessagingConfiguration.java
index 4e96078..828d7ea 100644
--- a/modules/core/src/flex/messaging/config/MessagingConfiguration.java
+++ b/modules/core/src/flex/messaging/config/MessagingConfiguration.java
@@ -58,7 +58,7 @@ import java.util.Map;
  * instead, this object sets the relevant values on the broker using
  * information which a ConfigurationParser has provided for it.
  *
- * @exclude
+ *
  */
 public class MessagingConfiguration implements ServicesConfiguration
 {
@@ -456,7 +456,7 @@ public class MessagingConfiguration implements ServicesConfiguration
     }
 
     /**
-     * @exclude
+     *
      * Used by the MessageBrokerServlet to set up the singleton Log instance
      * and add any targets defined in the logging configuration.
      * This needs to be invoked ahead of creating and bootstrapping a MessageBroker
@@ -506,7 +506,7 @@ public class MessagingConfiguration implements ServicesConfiguration
             {
                 // Unwrap to get to the interesting exception
                 if (t instanceof InvocationTargetException)
-                    t = ((InvocationTargetException ) t).getCause();
+                    t = t.getCause();
 
                 System.err.println("*** Error setting up logging system");
                 t.printStackTrace();
@@ -558,7 +558,7 @@ public class MessagingConfiguration implements ServicesConfiguration
                 Object filterChain = getMessageFilterChain.invoke(broker, (Object[])null);
                 Class arg = filterIsAsync ? asyncFilterClass : syncFilterClass; 
                 Method addFilter = filterChain.getClass().getDeclaredMethod("add", arg);
-                addFilter.invoke(filterChain, new Object[] {filter});
+                addFilter.invoke(filterChain, filter);
             }
             catch (Exception e)
             {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/SecuritySettings.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/SecuritySettings.java b/modules/core/src/flex/messaging/config/SecuritySettings.java
index b5db672..f95412a 100644
--- a/modules/core/src/flex/messaging/config/SecuritySettings.java
+++ b/modules/core/src/flex/messaging/config/SecuritySettings.java
@@ -24,7 +24,7 @@ import java.util.HashMap;
 import java.util.Map;
 
 /**
- * @exclude
+ *
  */
 public class SecuritySettings
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/ServerConfigurationParser.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/ServerConfigurationParser.java b/modules/core/src/flex/messaging/config/ServerConfigurationParser.java
index 35dfb79..9ff3e1c 100644
--- a/modules/core/src/flex/messaging/config/ServerConfigurationParser.java
+++ b/modules/core/src/flex/messaging/config/ServerConfigurationParser.java
@@ -35,7 +35,7 @@ import flex.messaging.util.LocaleUtils;
  * sections of the document need to be parsed first.
  * </p>
  *
- * @exclude
+ *
  */
 public abstract class ServerConfigurationParser extends AbstractConfigurationParser
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/ServletResourceResolver.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/ServletResourceResolver.java b/modules/core/src/flex/messaging/config/ServletResourceResolver.java
index d08cfd8..b79bc27 100644
--- a/modules/core/src/flex/messaging/config/ServletResourceResolver.java
+++ b/modules/core/src/flex/messaging/config/ServletResourceResolver.java
@@ -28,7 +28,7 @@ import java.util.Set;
 import java.util.Stack;
 
 /**
- * @exclude
+ *
  */
 public class ServletResourceResolver implements ConfigurationFileResolver
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/SharedServerSettings.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/SharedServerSettings.java b/modules/core/src/flex/messaging/config/SharedServerSettings.java
index 82cac64..8fe815a 100644
--- a/modules/core/src/flex/messaging/config/SharedServerSettings.java
+++ b/modules/core/src/flex/messaging/config/SharedServerSettings.java
@@ -23,7 +23,7 @@ package flex.messaging.config;
  * The <tt>MessagingConfiguration</tt> instance using the parser will store these and
  * use them to configure the <tt>MessageBroker</tt> with shared server instances.
  *
- * @exclude
+ *
  */
 public class SharedServerSettings extends PropertiesSettings
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/SystemSettings.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/SystemSettings.java b/modules/core/src/flex/messaging/config/SystemSettings.java
index 86619e7..cf4cd49 100644
--- a/modules/core/src/flex/messaging/config/SystemSettings.java
+++ b/modules/core/src/flex/messaging/config/SystemSettings.java
@@ -31,7 +31,7 @@ import java.util.Locale;
 import javax.servlet.ServletContext;
 
 /**
- * @exclude
+ *
  */
 public class SystemSettings
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/config/XPathServerConfigurationParser.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/config/XPathServerConfigurationParser.java b/modules/core/src/flex/messaging/config/XPathServerConfigurationParser.java
index 4860290..c567f21 100644
--- a/modules/core/src/flex/messaging/config/XPathServerConfigurationParser.java
+++ b/modules/core/src/flex/messaging/config/XPathServerConfigurationParser.java
@@ -32,7 +32,7 @@ import javax.xml.xpath.XPathFactory;
  * sections of the document need to be parsed first.
  * </p>
  *
- * @exclude
+ *
  */
 public class XPathServerConfigurationParser extends ServerConfigurationParser
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/endpoints/AbstractEndpoint.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/endpoints/AbstractEndpoint.java b/modules/core/src/flex/messaging/endpoints/AbstractEndpoint.java
index d773f1c..7a81ee8 100644
--- a/modules/core/src/flex/messaging/endpoints/AbstractEndpoint.java
+++ b/modules/core/src/flex/messaging/endpoints/AbstractEndpoint.java
@@ -738,7 +738,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      * Returns the url of the endpoint parsed for the client.
      *
      * @return The url of the endpoint parsed for the client.
@@ -762,7 +762,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      * Returns the total throughput for the endpoint.
      *
      * @return The total throughput for the endpoint.
@@ -800,7 +800,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      */
     public Message convertToSmallMessage(Message message)
     {
@@ -896,7 +896,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      * Make sure this matches with ChannelSettings.getParsedUri.
      */
     public String getParsedUrl(String contextPath)
@@ -906,7 +906,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      */
     public void handleClientMessagingVersion(Number version)
     {
@@ -1107,7 +1107,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
    }
 
    /**
-    * @exclude
+    *
     * Performance metrics gathering property
     */
     public boolean isRecordMessageSizes()
@@ -1116,7 +1116,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
    /**
-    * @exclude
+    *
     * Performance metrics gathering property
     */
     public boolean isRecordMessageTimes()
@@ -1125,7 +1125,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      */
     public void setThreadLocals()
     {
@@ -1143,7 +1143,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      */
     public void clearThreadLocals()
     {
@@ -1372,7 +1372,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      * Verifies that the remote client supports the FlexClient API.
      * Legacy clients that do not support this receive a message fault for any messages they send.
      *
@@ -1389,7 +1389,7 @@ public abstract class AbstractEndpoint extends ManageableComponent
     }
 
     /**
-     * @exclude
+     *
      */
     protected Class<?> createClass(String className)
     {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/endpoints/BaseHTTPEndpoint.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/endpoints/BaseHTTPEndpoint.java b/modules/core/src/flex/messaging/endpoints/BaseHTTPEndpoint.java
index 5dbf48f..bb31b39 100644
--- a/modules/core/src/flex/messaging/endpoints/BaseHTTPEndpoint.java
+++ b/modules/core/src/flex/messaging/endpoints/BaseHTTPEndpoint.java
@@ -203,7 +203,7 @@ public abstract class BaseHTTPEndpoint extends AbstractEndpoint
     //----------------------------------
 
     /**
-     * @exclude
+     *
      * This is a property used on the client.
      */
     protected boolean loginAfterDisconnect;
@@ -389,7 +389,7 @@ public abstract class BaseHTTPEndpoint extends AbstractEndpoint
 
 
     /**
-     * @exclude
+     *
      * Returns a <code>ConfigMap</code> of endpoint properties that the client
      * needs. This includes properties from <code>super.describeEndpoint</code>
      * and additional <code>BaseHTTPEndpoint</code> specific properties under

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/endpoints/BasePollingHTTPEndpoint.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/endpoints/BasePollingHTTPEndpoint.java b/modules/core/src/flex/messaging/endpoints/BasePollingHTTPEndpoint.java
index 70f1318..3c29fae 100644
--- a/modules/core/src/flex/messaging/endpoints/BasePollingHTTPEndpoint.java
+++ b/modules/core/src/flex/messaging/endpoints/BasePollingHTTPEndpoint.java
@@ -252,7 +252,7 @@ public abstract class BasePollingHTTPEndpoint extends BaseHTTPEndpoint implement
     //----------------------------------
 
     /**
-     * @exclude
+     *
      * This is a property used on the client.
      */
     protected boolean piggybackingEnabled;
@@ -262,7 +262,7 @@ public abstract class BasePollingHTTPEndpoint extends BaseHTTPEndpoint implement
     //----------------------------------
 
     /**
-     * @exclude
+     *
      * This is a property used on the client.
      */
     protected boolean pollingEnabled;
@@ -272,7 +272,7 @@ public abstract class BasePollingHTTPEndpoint extends BaseHTTPEndpoint implement
     //----------------------------------
 
     /**
-     * @exclude
+     *
      * This is a property used on the client.
      */
     protected long pollingIntervalMillis = -1;
@@ -332,7 +332,7 @@ public abstract class BasePollingHTTPEndpoint extends BaseHTTPEndpoint implement
     //--------------------------------------------------------------------------
 
     /**
-     * @exclude
+     *
      * Returns a <code>ConfigMap</code> of endpoint properties that the client
      * needs. This includes properties from <code>super.describeEndpoint</code>
      * and additional <code>BaseHTTPEndpoint</code> specific properties under

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/endpoints/DuplicateSessionException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/endpoints/DuplicateSessionException.java b/modules/core/src/flex/messaging/endpoints/DuplicateSessionException.java
index a1700c1..2cc6b0f 100644
--- a/modules/core/src/flex/messaging/endpoints/DuplicateSessionException.java
+++ b/modules/core/src/flex/messaging/endpoints/DuplicateSessionException.java
@@ -25,12 +25,12 @@ import flex.messaging.log.LogEvent;
 public class DuplicateSessionException extends MessageException
 {
     /**
-     * @exclude
+     *
      */
     public static final String DUPLICATE_SESSION_DETECTED_CODE = "Server.Processing.DuplicateSessionDetected";
 
     /**
-     * @exclude
+     *
      */
     private static final long serialVersionUID = -741704726700619666L;
 

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/endpoints/Endpoint.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/endpoints/Endpoint.java b/modules/core/src/flex/messaging/endpoints/Endpoint.java
index 3182ce5..e16342f 100644
--- a/modules/core/src/flex/messaging/endpoints/Endpoint.java
+++ b/modules/core/src/flex/messaging/endpoints/Endpoint.java
@@ -179,7 +179,7 @@ public interface Endpoint extends Manageable
     void setUrl(String url);  
     
     /**
-     * @exclude
+     *
      * Returns the url of the endpoint parsed for the client. 
      *  
      * @return The url of the endpoint parsed for the client.

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/factories/JavaFactory.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/factories/JavaFactory.java b/modules/core/src/flex/messaging/factories/JavaFactory.java
index 333ae96..e488919 100644
--- a/modules/core/src/flex/messaging/factories/JavaFactory.java
+++ b/modules/core/src/flex/messaging/factories/JavaFactory.java
@@ -55,7 +55,7 @@ public class JavaFactory implements FlexFactory, DestructibleFlexFactory
     private static final int INVALID_CLASS_FOUND = 10654;
 
     /**
-     * @exclude
+     *
      * Default constructor
      */
     public JavaFactory()

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/AbstractProxy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/AbstractProxy.java b/modules/core/src/flex/messaging/io/AbstractProxy.java
index 6d86da9..2f29fb6 100644
--- a/modules/core/src/flex/messaging/io/AbstractProxy.java
+++ b/modules/core/src/flex/messaging/io/AbstractProxy.java
@@ -34,7 +34,7 @@ import flex.messaging.util.ClassUtil;
  * a given property name.
  *
  * @see flex.messaging.io.PropertyProxy
- * @exclude
+ *
  */
 public abstract class AbstractProxy implements PropertyProxy, Serializable
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/ArrayList.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/ArrayList.java b/modules/core/src/flex/messaging/io/ArrayList.java
index 6c5c383..b3eeb24 100644
--- a/modules/core/src/flex/messaging/io/ArrayList.java
+++ b/modules/core/src/flex/messaging/io/ArrayList.java
@@ -21,7 +21,7 @@ package flex.messaging.io;
 import java.util.Collection;
 
 /**
- * @exclude
+ *
  */
 public class ArrayList extends ArrayCollection 
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/ManagedObjectProxy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/ManagedObjectProxy.java b/modules/core/src/flex/messaging/io/ManagedObjectProxy.java
index 02072f3..34bde91 100644
--- a/modules/core/src/flex/messaging/io/ManagedObjectProxy.java
+++ b/modules/core/src/flex/messaging/io/ManagedObjectProxy.java
@@ -22,7 +22,7 @@ import java.io.ObjectOutput;
 import java.util.Iterator;
 
 /**
- * @exclude
+ *
  */
 public class ManagedObjectProxy extends ObjectProxy 
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/MessageIOConstants.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/MessageIOConstants.java b/modules/core/src/flex/messaging/io/MessageIOConstants.java
index 245efec..844590b 100644
--- a/modules/core/src/flex/messaging/io/MessageIOConstants.java
+++ b/modules/core/src/flex/messaging/io/MessageIOConstants.java
@@ -17,7 +17,7 @@
 package flex.messaging.io;
 
 /**
- * @exclude
+ *
  */
 public interface MessageIOConstants
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/MessageSerializer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/MessageSerializer.java b/modules/core/src/flex/messaging/io/MessageSerializer.java
index 02d4c00..5347db7 100644
--- a/modules/core/src/flex/messaging/io/MessageSerializer.java
+++ b/modules/core/src/flex/messaging/io/MessageSerializer.java
@@ -23,7 +23,7 @@ import java.io.IOException;
 import java.io.OutputStream;
 
 /**
- * @exclude
+ *
  */
 public interface MessageSerializer
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/SerializationContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/SerializationContext.java b/modules/core/src/flex/messaging/io/SerializationContext.java
index 24f5d78..d4a9f41 100644
--- a/modules/core/src/flex/messaging/io/SerializationContext.java
+++ b/modules/core/src/flex/messaging/io/SerializationContext.java
@@ -274,7 +274,7 @@ public class SerializationContext implements Serializable, Cloneable
     }
 
     /**
-     * @exclude
+     *
      * Create thread local storage.
      */
     public static void createThreadLocalObjects()
@@ -284,7 +284,7 @@ public class SerializationContext implements Serializable, Cloneable
     }
 
     /**
-     * @exclude
+     *
      * Destroy thread local storage.
      * Call ONLY on shutdown.
      */

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/TypeMarshallingContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/TypeMarshallingContext.java b/modules/core/src/flex/messaging/io/TypeMarshallingContext.java
index 1201fac..7a505a0 100644
--- a/modules/core/src/flex/messaging/io/TypeMarshallingContext.java
+++ b/modules/core/src/flex/messaging/io/TypeMarshallingContext.java
@@ -215,7 +215,7 @@ public class TypeMarshallingContext
     }
 
     /**
-     * @exclude
+     *
      * Destroy static thread local storage.
      * Call ONLY on shutdown.
      */
@@ -228,7 +228,7 @@ public class TypeMarshallingContext
     }
 
     /**
-     * @exclude
+     *
      * Create static thread local storage.
      */
     public static void createThreadLocalObjects()

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/UnknownTypeException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/UnknownTypeException.java b/modules/core/src/flex/messaging/io/UnknownTypeException.java
index 40dd7b2..9788b41 100644
--- a/modules/core/src/flex/messaging/io/UnknownTypeException.java
+++ b/modules/core/src/flex/messaging/io/UnknownTypeException.java
@@ -17,7 +17,7 @@
 package flex.messaging.io;
 
 /**
- * @exclude
+ *
  */
 public class UnknownTypeException extends SerializationException
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/AbstractAmfInput.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/AbstractAmfInput.java b/modules/core/src/flex/messaging/io/amf/AbstractAmfInput.java
index 1ee3d12..5d985f6 100644
--- a/modules/core/src/flex/messaging/io/amf/AbstractAmfInput.java
+++ b/modules/core/src/flex/messaging/io/amf/AbstractAmfInput.java
@@ -35,7 +35,7 @@ import flex.messaging.util.XMLUtil;
  * A deserializer of AMF protocol data.
  *
  * @see ActionMessageOutput
- * @exclude
+ *
  */
 public abstract class AbstractAmfInput extends AmfIO implements ActionMessageInput
 {
@@ -68,7 +68,7 @@ public abstract class AbstractAmfInput extends AmfIO implements ActionMessageInp
 
     /**
      * Internal use
-     * @exclude
+     *
      */
     public void setInputStream(InputStream in)
     {
@@ -116,7 +116,7 @@ public abstract class AbstractAmfInput extends AmfIO implements ActionMessageInp
      *               [0] - String className - the name or alias of the class to create
      *               [1] - PropertyProxy proxy
      * @return an instance of the appropriate object for deserialization
-     * @exclude
+     *
      */
     protected Object createObjectInstance(Object[] params)
     {
@@ -188,7 +188,7 @@ public abstract class AbstractAmfInput extends AmfIO implements ActionMessageInp
      * Internal use. Convenience method for creating an ASObject and assigning it a type
      * @param type named type for the ASObject or null
      * @return a new instance of ASObject
-     * @exclude
+     *
      */
     protected ASObject createDefaultASObject(String type)
     {
@@ -199,7 +199,7 @@ public abstract class AbstractAmfInput extends AmfIO implements ActionMessageInp
     }
 
     /**
-     * @exclude
+     *
      */
     protected void readMaxStringBytes()
     {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/AbstractAmfOutput.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/AbstractAmfOutput.java b/modules/core/src/flex/messaging/io/amf/AbstractAmfOutput.java
index 09f4224..0a3fb4f 100644
--- a/modules/core/src/flex/messaging/io/amf/AbstractAmfOutput.java
+++ b/modules/core/src/flex/messaging/io/amf/AbstractAmfOutput.java
@@ -29,12 +29,12 @@ import org.w3c.dom.Document;
  * An abstract serializer of AMF protocol data.
  *
  * @see ActionMessageOutput
- * @exclude
+ *
  */
 public abstract class AbstractAmfOutput extends AmfIO implements ActionMessageOutput
 {
     /**
-     * @exclude
+     *
      */
     protected DataOutputStream out;
 

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/ActionContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/ActionContext.java b/modules/core/src/flex/messaging/io/amf/ActionContext.java
index 16cb1bb..3b7d2a5 100644
--- a/modules/core/src/flex/messaging/io/amf/ActionContext.java
+++ b/modules/core/src/flex/messaging/io/amf/ActionContext.java
@@ -24,7 +24,7 @@ import java.io.Serializable;
 
 /**
  * A context for reading and writing messages.
- * @exclude
+ *
  */
 public class ActionContext implements Serializable
 {
@@ -42,38 +42,38 @@ public class ActionContext implements Serializable
     public boolean isDebug;
 
     /**
-     * @exclude
+     *
      * Performance metrics related field, keeps track of bytes deserialized using this context
      */
     private int deserializedBytes;
 
     /**
-     * @exclude
+     *
      * Performance metrics related field, keeps track of bytes serialized using this context
      */
     private int serializedBytes;
 
     /**
-     * @exclude
+     *
      * Performance metrics related field, recordMessageSizes flag
      */
     private boolean recordMessageSizes;
 
     /**
-     * @exclude
+     *
      * Performance metrics related field, recordMessageTimes flag
      */
     private boolean recordMessageTimes;
 
     /**
-     * @exclude
+     *
      * Performance metrics related field, incoming MPI object, will only be populated when one of
      * the record-message-* params is enabled
      */
     private MessagePerformanceInfo mpii;
 
     /**
-     * @exclude
+     *
      * Performance metrics related field, outgoing MPI object, will only be populated when one of
      * the record-message-* params is enabled
      */

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/ActionMessageInput.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/ActionMessageInput.java b/modules/core/src/flex/messaging/io/amf/ActionMessageInput.java
index e6666be..8d8ecd3 100644
--- a/modules/core/src/flex/messaging/io/amf/ActionMessageInput.java
+++ b/modules/core/src/flex/messaging/io/amf/ActionMessageInput.java
@@ -85,19 +85,19 @@ public interface ActionMessageInput extends ObjectInput
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void setInputStream(InputStream in);
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void setDebugTrace(AmfTrace trace);
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void reset();
 }

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/ActionMessageOutput.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/ActionMessageOutput.java b/modules/core/src/flex/messaging/io/amf/ActionMessageOutput.java
index 190a4f4..7b319af 100644
--- a/modules/core/src/flex/messaging/io/amf/ActionMessageOutput.java
+++ b/modules/core/src/flex/messaging/io/amf/ActionMessageOutput.java
@@ -74,19 +74,19 @@ public interface ActionMessageOutput extends ObjectOutput
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void writeObjectTraits(TraitsInfo traits) throws IOException;
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void writeObjectProperty(String name, Object value) throws IOException;
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void writeObjectEnd() throws IOException;
 
@@ -97,19 +97,19 @@ public interface ActionMessageOutput extends ObjectOutput
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void setDebugTrace(AmfTrace debugBuffer);
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void setOutputStream(OutputStream out);
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     void reset();
 

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/Amf0Input.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/Amf0Input.java b/modules/core/src/flex/messaging/io/amf/Amf0Input.java
index 7027461..fa66ae9 100644
--- a/modules/core/src/flex/messaging/io/amf/Amf0Input.java
+++ b/modules/core/src/flex/messaging/io/amf/Amf0Input.java
@@ -33,7 +33,7 @@ import flex.messaging.util.ClassUtil;
 
 /**
  * An Amf0 input object.
- * @exclude
+ *
  */
 public class Amf0Input extends AbstractAmfInput implements AmfTypes
 {
@@ -43,12 +43,12 @@ public class Amf0Input extends AbstractAmfInput implements AmfTypes
      * that the next object in the stream is to be deserialized differently. The
      * original hope was for two independent encoding versions... but for now
      * we just keep a reference to objectInput here.
-     * @exclude
+     *
      */
     protected ActionMessageInput avmPlusInput;
 
     /**
-     * @exclude
+     *
      */
     protected List objectsTable;
 

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/Amf0Output.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/Amf0Output.java b/modules/core/src/flex/messaging/io/amf/Amf0Output.java
index d8752bb..b04713a 100644
--- a/modules/core/src/flex/messaging/io/amf/Amf0Output.java
+++ b/modules/core/src/flex/messaging/io/amf/Amf0Output.java
@@ -44,38 +44,38 @@ import javax.sql.RowSet;
 
 /**
  * An Amf0 output object.
- * @exclude
+ *
  */
 public class Amf0Output extends AbstractAmfOutput implements AmfTypes
 {
     /**
      * 3-byte marker for object end; used for faster serialization
      * than a combination of writeUTF("") and writeByte(kObjectEndType).
-     * @exclude
+     *
      */
     public static final byte[] OBJECT_END_MARKER = {0, 0, kObjectEndType};
 
     /**
      * A mapping of object instances to their serialization numbers
      * for storing object references on the stream.
-     * @exclude
+     *
      */
     protected IdentityHashMap serializedObjects;
 
     /**
      * Number of serialized objects.
-     * @exclude
+     *
      */
     protected int serializedObjectCount = 0;
 
     /**
      * AVM+ Encoding.
-     * @exclude
+     *
      */
     protected boolean avmPlus;
 
     /**
-     * @exclude
+     *
      */
     protected Amf3Output avmPlusOutput;
 
@@ -250,7 +250,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     public void writeObjectTraits(TraitsInfo traits) throws IOException
     {
@@ -273,7 +273,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     public void writeObjectProperty(String name, Object value) throws IOException
     {
@@ -287,7 +287,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     public void writeObjectEnd() throws IOException
     {
@@ -303,7 +303,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     //
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFBoolean(boolean b) throws IOException
     {
@@ -316,7 +316,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFDouble(double d) throws IOException
     {
@@ -329,7 +329,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFDate(Date d) throws IOException
     {
@@ -344,7 +344,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFArray(Object o, Class componentType) throws IOException
     {
@@ -363,7 +363,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeArrayCollection(Collection col, SerializationDescriptor desc) throws IOException
     {
@@ -392,7 +392,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeCustomObject(Object o) throws IOException
     {
@@ -444,7 +444,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writePropertyProxy(PropertyProxy pp, Object instance) throws IOException
     {
@@ -500,7 +500,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeMapAsECMAArray(Map m) throws IOException
     {
@@ -525,7 +525,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFNull() throws IOException
     {
@@ -536,7 +536,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFString(String str) throws IOException
     {
@@ -547,7 +547,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeObjectArray(Object[] values, SerializationDescriptor descriptor) throws IOException
     {
@@ -589,7 +589,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
      *
      * @param c Collection to be serialized as an array.
      * @throws java.io.IOException The exception can be generated by the output stream
-     * @exclude
+     *
      */
     protected void writeCollection(Collection c, SerializationDescriptor descriptor) throws IOException
     {
@@ -634,7 +634,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
      * boolean, char, double, float, long, int, short, byte
      * </p>
      * @param obj An array of primitives
-     * @exclude
+     *
      */
     protected void writePrimitiveArray(Object obj) throws IOException
     {
@@ -710,7 +710,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeCharArrayAsString(Character[] ca) throws IOException
     {
@@ -729,7 +729,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeCharArrayAsString(char[] ca) throws IOException
     {
@@ -737,7 +737,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeUTF(String str, boolean forceLong, boolean writeType) throws IOException
     {
@@ -820,7 +820,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
      * Remember the object's serialization number so that it can be referred to
      * as a reference later. Only complex ojects should be stored as references.
      *
-     * @exclude
+     *
      */
     protected void rememberObjectReference(Object obj)
     {
@@ -834,7 +834,7 @@ public class Amf0Output extends AbstractAmfOutput implements AmfTypes
      *
      * @return Success/failure indicator as to whether the object could be
      *         serialized as a reference.
-     * @exclude
+     *
      */
     protected boolean serializeAsReference(Object obj) throws IOException
     {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/Amf3Input.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/Amf3Input.java b/modules/core/src/flex/messaging/io/amf/Amf3Input.java
index 2cc1f30..0e62b88 100644
--- a/modules/core/src/flex/messaging/io/amf/Amf3Input.java
+++ b/modules/core/src/flex/messaging/io/amf/Amf3Input.java
@@ -43,22 +43,22 @@ import flex.messaging.util.Trace;
  * in avmglue/DataIO.cpp
  * </p>
  *
- * @exclude
+ *
  */
 public class Amf3Input extends AbstractAmfInput implements Amf3Types
 {
     /**
-     * @exclude
+     *
      */
     protected List objectTable;
 
     /**
-     * @exclude
+     *
      */
     protected List stringTable;
 
     /**
-     * @exclude
+     *
      */
     protected List traitsTable;
 
@@ -134,7 +134,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected Object readObjectValue(int type) throws ClassNotFoundException, IOException
     {
@@ -248,7 +248,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected String readString() throws IOException
     {
@@ -621,7 +621,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected Object readArray() throws ClassNotFoundException, IOException
     {
@@ -727,7 +727,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected Object readScriptObject() throws ClassNotFoundException, IOException
     {
@@ -814,7 +814,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void readExternalizable(String className, Object object) throws ClassNotFoundException, IOException
     {
@@ -837,7 +837,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected byte[] readByteArray() throws IOException
     {
@@ -863,7 +863,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected TraitsInfo readTraits(int ref) throws IOException
     {
@@ -890,7 +890,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected String readUTF(int utflen) throws IOException
     {
@@ -919,7 +919,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
      *
      * @return A int capable of holding an unsigned 29 bit integer.
      * @throws IOException
-     * @exclude
+     *
      */
     protected int readUInt29() throws IOException
     {
@@ -950,7 +950,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected Object readXml() throws IOException
     {
@@ -986,7 +986,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected Object getObjectReference(int ref)
     {
@@ -997,7 +997,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected String getStringReference(int ref)
     {
@@ -1010,7 +1010,7 @@ public class Amf3Input extends AbstractAmfInput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected TraitsInfo getTraitReference(int ref)
     {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/Amf3Output.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/Amf3Output.java b/modules/core/src/flex/messaging/io/amf/Amf3Output.java
index a33a7d5..7919530 100644
--- a/modules/core/src/flex/messaging/io/amf/Amf3Output.java
+++ b/modules/core/src/flex/messaging/io/amf/Amf3Output.java
@@ -55,22 +55,22 @@ import java.util.Map;
  * in avmglue/DataIO.cpp
  * </p>
  *
- * @exclude
+ *
  */
 public class Amf3Output extends AbstractAmfOutput implements Amf3Types
 {
     /**
-     * @exclude
+     *
      */
     protected IdentityHashMap<Object, Integer> objectTable;
 
     /**
-     * @exclude
+     *
      */
     protected HashMap<TraitsInfo, Integer> traitsTable;
 
     /**
-     * @exclude
+     *
      */
     protected HashMap<String, Integer> stringTable;
 
@@ -130,7 +130,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
                 // Using double to write big numbers such as BigInteger or
                 // BigDecimal can result in information loss so we write
                 // them as String by default...
-                writeAMFString(((Number)o).toString());
+                writeAMFString(o.toString());
             }
             else
             {
@@ -286,7 +286,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     //
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFBoolean(boolean b) throws IOException
     {
@@ -300,7 +300,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFDate(Date d) throws IOException
     {
@@ -320,7 +320,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFDouble(double d) throws IOException
     {
@@ -332,7 +332,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFInt(int i) throws IOException
     {
@@ -590,7 +590,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeMapAsECMAArray(Map map) throws IOException
     {
@@ -629,7 +629,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFNull() throws IOException
     {
@@ -640,7 +640,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFString(String s) throws IOException
     {
@@ -654,7 +654,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeStringWithoutType(String s) throws IOException
     {
@@ -675,7 +675,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFArray(Object o, Class componentType) throws IOException
     {
@@ -698,7 +698,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeArrayCollection(Collection col, SerializationDescriptor desc) throws IOException
     {
@@ -729,7 +729,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeCustomObject(Object o) throws IOException
     {
@@ -785,7 +785,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writePropertyProxy(PropertyProxy proxy, Object instance) throws IOException
     {
@@ -866,7 +866,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
      * </p>
      *
      * @param obj An array of primitives
-     * @exclude
+     *
      */
     protected void writePrimitiveArray(Object obj) throws IOException
     {
@@ -989,7 +989,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFByteArray(byte[] ba) throws IOException
     {
@@ -1012,7 +1012,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeAMFByteArray(Byte[] ba) throws IOException
     {
@@ -1042,7 +1042,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeCharArrayAsString(Character[] ca) throws IOException
     {
@@ -1061,7 +1061,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeCharArrayAsString(char[] ca) throws IOException
     {
@@ -1070,7 +1070,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeObjectArray(Object[] values, SerializationDescriptor descriptor) throws IOException
     {
@@ -1113,7 +1113,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeCollection(Collection c, SerializationDescriptor descriptor) throws IOException
     {
@@ -1164,7 +1164,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected void writeUInt29(int ref) throws IOException
     {
@@ -1215,7 +1215,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     public void writeAMFUTF(String s) throws IOException
     {
@@ -1276,7 +1276,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
      *
      * @return Success/failure indicator as to whether the object could be
      *         serialized as a reference.
-     * @exclude
+     *
      */
     protected boolean byReference(Object o) throws IOException
     {
@@ -1306,7 +1306,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     public void addObjectReference(Object o) throws IOException
     {
@@ -1314,7 +1314,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected boolean byReference(String s) throws IOException
     {
@@ -1342,7 +1342,7 @@ public class Amf3Output extends AbstractAmfOutput implements Amf3Types
     }
 
     /**
-     * @exclude
+     *
      */
     protected boolean byReference(TraitsInfo ti) throws IOException
     {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/Amf3Types.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/Amf3Types.java b/modules/core/src/flex/messaging/io/amf/Amf3Types.java
index 6aeb74c..72e1b82 100644
--- a/modules/core/src/flex/messaging/io/amf/Amf3Types.java
+++ b/modules/core/src/flex/messaging/io/amf/Amf3Types.java
@@ -47,7 +47,7 @@ public interface Amf3Types
 
     /**
      * Internal use only.
-     * @exclude
+     *
      */
     int UINT29_MASK = 0x1FFFFFFF; // 2^29 - 1
 

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/AmfIO.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/AmfIO.java b/modules/core/src/flex/messaging/io/amf/AmfIO.java
index 56747db..6336a4d 100644
--- a/modules/core/src/flex/messaging/io/amf/AmfIO.java
+++ b/modules/core/src/flex/messaging/io/amf/AmfIO.java
@@ -24,7 +24,7 @@ import flex.messaging.io.TypeMarshallingContext;
 
 /**
  * Base class for Amf I/O. 
- * @exclude
+ *
  */
 abstract class AmfIO
 {
@@ -163,8 +163,6 @@ abstract class AmfIO
             return true;
         if (flex.messaging.io.ArrayCollection.class.equals(clazz))
             return true;
-        if (flex.messaging.io.ArrayList.class.equals(clazz))
-            return true;
-        return false;
+        return flex.messaging.io.ArrayList.class.equals(clazz);
     }
 }

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/TraitsInfo.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/TraitsInfo.java b/modules/core/src/flex/messaging/io/amf/TraitsInfo.java
index 63d8bf0..ccf4011 100644
--- a/modules/core/src/flex/messaging/io/amf/TraitsInfo.java
+++ b/modules/core/src/flex/messaging/io/amf/TraitsInfo.java
@@ -26,7 +26,7 @@ import java.util.List;
  * sending only the values of each instance of the type
  * as it occurs in the stream.
  *
- * @exclude
+ *
  */
 public class TraitsInfo
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/TranslationException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/TranslationException.java b/modules/core/src/flex/messaging/io/amf/translator/TranslationException.java
index 7bd4db3..e4e41ed 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/TranslationException.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/TranslationException.java
@@ -19,7 +19,7 @@ package flex.messaging.io.amf.translator;
 import flex.messaging.MessageException;
 
 /**
- * @exclude
+ *
  */
 public class TranslationException extends MessageException
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ActionScriptDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ActionScriptDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ActionScriptDecoder.java
index 10a8f81..0ca6c36 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ActionScriptDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ActionScriptDecoder.java
@@ -24,7 +24,7 @@ import java.util.Date;
 /**
  * Decode an ActionScript object (of some type) to a Java object (of some type).
  *
- * @exclude
+ *
  */
 public abstract class ActionScriptDecoder
 {
@@ -92,10 +92,7 @@ public abstract class ActionScriptDecoder
 
         else if (o instanceof Date)
         {
-            if (SerializationContext.getSerializationContext().supportDatesByReference)
-                return true;
-            else
-                return false;
+            return SerializationContext.getSerializationContext().supportDatesByReference;
         }
 
         else if (o instanceof Calendar)

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ArrayDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ArrayDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ArrayDecoder.java
index a5c113d..8563504 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ArrayDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ArrayDecoder.java
@@ -23,7 +23,7 @@ import java.lang.reflect.Array;
 import java.util.Collection;
 
 /**
- * @exclude
+ *
  * Decodes native Java Array, java.util.Collection, or
  * java.lang.String (to char[]) instances to a native
  * Java Array instance with desired component type.

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/BooleanDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/BooleanDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/BooleanDecoder.java
index 33b10ca..ae3e79d 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/BooleanDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/BooleanDecoder.java
@@ -25,7 +25,7 @@ package flex.messaging.io.amf.translator.decoder;
  * values will be interpreted as false.
  * </p>
  *
- * @exclude
+ *
  */
 public class BooleanDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/CalendarDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/CalendarDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/CalendarDecoder.java
index 5e70ead..285775b 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/CalendarDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/CalendarDecoder.java
@@ -31,7 +31,7 @@ import java.util.Date;
  * pointers to Date instances in our representation of an ActionScript
  * object graph.
  *
- * @exclude
+ *
  */
 public class CalendarDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/CharacterDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/CharacterDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/CharacterDecoder.java
index 509c407..b58c37f 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/CharacterDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/CharacterDecoder.java
@@ -24,7 +24,7 @@ package flex.messaging.io.amf.translator.decoder;
  * character in the String will be used.
  * </p>
  *
- * @exclude
+ *
  */
 public class CharacterDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/CollectionDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/CollectionDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/CollectionDecoder.java
index a8c78f1..f733adc 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/CollectionDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/CollectionDecoder.java
@@ -50,7 +50,7 @@ import java.util.TreeSet;
  *
  * @see java.util.Collection
  *
- * @exclude
+ *
  */
 public class CollectionDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/DateDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/DateDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/DateDecoder.java
index c6da90a..5aac5cb 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/DateDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/DateDecoder.java
@@ -30,7 +30,7 @@ import java.util.Calendar;
  * pointers to Date instances in our representation of an ActionScript
  * object graph.
  *
- * @exclude
+ *
  */
 public class DateDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/DecoderFactory.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/DecoderFactory.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/DecoderFactory.java
index a1812fd..71f366b 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/DecoderFactory.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/DecoderFactory.java
@@ -31,7 +31,7 @@ import java.util.Map;
  *
  * @see ActionScriptDecoder
  *
- * @exclude
+ *
  */
 public class DecoderFactory
 {
@@ -335,7 +335,7 @@ public class DecoderFactory
 
         if (encodedObject instanceof ASObject)
         {
-            typed = TypeMarshallingContext.getType((ASObject)encodedObject) != null;
+            typed = TypeMarshallingContext.getType(encodedObject) != null;
         }
 
         return typed;

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/EnumDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/EnumDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/EnumDecoder.java
index b566b83..926ae26 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/EnumDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/EnumDecoder.java
@@ -18,7 +18,7 @@ package flex.messaging.io.amf.translator.decoder;
 
 /**
  * Decode an ActionScript enumeration object (generally a string) to a Java enum.
- * @exclude
+ *
  */
 public class EnumDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/MapDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/MapDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/MapDecoder.java
index 2f0417e..60cbe15 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/MapDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/MapDecoder.java
@@ -26,7 +26,7 @@ import java.util.TreeMap;
 /**
  * Decodes an ActionScript object to a Java Map.
  *
- * @exclude
+ *
  */
 public class MapDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/NativeDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/NativeDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/NativeDecoder.java
index e37a7f5..8f9a775 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/NativeDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/NativeDecoder.java
@@ -19,7 +19,7 @@ package flex.messaging.io.amf.translator.decoder;
 /**
  * Decodes an ActionScript native object to a Java native object.
  *
- * @exclude
+ *
  */
 public class NativeDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/NullDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/NullDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/NullDecoder.java
index 0ea6fb8..26e1b7d 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/NullDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/NullDecoder.java
@@ -17,7 +17,7 @@
 package flex.messaging.io.amf.translator.decoder;
 
 /**
- * @exclude
+ *
  */
 public class NullDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/NumberDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/NumberDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/NumberDecoder.java
index e9bf158..90ce221 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/NumberDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/NumberDecoder.java
@@ -24,7 +24,7 @@ import flex.messaging.io.SerializationContext;
 /**
  * Decode an ActionScript type (a string or a double) to a Java number (of any type).
  *
- * @exclude
+ *
  */
 public class NumberDecoder extends ActionScriptDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareArrayDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareArrayDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareArrayDecoder.java
index 5262ec2..7101cfe 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareArrayDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareArrayDecoder.java
@@ -22,7 +22,7 @@ import java.util.Collection;
 import flex.messaging.io.TypeMarshallingContext;
 
 /**
- * @exclude
+ *
  */
 public class ReferenceAwareArrayDecoder extends ArrayDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCalendarDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCalendarDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCalendarDecoder.java
index 569bbea..e9d6dfb 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCalendarDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCalendarDecoder.java
@@ -20,7 +20,7 @@ import flex.messaging.io.SerializationContext;
 import flex.messaging.io.TypeMarshallingContext;
 
 /**
- * @exclude
+ *
  */
 public class ReferenceAwareCalendarDecoder extends CalendarDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCollectionDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCollectionDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCollectionDecoder.java
index db8fc4f..60b5681 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCollectionDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareCollectionDecoder.java
@@ -30,7 +30,7 @@ import java.lang.reflect.Array;
  * Note that tracking references is an expensive exercise and will
  * scale poorly with larger amounts of data.`
  *
- * @exclude
+ *
  */
 public class ReferenceAwareCollectionDecoder extends CollectionDecoder
 {
@@ -49,7 +49,7 @@ public class ReferenceAwareCollectionDecoder extends CollectionDecoder
 
     protected Collection decodeCollection(Collection shell, Object encodedObject)
     {
-        Collection decodedCollection = (Collection)shell;
+        Collection decodedCollection = shell;
         Object decodedObject = null;
         Object obj = null;
 

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareDateDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareDateDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareDateDecoder.java
index 290667d..849a85e 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareDateDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareDateDecoder.java
@@ -20,7 +20,7 @@ import flex.messaging.io.SerializationContext;
 import flex.messaging.io.TypeMarshallingContext;
 
 /**
- * @exclude
+ *
  */
 public class ReferenceAwareDateDecoder extends DateDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareMapDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareMapDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareMapDecoder.java
index f2933ba..85dcb85 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareMapDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareMapDecoder.java
@@ -22,7 +22,7 @@ import java.util.Map;
 import java.util.Iterator;
 
 /**
- * @exclude
+ *
  */
 public class ReferenceAwareMapDecoder extends MapDecoder
 {

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/56d1a01d/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareTypedObjectDecoder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareTypedObjectDecoder.java b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareTypedObjectDecoder.java
index 66656f6..4d38d38 100644
--- a/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareTypedObjectDecoder.java
+++ b/modules/core/src/flex/messaging/io/amf/translator/decoder/ReferenceAwareTypedObjectDecoder.java
@@ -26,7 +26,7 @@ import flex.messaging.io.TypeMarshallingContext;
 import flex.messaging.io.amf.translator.TranslationException;
 
 /**
- * @exclude
+ *
  */
 public class ReferenceAwareTypedObjectDecoder extends TypedObjectDecoder
 {