You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by rg...@apache.org on 2014/04/30 03:22:16 UTC

svn commit: r1591170 [3/4] - in /qpid/trunk/qpid/java: broker-codegen/src/main/java/org/apache/qpid/server/model/ broker-codegen/src/main/resources/META-INF/services/ broker-core/src/main/java/org/apache/qpid/server/exchange/ broker-core/src/main/java/...

Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/amqp-0-10-protocol/src/main/java/org/apache/qpid/server/protocol/v0_10/ServerSessionDelegate.java Wed Apr 30 01:22:13 2014
@@ -32,10 +32,9 @@ import java.util.UUID;
 
 import org.apache.log4j.Logger;
 
+import org.apache.qpid.exchange.ExchangeDefaults;
 import org.apache.qpid.server.consumer.ConsumerImpl;
-import org.apache.qpid.server.exchange.DirectExchange;
 import org.apache.qpid.server.exchange.ExchangeImpl;
-import org.apache.qpid.server.exchange.HeadersExchange;
 import org.apache.qpid.server.filter.AMQInvalidArgumentException;
 import org.apache.qpid.server.filter.FilterManager;
 import org.apache.qpid.server.filter.FilterManagerFactory;
@@ -49,7 +48,6 @@ import org.apache.qpid.server.model.Life
 import org.apache.qpid.server.model.NoFactoryForTypeException;
 import org.apache.qpid.server.model.Queue;
 import org.apache.qpid.server.model.UnknownConfiguredObjectException;
-import org.apache.qpid.server.plugin.ExchangeType;
 import org.apache.qpid.server.queue.AMQQueue;
 import org.apache.qpid.server.queue.QueueArgumentsConverter;
 import org.apache.qpid.server.store.DurableConfigurationStore;
@@ -694,11 +692,11 @@ public class ServerSessionDelegate exten
         if(nameNullOrEmpty(method.getExchange()))
         {
             // special case handling to fake the existence of the default exchange for 0-10
-            if(!DirectExchange.TYPE.getType().equals(method.getType()))
+            if(!ExchangeDefaults.DIRECT_EXCHANGE_CLASS.equals(method.getType()))
             {
                 exception(session, method, ExecutionErrorCode.NOT_ALLOWED,
                           "Attempt to redeclare default exchange "
-                          + " of type " + DirectExchange.TYPE.getType()
+                          + " of type " + ExchangeDefaults.DIRECT_EXCHANGE_CLASS
                           + " to " + method.getType() +".");
             }
             if(!nameNullOrEmpty(method.getAlternateExchange()))
@@ -721,11 +719,11 @@ public class ServerSessionDelegate exten
                 }
                 else
                 {
-                    if (!exchange.getTypeName().equals(method.getType())
+                    if (!exchange.getType().equals(method.getType())
                             && (method.getType() != null && method.getType().length() > 0))
                     {
                         exception(session, method, ExecutionErrorCode.NOT_ALLOWED, "Attempt to redeclare exchange: "
-                                + exchangeName + " of type " + exchange.getTypeName() + " to " + method.getType() + ".");
+                                + exchangeName + " of type " + exchange.getType() + " to " + method.getType() + ".");
                     }
                 }
             }
@@ -762,11 +760,11 @@ public class ServerSessionDelegate exten
                 catch(ExchangeExistsException e)
                 {
                     ExchangeImpl exchange = e.getExistingExchange();
-                    if(!exchange.getTypeName().equals(method.getType()))
+                    if(!exchange.getType().equals(method.getType()))
                     {
                         exception(session, method, ExecutionErrorCode.NOT_ALLOWED,
                                 "Attempt to redeclare exchange: " + exchangeName
-                                        + " of type " + exchange.getTypeName()
+                                        + " of type " + exchange.getType()
                                         + " to " + method.getType() +".");
                     }
                     else if(method.hasAlternateExchange()
@@ -887,18 +885,6 @@ public class ServerSessionDelegate exten
         return false;
     }
 
-    private boolean isStandardExchange(ExchangeImpl exchange, Collection<ExchangeType<? extends ExchangeImpl>> registeredTypes)
-    {
-        for(ExchangeType type : registeredTypes)
-        {
-            if(type.getDefaultExchangeName().equals( exchange.getName() ))
-            {
-                return true;
-            }
-        }
-        return false;
-    }
-
     @Override
     public void exchangeQuery(Session session, ExchangeQuery method)
     {
@@ -912,7 +898,7 @@ public class ServerSessionDelegate exten
         {
             // Fake the existence of the "default" exchange for 0-10
             result.setDurable(true);
-            result.setType(DirectExchange.TYPE.getType());
+            result.setType(ExchangeDefaults.DIRECT_EXCHANGE_CLASS);
             result.setNotFound(false);
         }
         else
@@ -922,7 +908,7 @@ public class ServerSessionDelegate exten
             if(exchange != null)
             {
                 result.setDurable(exchange.isDurable());
-                result.setType(exchange.getTypeName());
+                result.setType(exchange.getType());
                 result.setNotFound(false);
             }
             else
@@ -968,9 +954,9 @@ public class ServerSessionDelegate exten
                 {
                     exception(session, method, ExecutionErrorCode.NOT_FOUND, "Exchange: '" + exchangeName + "' not found");
                 }
-                else if(exchange.getExchangeType().equals(HeadersExchange.TYPE) && (!method.hasArguments() || method.getArguments() == null || !method.getArguments().containsKey("x-match")))
+                else if(exchange.getType().equals(ExchangeDefaults.HEADERS_EXCHANGE_CLASS) && (!method.hasArguments() || method.getArguments() == null || !method.getArguments().containsKey("x-match")))
                 {
-                    exception(session, method, ExecutionErrorCode.INTERNAL_ERROR, "Bindings to an exchange of type " + HeadersExchange.TYPE.getType() + " require an x-match header");
+                    exception(session, method, ExecutionErrorCode.INTERNAL_ERROR, "Bindings to an exchange of type " + ExchangeDefaults.HEADERS_EXCHANGE_CLASS + " require an x-match header");
                 }
                 else
                 {

Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeclareHandler.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeclareHandler.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeclareHandler.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/ExchangeDeclareHandler.java Wed Apr 30 01:22:13 2014
@@ -28,12 +28,12 @@ import org.apache.log4j.Logger;
 
 import org.apache.qpid.AMQConnectionException;
 import org.apache.qpid.AMQException;
+import org.apache.qpid.exchange.ExchangeDefaults;
 import org.apache.qpid.framing.AMQMethodBody;
 import org.apache.qpid.framing.AMQShortString;
 import org.apache.qpid.framing.ExchangeDeclareBody;
 import org.apache.qpid.framing.MethodRegistry;
 import org.apache.qpid.protocol.AMQConstant;
-import org.apache.qpid.server.exchange.DirectExchange;
 import org.apache.qpid.server.exchange.ExchangeImpl;
 import org.apache.qpid.server.model.LifetimePolicy;
 import org.apache.qpid.server.model.NoFactoryForTypeException;
@@ -81,11 +81,11 @@ public class ExchangeDeclareHandler impl
 
         if(isDefaultExchange(exchangeName))
         {
-            if(!new AMQShortString(DirectExchange.TYPE.getType()).equals(body.getType()))
+            if(!new AMQShortString(ExchangeDefaults.DIRECT_EXCHANGE_CLASS).equals(body.getType()))
             {
                 throw new AMQConnectionException(AMQConstant.NOT_ALLOWED, "Attempt to redeclare default exchange: "
                                                                           + " of type "
-                                                                          + DirectExchange.TYPE.getType()
+                                                                          + ExchangeDefaults.DIRECT_EXCHANGE_CLASS
                                                                           + " to " + body.getType() +".",
                                                  body.getClazz(), body.getMethod(),
                                                  body.getMajor(), body.getMinor(),null);
@@ -100,11 +100,11 @@ public class ExchangeDeclareHandler impl
                 {
                     throw body.getChannelException(AMQConstant.NOT_FOUND, "Unknown exchange: " + exchangeName);
                 }
-                else if (!(body.getType() == null || body.getType().length() ==0) && !exchange.getTypeName().equals(body.getType().asString()))
+                else if (!(body.getType() == null || body.getType().length() ==0) && !exchange.getType().equals(body.getType().asString()))
                 {
 
                     throw new AMQConnectionException(AMQConstant.NOT_ALLOWED, "Attempt to redeclare exchange: " +
-                                      exchangeName + " of type " + exchange.getTypeName()
+                                      exchangeName + " of type " + exchange.getType()
                                       + " to " + body.getType() +".",body.getClazz(), body.getMethod(),body.getMajor(),body.getMinor(),null);
                 }
 
@@ -137,11 +137,11 @@ public class ExchangeDeclareHandler impl
                 catch(ExchangeExistsException e)
                 {
                     exchange = e.getExistingExchange();
-                    if(!new AMQShortString(exchange.getTypeName()).equals(body.getType()))
+                    if(!new AMQShortString(exchange.getType()).equals(body.getType()))
                     {
                         throw new AMQConnectionException(AMQConstant.NOT_ALLOWED, "Attempt to redeclare exchange: "
                                                                                   + exchangeName + " of type "
-                                                                                  + exchange.getTypeName()
+                                                                                  + exchange.getType()
                                                                                   + " to " + body.getType() +".",
                                                          body.getClazz(), body.getMethod(),
                                                          body.getMajor(), body.getMinor(),null);

Modified: qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueBindHandler.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueBindHandler.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueBindHandler.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/amqp-0-8-protocol/src/main/java/org/apache/qpid/server/protocol/v0_8/handler/QueueBindHandler.java Wed Apr 30 01:22:13 2014
@@ -20,9 +20,13 @@
  */
 package org.apache.qpid.server.protocol.v0_8.handler;
 
+import java.security.AccessControlException;
+import java.util.Map;
+
 import org.apache.log4j.Logger;
 
 import org.apache.qpid.AMQException;
+import org.apache.qpid.exchange.ExchangeDefaults;
 import org.apache.qpid.framing.AMQMethodBody;
 import org.apache.qpid.framing.AMQShortString;
 import org.apache.qpid.framing.FieldTable;
@@ -30,17 +34,13 @@ import org.apache.qpid.framing.MethodReg
 import org.apache.qpid.framing.QueueBindBody;
 import org.apache.qpid.protocol.AMQConstant;
 import org.apache.qpid.server.exchange.ExchangeImpl;
-import org.apache.qpid.server.exchange.TopicExchange;
 import org.apache.qpid.server.protocol.v0_8.AMQChannel;
 import org.apache.qpid.server.protocol.v0_8.AMQProtocolSession;
-import org.apache.qpid.server.queue.AMQQueue;
 import org.apache.qpid.server.protocol.v0_8.state.AMQStateManager;
 import org.apache.qpid.server.protocol.v0_8.state.StateAwareMethodListener;
+import org.apache.qpid.server.queue.AMQQueue;
 import org.apache.qpid.server.virtualhost.VirtualHostImpl;
 
-import java.security.AccessControlException;
-import java.util.Map;
-
 public class QueueBindHandler implements StateAwareMethodListener<QueueBindBody>
 {
     private static final Logger _log = Logger.getLogger(QueueBindHandler.class);
@@ -125,7 +125,7 @@ public class QueueBindHandler implements
             if (!exch.isBound(bindingKey, arguments, queue))
             {
 
-                if(!exch.addBinding(bindingKey, queue, arguments) && TopicExchange.TYPE.equals(exch.getExchangeType()))
+                if(!exch.addBinding(bindingKey, queue, arguments) && ExchangeDefaults.TOPIC_EXCHANGE_CLASS.equals(exch.getType()))
                 {
                     exch.replaceBinding(bindingKey, queue, arguments);
                 }

Modified: qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/SendingLink_1_0.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/SendingLink_1_0.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/SendingLink_1_0.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/amqp-1-0-protocol/src/main/java/org/apache/qpid/server/protocol/v1_0/SendingLink_1_0.java Wed Apr 30 01:22:13 2014
@@ -58,13 +58,12 @@ import org.apache.qpid.amqp_1_0.type.tra
 import org.apache.qpid.amqp_1_0.type.transport.Detach;
 import org.apache.qpid.amqp_1_0.type.transport.Error;
 import org.apache.qpid.amqp_1_0.type.transport.Transfer;
+import org.apache.qpid.exchange.ExchangeDefaults;
 import org.apache.qpid.filter.SelectorParsingException;
 import org.apache.qpid.filter.selector.ParseException;
 import org.apache.qpid.server.binding.BindingImpl;
 import org.apache.qpid.server.consumer.ConsumerImpl;
-import org.apache.qpid.server.exchange.DirectExchange;
 import org.apache.qpid.server.exchange.ExchangeImpl;
-import org.apache.qpid.server.exchange.TopicExchange;
 import org.apache.qpid.server.filter.JMSSelectorFilter;
 import org.apache.qpid.server.filter.SimpleFilterManager;
 import org.apache.qpid.server.message.MessageInstance;
@@ -259,7 +258,7 @@ public class SendingLink_1_0 implements 
                     {
                         if(!hasBindingFilter
                            && entry.getValue() instanceof ExactSubjectFilter
-                           && exchange.getExchangeType() == DirectExchange.TYPE)
+                           && exchange.getType().equals(ExchangeDefaults.DIRECT_EXCHANGE_CLASS))
                         {
                             ExactSubjectFilter filter = (ExactSubjectFilter) filters.values().iterator().next();
                             source.setFilter(filters);
@@ -269,7 +268,7 @@ public class SendingLink_1_0 implements 
                         }
                         else if(!hasBindingFilter
                                 && entry.getValue() instanceof MatchingSubjectFilter
-                                && exchange.getExchangeType() == TopicExchange.TYPE)
+                                && exchange.getType().equals(ExchangeDefaults.TOPIC_EXCHANGE_CLASS))
                         {
                             MatchingSubjectFilter filter = (MatchingSubjectFilter) filters.values().iterator().next();
                             source.setFilter(filters);

Modified: qpid/trunk/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/amqp-msg-conv-0-8-to-0-10/src/main/java/org/apache/qpid/server/protocol/converter/v0_8_v0_10/MessageConverter_0_10_to_0_8.java Wed Apr 30 01:22:13 2014
@@ -115,7 +115,7 @@ public class MessageConverter_0_10_to_0_
                 ExchangeImpl exchange = vhost.getExchange(exchangeName);
                 String exchangeClass = exchange == null
                                             ? ExchangeDefaults.DIRECT_EXCHANGE_CLASS
-                                            : exchange.getTypeName();
+                                            : exchange.getType();
                 props.setReplyTo(exchangeClass + "://" + exchangeName + "//?routingkey='" + (routingKey == null
                                                                                              ? ""
                                                                                              : routingKey + "'"));

Modified: qpid/trunk/qpid/java/broker-plugins/management-amqp/src/main/java/org/apache/qpid/server/management/amqp/ManagementNode.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-amqp/src/main/java/org/apache/qpid/server/management/amqp/ManagementNode.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/management-amqp/src/main/java/org/apache/qpid/server/management/amqp/ManagementNode.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/management-amqp/src/main/java/org/apache/qpid/server/management/amqp/ManagementNode.java Wed Apr 30 01:22:13 2014
@@ -50,9 +50,9 @@ import org.apache.qpid.server.message.Me
 import org.apache.qpid.server.message.ServerMessage;
 import org.apache.qpid.server.message.internal.InternalMessage;
 import org.apache.qpid.server.message.internal.InternalMessageHeader;
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 import org.apache.qpid.server.model.ConfigurationChangeListener;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
 import org.apache.qpid.server.model.ManagedObject;
 import org.apache.qpid.server.model.State;
 import org.apache.qpid.server.plugin.MessageConverter;
@@ -235,7 +235,7 @@ class ManagementNode implements MessageS
                 }
             }
             managedEntityType = new ManagedEntityType(clazz.getName(), parentSet.toArray(new ManagedEntityType[parentSet.size()]),
-                                                      (String[])(AbstractConfiguredObject.getAttributeNames(
+                                                      (String[])(ConfiguredObjectTypeRegistry.getAttributeNames(
                                                               clazz).toArray(new String[0])),
                                                       opsList.toArray(new String[opsList.size()]));
             _entityTypes.put(clazz.getName(),managedEntityType);

Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/HttpManagementUtil.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/HttpManagementUtil.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/HttpManagementUtil.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/HttpManagementUtil.java Wed Apr 30 01:22:13 2014
@@ -34,6 +34,7 @@ import javax.servlet.http.HttpServletReq
 import javax.servlet.http.HttpSession;
 
 import org.apache.commons.codec.binary.Base64;
+
 import org.apache.qpid.server.management.plugin.servlet.ServletConnectionPrincipal;
 import org.apache.qpid.server.management.plugin.session.LoginLogoutReporter;
 import org.apache.qpid.server.model.AuthenticationProvider;
@@ -44,7 +45,7 @@ import org.apache.qpid.server.security.a
 import org.apache.qpid.server.security.auth.AuthenticationResult.AuthenticationStatus;
 import org.apache.qpid.server.security.auth.SubjectAuthenticationResult;
 import org.apache.qpid.server.security.auth.UsernamePrincipal;
-import org.apache.qpid.server.security.auth.manager.ExternalAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.ExternalAuthenticationManager;
 import org.apache.qpid.transport.network.security.ssl.SSLUtil;
 
 public class HttpManagementUtil
@@ -162,7 +163,7 @@ public class HttpManagementUtil
             {
                 principal = certificates[0].getSubjectX500Principal();
 
-                if(!Boolean.valueOf(String.valueOf(authenticationProvider.getAttribute(ExternalAuthenticationManagerFactory.ATTRIBUTE_USE_FULL_DN))))
+                if(!Boolean.valueOf(String.valueOf(authenticationProvider.getAttribute(ExternalAuthenticationManager.ATTRIBUTE_USE_FULL_DN))))
                 {
                     String username;
                     String dn = ((X500Principal) principal).getName(X500Principal.RFC2253);

Added: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/AbstractSpecialisedAttributeLister.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/AbstractSpecialisedAttributeLister.java?rev=1591170&view=auto
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/AbstractSpecialisedAttributeLister.java (added)
+++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/AbstractSpecialisedAttributeLister.java Wed Apr 30 01:22:13 2014
@@ -0,0 +1,77 @@
+/*
+ *
+ * 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 org.apache.qpid.server.management.plugin.servlet.rest.action;
+
+import java.util.Collection;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.TreeMap;
+import java.util.TreeSet;
+
+import org.apache.qpid.server.management.plugin.servlet.rest.Action;
+import org.apache.qpid.server.model.Broker;
+import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectAttribute;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
+
+abstract class AbstractSpecialisedAttributeLister<T extends ConfiguredObject>  implements Action
+{
+
+
+    private static final String ATTRIBUTES = "attributes";
+    private static final String DESCRIPTIONS = "descriptions";
+
+    @Override
+    final public Object perform(Map<String, Object> request, Broker broker)
+    {
+        Collection<Class<? extends ConfiguredObject>> groupProviderTypes =
+                ConfiguredObjectTypeRegistry.getTypeSpecialisations(getCategoryClass());
+
+        Map<String, Object> attributes = new TreeMap<String, Object>();
+
+        for (Class<? extends ConfiguredObject> groupProviderType : groupProviderTypes)
+        {
+            Collection<ConfiguredObjectAttribute<?, ?>> typeSpecificAttributes =
+                    ConfiguredObjectTypeRegistry.getTypeSpecificAttributes(groupProviderType);
+
+            Map<String, Object> data = new HashMap<String, Object>();
+
+            Collection<String> attributeNames = new TreeSet<>();
+            Map<String,String> descriptions = new HashMap<>();
+            for(ConfiguredObjectAttribute<?, ?> attr : typeSpecificAttributes)
+            {
+                attributeNames.add(attr.getName());
+                if(!"".equals(attr.getAnnotation().description()))
+                {
+                    descriptions.put(attr.getName(), attr.getAnnotation().description());
+                }
+            }
+            data.put(ATTRIBUTES, attributeNames);
+            data.put(DESCRIPTIONS, descriptions);
+
+            attributes.put(ConfiguredObjectTypeRegistry.getType(groupProviderType), data);
+        }
+        return attributes;
+    }
+
+    abstract Class<T> getCategoryClass();
+
+}

Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAccessControlProviderAttributes.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAccessControlProviderAttributes.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAccessControlProviderAttributes.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAccessControlProviderAttributes.java Wed Apr 30 01:22:13 2014
@@ -20,32 +20,10 @@
  */
 package org.apache.qpid.server.management.plugin.servlet.rest.action;
 
-import java.util.HashMap;
-import java.util.Map;
-import java.util.TreeMap;
+import org.apache.qpid.server.model.AccessControlProvider;
 
-import org.apache.qpid.server.management.plugin.servlet.rest.Action;
-import org.apache.qpid.server.model.Broker;
-import org.apache.qpid.server.plugin.AccessControlProviderFactory;
-import org.apache.qpid.server.plugin.QpidServiceLoader;
-
-public class ListAccessControlProviderAttributes  implements Action
+public class ListAccessControlProviderAttributes  extends AbstractSpecialisedAttributeLister<AccessControlProvider>
 {
-    private static final String ATTRIBUTES = "attributes";
-    private static final String DESCRIPTIONS = "descriptions";
-    private Map<String, AccessControlProviderFactory> _factories;
-
-    public ListAccessControlProviderAttributes()
-    {
-        _factories = new TreeMap<String, AccessControlProviderFactory>();
-        Iterable<AccessControlProviderFactory> factories = new QpidServiceLoader<AccessControlProviderFactory>()
-                .instancesOf(AccessControlProviderFactory.class);
-        for (AccessControlProviderFactory factory : factories)
-        {
-            _factories.put(factory.getType(), factory);
-        }
-    }
-
     @Override
     public String getName()
     {
@@ -53,25 +31,8 @@ public class ListAccessControlProviderAt
     }
 
     @Override
-    public Object perform(Map<String, Object> request, Broker broker)
+    Class<AccessControlProvider> getCategoryClass()
     {
-        Map<String, Object> attributes = new TreeMap<String, Object>();
-        for (String providerType : _factories.keySet())
-        {
-            AccessControlProviderFactory<?> factory = _factories.get(providerType);
-
-            Map<String, Object> data = new HashMap<String, Object>();
-            // TODO RG - fix
-            // data.put(ATTRIBUTES, factory.getAttributeNames());
-            Map<String, String> resources = factory.getAttributeDescriptions();
-            if (resources != null)
-            {
-                data.put(DESCRIPTIONS, resources);
-            }
-
-            attributes.put(factory.getType(), data);
-        }
-        return attributes;
+        return AccessControlProvider.class;
     }
-
 }

Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAuthenticationProviderAttributes.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAuthenticationProviderAttributes.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAuthenticationProviderAttributes.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListAuthenticationProviderAttributes.java Wed Apr 30 01:22:13 2014
@@ -20,32 +20,10 @@
  */
 package org.apache.qpid.server.management.plugin.servlet.rest.action;
 
-import java.util.HashMap;
-import java.util.Map;
-import java.util.TreeMap;
+import org.apache.qpid.server.model.AuthenticationProvider;
 
-import org.apache.qpid.server.management.plugin.servlet.rest.Action;
-import org.apache.qpid.server.model.Broker;
-import org.apache.qpid.server.plugin.AuthenticationManagerFactory;
-import org.apache.qpid.server.plugin.QpidServiceLoader;
-
-public class ListAuthenticationProviderAttributes implements Action
+public class ListAuthenticationProviderAttributes extends AbstractSpecialisedAttributeLister<AuthenticationProvider>
 {
-    private static final String ATTRIBUTES = "attributes";
-    private static final String DESCRIPTIONS = "descriptions";
-    private Map<String, AuthenticationManagerFactory> _factories;
-
-    public ListAuthenticationProviderAttributes()
-    {
-        _factories = new TreeMap<String, AuthenticationManagerFactory>();
-        Iterable<AuthenticationManagerFactory> factories = new QpidServiceLoader<AuthenticationManagerFactory>()
-                .instancesOf(AuthenticationManagerFactory.class);
-        for (AuthenticationManagerFactory factory : factories)
-        {
-            _factories.put(factory.getType(), factory);
-        }
-    }
-
     @Override
     public String getName()
     {
@@ -53,24 +31,8 @@ public class ListAuthenticationProviderA
     }
 
     @Override
-    public Object perform(Map<String, Object> request, Broker broker)
+    Class<AuthenticationProvider> getCategoryClass()
     {
-        Map<String, Object> attributes = new TreeMap<String, Object>();
-        for (String providerType : _factories.keySet())
-        {
-            AuthenticationManagerFactory factory = _factories.get(providerType);
-
-            Map<String, Object> data = new HashMap<String, Object>();
-            data.put(ATTRIBUTES, factory.getAttributeNames());
-            Map<String, String> resources = factory.getAttributeDescriptions();
-            if (resources != null)
-            {
-                data.put(DESCRIPTIONS, resources);
-            }
-
-            attributes.put(factory.getType(), data);
-        }
-        return attributes;
+        return AuthenticationProvider.class;
     }
-
 }

Modified: qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListGroupProviderAttributes.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListGroupProviderAttributes.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListGroupProviderAttributes.java (original)
+++ qpid/trunk/qpid/java/broker-plugins/management-http/src/main/java/org/apache/qpid/server/management/plugin/servlet/rest/action/ListGroupProviderAttributes.java Wed Apr 30 01:22:13 2014
@@ -20,32 +20,10 @@
  */
 package org.apache.qpid.server.management.plugin.servlet.rest.action;
 
-import java.util.HashMap;
-import java.util.Map;
-import java.util.TreeMap;
+import org.apache.qpid.server.model.GroupProvider;
 
-import org.apache.qpid.server.management.plugin.servlet.rest.Action;
-import org.apache.qpid.server.model.Broker;
-import org.apache.qpid.server.plugin.GroupManagerFactory;
-import org.apache.qpid.server.plugin.QpidServiceLoader;
-
-public class ListGroupProviderAttributes implements Action
+public class ListGroupProviderAttributes extends AbstractSpecialisedAttributeLister<GroupProvider>
 {
-    private static final String ATTRIBUTES = "attributes";
-    private static final String DESCRIPTIONS = "descriptions";
-    private Map<String, GroupManagerFactory> _factories;
-
-    public ListGroupProviderAttributes()
-    {
-        _factories = new TreeMap<String, GroupManagerFactory>();
-        Iterable<GroupManagerFactory> factories = new QpidServiceLoader<GroupManagerFactory>()
-                .instancesOf(GroupManagerFactory.class);
-        for (GroupManagerFactory factory : factories)
-        {
-            _factories.put(factory.getType(), factory);
-        }
-    }
-
     @Override
     public String getName()
     {
@@ -53,24 +31,8 @@ public class ListGroupProviderAttributes
     }
 
     @Override
-    public Object perform(Map<String, Object> request, Broker broker)
+    Class<GroupProvider> getCategoryClass()
     {
-        Map<String, Object> attributes = new TreeMap<String, Object>();
-        for (String providerType : _factories.keySet())
-        {
-            GroupManagerFactory factory = _factories.get(providerType);
-
-            Map<String, Object> data = new HashMap<String, Object>();
-            data.put(ATTRIBUTES, factory.getAttributeNames());
-            Map<String, String> resources = factory.getAttributeDescriptions();
-            if (resources != null)
-            {
-                data.put(DESCRIPTIONS, resources);
-            }
-
-            attributes.put(factory.getType(), data);
-        }
-        return attributes;
+        return GroupProvider.class;
     }
-
 }

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/logging/AlertingTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/logging/AlertingTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/logging/AlertingTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/logging/AlertingTest.java Wed Apr 30 01:22:13 2014
@@ -34,7 +34,7 @@ import org.apache.qpid.server.management
 import org.apache.qpid.server.model.AuthenticationProvider;
 import org.apache.qpid.server.model.Plugin;
 import org.apache.qpid.server.model.Port;
-import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManager;
 import org.apache.qpid.systest.rest.RestTestHelper;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
 
@@ -159,7 +159,7 @@ public class AlertingTest extends Abstra
         config.removeObjectConfiguration(Port.class, TestBrokerConfiguration.ENTRY_NAME_RMI_PORT);
 
         Map<String, Object> anonymousProviderAttributes = new HashMap<String, Object>();
-        anonymousProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        anonymousProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
         anonymousProviderAttributes.put(AuthenticationProvider.NAME, "testAnonymous");
         config.addObjectConfiguration(AuthenticationProvider.class, anonymousProviderAttributes);
 

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/ExternalAuthenticationTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/ExternalAuthenticationTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/ExternalAuthenticationTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/ExternalAuthenticationTest.java Wed Apr 30 01:22:13 2014
@@ -284,7 +284,7 @@ public class ExternalAuthenticationTest 
         JMXTestUtils jmxUtils = new JMXTestUtils(this);
 
         setCommonBrokerSSLProperties(true);
-        getBrokerConfiguration().setObjectAttribute(AuthenticationProvider.class, TestBrokerConfiguration.ENTRY_NAME_EXTERNAL_PROVIDER, ExternalAuthenticationManagerFactory.ATTRIBUTE_USE_FULL_DN, "true");
+        getBrokerConfiguration().setObjectAttribute(AuthenticationProvider.class, TestBrokerConfiguration.ENTRY_NAME_EXTERNAL_PROVIDER, ExternalAuthenticationManager.ATTRIBUTE_USE_FULL_DN, "true");
         getBrokerConfiguration().addJmxManagementConfiguration();
 
         super.setUp();
@@ -348,7 +348,7 @@ public class ExternalAuthenticationTest 
 
         Map<String, Object> externalAuthProviderAttributes = new HashMap<String, Object>();
         externalAuthProviderAttributes.put(AuthenticationProvider.NAME, TestBrokerConfiguration.ENTRY_NAME_EXTERNAL_PROVIDER);
-        externalAuthProviderAttributes.put(AuthenticationProvider.TYPE, ExternalAuthenticationManagerFactory.PROVIDER_TYPE);
+        externalAuthProviderAttributes.put(AuthenticationProvider.TYPE, ExternalAuthenticationManager.PROVIDER_TYPE);
         config.addObjectConfiguration(AuthenticationProvider.class, externalAuthProviderAttributes);
 
         config.setObjectAttribute(Port.class, TestBrokerConfiguration.ENTRY_NAME_SSL_PORT, Port.AUTHENTICATION_PROVIDER, TestBrokerConfiguration.ENTRY_NAME_EXTERNAL_PROVIDER);

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/MultipleAuthenticationManagersTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/MultipleAuthenticationManagersTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/MultipleAuthenticationManagersTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/security/auth/manager/MultipleAuthenticationManagersTest.java Wed Apr 30 01:22:13 2014
@@ -48,7 +48,7 @@ public class MultipleAuthenticationManag
         TestBrokerConfiguration config = getBrokerConfiguration();
 
         Map<String, Object> externalAuthProviderAttributes = new HashMap<String, Object>();
-        externalAuthProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        externalAuthProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
         externalAuthProviderAttributes.put(AuthenticationProvider.NAME, TestBrokerConfiguration.ENTRY_NAME_ANONYMOUS_PROVIDER);
         config.addObjectConfiguration(AuthenticationProvider.class, externalAuthProviderAttributes);
 

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/server/store/VirtualHostMessageStoreTest.java Wed Apr 30 01:22:13 2014
@@ -20,7 +20,6 @@
  */
 package org.apache.qpid.server.store;
 
-import static org.mockito.Mockito.mock;
 import static org.mockito.Mockito.when;
 
 import java.io.File;
@@ -31,6 +30,7 @@ import java.util.Map;
 import java.util.UUID;
 
 import org.apache.qpid.common.AMQPFilterTypes;
+import org.apache.qpid.exchange.ExchangeDefaults;
 import org.apache.qpid.framing.AMQShortString;
 import org.apache.qpid.framing.BasicContentHeaderProperties;
 import org.apache.qpid.framing.ContentHeaderBody;
@@ -39,9 +39,7 @@ import org.apache.qpid.framing.abstracti
 import org.apache.qpid.framing.amqp_8_0.BasicConsumeBodyImpl;
 import org.apache.qpid.server.configuration.updater.TaskExecutor;
 import org.apache.qpid.server.configuration.updater.TaskExecutorImpl;
-import org.apache.qpid.server.exchange.DirectExchange;
 import org.apache.qpid.server.exchange.ExchangeImpl;
-import org.apache.qpid.server.exchange.TopicExchange;
 import org.apache.qpid.server.message.InstanceProperties;
 import org.apache.qpid.server.message.MessageSource;
 import org.apache.qpid.server.model.Binding;
@@ -54,7 +52,6 @@ import org.apache.qpid.server.model.Queu
 import org.apache.qpid.server.model.State;
 import org.apache.qpid.server.model.UUIDGenerator;
 import org.apache.qpid.server.model.VirtualHostNode;
-import org.apache.qpid.server.plugin.ExchangeType;
 import org.apache.qpid.server.protocol.v0_8.AMQMessage;
 import org.apache.qpid.server.protocol.v0_8.MessageMetaData;
 import org.apache.qpid.server.queue.AMQQueue;
@@ -176,15 +173,15 @@ public class VirtualHostMessageStoreTest
         createAllTopicQueues();
 
         //Register Non-Durable DirectExchange
-        ExchangeImpl<?> nonDurableExchange = createExchange(DirectExchange.TYPE, nonDurableExchangeName, false);
+        ExchangeImpl<?> nonDurableExchange = createExchange(ExchangeDefaults.DIRECT_EXCHANGE_CLASS, nonDurableExchangeName, false);
         bindAllQueuesToExchange(nonDurableExchange, directRouting);
 
         //Register DirectExchange
-        ExchangeImpl<?> directExchange = createExchange(DirectExchange.TYPE, directExchangeName, true);
+        ExchangeImpl<?> directExchange = createExchange(ExchangeDefaults.DIRECT_EXCHANGE_CLASS, directExchangeName, true);
         bindAllQueuesToExchange(directExchange, directRouting);
 
         //Register TopicExchange
-        ExchangeImpl<?> topicExchange = createExchange(TopicExchange.TYPE, topicExchangeName, true);
+        ExchangeImpl<?> topicExchange = createExchange(ExchangeDefaults.TOPIC_EXCHANGE_CLASS, topicExchangeName, true);
         bindAllTopicQueuesToExchange(topicExchange, topicRouting);
 
         //Send Message To NonDurable direct Exchange = persistent
@@ -344,7 +341,7 @@ public class VirtualHostMessageStoreTest
     {
         int origExchangeCount = _virtualHost.getExchanges().size();
 
-        createExchange(DirectExchange.TYPE, directExchangeName, true);
+        createExchange(ExchangeDefaults.DIRECT_EXCHANGE_CLASS, directExchangeName, true);
 
         assertEquals("Incorrect number of exchanges registered before recovery",
                 origExchangeCount + 1,  _virtualHost.getExchanges().size());
@@ -408,7 +405,7 @@ public class VirtualHostMessageStoreTest
     public void testDurableBindingRemoval() throws Exception
     {
         //create durable queue and exchange, bind them
-        ExchangeImpl<?> exch = createExchange(DirectExchange.TYPE, directExchangeName, true);
+        ExchangeImpl<?> exch = createExchange(ExchangeDefaults.DIRECT_EXCHANGE_CLASS, directExchangeName, true);
         createQueue(durableQueueName, false, true, false, false);
         bindQueueToExchange(exch, directRouting, _virtualHost.getQueue(durableQueueName), false);
 
@@ -670,23 +667,23 @@ public class VirtualHostMessageStoreTest
         Map<String, ExchangeImpl<?>> exchanges = new HashMap<String, ExchangeImpl<?>>();
 
         //Register non-durable DirectExchange
-        exchanges.put(nonDurableExchangeName, createExchange(DirectExchange.TYPE, nonDurableExchangeName, false));
+        exchanges.put(nonDurableExchangeName, createExchange(ExchangeDefaults.DIRECT_EXCHANGE_CLASS, nonDurableExchangeName, false));
 
         //Register durable DirectExchange and TopicExchange
-        exchanges.put(directExchangeName ,createExchange(DirectExchange.TYPE, directExchangeName, true));
-        exchanges.put(topicExchangeName,createExchange(TopicExchange.TYPE, topicExchangeName, true));
+        exchanges.put(directExchangeName ,createExchange(ExchangeDefaults.DIRECT_EXCHANGE_CLASS, directExchangeName, true));
+        exchanges.put(topicExchangeName,createExchange(ExchangeDefaults.TOPIC_EXCHANGE_CLASS, topicExchangeName, true));
 
         return exchanges;
     }
 
-    private ExchangeImpl<?> createExchange(ExchangeType<?> type, String name, boolean durable) throws Exception
+    private ExchangeImpl<?> createExchange(String type, String name, boolean durable) throws Exception
     {
         ExchangeImpl<?> exchange = null;
 
         Map<String,Object> attributes = new HashMap<String, Object>();
 
         attributes.put(org.apache.qpid.server.model.Exchange.NAME, name);
-        attributes.put(org.apache.qpid.server.model.Exchange.TYPE, type.getType());
+        attributes.put(org.apache.qpid.server.model.Exchange.TYPE, type);
         attributes.put(org.apache.qpid.server.model.Exchange.DURABLE, durable);
         attributes.put(org.apache.qpid.server.model.Exchange.LIFETIME_POLICY,
                 durable ? LifetimePolicy.DELETE_ON_NO_LINKS : LifetimePolicy.PERMANENT);

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementTest.java Wed Apr 30 01:22:13 2014
@@ -31,7 +31,7 @@ import javax.jms.JMSException;
 
 import org.apache.qpid.management.common.mbeans.UserManagement;
 import org.apache.qpid.server.model.AuthenticationProvider;
-import org.apache.qpid.server.security.auth.manager.PlainPasswordFileAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.PlainPasswordDatabaseAuthenticationManager;
 import org.apache.qpid.test.utils.JMXTestUtils;
 import org.apache.qpid.test.utils.QpidBrokerTestCase;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
@@ -175,7 +175,7 @@ public class UserManagementTest extends 
 
     protected String getAuthenticationManagerType()
     {
-        return PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE;
+        return PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE;
     }
 
     private File createTemporaryPasswordFileWithJmxAdminUser() throws Exception

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementWithBase64MD5PasswordsTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementWithBase64MD5PasswordsTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementWithBase64MD5PasswordsTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/management/jmx/UserManagementWithBase64MD5PasswordsTest.java Wed Apr 30 01:22:13 2014
@@ -18,7 +18,7 @@
  */
 package org.apache.qpid.systest.management.jmx;
 
-import org.apache.qpid.server.security.auth.manager.Base64MD5PasswordFileAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.Base64MD5PasswordDatabaseAuthenticationManager;
 import org.apache.qpid.tools.security.Passwd;
 
 public class UserManagementWithBase64MD5PasswordsTest extends UserManagementTest
@@ -32,6 +32,6 @@ public class UserManagementWithBase64MD5
     @Override
     protected String getAuthenticationManagerType()
     {
-        return Base64MD5PasswordFileAuthenticationManagerFactory.PROVIDER_TYPE;
+        return Base64MD5PasswordDatabaseAuthenticationManager.PROVIDER_TYPE;
     }
 }

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AnonymousAccessRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AnonymousAccessRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AnonymousAccessRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AnonymousAccessRestTest.java Wed Apr 30 01:22:13 2014
@@ -29,7 +29,7 @@ import org.apache.qpid.server.model.Auth
 import org.apache.qpid.server.model.Broker;
 import org.apache.qpid.server.model.Plugin;
 import org.apache.qpid.server.model.Port;
-import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManager;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
 
 public class AnonymousAccessRestTest extends QpidRestTestCase
@@ -52,7 +52,7 @@ public class AnonymousAccessRestTest ext
         TestBrokerConfiguration config = getBrokerConfiguration();
 
         Map<String, Object> anonymousAuthProviderAttributes = new HashMap<String, Object>();
-        anonymousAuthProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        anonymousAuthProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
         anonymousAuthProviderAttributes.put(AuthenticationProvider.NAME, TestBrokerConfiguration.ENTRY_NAME_ANONYMOUS_PROVIDER);
         config.addObjectConfiguration(AuthenticationProvider.class, anonymousAuthProviderAttributes);
 

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/Asserts.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/Asserts.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/Asserts.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/Asserts.java Wed Apr 30 01:22:13 2014
@@ -31,10 +31,10 @@ import java.util.Map;
 import javax.jms.JMSException;
 
 import org.apache.qpid.client.AMQConnection;
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 import org.apache.qpid.server.model.Binding;
 import org.apache.qpid.server.model.Broker;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
 import org.apache.qpid.server.model.Connection;
 import org.apache.qpid.server.model.Exchange;
 import org.apache.qpid.server.model.ExclusivityPolicy;
@@ -56,7 +56,7 @@ public class Asserts
     {
         assertNotNull("Virtualhost " + virtualHostName + " data are not found", virtualHost);
         assertAttributesPresent(virtualHost,
-                                AbstractConfiguredObject.getAttributeNames(VirtualHost.class),
+                                ConfiguredObjectTypeRegistry.getAttributeNames(VirtualHost.class),
                                 ConfiguredObject.CREATED_BY,
                                 ConfiguredObject.CREATED_TIME,
                                 ConfiguredObject.LAST_UPDATED_BY,
@@ -105,7 +105,7 @@ public class Asserts
     {
         assertNotNull("Queue " + queueName + " is not found!", queueData);
         Asserts.assertAttributesPresent(queueData,
-                                        AbstractConfiguredObject.getAttributeNames(Queue.class),
+                                        ConfiguredObjectTypeRegistry.getAttributeNames(Queue.class),
                                         Queue.CREATED_BY,
                                         Queue.CREATED_TIME,
                                         Queue.LAST_UPDATED_BY,
@@ -211,7 +211,7 @@ public class Asserts
     {
         assertNotNull("Unexpected connection data", connectionData);
         assertAttributesPresent(connectionData,
-                                AbstractConfiguredObject.getAttributeNames(Connection.class),
+                                ConfiguredObjectTypeRegistry.getAttributeNames(Connection.class),
                                 Connection.STATE,
                                 Connection.DURABLE,
                                 Connection.LIFETIME_POLICY,
@@ -271,7 +271,7 @@ public class Asserts
         if ("AMQP".equals(port.get(ConfiguredObject.TYPE)))
         {
             assertAttributesPresent(port,
-                                    AbstractConfiguredObject.getAttributeNames(Port.class),
+                                    ConfiguredObjectTypeRegistry.getAttributeNames(Port.class),
                                     ConfiguredObject.TYPE,
                                     ConfiguredObject.CREATED_BY,
                                     ConfiguredObject.CREATED_TIME,
@@ -288,7 +288,7 @@ public class Asserts
         else
         {
             assertAttributesPresent(port,
-                                    AbstractConfiguredObject.getAttributeNames(Port.class),
+                                    ConfiguredObjectTypeRegistry.getAttributeNames(Port.class),
                                     ConfiguredObject.TYPE,
                                     ConfiguredObject.CREATED_BY,
                                     ConfiguredObject.CREATED_TIME,
@@ -325,7 +325,7 @@ public class Asserts
     public static void assertExchange(String exchangeName, String type, Map<String, Object> exchangeData)
     {
         assertNotNull("Exchange " + exchangeName + " is not found!", exchangeData);
-        assertAttributesPresent(exchangeData, AbstractConfiguredObject.getAttributeNames(Exchange.class),
+        assertAttributesPresent(exchangeData, ConfiguredObjectTypeRegistry.getAttributeNames(Exchange.class),
                                 Exchange.ALTERNATE_EXCHANGE,
                                 ConfiguredObject.CREATED_BY,
                                 ConfiguredObject.CREATED_TIME,
@@ -360,7 +360,7 @@ public class Asserts
     {
         assertNotNull("Binding map should not be null", binding);
         assertAttributesPresent(binding,
-                                AbstractConfiguredObject.getAttributeNames(Binding.class),
+                                ConfiguredObjectTypeRegistry.getAttributeNames(Binding.class),
                                 Binding.STATE,
                                 ConfiguredObject.TYPE,
                                 ConfiguredObject.CREATED_BY,

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AuthenticationProviderRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AuthenticationProviderRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AuthenticationProviderRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/AuthenticationProviderRestTest.java Wed Apr 30 01:22:13 2014
@@ -27,15 +27,16 @@ import java.util.Map;
 import java.util.UUID;
 
 import org.apache.qpid.server.BrokerOptions;
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 import org.apache.qpid.server.model.AuthenticationProvider;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
+import org.apache.qpid.server.model.ExternalFileBasedAuthenticationManager;
 import org.apache.qpid.server.model.LifetimePolicy;
 import org.apache.qpid.server.model.Port;
 import org.apache.qpid.server.model.State;
 import org.apache.qpid.server.model.User;
-import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManagerFactory;
-import org.apache.qpid.server.security.auth.manager.PlainPasswordFileAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManager;
+import org.apache.qpid.server.security.auth.manager.PlainPasswordDatabaseAuthenticationManager;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
 
 public class AuthenticationProviderRestTest extends QpidRestTestCase
@@ -49,10 +50,10 @@ public class AuthenticationProviderRestT
         for (Map<String, Object> provider : providerDetails)
         {
             boolean managesPrincipals = true;
-            String type = PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE;
+            String type = PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE;
             if (ANONYMOUS_AUTHENTICATION_PROVIDER.equals(provider.get(AuthenticationProvider.NAME)))
             {
-                type = AnonymousAuthenticationManagerFactory.PROVIDER_TYPE;
+                type = AnonymousAuthenticationManager.PROVIDER_TYPE;
                 managesPrincipals = false;
             }
             assertProvider(managesPrincipals, type , provider);
@@ -70,8 +71,8 @@ public class AuthenticationProviderRestT
         String providerName = "test-provider";
         Map<String, Object> attributes = new HashMap<String, Object>();
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(AuthenticationProvider.TYPE, PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE);
-        attributes.put(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH, principalDatabase.getAbsolutePath());
+        attributes.put(AuthenticationProvider.TYPE, PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE);
+        attributes.put(ExternalFileBasedAuthenticationManager.PATH, principalDatabase.getAbsolutePath());
 
         int responseCode = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "PUT", attributes);
         assertEquals("failed to create authentication provider", 201, responseCode);
@@ -82,7 +83,7 @@ public class AuthenticationProviderRestT
         String providerName = "test-provider";
         Map<String, Object> attributes = new HashMap<String, Object>();
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
 
         int responseCode = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "PUT", attributes);
         assertEquals("Unexpected response code", 201, responseCode);
@@ -91,7 +92,7 @@ public class AuthenticationProviderRestT
         assertNotNull("Providers details cannot be null", providerDetails);
         assertEquals("Unexpected number of providers", 1, providerDetails.size());
         Map<String, Object> provider = providerDetails.get(0);
-        assertProvider(false, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE, provider);
+        assertProvider(false, AnonymousAuthenticationManager.PROVIDER_TYPE, provider);
     }
 
     public void testUpdateAuthenticationProviderIdFails() throws Exception
@@ -99,7 +100,7 @@ public class AuthenticationProviderRestT
         String providerName = "test-provider";
         Map<String, Object> attributes = new HashMap<String, Object>();
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
 
         int responseCode = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "PUT", attributes);
         assertEquals("Unexpected response code", 201, responseCode);
@@ -116,7 +117,7 @@ public class AuthenticationProviderRestT
         String providerName = "test-provider";
         Map<String, Object> attributes = new HashMap<String, Object>();
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
 
         int responseCode = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "PUT", attributes);
         assertEquals("Unexpected response code for provider creation", 201, responseCode);
@@ -137,7 +138,7 @@ public class AuthenticationProviderRestT
         List<Map<String, Object>> providerDetails = getRestTestHelper().getJsonAsList("/rest/authenticationprovider/" + providerName);
         assertNotNull("Providers details cannot be null", providerDetails);
         assertEquals("Unexpected number of providers", 1, providerDetails.size());
-        assertProvider(false, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE, providerDetails.get(0));
+        assertProvider(false, AnonymousAuthenticationManager.PROVIDER_TYPE, providerDetails.get(0));
     }
 
     public void testDeleteOfUnusedAuthenticationProvider() throws Exception
@@ -146,7 +147,7 @@ public class AuthenticationProviderRestT
         String providerName = "test-provider";
         Map<String, Object> attributes = new HashMap<String, Object>();
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        attributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
 
         int responseCode = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "PUT", attributes);
         assertEquals("Unexpected response code for provider creation", 201, responseCode);
@@ -174,9 +175,9 @@ public class AuthenticationProviderRestT
 
         String providerName = getTestName();
         Map<String, Object> attributes = new HashMap<String, Object>();
-        attributes.put(AuthenticationProvider.TYPE, PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE);
+        attributes.put(AuthenticationProvider.TYPE, PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE);
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH, file.getAbsoluteFile());
+        attributes.put(ExternalFileBasedAuthenticationManager.PATH, file.getAbsoluteFile());
 
         UUID id = config.addObjectConfiguration(AuthenticationProvider.class, attributes);
         config.setSaved(false);
@@ -187,7 +188,7 @@ public class AuthenticationProviderRestT
         Map<String, Object> provider = getRestTestHelper().getJsonAsSingletonList("/rest/authenticationprovider/" + providerName);
         assertEquals("Unexpected id", id.toString(), provider.get(AuthenticationProvider.ID));
         assertEquals("Unexpected name", providerName, provider.get(AuthenticationProvider.NAME));
-        assertEquals("Unexpected path", file.getAbsolutePath() , provider.get(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH));
+        assertEquals("Unexpected path", file.getAbsolutePath() , provider.get(ExternalFileBasedAuthenticationManager.PATH));
         assertEquals("Unexpected state", State.ERRORED.name() , provider.get(AuthenticationProvider.STATE));
 
         int status = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "DELETE", null);
@@ -212,9 +213,9 @@ public class AuthenticationProviderRestT
 
         String providerName = getTestName();
         Map<String, Object> attributes = new HashMap<String, Object>();
-        attributes.put(AuthenticationProvider.TYPE, PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE);
+        attributes.put(AuthenticationProvider.TYPE, PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE);
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH, file.getAbsoluteFile());
+        attributes.put(ExternalFileBasedAuthenticationManager.PATH, file.getAbsoluteFile());
 
         UUID id = config.addObjectConfiguration(AuthenticationProvider.class, attributes);
         config.setSaved(false);
@@ -225,7 +226,7 @@ public class AuthenticationProviderRestT
         Map<String, Object> provider = getRestTestHelper().getJsonAsSingletonList("/rest/authenticationprovider/" + providerName);
         assertEquals("Unexpected id", id.toString(), provider.get(AuthenticationProvider.ID));
         assertEquals("Unexpected name", providerName, provider.get(AuthenticationProvider.NAME));
-        assertEquals("Unexpected path", file.getAbsolutePath() , provider.get(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH));
+        assertEquals("Unexpected path", file.getAbsolutePath() , provider.get(ExternalFileBasedAuthenticationManager.PATH));
         assertEquals("Unexpected state", State.ERRORED.name() , provider.get(AuthenticationProvider.STATE));
 
         File principalDatabase = null;
@@ -235,8 +236,8 @@ public class AuthenticationProviderRestT
             attributes = new HashMap<String, Object>();
             attributes.put(AuthenticationProvider.NAME, providerName);
             attributes.put(AuthenticationProvider.ID, id);
-            attributes.put(AuthenticationProvider.TYPE, PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE);
-            attributes.put(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH, principalDatabase.getAbsolutePath());
+            attributes.put(AuthenticationProvider.TYPE, PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE);
+            attributes.put(ExternalFileBasedAuthenticationManager.PATH, principalDatabase.getAbsolutePath());
 
             int status = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "PUT", attributes);
             assertEquals("ACL was not deleted", 200, status);
@@ -244,7 +245,8 @@ public class AuthenticationProviderRestT
             provider = getRestTestHelper().getJsonAsSingletonList("/rest/authenticationprovider/" + providerName);
             assertEquals("Unexpected id", id.toString(), provider.get(AuthenticationProvider.ID));
             assertEquals("Unexpected name", providerName, provider.get(AuthenticationProvider.NAME));
-            assertEquals("Unexpected path", principalDatabase.getAbsolutePath() , provider.get(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH));
+            assertEquals("Unexpected path", principalDatabase.getAbsolutePath() , provider.get(
+                    ExternalFileBasedAuthenticationManager.PATH));
             assertEquals("Unexpected state", State.ACTIVE.name() , provider.get(AuthenticationProvider.STATE));
         }
         finally
@@ -277,8 +279,8 @@ public class AuthenticationProviderRestT
         String providerName = "test-provider";
         Map<String, Object> attributes = new HashMap<String, Object>();
         attributes.put(AuthenticationProvider.NAME, providerName);
-        attributes.put(AuthenticationProvider.TYPE, PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE);
-        attributes.put(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH, file.getAbsolutePath());
+        attributes.put(AuthenticationProvider.TYPE, PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE);
+        attributes.put(ExternalFileBasedAuthenticationManager.PATH, file.getAbsolutePath());
 
         int responseCode = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + providerName, "PUT", attributes);
         assertEquals("Password provider was not created", 201, responseCode);
@@ -287,8 +289,9 @@ public class AuthenticationProviderRestT
         Map<String, Object> providerDetails = getRestTestHelper().getJsonAsSingletonList("/rest/authenticationprovider/" + providerName);
         assertNotNull("Providers details cannot be null", providerDetails);
         assertEquals("Unexpected name", providerName, providerDetails.get(AuthenticationProvider.NAME));
-        assertEquals("Unexpected type", PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE, providerDetails.get(AuthenticationProvider.TYPE));
-        assertEquals("Unexpected path", file.getAbsolutePath(), providerDetails.get(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH));
+        assertEquals("Unexpected type", PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE, providerDetails.get(AuthenticationProvider.TYPE));
+        assertEquals("Unexpected path", file.getAbsolutePath(), providerDetails.get(
+                ExternalFileBasedAuthenticationManager.PATH));
 
         assertTrue("User file should be created", file.exists());
 
@@ -304,8 +307,8 @@ public class AuthenticationProviderRestT
 
     private void assertProvider(boolean managesPrincipals, String type, Map<String, Object> provider)
     {
-        Asserts.assertAttributesPresent(provider, AbstractConfiguredObject.getAttributeNames(
-                AuthenticationProvider.class),
+        Asserts.assertAttributesPresent(provider, ConfiguredObjectTypeRegistry.getAttributeNames(
+                                                AuthenticationProvider.class),
                 AuthenticationProvider.DESCRIPTION, ConfiguredObject.CONTEXT, ConfiguredObject.CREATED_BY,
                 ConfiguredObject.CREATED_TIME, ConfiguredObject.LAST_UPDATED_BY, ConfiguredObject.LAST_UPDATED_TIME);
         assertEquals("Unexpected value of provider attribute " + AuthenticationProvider.STATE, State.ACTIVE.name(),

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsClientCertAuthTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsClientCertAuthTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsClientCertAuthTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsClientCertAuthTest.java Wed Apr 30 01:22:13 2014
@@ -34,7 +34,7 @@ import org.apache.qpid.server.model.Auth
 import org.apache.qpid.server.model.Port;
 import org.apache.qpid.server.model.Protocol;
 import org.apache.qpid.server.model.Transport;
-import org.apache.qpid.server.security.auth.manager.ExternalAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.ExternalAuthenticationManager;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
 
 public class BrokerRestHttpsClientCertAuthTest extends QpidRestTestCase
@@ -66,7 +66,7 @@ public class BrokerRestHttpsClientCertAu
 
 
         Map<String, Object> externalProviderAttributes = new HashMap<String, Object>();
-        externalProviderAttributes.put(AuthenticationProvider.TYPE, ExternalAuthenticationManagerFactory.PROVIDER_TYPE);
+        externalProviderAttributes.put(AuthenticationProvider.TYPE, ExternalAuthenticationManager.PROVIDER_TYPE);
         externalProviderAttributes.put(AuthenticationProvider.NAME, EXTERNAL_AUTHENTICATION_PROVIDER);
         getBrokerConfiguration().addObjectConfiguration(AuthenticationProvider.class, externalProviderAttributes);
 

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestHttpsTest.java Wed Apr 30 01:22:13 2014
@@ -28,9 +28,9 @@ import java.util.Collections;
 import java.util.HashMap;
 import java.util.Map;
 
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 import org.apache.qpid.server.model.Broker;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
 import org.apache.qpid.server.model.Port;
 import org.apache.qpid.server.model.Protocol;
 import org.apache.qpid.server.model.Transport;
@@ -63,7 +63,7 @@ public class BrokerRestHttpsTest extends
     {
         Map<String, Object> brokerDetails = getRestTestHelper().getJsonAsSingletonList("/rest/broker");
 
-        Asserts.assertAttributesPresent(brokerDetails, AbstractConfiguredObject.getAttributeNames(Broker.class),
+        Asserts.assertAttributesPresent(brokerDetails, ConfiguredObjectTypeRegistry.getAttributeNames(Broker.class),
                 Broker.PROCESS_PID, Broker.SUPPORTED_VIRTUALHOST_STORE_TYPES,
                 ConfiguredObject.TYPE,
                 ConfiguredObject.CREATED_BY,

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/BrokerRestTest.java Wed Apr 30 01:22:13 2014
@@ -33,13 +33,12 @@ import javax.jms.Session;
 import javax.jms.TextMessage;
 
 import org.apache.qpid.common.QpidProperties;
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 import org.apache.qpid.server.model.Broker;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
 import org.apache.qpid.server.model.LifetimePolicy;
 import org.apache.qpid.server.model.Port;
 import org.apache.qpid.server.model.State;
-import org.apache.qpid.server.model.VirtualHost;
 import org.apache.qpid.server.model.VirtualHostNode;
 import org.apache.qpid.server.plugin.MessageStoreFactory;
 import org.apache.qpid.test.client.UnroutableMessageTestExceptionListener;
@@ -203,7 +202,7 @@ public class BrokerRestTest extends Qpid
 
     protected void assertBrokerAttributes(Map<String, Object> brokerDetails)
     {
-        Asserts.assertAttributesPresent(brokerDetails, AbstractConfiguredObject.getAttributeNames(Broker.class),
+        Asserts.assertAttributesPresent(brokerDetails, ConfiguredObjectTypeRegistry.getAttributeNames(Broker.class),
                 Broker.PROCESS_PID,
                 ConfiguredObject.TYPE,
                 ConfiguredObject.CREATED_BY,

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/ConnectionRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/ConnectionRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/ConnectionRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/ConnectionRestTest.java Wed Apr 30 01:22:13 2014
@@ -34,9 +34,9 @@ import javax.jms.MessageProducer;
 import org.apache.qpid.client.AMQConnection;
 import org.apache.qpid.client.AMQSession;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
 import org.apache.qpid.server.model.Connection;
 import org.apache.qpid.server.model.Session;
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 
 public class ConnectionRestTest extends QpidRestTestCase
 {
@@ -174,7 +174,7 @@ public class ConnectionRestTest extends 
     private void assertSession(Map<String, Object> sessionData, AMQSession<?, ?> session)
     {
         assertNotNull("Session map cannot be null", sessionData);
-        Asserts.assertAttributesPresent(sessionData, AbstractConfiguredObject.getAttributeNames(Session.class),
+        Asserts.assertAttributesPresent(sessionData, ConfiguredObjectTypeRegistry.getAttributeNames(Session.class),
                                         ConfiguredObject.TYPE,
                                         ConfiguredObject.CREATED_BY,
                                         ConfiguredObject.CREATED_TIME,

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/GroupProviderRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/GroupProviderRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/GroupProviderRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/GroupProviderRestTest.java Wed Apr 30 01:22:13 2014
@@ -29,8 +29,8 @@ import java.util.Properties;
 import java.util.UUID;
 
 import org.apache.qpid.server.BrokerOptions;
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
 import org.apache.qpid.server.model.Group;
 import org.apache.qpid.server.model.GroupProvider;
 import org.apache.qpid.server.model.LifetimePolicy;
@@ -322,7 +322,7 @@ public class GroupProviderRestTest exten
 
     private void assertProvider(String name, String type, Map<String, Object> provider)
     {
-        Asserts.assertAttributesPresent(provider, AbstractConfiguredObject.getAttributeNames(GroupProvider.class),
+        Asserts.assertAttributesPresent(provider, ConfiguredObjectTypeRegistry.getAttributeNames(GroupProvider.class),
                 ConfiguredObject.TYPE,
                 ConfiguredObject.CREATED_BY,
                 ConfiguredObject.CREATED_TIME,

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PortRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PortRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PortRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PortRestTest.java Wed Apr 30 01:22:13 2014
@@ -35,7 +35,7 @@ import org.apache.qpid.server.model.Port
 import org.apache.qpid.server.model.Protocol;
 import org.apache.qpid.server.model.State;
 import org.apache.qpid.server.model.Transport;
-import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManager;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
 
 public class PortRestTest extends QpidRestTestCase
@@ -152,7 +152,7 @@ public class PortRestTest extends QpidRe
         Asserts.assertPortAttributes(port);
 
         Map<String, Object> authProviderAttributes = new HashMap<String, Object>();
-        authProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        authProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
         authProviderAttributes.put(AuthenticationProvider.NAME, TestBrokerConfiguration.ENTRY_NAME_ANONYMOUS_PROVIDER);
 
         responseCode = getRestTestHelper().submitRequest("/rest/authenticationprovider/" + TestBrokerConfiguration.ENTRY_NAME_ANONYMOUS_PROVIDER, "PUT", authProviderAttributes);

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PreferencesProviderRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PreferencesProviderRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PreferencesProviderRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/PreferencesProviderRestTest.java Wed Apr 30 01:22:13 2014
@@ -27,14 +27,15 @@ import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 import org.apache.qpid.server.model.AuthenticationProvider;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
+import org.apache.qpid.server.model.ExternalFileBasedAuthenticationManager;
 import org.apache.qpid.server.model.LifetimePolicy;
 import org.apache.qpid.server.model.PreferencesProvider;
 import org.apache.qpid.server.model.State;
 import org.apache.qpid.server.model.adapter.FileSystemPreferencesProvider;
-import org.apache.qpid.server.security.auth.manager.PlainPasswordFileAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.PlainPasswordDatabaseAuthenticationManager;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
 import org.apache.qpid.test.utils.TestFileUtils;
 
@@ -74,9 +75,9 @@ public class PreferencesProviderRestTest
     {
         super.customizeConfiguration();
         Map<String, Object> anonymousAuthProviderAttributes = new HashMap<String, Object>();
-        anonymousAuthProviderAttributes.put(AuthenticationProvider.TYPE, PlainPasswordFileAuthenticationManagerFactory.PROVIDER_TYPE);
+        anonymousAuthProviderAttributes.put(AuthenticationProvider.TYPE, PlainPasswordDatabaseAuthenticationManager.PROVIDER_TYPE);
         anonymousAuthProviderAttributes.put(AuthenticationProvider.NAME,  TestBrokerConfiguration.ENTRY_NAME_AUTHENTICATION_PROVIDER + "-2");
-        anonymousAuthProviderAttributes.put(PlainPasswordFileAuthenticationManagerFactory.ATTRIBUTE_PATH, _authenticationProviderFile.getAbsolutePath());
+        anonymousAuthProviderAttributes.put(ExternalFileBasedAuthenticationManager.PATH, _authenticationProviderFile.getAbsolutePath());
         getBrokerConfiguration().addObjectConfiguration(AuthenticationProvider.class,anonymousAuthProviderAttributes);
     }
 
@@ -162,7 +163,7 @@ public class PreferencesProviderRestTest
     public void assertProviderCommonAttributes(Map<String, Object> provider)
     {
         Asserts.assertAttributesPresent(provider,
-                                        AbstractConfiguredObject.getAttributeNames(PreferencesProvider.class),
+                                        ConfiguredObjectTypeRegistry.getAttributeNames(PreferencesProvider.class),
                                         ConfiguredObject.CREATED_BY,
                                         ConfiguredObject.CREATED_TIME,
                                         ConfiguredObject.LAST_UPDATED_BY,

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QpidRestTestCase.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QpidRestTestCase.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QpidRestTestCase.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QpidRestTestCase.java Wed Apr 30 01:22:13 2014
@@ -28,9 +28,8 @@ import org.apache.qpid.server.management
 import org.apache.qpid.server.model.AuthenticationProvider;
 import org.apache.qpid.server.model.Plugin;
 import org.apache.qpid.server.model.Port;
-import org.apache.qpid.server.model.VirtualHost;
 import org.apache.qpid.server.model.VirtualHostNode;
-import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManagerFactory;
+import org.apache.qpid.server.security.auth.manager.AnonymousAuthenticationManager;
 import org.apache.qpid.test.utils.QpidBrokerTestCase;
 import org.apache.qpid.test.utils.TestBrokerConfiguration;
 
@@ -89,7 +88,7 @@ public class QpidRestTestCase extends Qp
         config.removeObjectConfiguration(Port.class, TestBrokerConfiguration.ENTRY_NAME_RMI_PORT);
 
         Map<String, Object> anonymousProviderAttributes = new HashMap<String, Object>();
-        anonymousProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManagerFactory.PROVIDER_TYPE);
+        anonymousProviderAttributes.put(AuthenticationProvider.TYPE, AnonymousAuthenticationManager.PROVIDER_TYPE);
         anonymousProviderAttributes.put(AuthenticationProvider.NAME, ANONYMOUS_AUTHENTICATION_PROVIDER);
         config.addObjectConfiguration(AuthenticationProvider.class, anonymousProviderAttributes);
 

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QueueRestTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QueueRestTest.java?rev=1591170&r1=1591169&r2=1591170&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QueueRestTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/systest/rest/QueueRestTest.java Wed Apr 30 01:22:13 2014
@@ -36,10 +36,10 @@ import javax.jms.Session;
 
 import org.apache.qpid.server.model.Binding;
 import org.apache.qpid.server.model.ConfiguredObject;
+import org.apache.qpid.server.model.ConfiguredObjectTypeRegistry;
 import org.apache.qpid.server.model.Consumer;
 import org.apache.qpid.server.model.LifetimePolicy;
 import org.apache.qpid.server.model.Queue;
-import org.apache.qpid.server.model.AbstractConfiguredObject;
 
 public class QueueRestTest extends QpidRestTestCase
 {
@@ -212,7 +212,7 @@ public class QueueRestTest extends QpidR
     {
         assertNotNull("Consumer map should not be null", consumer);
         Asserts.assertAttributesPresent(consumer,
-                                        AbstractConfiguredObject.getAttributeNames(Consumer.class), Consumer.STATE,
+                                        ConfiguredObjectTypeRegistry.getAttributeNames(Consumer.class), Consumer.STATE,
                 Consumer.SETTLEMENT_MODE, Consumer.EXCLUSIVE, Consumer.SELECTOR,
                 Consumer.NO_LOCAL,
                 ConfiguredObject.TYPE,



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