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 2014/05/05 22:08:50 UTC

[36/51] [partial] FLEX-34306 - [BlazeDS] Make the BlazeDS build run on Windows machines - Added some mkdir commands to the ANT Build.java - Did some fine-tuning to resolve some compile errors

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/MessageDestinationControl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/MessageDestinationControl.java b/modules/core/src/flex/management/runtime/messaging/MessageDestinationControl.java
old mode 100755
new mode 100644
index 2cefc37..f4c16f7
--- a/modules/core/src/flex/management/runtime/messaging/MessageDestinationControl.java
+++ b/modules/core/src/flex/management/runtime/messaging/MessageDestinationControl.java
@@ -1,312 +1,312 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging;
-
-import java.util.Date;
-import java.util.concurrent.atomic.AtomicInteger;
-
-import flex.management.BaseControl;
-import flex.management.runtime.AdminConsoleTypes;
-import flex.messaging.Destination;
-
-import javax.management.ObjectName;
-
-/**
- * The <code>MessageDestinationControl</code> class is the MBean implementation for
- * monitoring and managing a <code>MessageDestination</code> at runtime.
- * 
- * @author shodgson
- */
-public class MessageDestinationControl extends DestinationControl implements
-        MessageDestinationControlMBean
-{
-    private static final String TYPE = "MessageDestination";
-    private ObjectName messageCache;
-    private ObjectName throttleManager;
-    private ObjectName subscriptionManager;
-
-    private AtomicInteger serviceMessageCount = new AtomicInteger(0);
-    private Date lastServiceMessageTimestamp;
-    private long serviceMessageStart;
-    private AtomicInteger serviceCommandCount = new AtomicInteger(0);
-    private Date lastServiceCommandTimestamp;
-    private long serviceCommandStart;
-    private AtomicInteger serviceMessageFromAdapterCount = new AtomicInteger(0);
-    private Date lastServiceMessageFromAdapterTimestamp;
-    private long serviceMessageFromAdapterStart;   
-    /**
-     * Constructs a new <code>MessageDestinationControl</code> instance.
-     * 
-     * @param destination The destination managed by this MBean.
-     * @param parent The parent MBean in the management hierarchy.
-     */
-    public MessageDestinationControl(Destination destination, BaseControl parent)
-    {
-        super(destination, parent);          
-        serviceMessageStart = System.currentTimeMillis();
-        serviceCommandStart = serviceMessageStart;
-        serviceMessageFromAdapterStart = serviceMessageStart;             
-    }
-    
-    protected void onRegistrationComplete()
-    {
-        String name = this.getObjectName().getCanonicalName();
-        
-        String[] pollablePerInterval = { "ServiceCommandCount", "ServiceMessageCount",
-                "ServiceMessageFromAdapterCount" };
-        String[] pollableGeneral = { "ServiceCommandFrequency", "ServiceMessageFrequency",
-                "ServiceMessageFromAdapterFrequency", "LastServiceCommandTimestamp", 
-                "LastServiceMessageTimestamp", "LastServiceMessageFromAdapterTimestamp"};
-        
-        getRegistrar().registerObjects(
-                new int[] {AdminConsoleTypes.DESTINATION_POLLABLE, AdminConsoleTypes.GRAPH_BY_POLL_INTERVAL},
-                name, pollablePerInterval);
-        getRegistrar().registerObjects(AdminConsoleTypes.DESTINATION_POLLABLE, name,
-                pollableGeneral);
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.BaseControlMBean#getType()
-     */
-    public String getType()
-    {
-        return TYPE;
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.MessageDestinationControlMBean#getMessageCache()
-     */
-    public ObjectName getMessageCache()
-    {
-        return messageCache;
-    }
-    
-    /**
-     * Sets the <code>ObjectName</code> for the message cache used by the managed destination.
-     * 
-     * @param value The <code>ObjectName</code> for the message cache.
-     */
-    public void setMessageCache(ObjectName value)
-    {
-        messageCache = value;
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.MessageDestinationControlMBean#getThrottleManager()
-     */
-    public ObjectName getThrottleManager()
-    {
-        return throttleManager;
-    }
-    
-    /**
-     * Sets the <code>ObjectName</code> for the throttle manager used by the managed destination.
-     * 
-     * @param value The <code>ObjectName</code> for the throttle manager.
-     */
-    public void setThrottleManager(ObjectName value)
-    {
-        throttleManager = value;
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.MessageDestinationControlMBean#getSubscriptionManager()
-     */
-    public ObjectName getSubscriptionManager()
-    {
-        return subscriptionManager;
-    }
-    
-    /**
-     * Sets the <code>ObjectName</code> for the subscription manager used by the managed destination.
-     * 
-     * @param value The <code>ObjectName</code> for the subscription manager.
-     */
-    public void setSubscriptionManager(ObjectName value)
-    {
-        subscriptionManager = value;
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageCount()
-     */
-    public Integer getServiceMessageCount()
-    {
-        return Integer.valueOf(serviceMessageCount.get());
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#resetServiceMessageCount()
-     */
-    public void resetServiceMessageCount()
-    {
-        serviceMessageStart = System.currentTimeMillis();
-        serviceMessageCount = new AtomicInteger(0);
-        lastServiceMessageTimestamp = null;
-    }
-    
-    /**
-     * Increments the count of messages serviced.
-     */
-    public void incrementServiceMessageCount()
-    {
-        serviceMessageCount.incrementAndGet();
-        lastServiceMessageTimestamp = new Date();
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getLastServiceMessageTimestamp()
-     */
-    public Date getLastServiceMessageTimestamp()
-    {
-        return lastServiceMessageTimestamp;
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageFrequency()
-     */
-    public Double getServiceMessageFrequency()
-    {
-        if (serviceMessageCount.get() > 0)
-        {
-            double runtime = differenceInMinutes(serviceMessageStart, System.currentTimeMillis());
-            return new Double(serviceMessageCount.get()/runtime);
-        }
-        else
-        {
-            return new Double(0);
-        }
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceCommandCount()
-     */
-    public Integer getServiceCommandCount()
-    {        
-        return Integer.valueOf(serviceCommandCount.get());
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#resetServiceCommandCount()
-     */
-    public void resetServiceCommandCount()
-    {
-        serviceCommandStart = System.currentTimeMillis();
-        serviceCommandCount = new AtomicInteger(0);
-        lastServiceCommandTimestamp = null;
-    }
-    
-    /**
-     * Increments the count of command messages serviced.
-     */
-    public void incrementServiceCommandCount()
-    {
-        serviceCommandCount.incrementAndGet();
-        lastServiceCommandTimestamp = new Date();
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getLastServiceCommandTimestamp()
-     */
-    public Date getLastServiceCommandTimestamp()
-    {
-        return lastServiceCommandTimestamp;
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceCommandFrequency()
-     */
-    public Double getServiceCommandFrequency()
-    {
-        if (serviceCommandCount.get() > 0)
-        {
-            double runtime = differenceInMinutes(serviceCommandStart, System.currentTimeMillis());
-            return new Double(serviceCommandCount.get()/runtime);
-        }
-        else
-        {
-            return new Double(0);
-        }
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageFromAdapterCount()
-     */
-    public Integer getServiceMessageFromAdapterCount()
-    {
-        return Integer.valueOf(serviceMessageFromAdapterCount.get());
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#resetServiceMessageFromAdapterCount()
-     */
-    public void resetServiceMessageFromAdapterCount()
-    {
-        serviceMessageFromAdapterStart = System.currentTimeMillis();
-        serviceMessageFromAdapterCount = new AtomicInteger(0);
-        lastServiceMessageFromAdapterTimestamp = null;
-    }
-    
-    /**
-     * Increments the count of messages from adapters processed.
-     */
-    public void incrementServiceMessageFromAdapterCount()
-    {
-        serviceMessageFromAdapterCount.incrementAndGet();
-        lastServiceMessageFromAdapterTimestamp = new Date();
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getLastServiceMessageFromAdapterTimestamp()
-     */
-    public Date getLastServiceMessageFromAdapterTimestamp()
-    {
-        return lastServiceMessageFromAdapterTimestamp;
-    }
-    
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageFromAdapterFrequency()
-     */
-    public Double getServiceMessageFromAdapterFrequency()
-    {
-        if (serviceMessageFromAdapterCount.get() > 0)
-        {
-            double runtime = differenceInMinutes(serviceMessageFromAdapterStart, System.currentTimeMillis());
-            return new Double(serviceMessageFromAdapterCount.get()/runtime);
-        }
-        else
-        {
-            return new Double(0);
-        }
-    }    
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging;
+
+import java.util.Date;
+import java.util.concurrent.atomic.AtomicInteger;
+
+import flex.management.BaseControl;
+import flex.management.runtime.AdminConsoleTypes;
+import flex.messaging.Destination;
+
+import javax.management.ObjectName;
+
+/**
+ * The <code>MessageDestinationControl</code> class is the MBean implementation for
+ * monitoring and managing a <code>MessageDestination</code> at runtime.
+ * 
+ * @author shodgson
+ */
+public class MessageDestinationControl extends DestinationControl implements
+        MessageDestinationControlMBean
+{
+    private static final String TYPE = "MessageDestination";
+    private ObjectName messageCache;
+    private ObjectName throttleManager;
+    private ObjectName subscriptionManager;
+
+    private AtomicInteger serviceMessageCount = new AtomicInteger(0);
+    private Date lastServiceMessageTimestamp;
+    private long serviceMessageStart;
+    private AtomicInteger serviceCommandCount = new AtomicInteger(0);
+    private Date lastServiceCommandTimestamp;
+    private long serviceCommandStart;
+    private AtomicInteger serviceMessageFromAdapterCount = new AtomicInteger(0);
+    private Date lastServiceMessageFromAdapterTimestamp;
+    private long serviceMessageFromAdapterStart;   
+    /**
+     * Constructs a new <code>MessageDestinationControl</code> instance.
+     * 
+     * @param destination The destination managed by this MBean.
+     * @param parent The parent MBean in the management hierarchy.
+     */
+    public MessageDestinationControl(Destination destination, BaseControl parent)
+    {
+        super(destination, parent);          
+        serviceMessageStart = System.currentTimeMillis();
+        serviceCommandStart = serviceMessageStart;
+        serviceMessageFromAdapterStart = serviceMessageStart;             
+    }
+    
+    protected void onRegistrationComplete()
+    {
+        String name = this.getObjectName().getCanonicalName();
+        
+        String[] pollablePerInterval = { "ServiceCommandCount", "ServiceMessageCount",
+                "ServiceMessageFromAdapterCount" };
+        String[] pollableGeneral = { "ServiceCommandFrequency", "ServiceMessageFrequency",
+                "ServiceMessageFromAdapterFrequency", "LastServiceCommandTimestamp", 
+                "LastServiceMessageTimestamp", "LastServiceMessageFromAdapterTimestamp"};
+        
+        getRegistrar().registerObjects(
+                new int[] {AdminConsoleTypes.DESTINATION_POLLABLE, AdminConsoleTypes.GRAPH_BY_POLL_INTERVAL},
+                name, pollablePerInterval);
+        getRegistrar().registerObjects(AdminConsoleTypes.DESTINATION_POLLABLE, name,
+                pollableGeneral);
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.BaseControlMBean#getType()
+     */
+    public String getType()
+    {
+        return TYPE;
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.MessageDestinationControlMBean#getMessageCache()
+     */
+    public ObjectName getMessageCache()
+    {
+        return messageCache;
+    }
+    
+    /**
+     * Sets the <code>ObjectName</code> for the message cache used by the managed destination.
+     * 
+     * @param value The <code>ObjectName</code> for the message cache.
+     */
+    public void setMessageCache(ObjectName value)
+    {
+        messageCache = value;
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.MessageDestinationControlMBean#getThrottleManager()
+     */
+    public ObjectName getThrottleManager()
+    {
+        return throttleManager;
+    }
+    
+    /**
+     * Sets the <code>ObjectName</code> for the throttle manager used by the managed destination.
+     * 
+     * @param value The <code>ObjectName</code> for the throttle manager.
+     */
+    public void setThrottleManager(ObjectName value)
+    {
+        throttleManager = value;
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.MessageDestinationControlMBean#getSubscriptionManager()
+     */
+    public ObjectName getSubscriptionManager()
+    {
+        return subscriptionManager;
+    }
+    
+    /**
+     * Sets the <code>ObjectName</code> for the subscription manager used by the managed destination.
+     * 
+     * @param value The <code>ObjectName</code> for the subscription manager.
+     */
+    public void setSubscriptionManager(ObjectName value)
+    {
+        subscriptionManager = value;
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageCount()
+     */
+    public Integer getServiceMessageCount()
+    {
+        return Integer.valueOf(serviceMessageCount.get());
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#resetServiceMessageCount()
+     */
+    public void resetServiceMessageCount()
+    {
+        serviceMessageStart = System.currentTimeMillis();
+        serviceMessageCount = new AtomicInteger(0);
+        lastServiceMessageTimestamp = null;
+    }
+    
+    /**
+     * Increments the count of messages serviced.
+     */
+    public void incrementServiceMessageCount()
+    {
+        serviceMessageCount.incrementAndGet();
+        lastServiceMessageTimestamp = new Date();
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getLastServiceMessageTimestamp()
+     */
+    public Date getLastServiceMessageTimestamp()
+    {
+        return lastServiceMessageTimestamp;
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageFrequency()
+     */
+    public Double getServiceMessageFrequency()
+    {
+        if (serviceMessageCount.get() > 0)
+        {
+            double runtime = differenceInMinutes(serviceMessageStart, System.currentTimeMillis());
+            return new Double(serviceMessageCount.get()/runtime);
+        }
+        else
+        {
+            return new Double(0);
+        }
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceCommandCount()
+     */
+    public Integer getServiceCommandCount()
+    {        
+        return Integer.valueOf(serviceCommandCount.get());
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#resetServiceCommandCount()
+     */
+    public void resetServiceCommandCount()
+    {
+        serviceCommandStart = System.currentTimeMillis();
+        serviceCommandCount = new AtomicInteger(0);
+        lastServiceCommandTimestamp = null;
+    }
+    
+    /**
+     * Increments the count of command messages serviced.
+     */
+    public void incrementServiceCommandCount()
+    {
+        serviceCommandCount.incrementAndGet();
+        lastServiceCommandTimestamp = new Date();
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getLastServiceCommandTimestamp()
+     */
+    public Date getLastServiceCommandTimestamp()
+    {
+        return lastServiceCommandTimestamp;
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceCommandFrequency()
+     */
+    public Double getServiceCommandFrequency()
+    {
+        if (serviceCommandCount.get() > 0)
+        {
+            double runtime = differenceInMinutes(serviceCommandStart, System.currentTimeMillis());
+            return new Double(serviceCommandCount.get()/runtime);
+        }
+        else
+        {
+            return new Double(0);
+        }
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageFromAdapterCount()
+     */
+    public Integer getServiceMessageFromAdapterCount()
+    {
+        return Integer.valueOf(serviceMessageFromAdapterCount.get());
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#resetServiceMessageFromAdapterCount()
+     */
+    public void resetServiceMessageFromAdapterCount()
+    {
+        serviceMessageFromAdapterStart = System.currentTimeMillis();
+        serviceMessageFromAdapterCount = new AtomicInteger(0);
+        lastServiceMessageFromAdapterTimestamp = null;
+    }
+    
+    /**
+     * Increments the count of messages from adapters processed.
+     */
+    public void incrementServiceMessageFromAdapterCount()
+    {
+        serviceMessageFromAdapterCount.incrementAndGet();
+        lastServiceMessageFromAdapterTimestamp = new Date();
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getLastServiceMessageFromAdapterTimestamp()
+     */
+    public Date getLastServiceMessageFromAdapterTimestamp()
+    {
+        return lastServiceMessageFromAdapterTimestamp;
+    }
+    
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.messaging.MessageDestinationControlMBean#getServiceMessageFromAdapterFrequency()
+     */
+    public Double getServiceMessageFromAdapterFrequency()
+    {
+        if (serviceMessageFromAdapterCount.get() > 0)
+        {
+            double runtime = differenceInMinutes(serviceMessageFromAdapterStart, System.currentTimeMillis());
+            return new Double(serviceMessageFromAdapterCount.get()/runtime);
+        }
+        else
+        {
+            return new Double(0);
+        }
+    }    
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/MessageDestinationControlMBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/MessageDestinationControlMBean.java b/modules/core/src/flex/management/runtime/messaging/MessageDestinationControlMBean.java
old mode 100755
new mode 100644
index 43da0a7..fa8551e
--- a/modules/core/src/flex/management/runtime/messaging/MessageDestinationControlMBean.java
+++ b/modules/core/src/flex/management/runtime/messaging/MessageDestinationControlMBean.java
@@ -1,155 +1,155 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging;
-
-import java.io.IOException;
-import java.util.Date;
-
-import javax.management.ObjectName;
-
-
-/**
- * Defines the runtime monitoring and management interface for managed
- * <code>MessageDestination</code>s.
- *
- * @author shodgson
- */
-public interface MessageDestinationControlMBean extends DestinationControlMBean
-{
-    /**
-     * Returns the <code>ObjectName</code> for the message cache used by the managed
-     * destination.
-     *
-     * @return The <code>ObjectName</code> for the message cache.
-     * @throws IOException Throws IOException.
-     */
-    ObjectName getMessageCache() throws IOException;
-
-    /**
-     * Returns the <code>ObjectName</code> for the throttle manager used by the
-     * managed destination.
-     *
-     * @return The <code>ObjectName</code> for the throttle manager.
-     * @throws IOException Throws IOException.
-     */
-    ObjectName getThrottleManager() throws IOException;
-
-    /**
-     * Returns the <code>ObjectName</code> for the subscription manager used
-     * by the managed destination.
-     *
-     * @return The <code>ObjectName</code> for the subscription manager.
-     * @throws IOException Throws IOException.
-     */
-    ObjectName getSubscriptionManager() throws IOException;
-
-    /**
-     * Returns the number of service message invocations.
-     *
-     * @return The number of service message invocations.
-     * @throws IOException Throws IOException.
-     */
-    Integer getServiceMessageCount() throws IOException;
-
-    /**
-     * Resets the count of service message invocations.
-     *
-     * @throws IOException Throws IOException.
-     */
-    void resetServiceMessageCount() throws IOException;
-
-    /**
-     * Returns the timestamp for the most recent service message
-     * invocation.
-     *
-     * @return The timestamp for the most recent service message invocation.
-     * @throws IOException Throws IOException.
-     */
-    Date getLastServiceMessageTimestamp() throws IOException;
-
-    /**
-     * Returns the number of service message invocations per minute.
-     *
-     * @return The number of service message invocations per minute.
-     * @throws IOException Throws IOException.
-     */
-    Double getServiceMessageFrequency() throws IOException;
-
-    /**
-     * Returns the number of service command invocations.
-     *
-     * @return The number of service command invocations.
-     * @throws IOException Throws IOException.
-     */
-    Integer getServiceCommandCount() throws IOException;
-
-    /**
-     * Resets the count of service command invocations.
-     *
-     * @throws IOException Throws IOException.
-     */
-    void resetServiceCommandCount() throws IOException;
-
-    /**
-     * Returns the timestamp for the most recent service command invocation.
-     *
-     * @return The timestamp for the most recent service command invocation.
-     * @throws IOException Throws IOException.
-     */
-    Date getLastServiceCommandTimestamp() throws IOException;
-
-    /**
-     * Returns the number of service command invocations per minute.
-     *
-     * @return The number of service command invocations per minute.
-     * @throws IOException Throws IOException.
-     */
-    Double getServiceCommandFrequency() throws IOException;
-
-    /**
-     * Returns the number of messages from an adapter that the managed service
-     * has processed.
-     *
-     * @return The number of messages from an adapter that the managed service
-     * has processed
-     * @throws IOException Throws IOException.
-     */
-    Integer getServiceMessageFromAdapterCount() throws IOException;
-
-    /**
-     * Resets the count of service message from adapter invocations.
-     *
-     * @throws IOException Throws IOException.
-     */
-    void resetServiceMessageFromAdapterCount() throws IOException;
-
-    /**
-     * Returns the timestamp of the most recent service message from adapter invocation.
-     *
-     * @return The timestamp of the most recent service message from adapter invocation.
-     * @throws IOException Throws IOException.
-     */
-    Date getLastServiceMessageFromAdapterTimestamp() throws IOException;
-
-    /**
-     * Returns the number of service message from adapter invocations per minute.
-     *
-     * @return The number of service message from adapter invocations per minute.
-     * @throws IOException Throws IOException.
-     */
-    Double getServiceMessageFromAdapterFrequency() throws IOException;
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging;
+
+import java.io.IOException;
+import java.util.Date;
+
+import javax.management.ObjectName;
+
+
+/**
+ * Defines the runtime monitoring and management interface for managed
+ * <code>MessageDestination</code>s.
+ *
+ * @author shodgson
+ */
+public interface MessageDestinationControlMBean extends DestinationControlMBean
+{
+    /**
+     * Returns the <code>ObjectName</code> for the message cache used by the managed
+     * destination.
+     *
+     * @return The <code>ObjectName</code> for the message cache.
+     * @throws IOException Throws IOException.
+     */
+    ObjectName getMessageCache() throws IOException;
+
+    /**
+     * Returns the <code>ObjectName</code> for the throttle manager used by the
+     * managed destination.
+     *
+     * @return The <code>ObjectName</code> for the throttle manager.
+     * @throws IOException Throws IOException.
+     */
+    ObjectName getThrottleManager() throws IOException;
+
+    /**
+     * Returns the <code>ObjectName</code> for the subscription manager used
+     * by the managed destination.
+     *
+     * @return The <code>ObjectName</code> for the subscription manager.
+     * @throws IOException Throws IOException.
+     */
+    ObjectName getSubscriptionManager() throws IOException;
+
+    /**
+     * Returns the number of service message invocations.
+     *
+     * @return The number of service message invocations.
+     * @throws IOException Throws IOException.
+     */
+    Integer getServiceMessageCount() throws IOException;
+
+    /**
+     * Resets the count of service message invocations.
+     *
+     * @throws IOException Throws IOException.
+     */
+    void resetServiceMessageCount() throws IOException;
+
+    /**
+     * Returns the timestamp for the most recent service message
+     * invocation.
+     *
+     * @return The timestamp for the most recent service message invocation.
+     * @throws IOException Throws IOException.
+     */
+    Date getLastServiceMessageTimestamp() throws IOException;
+
+    /**
+     * Returns the number of service message invocations per minute.
+     *
+     * @return The number of service message invocations per minute.
+     * @throws IOException Throws IOException.
+     */
+    Double getServiceMessageFrequency() throws IOException;
+
+    /**
+     * Returns the number of service command invocations.
+     *
+     * @return The number of service command invocations.
+     * @throws IOException Throws IOException.
+     */
+    Integer getServiceCommandCount() throws IOException;
+
+    /**
+     * Resets the count of service command invocations.
+     *
+     * @throws IOException Throws IOException.
+     */
+    void resetServiceCommandCount() throws IOException;
+
+    /**
+     * Returns the timestamp for the most recent service command invocation.
+     *
+     * @return The timestamp for the most recent service command invocation.
+     * @throws IOException Throws IOException.
+     */
+    Date getLastServiceCommandTimestamp() throws IOException;
+
+    /**
+     * Returns the number of service command invocations per minute.
+     *
+     * @return The number of service command invocations per minute.
+     * @throws IOException Throws IOException.
+     */
+    Double getServiceCommandFrequency() throws IOException;
+
+    /**
+     * Returns the number of messages from an adapter that the managed service
+     * has processed.
+     *
+     * @return The number of messages from an adapter that the managed service
+     * has processed
+     * @throws IOException Throws IOException.
+     */
+    Integer getServiceMessageFromAdapterCount() throws IOException;
+
+    /**
+     * Resets the count of service message from adapter invocations.
+     *
+     * @throws IOException Throws IOException.
+     */
+    void resetServiceMessageFromAdapterCount() throws IOException;
+
+    /**
+     * Returns the timestamp of the most recent service message from adapter invocation.
+     *
+     * @return The timestamp of the most recent service message from adapter invocation.
+     * @throws IOException Throws IOException.
+     */
+    Date getLastServiceMessageFromAdapterTimestamp() throws IOException;
+
+    /**
+     * Returns the number of service message from adapter invocations per minute.
+     *
+     * @return The number of service message from adapter invocations per minute.
+     * @throws IOException Throws IOException.
+     */
+    Double getServiceMessageFromAdapterFrequency() throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControl.java b/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControl.java
old mode 100755
new mode 100644
index 70fe26b..6bb1c71
--- a/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControl.java
+++ b/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControl.java
@@ -1,99 +1,99 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.client;
-
-import flex.management.BaseControl;
-import flex.management.runtime.AdminConsoleTypes;
-import flex.messaging.client.FlexClientManager;
-
-/**
- * @author majacobs
- *
- * @exclude
- */
-public class FlexClientManagerControl extends BaseControl implements FlexClientManagerControlMBean
-{
-    private FlexClientManager flexClientManager;
-    
-    public FlexClientManagerControl(BaseControl parent, FlexClientManager manager)
-    {
-        super(parent);        
-        flexClientManager = manager;
-    }
-    
-    public void onRegistrationComplete()
-    {
-        String name = getObjectName().getCanonicalName();
-        getRegistrar().registerObject(AdminConsoleTypes.GENERAL_POLLABLE, name, "FlexClientCount");
-    }
-
-    /* (non-Javadoc)
-     * @see flex.management.BaseControl#getId()
-     */
-    public String getId()
-    {
-        return flexClientManager.getId();
-    }
-
-    /* (non-Javadoc)
-     * @see flex.management.BaseControl#getType()
-     */
-    public String getType()
-    {
-        return flexClientManager.getId();
-    }
-
-    /* (non-Javadoc)
-     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientIds()
-     */
-    public String[] getClientIds() 
-    {
-        return flexClientManager.getClientIds();
-    }
-
-    /* (non-Javadoc)
-     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientLastUse(java.lang.String)
-     */
-    public Long getClientLastUse(String clientId)
-    {
-        return new Long(flexClientManager.getFlexClient(clientId).getLastUse());
-    }
-
-    /* (non-Javadoc)
-     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientSessionCount(java.lang.String)
-     */
-    public Integer getClientSessionCount(String clientId)
-    {
-        return new Integer(flexClientManager.getFlexClient(clientId).getSessionCount());
-    }
-
-    /* (non-Javadoc)
-     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientSubscriptionCount(java.lang.String)
-     */
-    public Integer getClientSubscriptionCount(String clientId)
-    {
-        return new Integer(flexClientManager.getFlexClient(clientId).getSubscriptionCount());
-    }
-    
-    /* (non-Javadoc)
-     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getFlexClientCount()
-     */
-    public Integer getFlexClientCount() 
-    {
-        return new Integer(flexClientManager.getFlexClientCount());
-    }    
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.client;
+
+import flex.management.BaseControl;
+import flex.management.runtime.AdminConsoleTypes;
+import flex.messaging.client.FlexClientManager;
+
+/**
+ * @author majacobs
+ *
+ * @exclude
+ */
+public class FlexClientManagerControl extends BaseControl implements FlexClientManagerControlMBean
+{
+    private FlexClientManager flexClientManager;
+    
+    public FlexClientManagerControl(BaseControl parent, FlexClientManager manager)
+    {
+        super(parent);        
+        flexClientManager = manager;
+    }
+    
+    public void onRegistrationComplete()
+    {
+        String name = getObjectName().getCanonicalName();
+        getRegistrar().registerObject(AdminConsoleTypes.GENERAL_POLLABLE, name, "FlexClientCount");
+    }
+
+    /* (non-Javadoc)
+     * @see flex.management.BaseControl#getId()
+     */
+    public String getId()
+    {
+        return flexClientManager.getId();
+    }
+
+    /* (non-Javadoc)
+     * @see flex.management.BaseControl#getType()
+     */
+    public String getType()
+    {
+        return flexClientManager.getId();
+    }
+
+    /* (non-Javadoc)
+     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientIds()
+     */
+    public String[] getClientIds() 
+    {
+        return flexClientManager.getClientIds();
+    }
+
+    /* (non-Javadoc)
+     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientLastUse(java.lang.String)
+     */
+    public Long getClientLastUse(String clientId)
+    {
+        return new Long(flexClientManager.getFlexClient(clientId).getLastUse());
+    }
+
+    /* (non-Javadoc)
+     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientSessionCount(java.lang.String)
+     */
+    public Integer getClientSessionCount(String clientId)
+    {
+        return new Integer(flexClientManager.getFlexClient(clientId).getSessionCount());
+    }
+
+    /* (non-Javadoc)
+     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getClientSubscriptionCount(java.lang.String)
+     */
+    public Integer getClientSubscriptionCount(String clientId)
+    {
+        return new Integer(flexClientManager.getFlexClient(clientId).getSubscriptionCount());
+    }
+    
+    /* (non-Javadoc)
+     * @see flex.management.runtime.messaging.client.FlexClientManagerControlMBean#getFlexClientCount()
+     */
+    public Integer getFlexClientCount() 
+    {
+        return new Integer(flexClientManager.getFlexClientCount());
+    }    
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControlMBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControlMBean.java b/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControlMBean.java
old mode 100755
new mode 100644
index f56419b..f063259
--- a/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControlMBean.java
+++ b/modules/core/src/flex/management/runtime/messaging/client/FlexClientManagerControlMBean.java
@@ -1,70 +1,70 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.client;
-
-import java.io.IOException;
-
-import flex.management.BaseControlMBean;
-
-/**
- * Defines the runtime monitoring and management interface for managed flex client managers.
- */
-public interface FlexClientManagerControlMBean extends BaseControlMBean
-{
-    /**
-     * Returns ids of managed clients.
-     *
-     * @return An array of client ids.
-     * @throws IOException Throws IOException.
-     */
-    String[] getClientIds() throws IOException;
-
-    /**
-     * Returns the number of subscriptions for the client with the clientId.
-     *
-     * @param clientId The client id.
-     * @return The number of subscriptions for the client with the cliendId
-     * @throws IOException Throws IOException.
-     */
-    Integer getClientSubscriptionCount(String clientId) throws IOException;
-
-    /**
-     * Returns the number of sessiosn for the client with the clientId.
-     *
-     * @param clientId The client id.
-     * @return The number of sessions for the client with the cliendId
-     * @throws IOException Throws IOException.
-     */
-    Integer getClientSessionCount(String clientId) throws IOException;
-
-    /**
-     * Returns the last use by the client with the clientId.
-     *
-     * @param clientId The client id.
-     * @return The last use by the client with the clientId
-     * @throws IOException Throws IOException.
-     */
-    Long getClientLastUse(String clientId) throws IOException;
-
-    /**
-     * Returns the number of clients.
-     *
-     * @return The number of clients.
-     * @throws IOException Throws IOException.
-     */
-    Integer getFlexClientCount() throws IOException;
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.client;
+
+import java.io.IOException;
+
+import flex.management.BaseControlMBean;
+
+/**
+ * Defines the runtime monitoring and management interface for managed flex client managers.
+ */
+public interface FlexClientManagerControlMBean extends BaseControlMBean
+{
+    /**
+     * Returns ids of managed clients.
+     *
+     * @return An array of client ids.
+     * @throws IOException Throws IOException.
+     */
+    String[] getClientIds() throws IOException;
+
+    /**
+     * Returns the number of subscriptions for the client with the clientId.
+     *
+     * @param clientId The client id.
+     * @return The number of subscriptions for the client with the cliendId
+     * @throws IOException Throws IOException.
+     */
+    Integer getClientSubscriptionCount(String clientId) throws IOException;
+
+    /**
+     * Returns the number of sessiosn for the client with the clientId.
+     *
+     * @param clientId The client id.
+     * @return The number of sessions for the client with the cliendId
+     * @throws IOException Throws IOException.
+     */
+    Integer getClientSessionCount(String clientId) throws IOException;
+
+    /**
+     * Returns the last use by the client with the clientId.
+     *
+     * @param clientId The client id.
+     * @return The last use by the client with the clientId
+     * @throws IOException Throws IOException.
+     */
+    Long getClientLastUse(String clientId) throws IOException;
+
+    /**
+     * Returns the number of clients.
+     *
+     * @return The number of clients.
+     * @throws IOException Throws IOException.
+     */
+    Integer getFlexClientCount() throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/client/package-info.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/client/package-info.java b/modules/core/src/flex/management/runtime/messaging/client/package-info.java
old mode 100755
new mode 100644
index e09baf8..713b8b3
--- a/modules/core/src/flex/management/runtime/messaging/client/package-info.java
+++ b/modules/core/src/flex/management/runtime/messaging/client/package-info.java
@@ -1,17 +1,17 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package flex.management.runtime.messaging.client;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControl.java b/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControl.java
old mode 100755
new mode 100644
index f127ba6..88d877b
--- a/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControl.java
+++ b/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControl.java
@@ -1,50 +1,50 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.endpoints;
-
-import flex.management.BaseControl;
-import flex.messaging.endpoints.AMFEndpoint;
-
-/**
- * The <code>AMFEndpointControl</code> class is the MBean implemenation
- * for monitoring and managing an <code>AMFEndpoint</code> at runtime.
- *
- * @author shodgson
- */
-public class AMFEndpointControl extends PollingEndpointControl implements
-        AMFEndpointControlMBean
-{
-    private static final String TYPE = "AMFEndpoint";
-
-    /**
-     * Constructs a <code>AMFEndpointControl</code>, assigning managed message
-     * endpoint and parent MBean.
-     *
-     * @param endpoint The <code>AMFEndpoint</code> managed by this MBean.
-     * @param parent The parent MBean in the management hierarchy.
-     */
-    public AMFEndpointControl(AMFEndpoint endpoint, BaseControl parent)
-    {
-        super(endpoint, parent);
-    }
-
-    /** {@inheritDoc} */
-    public String getType()
-    {
-        return TYPE;
-    }
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.endpoints;
+
+import flex.management.BaseControl;
+import flex.messaging.endpoints.AMFEndpoint;
+
+/**
+ * The <code>AMFEndpointControl</code> class is the MBean implemenation
+ * for monitoring and managing an <code>AMFEndpoint</code> at runtime.
+ *
+ * @author shodgson
+ */
+public class AMFEndpointControl extends PollingEndpointControl implements
+        AMFEndpointControlMBean
+{
+    private static final String TYPE = "AMFEndpoint";
+
+    /**
+     * Constructs a <code>AMFEndpointControl</code>, assigning managed message
+     * endpoint and parent MBean.
+     *
+     * @param endpoint The <code>AMFEndpoint</code> managed by this MBean.
+     * @param parent The parent MBean in the management hierarchy.
+     */
+    public AMFEndpointControl(AMFEndpoint endpoint, BaseControl parent)
+    {
+        super(endpoint, parent);
+    }
+
+    /** {@inheritDoc} */
+    public String getType()
+    {
+        return TYPE;
+    }
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControlMBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControlMBean.java b/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControlMBean.java
old mode 100755
new mode 100644
index 6c221b8..0beb412
--- a/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControlMBean.java
+++ b/modules/core/src/flex/management/runtime/messaging/endpoints/AMFEndpointControlMBean.java
@@ -1,28 +1,28 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.endpoints;
-
-
-/**
- * Defines the runtime monitoring and management interface for managed AMF endpoints.
- *
- * @author shodgson
- */
-public interface AMFEndpointControlMBean extends PollingEndpointControlMBean
-{
-    // Empty for now.
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.endpoints;
+
+
+/**
+ * Defines the runtime monitoring and management interface for managed AMF endpoints.
+ *
+ * @author shodgson
+ */
+public interface AMFEndpointControlMBean extends PollingEndpointControlMBean
+{
+    // Empty for now.
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControl.java b/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControl.java
old mode 100755
new mode 100644
index 2d127ce..6e7e417
--- a/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControl.java
+++ b/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControl.java
@@ -1,241 +1,241 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.endpoints;
-
-import flex.management.BaseControl;
-import flex.management.runtime.AdminConsoleTypes;
-import flex.management.runtime.messaging.MessageBrokerControl;
-import flex.messaging.config.SecurityConstraint;
-import flex.messaging.endpoints.Endpoint;
-
-import java.util.Date;
-import java.util.List;
-import java.util.concurrent.atomic.AtomicInteger;
-import java.util.concurrent.atomic.AtomicLong;
-
-/**
- * The <code>EndpointControl</code> class is the MBean implementation for
- * monitoring and managing an <code>Endpoint</code> at runtime.
- *
- * @author shodgson
- */
-public abstract class EndpointControl extends BaseControl implements EndpointControlMBean
-{
-    protected Endpoint endpoint;
-    private AtomicInteger serviceMessageCount = new AtomicInteger(0);
-    private Date lastServiceMessageTimestamp;
-    private long serviceMessageStart;
-    private AtomicLong bytesDeserialized = new AtomicLong(0);
-    private AtomicLong bytesSerialized = new AtomicLong(0);
-
-    /**
-     * Constructs an <code>EndpointControl</code>, assigning its managed endpoint and
-     * parent MBean.
-     *
-     * @param endpoint The <code>Endpoint</code> managed by this MBean.
-     * @param parent The parent MBean in the management hierarchy.
-     */
-    public EndpointControl(Endpoint endpoint, BaseControl parent)
-    {
-        super(parent);
-        this.endpoint = endpoint;
-        serviceMessageStart = System.currentTimeMillis();
-    }
-
-
-    protected void onRegistrationComplete()
-    {
-        String name = this.getObjectName().getCanonicalName();
-        String[] generalNames = { "SecurityConstraint"};
-        String[] generalPollables = { "ServiceMessageCount", "LastServiceMessageTimestamp", "ServiceMessageFrequency"};
-        String[] pollableGraphByInterval = {"BytesDeserialized", "BytesSerialized"};
-
-        getRegistrar().registerObjects(AdminConsoleTypes.ENDPOINT_SCALAR,
-                name, generalNames);
-        getRegistrar().registerObjects(AdminConsoleTypes.ENDPOINT_POLLABLE,
-                name, generalPollables);
-        getRegistrar().registerObjects(new int[] {AdminConsoleTypes.GRAPH_BY_POLL_INTERVAL, AdminConsoleTypes.ENDPOINT_POLLABLE},
-                name, pollableGraphByInterval);
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.BaseControlMBean#getId()
-     */
-    public String getId()
-    {
-        return endpoint.getId();
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#isRunning()
-     */
-    public Boolean isRunning()
-    {
-        return Boolean.valueOf(endpoint.isStarted());
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#getStartTimestamp()
-     */
-    public Date getStartTimestamp()
-    {
-        return startTimestamp;
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#getServiceMessageCount()
-     */
-    public Integer getServiceMessageCount()
-    {
-        return Integer.valueOf(serviceMessageCount.get());
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#resetServiceMessageCount()
-     */
-    public void resetServiceMessageCount()
-    {
-        serviceMessageStart = System.currentTimeMillis();
-        serviceMessageCount = new AtomicInteger(0);
-        lastServiceMessageTimestamp = null;
-    }
-
-    /**
-     * Increments the count of <code>serviceMessage()</code> invocations by the endpoint.
-     */
-    public void incrementServiceMessageCount()
-    {
-        serviceMessageCount.incrementAndGet();
-        lastServiceMessageTimestamp = new Date();
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#getLastServiceMessageTimestamp()
-     */
-    public Date getLastServiceMessageTimestamp()
-    {
-        return lastServiceMessageTimestamp;
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#getServiceMessageFrequency()
-     */
-    public Double getServiceMessageFrequency()
-    {
-        if (serviceMessageCount.get() > 0)
-        {
-            double runtime = differenceInMinutes(serviceMessageStart, System.currentTimeMillis());
-            return new Double(serviceMessageCount.get()/runtime);
-        }
-        else
-        {
-            return new Double(0);
-        }
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see javax.management.MBeanRegistration#preDeregister()
-     */
-    public void preDeregister() throws Exception
-    {
-        MessageBrokerControl parent = (MessageBrokerControl)getParentControl();
-        parent.removeEndpoint(getObjectName());
-    }
-
-    public String getURI()
-    {
-        return endpoint.getUrl();
-    }
-
-    public String getSecurityConstraint()
-    {
-        return getSecurityConstraintOf(endpoint);
-    }
-
-    public static String getSecurityConstraintOf(Endpoint endpoint)
-    {
-        String result = "None";
-
-        SecurityConstraint constraint = endpoint.getSecurityConstraint();
-        if (constraint != null)
-        {
-            String authMethod = constraint.getMethod();
-            if (authMethod != null)
-            {
-                StringBuffer buffer = new StringBuffer();
-                buffer.append(authMethod);
-
-                List roles = constraint.getRoles();
-                if ((roles != null) && !roles.isEmpty())
-                {
-                    buffer.append(':');
-                    for (int i = 0; i < roles.size(); i++)
-                    {
-                        if (i > 0)
-                        {
-                            buffer.append(',');
-                        }
-                        buffer.append(' ');
-                        buffer.append(roles.get(i));
-                    }
-                }
-                result = buffer.toString();
-            }
-        }
-        return result;
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#getBytesDeserialized()
-     */
-    public Long getBytesDeserialized(){
-        return Long.valueOf(bytesDeserialized.get());
-    }
-
-    /**
-     * Increments the count of bytes deserialized by the endpoint.
-     * @param currentBytesDeserialized the bytes is deserialized
-     */
-    public void addToBytesDeserialized(int currentBytesDeserialized) {
-        bytesDeserialized.addAndGet(currentBytesDeserialized);
-    }
-
-    /*
-     *  (non-Javadoc)
-     * @see flex.management.runtime.EndpointControlMBean#getBytesSerialized()
-     */
-    public Long getBytesSerialized() {
-        return Long.valueOf(bytesSerialized.get());
-    }
-
-    /**
-     * Increments the count of bytes serialized by the endpoint.
-     * @param currentBytesSerialized the bytes is serialized
-     */
-    public void addToBytesSerialized(int currentBytesSerialized) {
-        bytesSerialized.addAndGet(currentBytesSerialized);
-    }
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.endpoints;
+
+import flex.management.BaseControl;
+import flex.management.runtime.AdminConsoleTypes;
+import flex.management.runtime.messaging.MessageBrokerControl;
+import flex.messaging.config.SecurityConstraint;
+import flex.messaging.endpoints.Endpoint;
+
+import java.util.Date;
+import java.util.List;
+import java.util.concurrent.atomic.AtomicInteger;
+import java.util.concurrent.atomic.AtomicLong;
+
+/**
+ * The <code>EndpointControl</code> class is the MBean implementation for
+ * monitoring and managing an <code>Endpoint</code> at runtime.
+ *
+ * @author shodgson
+ */
+public abstract class EndpointControl extends BaseControl implements EndpointControlMBean
+{
+    protected Endpoint endpoint;
+    private AtomicInteger serviceMessageCount = new AtomicInteger(0);
+    private Date lastServiceMessageTimestamp;
+    private long serviceMessageStart;
+    private AtomicLong bytesDeserialized = new AtomicLong(0);
+    private AtomicLong bytesSerialized = new AtomicLong(0);
+
+    /**
+     * Constructs an <code>EndpointControl</code>, assigning its managed endpoint and
+     * parent MBean.
+     *
+     * @param endpoint The <code>Endpoint</code> managed by this MBean.
+     * @param parent The parent MBean in the management hierarchy.
+     */
+    public EndpointControl(Endpoint endpoint, BaseControl parent)
+    {
+        super(parent);
+        this.endpoint = endpoint;
+        serviceMessageStart = System.currentTimeMillis();
+    }
+
+
+    protected void onRegistrationComplete()
+    {
+        String name = this.getObjectName().getCanonicalName();
+        String[] generalNames = { "SecurityConstraint"};
+        String[] generalPollables = { "ServiceMessageCount", "LastServiceMessageTimestamp", "ServiceMessageFrequency"};
+        String[] pollableGraphByInterval = {"BytesDeserialized", "BytesSerialized"};
+
+        getRegistrar().registerObjects(AdminConsoleTypes.ENDPOINT_SCALAR,
+                name, generalNames);
+        getRegistrar().registerObjects(AdminConsoleTypes.ENDPOINT_POLLABLE,
+                name, generalPollables);
+        getRegistrar().registerObjects(new int[] {AdminConsoleTypes.GRAPH_BY_POLL_INTERVAL, AdminConsoleTypes.ENDPOINT_POLLABLE},
+                name, pollableGraphByInterval);
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.BaseControlMBean#getId()
+     */
+    public String getId()
+    {
+        return endpoint.getId();
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#isRunning()
+     */
+    public Boolean isRunning()
+    {
+        return Boolean.valueOf(endpoint.isStarted());
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#getStartTimestamp()
+     */
+    public Date getStartTimestamp()
+    {
+        return startTimestamp;
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#getServiceMessageCount()
+     */
+    public Integer getServiceMessageCount()
+    {
+        return Integer.valueOf(serviceMessageCount.get());
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#resetServiceMessageCount()
+     */
+    public void resetServiceMessageCount()
+    {
+        serviceMessageStart = System.currentTimeMillis();
+        serviceMessageCount = new AtomicInteger(0);
+        lastServiceMessageTimestamp = null;
+    }
+
+    /**
+     * Increments the count of <code>serviceMessage()</code> invocations by the endpoint.
+     */
+    public void incrementServiceMessageCount()
+    {
+        serviceMessageCount.incrementAndGet();
+        lastServiceMessageTimestamp = new Date();
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#getLastServiceMessageTimestamp()
+     */
+    public Date getLastServiceMessageTimestamp()
+    {
+        return lastServiceMessageTimestamp;
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#getServiceMessageFrequency()
+     */
+    public Double getServiceMessageFrequency()
+    {
+        if (serviceMessageCount.get() > 0)
+        {
+            double runtime = differenceInMinutes(serviceMessageStart, System.currentTimeMillis());
+            return new Double(serviceMessageCount.get()/runtime);
+        }
+        else
+        {
+            return new Double(0);
+        }
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see javax.management.MBeanRegistration#preDeregister()
+     */
+    public void preDeregister() throws Exception
+    {
+        MessageBrokerControl parent = (MessageBrokerControl)getParentControl();
+        parent.removeEndpoint(getObjectName());
+    }
+
+    public String getURI()
+    {
+        return endpoint.getUrl();
+    }
+
+    public String getSecurityConstraint()
+    {
+        return getSecurityConstraintOf(endpoint);
+    }
+
+    public static String getSecurityConstraintOf(Endpoint endpoint)
+    {
+        String result = "None";
+
+        SecurityConstraint constraint = endpoint.getSecurityConstraint();
+        if (constraint != null)
+        {
+            String authMethod = constraint.getMethod();
+            if (authMethod != null)
+            {
+                StringBuffer buffer = new StringBuffer();
+                buffer.append(authMethod);
+
+                List roles = constraint.getRoles();
+                if ((roles != null) && !roles.isEmpty())
+                {
+                    buffer.append(':');
+                    for (int i = 0; i < roles.size(); i++)
+                    {
+                        if (i > 0)
+                        {
+                            buffer.append(',');
+                        }
+                        buffer.append(' ');
+                        buffer.append(roles.get(i));
+                    }
+                }
+                result = buffer.toString();
+            }
+        }
+        return result;
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#getBytesDeserialized()
+     */
+    public Long getBytesDeserialized(){
+        return Long.valueOf(bytesDeserialized.get());
+    }
+
+    /**
+     * Increments the count of bytes deserialized by the endpoint.
+     * @param currentBytesDeserialized the bytes is deserialized
+     */
+    public void addToBytesDeserialized(int currentBytesDeserialized) {
+        bytesDeserialized.addAndGet(currentBytesDeserialized);
+    }
+
+    /*
+     *  (non-Javadoc)
+     * @see flex.management.runtime.EndpointControlMBean#getBytesSerialized()
+     */
+    public Long getBytesSerialized() {
+        return Long.valueOf(bytesSerialized.get());
+    }
+
+    /**
+     * Increments the count of bytes serialized by the endpoint.
+     * @param currentBytesSerialized the bytes is serialized
+     */
+    public void addToBytesSerialized(int currentBytesSerialized) {
+        bytesSerialized.addAndGet(currentBytesSerialized);
+    }
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControlMBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControlMBean.java b/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControlMBean.java
old mode 100755
new mode 100644
index d0aa61a..8a644ff
--- a/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControlMBean.java
+++ b/modules/core/src/flex/management/runtime/messaging/endpoints/EndpointControlMBean.java
@@ -1,113 +1,113 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.endpoints;
-
-import flex.management.BaseControlMBean;
-
-import java.io.IOException;
-import java.util.Date;
-
-/**
- * Defines the runtime monitoring and management interface for managed endpoints.
- *
- * @author shodgson
- */
-public interface EndpointControlMBean extends BaseControlMBean
-{
-    /**
-     * Returns <code>true</code> if the <code>Endpoint</code> is running.
-     *
-     * @return <code>true</code> if the <code>Endpoint</code> is running.
-     * @throws IOException Throws IOException.
-     */
-    Boolean isRunning() throws IOException;
-
-    /**
-     * Returns the start timestamp for the <code>Endpoint</code>.
-     *
-     * @return The start timestamp for the <code>Endpoint</code>.
-     * @throws IOException Throws IOException.
-     */
-    Date getStartTimestamp() throws IOException;
-
-    /**
-     * Returns the count of messages decoded by this endpoint and routed to the broker.
-     *
-     * @return The count of messages decoded by this endpoint and routed to the broker.
-     * @throws IOException Throws IOException.
-     */
-    Integer getServiceMessageCount() throws IOException;
-
-    /**
-     * Resets the count of service message invocations.
-     *
-     * @throws IOException Throws IOException.
-     */
-    void resetServiceMessageCount() throws IOException;
-
-    /**
-     * Returns the timestamp for the most recent message decoded by this endpoint and
-     * routed to the broker.
-     *
-     * @return The timestamp for the most recent message decoded by this endpoint and
-     * routed to the broker.
-     * @throws IOException Throws IOException.
-     */
-    Date getLastServiceMessageTimestamp() throws IOException;
-
-    /**
-     * Returns the number of service message invocations per minute.
-     *
-     * @return The number of service message invocations per minute.
-     * @throws IOException Throws IOException.
-     */
-    Double getServiceMessageFrequency() throws IOException;
-
-    /**
-     * Returns the URI that corresponds to this endpoint.
-     *
-     * @return The URI that corresponds to this endpoint.
-     * @throws IOException Throws IOException.
-     */
-    String getURI() throws IOException;
-
-    /**
-     * Returns the security constraint that is associated with this endpoint.
-     *
-     * @return The security constraint that is associated with this endpoint.
-     * @throws IOException Throws IOException.
-     */
-    String getSecurityConstraint() throws IOException;
-
-    /**
-     * Returns the total Bytes that have been deserialized by this endpoint
-     * during its lifetime.
-     *
-     * @return total Bytes deserialized.
-     * @throws IOException Throws IOException.
-     */
-    Long getBytesDeserialized() throws IOException;
-
-    /**
-     * Returns the total Bytes that have been serialized by this endpoint
-     * during its lifetime.
-     *
-     * @return total Bytes serialized.
-     * @throws IOException Throws IOException.
-     */
-    Long getBytesSerialized() throws IOException;
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.endpoints;
+
+import flex.management.BaseControlMBean;
+
+import java.io.IOException;
+import java.util.Date;
+
+/**
+ * Defines the runtime monitoring and management interface for managed endpoints.
+ *
+ * @author shodgson
+ */
+public interface EndpointControlMBean extends BaseControlMBean
+{
+    /**
+     * Returns <code>true</code> if the <code>Endpoint</code> is running.
+     *
+     * @return <code>true</code> if the <code>Endpoint</code> is running.
+     * @throws IOException Throws IOException.
+     */
+    Boolean isRunning() throws IOException;
+
+    /**
+     * Returns the start timestamp for the <code>Endpoint</code>.
+     *
+     * @return The start timestamp for the <code>Endpoint</code>.
+     * @throws IOException Throws IOException.
+     */
+    Date getStartTimestamp() throws IOException;
+
+    /**
+     * Returns the count of messages decoded by this endpoint and routed to the broker.
+     *
+     * @return The count of messages decoded by this endpoint and routed to the broker.
+     * @throws IOException Throws IOException.
+     */
+    Integer getServiceMessageCount() throws IOException;
+
+    /**
+     * Resets the count of service message invocations.
+     *
+     * @throws IOException Throws IOException.
+     */
+    void resetServiceMessageCount() throws IOException;
+
+    /**
+     * Returns the timestamp for the most recent message decoded by this endpoint and
+     * routed to the broker.
+     *
+     * @return The timestamp for the most recent message decoded by this endpoint and
+     * routed to the broker.
+     * @throws IOException Throws IOException.
+     */
+    Date getLastServiceMessageTimestamp() throws IOException;
+
+    /**
+     * Returns the number of service message invocations per minute.
+     *
+     * @return The number of service message invocations per minute.
+     * @throws IOException Throws IOException.
+     */
+    Double getServiceMessageFrequency() throws IOException;
+
+    /**
+     * Returns the URI that corresponds to this endpoint.
+     *
+     * @return The URI that corresponds to this endpoint.
+     * @throws IOException Throws IOException.
+     */
+    String getURI() throws IOException;
+
+    /**
+     * Returns the security constraint that is associated with this endpoint.
+     *
+     * @return The security constraint that is associated with this endpoint.
+     * @throws IOException Throws IOException.
+     */
+    String getSecurityConstraint() throws IOException;
+
+    /**
+     * Returns the total Bytes that have been deserialized by this endpoint
+     * during its lifetime.
+     *
+     * @return total Bytes deserialized.
+     * @throws IOException Throws IOException.
+     */
+    Long getBytesDeserialized() throws IOException;
+
+    /**
+     * Returns the total Bytes that have been serialized by this endpoint
+     * during its lifetime.
+     *
+     * @return total Bytes serialized.
+     * @throws IOException Throws IOException.
+     */
+    Long getBytesSerialized() throws IOException;
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControl.java b/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControl.java
old mode 100755
new mode 100644
index 6dc52ac..c8024de
--- a/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControl.java
+++ b/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControl.java
@@ -1,50 +1,50 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.endpoints;
-
-import flex.management.BaseControl;
-import flex.messaging.endpoints.HTTPEndpoint;
-
-/**
- * The <code>HTTPEndpointControl</code> class is the MBean implemenation
- * for monitoring and managing a <code>HTTPEndpoint</code> at runtime.
- *
- * @author shodgson
- */
-public class HTTPEndpointControl extends PollingEndpointControl implements
-    HTTPEndpointControlMBean
-{
-    private static final String TYPE = "HTTPEndpoint";
-
-    /**
-     * Constructs a <code>HTTPEndpointControl</code>, assigning managed message
-     * endpoint and parent MBean.
-     *
-     * @param endpoint The <code>HTTPEndpoint</code> managed by this MBean.
-     * @param parent The parent MBean in the management hierarchy.
-     */
-    public HTTPEndpointControl(HTTPEndpoint endpoint, BaseControl parent)
-    {
-        super(endpoint, parent);
-    }
-
-    /** {@inheritDoc} */
-    public String getType()
-    {
-        return TYPE;
-    }
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.endpoints;
+
+import flex.management.BaseControl;
+import flex.messaging.endpoints.HTTPEndpoint;
+
+/**
+ * The <code>HTTPEndpointControl</code> class is the MBean implemenation
+ * for monitoring and managing a <code>HTTPEndpoint</code> at runtime.
+ *
+ * @author shodgson
+ */
+public class HTTPEndpointControl extends PollingEndpointControl implements
+    HTTPEndpointControlMBean
+{
+    private static final String TYPE = "HTTPEndpoint";
+
+    /**
+     * Constructs a <code>HTTPEndpointControl</code>, assigning managed message
+     * endpoint and parent MBean.
+     *
+     * @param endpoint The <code>HTTPEndpoint</code> managed by this MBean.
+     * @param parent The parent MBean in the management hierarchy.
+     */
+    public HTTPEndpointControl(HTTPEndpoint endpoint, BaseControl parent)
+    {
+        super(endpoint, parent);
+    }
+
+    /** {@inheritDoc} */
+    public String getType()
+    {
+        return TYPE;
+    }
+}

http://git-wip-us.apache.org/repos/asf/flex-blazeds/blob/4f6a3052/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControlMBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControlMBean.java b/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControlMBean.java
old mode 100755
new mode 100644
index fce75d2..055b921
--- a/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControlMBean.java
+++ b/modules/core/src/flex/management/runtime/messaging/endpoints/HTTPEndpointControlMBean.java
@@ -1,27 +1,27 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package flex.management.runtime.messaging.endpoints;
-
-/**
- * Defines the runtime monitoring and management interface for managed HTTP endpoints.
- *
- * @author shodgson
- */
-public interface HTTPEndpointControlMBean extends PollingEndpointControlMBean
-{
-    // Empty for now.
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package flex.management.runtime.messaging.endpoints;
+
+/**
+ * Defines the runtime monitoring and management interface for managed HTTP endpoints.
+ *
+ * @author shodgson
+ */
+public interface HTTPEndpointControlMBean extends PollingEndpointControlMBean
+{
+    // Empty for now.
+}