You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cl...@apache.org on 2014/12/05 16:38:34 UTC

[10/13] activemq-6 git commit: ACTIVEMQ6-14 Replace JNDI server with client impl

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
----------------------------------------------------------------------
diff --git a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
index 139ffdb..cd948c1 100644
--- a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
+++ b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerConfigParserImpl.java
@@ -20,21 +20,15 @@ import java.io.InputStream;
 import java.io.InputStreamReader;
 import java.io.Reader;
 import java.util.ArrayList;
-import java.util.List;
 
 import org.apache.activemq.api.config.ActiveMQDefaultConfiguration;
-import org.apache.activemq.api.core.ActiveMQException;
-import org.apache.activemq.api.core.client.ActiveMQClient;
-import org.apache.activemq.api.jms.JMSFactoryType;
 import org.apache.activemq.core.config.impl.Validators;
-import org.apache.activemq.jms.server.ActiveMQJMSServerBundle;
 import org.apache.activemq.jms.server.ActiveMQJMSServerLogger;
 import org.apache.activemq.jms.server.JMSServerConfigParser;
 import org.apache.activemq.jms.server.config.ConnectionFactoryConfiguration;
 import org.apache.activemq.jms.server.config.JMSConfiguration;
 import org.apache.activemq.jms.server.config.JMSQueueConfiguration;
 import org.apache.activemq.jms.server.config.TopicConfiguration;
-import org.apache.activemq.jms.server.config.impl.ConnectionFactoryConfigurationImpl;
 import org.apache.activemq.jms.server.config.impl.JMSConfigurationImpl;
 import org.apache.activemq.jms.server.config.impl.JMSQueueConfigurationImpl;
 import org.apache.activemq.jms.server.config.impl.TopicConfigurationImpl;
@@ -85,8 +79,7 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
       org.apache.activemq.utils.XMLUtil.validate(rootnode, "schema/activemq-jms.xsd");
 
       String[] elements = new String[]{JMSServerDeployer.QUEUE_NODE_NAME,
-         JMSServerDeployer.TOPIC_NODE_NAME,
-         JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME};
+         JMSServerDeployer.TOPIC_NODE_NAME};
       for (String element : elements)
       {
          NodeList children = e.getElementsByTagName(element);
@@ -100,11 +93,7 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
                continue;
             }
 
-            if (node.getNodeName().equals(JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME))
-            {
-               cfs.add(parseConnectionFactoryConfiguration(node));
-            }
-            else if (node.getNodeName().equals(JMSServerDeployer.TOPIC_NODE_NAME))
+            if (node.getNodeName().equals(JMSServerDeployer.TOPIC_NODE_NAME))
             {
                topics.add(parseTopicConfiguration(node));
             }
@@ -118,7 +107,7 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
       domain = XMLConfigurationUtil.getString(e, JMSServerDeployer.JMX_DOMAIN_NAME, ActiveMQDefaultConfiguration.getDefaultJmxDomain(), Validators.NO_CHECK);
 
 
-      JMSConfiguration value = newConfig(queues, topics, cfs, domain);
+      JMSConfiguration value = newConfig(queues, topics, domain);
 
       return value;
    }
@@ -133,23 +122,8 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
    public TopicConfiguration parseTopicConfiguration(final Node node) throws Exception
    {
       String topicName = node.getAttributes().getNamedItem(JMSServerConfigParserImpl.NAME_ATTR).getNodeValue();
-      NodeList children = node.getChildNodes();
-      ArrayList<String> jndiNames = new ArrayList<String>();
-      for (int i = 0; i < children.getLength(); i++)
-      {
-         Node child = children.item(i);
-
-         if (JMSServerDeployer.ENTRY_NODE_NAME.equals(children.item(i).getNodeName()))
-         {
-            String jndiElement = child.getAttributes().getNamedItem("name").getNodeValue();
-            jndiNames.add(jndiElement);
-         }
-      }
-
-      String[] strBindings = jndiNames.toArray(new String[jndiNames.size()]);
-
-      return newTopic(topicName, strBindings);
 
+      return newTopic(topicName);
    }
 
    /**
@@ -167,17 +141,11 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
       String selectorString = null;
       boolean durable = XMLConfigurationUtil.getBoolean(e, "durable", JMSServerDeployer.DEFAULT_QUEUE_DURABILITY);
       NodeList children = node.getChildNodes();
-      ArrayList<String> jndiNames = new ArrayList<String>();
       for (int i = 0; i < children.getLength(); i++)
       {
          Node child = children.item(i);
 
-         if (JMSServerDeployer.ENTRY_NODE_NAME.equals(children.item(i).getNodeName()))
-         {
-            String jndiName = child.getAttributes().getNamedItem("name").getNodeValue();
-            jndiNames.add(jndiName);
-         }
-         else if (JMSServerDeployer.QUEUE_SELECTOR_NODE_NAME.equals(children.item(i).getNodeName()))
+         if (JMSServerDeployer.QUEUE_SELECTOR_NODE_NAME.equals(children.item(i).getNodeName()))
          {
             Node selectorNode = children.item(i);
             Node attNode = selectorNode.getAttributes().getNamedItem("string");
@@ -185,298 +153,19 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
          }
       }
 
-      String[] jndiArray = jndiNames.toArray(new String[jndiNames.size()]);
-      return newQueue(queueName, selectorString, durable, jndiArray);
-   }
-
-   /**
-    * Parse the Connection Configuration node as a ConnectionFactoryConfiguration object
-    *
-    * @param node
-    * @return ConnectionFactoryConfiguration
-    * @throws Exception
-    */
-   public ConnectionFactoryConfiguration parseConnectionFactoryConfiguration(final Node node) throws Exception
-   {
-      if (!node.getNodeName().equals(JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME))
-      {
-         // sanity check, this shouldn't ever happen
-         throw ActiveMQJMSServerBundle.BUNDLE.invalidNodeParsingCF(node.getNodeName());
-      }
-      Element e = (Element) node;
-
-      String name = node.getAttributes().getNamedItem(JMSServerConfigParserImpl.NAME_ATTR).getNodeValue();
-
-      String fact = e.getAttribute("signature");
-      boolean isXA = XMLConfigurationUtil.getBoolean(e,
-                                                     "xa",
-                                                     ActiveMQClient.DEFAULT_XA);
-
-      JMSFactoryType factType = resolveFactoryType(fact, isXA);
-
-      long clientFailureCheckPeriod = XMLConfigurationUtil.getLong(e,
-                                                                   "client-failure-check-period",
-                                                                   ActiveMQClient.DEFAULT_CLIENT_FAILURE_CHECK_PERIOD,
-                                                                   Validators.MINUS_ONE_OR_GT_ZERO);
-      long connectionTTL = XMLConfigurationUtil.getLong(e,
-                                                        "connection-ttl",
-                                                        ActiveMQClient.DEFAULT_CONNECTION_TTL,
-                                                        Validators.MINUS_ONE_OR_GE_ZERO);
-      long callTimeout = XMLConfigurationUtil.getLong(e,
-                                                      "call-timeout",
-                                                      ActiveMQClient.DEFAULT_CALL_TIMEOUT,
-                                                      Validators.GE_ZERO);
-      long callFailoverTimeout = XMLConfigurationUtil.getLong(e,
-                                                              "call-failover-timeout",
-                                                              ActiveMQClient.DEFAULT_CALL_FAILOVER_TIMEOUT,
-                                                              Validators.MINUS_ONE_OR_GT_ZERO);
-      String clientID = XMLConfigurationUtil.getString(e, "client-id", null, Validators.NO_CHECK);
-      int dupsOKBatchSize = XMLConfigurationUtil.getInteger(e,
-                                                            "dups-ok-batch-size",
-                                                            ActiveMQClient.DEFAULT_ACK_BATCH_SIZE,
-                                                            Validators.GT_ZERO);
-      int transactionBatchSize = XMLConfigurationUtil.getInteger(e,
-                                                                 "transaction-batch-size",
-                                                                 ActiveMQClient.DEFAULT_ACK_BATCH_SIZE,
-                                                                 Validators.GT_ZERO);
-      int consumerWindowSize = XMLConfigurationUtil.getInteger(e,
-                                                               "consumer-window-size",
-                                                               ActiveMQClient.DEFAULT_CONSUMER_WINDOW_SIZE,
-                                                               Validators.MINUS_ONE_OR_GE_ZERO);
-      int producerWindowSize = XMLConfigurationUtil.getInteger(e,
-                                                               "producer-window-size",
-                                                               ActiveMQClient.DEFAULT_PRODUCER_WINDOW_SIZE,
-                                                               Validators.MINUS_ONE_OR_GT_ZERO);
-      int consumerMaxRate = XMLConfigurationUtil.getInteger(e,
-                                                            "consumer-max-rate",
-                                                            ActiveMQClient.DEFAULT_CONSUMER_MAX_RATE,
-                                                            Validators.MINUS_ONE_OR_GT_ZERO);
-      int confirmationWindowSize = XMLConfigurationUtil.getInteger(e,
-                                                                   "confirmation-window-size",
-                                                                   ActiveMQClient.DEFAULT_CONFIRMATION_WINDOW_SIZE,
-                                                                   Validators.MINUS_ONE_OR_GT_ZERO);
-      int producerMaxRate = XMLConfigurationUtil.getInteger(e,
-                                                            "producer-max-rate",
-                                                            ActiveMQClient.DEFAULT_PRODUCER_MAX_RATE,
-                                                            Validators.MINUS_ONE_OR_GT_ZERO);
-      boolean cacheLargeMessagesClient = XMLConfigurationUtil.getBoolean(e,
-                                                                         "cache-large-message-client",
-                                                                         ActiveMQClient.DEFAULT_CACHE_LARGE_MESSAGE_CLIENT);
-      int minLargeMessageSize = XMLConfigurationUtil.getInteger(e,
-                                                                "min-large-message-size",
-                                                                ActiveMQClient.DEFAULT_MIN_LARGE_MESSAGE_SIZE,
-                                                                Validators.GT_ZERO);
-
-      boolean compressLargeMessages = XMLConfigurationUtil.getBoolean(e,
-                                                                      "compress-large-messages",
-                                                                      ActiveMQClient.DEFAULT_COMPRESS_LARGE_MESSAGES);
-
-      boolean blockOnAcknowledge = XMLConfigurationUtil.getBoolean(e,
-                                                                   "block-on-acknowledge",
-                                                                   ActiveMQClient.DEFAULT_BLOCK_ON_ACKNOWLEDGE);
-      boolean blockOnNonDurableSend = XMLConfigurationUtil.getBoolean(e,
-                                                                      "block-on-non-durable-send",
-                                                                      ActiveMQClient.DEFAULT_BLOCK_ON_NON_DURABLE_SEND);
-      boolean blockOnDurableSend = XMLConfigurationUtil.getBoolean(e,
-                                                                   "block-on-durable-send",
-                                                                   ActiveMQClient.DEFAULT_BLOCK_ON_DURABLE_SEND);
-      boolean autoGroup = XMLConfigurationUtil.getBoolean(e, "auto-group", ActiveMQClient.DEFAULT_AUTO_GROUP);
-      boolean preAcknowledge = XMLConfigurationUtil.getBoolean(e,
-                                                               "pre-acknowledge",
-                                                               ActiveMQClient.DEFAULT_PRE_ACKNOWLEDGE);
-      long retryInterval = XMLConfigurationUtil.getLong(e,
-                                                        "retry-interval",
-                                                        ActiveMQClient.DEFAULT_RETRY_INTERVAL,
-                                                        Validators.GT_ZERO);
-      double retryIntervalMultiplier = XMLConfigurationUtil.getDouble(e,
-                                                                      "retry-interval-multiplier",
-                                                                      ActiveMQClient.DEFAULT_RETRY_INTERVAL_MULTIPLIER,
-                                                                      Validators.GT_ZERO);
-      long maxRetryInterval = XMLConfigurationUtil.getLong(e,
-                                                           "max-retry-interval",
-                                                           ActiveMQClient.DEFAULT_MAX_RETRY_INTERVAL,
-                                                           Validators.GT_ZERO);
-      int reconnectAttempts = XMLConfigurationUtil.getInteger(e,
-                                                              "reconnect-attempts",
-                                                              ActiveMQClient.DEFAULT_RECONNECT_ATTEMPTS,
-                                                              Validators.MINUS_ONE_OR_GE_ZERO);
-      boolean failoverOnInitialConnection = XMLConfigurationUtil.getBoolean(e,
-                                                                            "failover-on-initial-connection",
-                                                                            ActiveMQClient.DEFAULT_FAILOVER_ON_INITIAL_CONNECTION);
-
-      boolean useGlobalPools = XMLConfigurationUtil.getBoolean(e,
-                                                               "use-global-pools",
-                                                               ActiveMQClient.DEFAULT_USE_GLOBAL_POOLS);
-      int scheduledThreadPoolMaxSize = XMLConfigurationUtil.getInteger(e,
-                                                                       "scheduled-thread-pool-max-size",
-                                                                       ActiveMQClient.DEFAULT_SCHEDULED_THREAD_POOL_MAX_SIZE,
-                                                                       Validators.MINUS_ONE_OR_GT_ZERO);
-      int threadPoolMaxSize = XMLConfigurationUtil.getInteger(e,
-                                                              "thread-pool-max-size",
-                                                              ActiveMQClient.DEFAULT_THREAD_POOL_MAX_SIZE,
-                                                              Validators.MINUS_ONE_OR_GT_ZERO);
-      String connectionLoadBalancingPolicyClassName = XMLConfigurationUtil.getString(e,
-                                                                                     "connection-load-balancing-policy-class-name",
-                                                                                     ActiveMQClient.DEFAULT_CONNECTION_LOAD_BALANCING_POLICY_CLASS_NAME,
-                                                                                     Validators.NOT_NULL_OR_EMPTY);
-      boolean ha = XMLConfigurationUtil.getBoolean(e, "ha", ActiveMQClient.DEFAULT_HA);
-
-      String groupid = XMLConfigurationUtil.getString(e, "group-id", null, Validators.NO_CHECK);
-      List<String> jndiBindings = new ArrayList<String>();
-      List<String> connectorNames = new ArrayList<String>();
-      String discoveryGroupName = null;
-
-      NodeList children = node.getChildNodes();
-
-      for (int j = 0; j < children.getLength(); j++)
-      {
-         Node child = children.item(j);
-
-         if (JMSServerDeployer.ENTRIES_NODE_NAME.equals(child.getNodeName()))
-         {
-            NodeList entries = child.getChildNodes();
-            for (int i = 0; i < entries.getLength(); i++)
-            {
-               Node entry = entries.item(i);
-               if (JMSServerDeployer.ENTRY_NODE_NAME.equals(entry.getNodeName()))
-               {
-                  String jndiName = entry.getAttributes().getNamedItem("name").getNodeValue();
-
-                  jndiBindings.add(jndiName);
-               }
-            }
-         }
-         else if (JMSServerDeployer.CONNECTORS_NODE_NAME.equals(child.getNodeName()))
-         {
-            NodeList entries = child.getChildNodes();
-            for (int i = 0; i < entries.getLength(); i++)
-            {
-               Node entry = entries.item(i);
-               if (JMSServerDeployer.CONNECTOR_REF_ELEMENT.equals(entry.getNodeName()))
-               {
-                  String connectorName = entry.getAttributes().getNamedItem("connector-name").getNodeValue();
-
-                  connectorNames.add(connectorName);
-               }
-            }
-         }
-         else if (JMSServerDeployer.DISCOVERY_GROUP_ELEMENT.equals(child.getNodeName()))
-         {
-            discoveryGroupName = child.getAttributes().getNamedItem("discovery-group-name").getNodeValue();
-
-         }
-      }
-
-      ConnectionFactoryConfiguration cfConfig;
-
-      String[] strbindings = jndiBindings.toArray(new String[jndiBindings.size()]);
-
-      if (discoveryGroupName != null)
-      {
-         cfConfig = new ConnectionFactoryConfigurationImpl()
-            .setDiscoveryGroupName(discoveryGroupName);
-      }
-      else
-      {
-         ArrayList<String> connectors = new ArrayList<String>(connectorNames.size());
-         for (String connectorName : connectorNames)
-         {
-            connectors.add(connectorName);
-         }
-         cfConfig = new ConnectionFactoryConfigurationImpl()
-            .setConnectorNames(connectors);
-      }
-
-      cfConfig
-         .setName(name)
-         .setHA(ha)
-         .setBindings(strbindings)
-         .setFactoryType(factType)
-         .setClientID(clientID)
-         .setClientFailureCheckPeriod(clientFailureCheckPeriod)
-         .setConnectionTTL(connectionTTL)
-         .setCallTimeout(callTimeout)
-         .setCallFailoverTimeout(callFailoverTimeout)
-         .setCacheLargeMessagesClient(cacheLargeMessagesClient)
-         .setMinLargeMessageSize(minLargeMessageSize)
-         .setCompressLargeMessages(compressLargeMessages)
-         .setConsumerWindowSize(consumerWindowSize)
-         .setConsumerMaxRate(consumerMaxRate)
-         .setConfirmationWindowSize(confirmationWindowSize)
-         .setProducerWindowSize(producerWindowSize)
-         .setProducerMaxRate(producerMaxRate)
-         .setBlockOnAcknowledge(blockOnAcknowledge)
-         .setBlockOnDurableSend(blockOnDurableSend)
-         .setBlockOnNonDurableSend(blockOnNonDurableSend)
-         .setAutoGroup(autoGroup)
-         .setPreAcknowledge(preAcknowledge)
-         .setLoadBalancingPolicyClassName(connectionLoadBalancingPolicyClassName)
-         .setTransactionBatchSize(transactionBatchSize)
-         .setDupsOKBatchSize(dupsOKBatchSize)
-         .setUseGlobalPools(useGlobalPools)
-         .setScheduledThreadPoolMaxSize(scheduledThreadPoolMaxSize)
-         .setThreadPoolMaxSize(threadPoolMaxSize)
-         .setRetryInterval(retryInterval)
-         .setRetryIntervalMultiplier(retryIntervalMultiplier)
-         .setMaxRetryInterval(maxRetryInterval)
-         .setReconnectAttempts(reconnectAttempts)
-         .setFailoverOnInitialConnection(failoverOnInitialConnection)
-         .setGroupID(groupid);
-
-      return cfConfig;
-   }
-
-   private JMSFactoryType resolveFactoryType(String fact, boolean isXA) throws ActiveMQException
-   {
-      if ("".equals(fact))
-      {
-         fact = "generic";
-      }
-      if (isXA)
-      {
-         if ("generic".equals(fact))
-         {
-            return JMSFactoryType.XA_CF;
-         }
-         if ("queue".equals(fact))
-         {
-            return JMSFactoryType.QUEUE_XA_CF;
-         }
-         if ("topic".equals(fact))
-         {
-            return JMSFactoryType.TOPIC_XA_CF;
-         }
-      }
-      else
-      {
-         if ("generic".equals(fact))
-         {
-            return JMSFactoryType.CF;
-         }
-         if ("queue".equals(fact))
-         {
-            return JMSFactoryType.QUEUE_CF;
-         }
-         if ("topic".equals(fact))
-         {
-            return JMSFactoryType.TOPIC_CF;
-         }
-      }
-      throw ActiveMQJMSServerBundle.BUNDLE.invalidSignatureParsingCF(fact);
+      return newQueue(queueName, selectorString, durable);
    }
 
    /**
     * hook for integration layers
     *
     * @param topicName
-    * @param strBindings
     * @return
     */
-   protected TopicConfiguration newTopic(final String topicName, final String[] strBindings)
+   protected TopicConfiguration newTopic(final String topicName)
    {
       return new TopicConfigurationImpl()
-         .setName(topicName)
-         .setBindings(strBindings);
+         .setName(topicName);
    }
 
    /**
@@ -485,19 +174,16 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
     * @param queueName
     * @param selectorString
     * @param durable
-    * @param jndiArray
     * @return
     */
    protected JMSQueueConfiguration newQueue(final String queueName,
                                             final String selectorString,
-                                            final boolean durable,
-                                            final String[] jndiArray)
+                                            final boolean durable)
    {
       return new JMSQueueConfigurationImpl().
          setName(queueName).
          setSelector(selectorString).
-         setDurable(durable).
-         setBindings(jndiArray);
+         setDurable(durable);
    }
 
    /**
@@ -505,16 +191,13 @@ public final class JMSServerConfigParserImpl implements JMSServerConfigParser
     *
     * @param queues
     * @param topics
-    * @param cfs
     * @param domain
     * @return
     */
    protected JMSConfiguration newConfig(final ArrayList<JMSQueueConfiguration> queues,
-                                        final ArrayList<TopicConfiguration> topics,
-                                        final ArrayList<ConnectionFactoryConfiguration> cfs, String domain)
+                                        final ArrayList<TopicConfiguration> topics, String domain)
    {
       return new JMSConfigurationImpl()
-         .setConnectionFactoryConfigurations(cfs)
          .setQueueConfigurations(queues)
          .setTopicConfigurations(topics)
          .setDomain(domain);

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerDeployer.java
----------------------------------------------------------------------
diff --git a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerDeployer.java b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerDeployer.java
index eaa2bec..eab54a6 100644
--- a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerDeployer.java
+++ b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerDeployer.java
@@ -20,7 +20,6 @@ import org.apache.activemq.core.deployers.DeploymentManager;
 import org.apache.activemq.core.deployers.impl.XmlDeployer;
 import org.apache.activemq.jms.server.JMSServerConfigParser;
 import org.apache.activemq.jms.server.JMSServerManager;
-import org.apache.activemq.jms.server.config.ConnectionFactoryConfiguration;
 import org.apache.activemq.jms.server.config.JMSQueueConfiguration;
 import org.apache.activemq.jms.server.config.TopicConfiguration;
 import org.w3c.dom.Node;
@@ -36,18 +35,6 @@ public class JMSServerDeployer extends XmlDeployer
 
    private final JMSServerManager jmsServerManager;
 
-   protected static final String CONNECTOR_REF_ELEMENT = "connector-ref";
-
-   protected static final String DISCOVERY_GROUP_ELEMENT = "discovery-group-ref";
-
-   protected static final String ENTRIES_NODE_NAME = "entries";
-
-   protected static final String ENTRY_NODE_NAME = "entry";
-
-   protected static final String CONNECTORS_NODE_NAME = "connectors";
-
-   protected static final String CONNECTION_FACTORY_NODE_NAME = "connection-factory";
-
    protected static final String QUEUE_NODE_NAME = "queue";
 
    protected static final String QUEUE_SELECTOR_NODE_NAME = "selector";
@@ -77,8 +64,7 @@ public class JMSServerDeployer extends XmlDeployer
    public String[] getElementTagName()
    {
       return new String[]{JMSServerDeployer.QUEUE_NODE_NAME,
-         JMSServerDeployer.TOPIC_NODE_NAME,
-         JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME};
+         JMSServerDeployer.TOPIC_NODE_NAME};
    }
 
    @Override
@@ -100,19 +86,14 @@ public class JMSServerDeployer extends XmlDeployer
    }
 
    /**
-    * Creates the object to bind, this will either be a JBossConnectionFActory, ActiveMQQueue or
-    * ActiveMQTopic.
+    * Creates the object to bind, this will either be a ActiveMQQueue or ActiveMQTopic.
     *
     * @param node the config
     * @throws Exception
     */
    private void createAndBindObject(final Node node) throws Exception
    {
-      if (node.getNodeName().equals(JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME))
-      {
-         deployConnectionFactory(node);
-      }
-      else if (node.getNodeName().equals(JMSServerDeployer.QUEUE_NODE_NAME))
+      if (node.getNodeName().equals(JMSServerDeployer.QUEUE_NODE_NAME))
       {
          deployQueue(node);
       }
@@ -131,12 +112,7 @@ public class JMSServerDeployer extends XmlDeployer
    @Override
    public void undeploy(final Node node) throws Exception
    {
-      if (node.getNodeName().equals(JMSServerDeployer.CONNECTION_FACTORY_NODE_NAME))
-      {
-         String cfName = node.getAttributes().getNamedItem(getKeyAttribute()).getNodeValue();
-         jmsServerManager.destroyConnectionFactory(cfName);
-      }
-      else if (node.getNodeName().equals(JMSServerDeployer.QUEUE_NODE_NAME))
+      if (node.getNodeName().equals(JMSServerDeployer.QUEUE_NODE_NAME))
       {
          String queueName = node.getAttributes().getNamedItem(getKeyAttribute()).getNodeValue();
          jmsServerManager.removeQueueFromJNDI(queueName);
@@ -162,7 +138,7 @@ public class JMSServerDeployer extends XmlDeployer
    private void deployTopic(final Node node) throws Exception
    {
       TopicConfiguration topicConfig = parser.parseTopicConfiguration(node);
-      jmsServerManager.createTopic(false, topicConfig.getName(), topicConfig.getBindings());
+      jmsServerManager.createTopic(false, topicConfig.getName());
    }
 
    /**
@@ -172,18 +148,6 @@ public class JMSServerDeployer extends XmlDeployer
    private void deployQueue(final Node node) throws Exception
    {
       JMSQueueConfiguration queueconfig = parser.parseQueueConfiguration(node);
-      jmsServerManager.createQueue(false, queueconfig.getName(), queueconfig.getSelector(), queueconfig.isDurable(), queueconfig.getBindings());
+      jmsServerManager.createQueue(false, queueconfig.getName(), queueconfig.getSelector(), queueconfig.isDurable());
    }
-
-   /**
-    * @param node
-    * @throws Exception
-    */
-   private void deployConnectionFactory(final Node node) throws Exception
-   {
-      ConnectionFactoryConfiguration cfConfig = parser.parseConnectionFactoryConfiguration(node);
-      jmsServerManager.createConnectionFactory(false, cfConfig, cfConfig.getBindings());
-   }
-
-
 }

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerManagerImpl.java
----------------------------------------------------------------------
diff --git a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerManagerImpl.java b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerManagerImpl.java
index 392a19b..3261033 100644
--- a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerManagerImpl.java
+++ b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/JMSServerManagerImpl.java
@@ -481,7 +481,10 @@ public class JMSServerManagerImpl implements JMSServerManager, ActivateCallback
       {
          if (!contextSet)
          {
-            registry = new JndiBindingRegistry(new InitialContext());
+            if (System.getProperty(Context.INITIAL_CONTEXT_FACTORY) != null)
+            {
+               registry = new JndiBindingRegistry(new InitialContext());
+            }
          }
       }
 
@@ -1731,10 +1734,9 @@ public class JMSServerManagerImpl implements JMSServerManager, ActivateCallback
 
    private void checkJNDI(final String... jndiNames) throws NamingException
    {
-
       for (String jndiName : jndiNames)
       {
-         if (registry.lookup(jndiName) != null)
+         if (registry != null && registry.lookup(jndiName) != null)
          {
             throw new NamingException(jndiName + " already has an object bound");
          }
@@ -1772,15 +1774,13 @@ public class JMSServerManagerImpl implements JMSServerManager, ActivateCallback
       List<JMSQueueConfiguration> queueConfigs = config.getQueueConfigurations();
       for (JMSQueueConfiguration qConfig : queueConfigs)
       {
-         String[] bindings = qConfig.getBindings();
-         createQueue(false, qConfig.getName(), qConfig.getSelector(), qConfig.isDurable(), bindings);
+         createQueue(false, qConfig.getName(), qConfig.getSelector(), qConfig.isDurable(), qConfig.getBindings());
       }
 
       List<TopicConfiguration> topicConfigs = config.getTopicConfigurations();
       for (TopicConfiguration tConfig : topicConfigs)
       {
-         String[] bindings = tConfig.getBindings();
-         createTopic(false, tConfig.getName(), bindings);
+         createTopic(false, tConfig.getName(), tConfig.getBindings());
       }
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/StandaloneNamingServer.java
----------------------------------------------------------------------
diff --git a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/StandaloneNamingServer.java b/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/StandaloneNamingServer.java
deleted file mode 100644
index 9d029a2..0000000
--- a/activemq-jms-server/src/main/java/org/apache/activemq/jms/server/impl/StandaloneNamingServer.java
+++ /dev/null
@@ -1,170 +0,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 org.apache.activemq.jms.server.impl;
-
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-
-import org.apache.activemq.core.server.ActivateCallback;
-import org.apache.activemq.core.server.ActiveMQComponent;
-import org.apache.activemq.core.server.ActiveMQServer;
-import org.apache.activemq.core.server.ActiveMQServerLogger;
-import org.jnp.server.Main;
-import org.jnp.server.NamingBeanImpl;
-
-/**
- * This server class is only used in the standalone mode, its used to control the life cycle of the Naming Server to allow
- * it to be activated and deactivated
- *
- * @author <a href="mailto:andy.taylor@jboss.org">Andy Taylor</a>
- *         11/8/12
- */
-public class StandaloneNamingServer implements ActiveMQComponent
-{
-   private Main jndiServer;
-
-   private ActiveMQServer server;
-
-   private NamingBeanImpl namingBean;
-
-   private int port = 1099;
-
-   private String bindAddress = "localhost";
-
-   private int rmiPort = 1098;
-
-   private String rmiBindAddress = "localhost";
-
-   private ExecutorService executor;
-
-   public StandaloneNamingServer(ActiveMQServer server)
-   {
-      this.server = server;
-   }
-
-   @Override
-   public void start() throws Exception
-   {
-      server.registerActivateCallback(new ServerActivateCallback());
-   }
-
-   @Override
-   public void stop() throws Exception
-   {
-   }
-
-   @Override
-   public boolean isStarted()
-   {
-      return false;
-   }
-
-   public void setPort(int port)
-   {
-      this.port = port;
-   }
-
-   public void setBindAddress(String bindAddress)
-   {
-      this.bindAddress = bindAddress;
-   }
-
-   public void setRmiPort(int rmiPort)
-   {
-      this.rmiPort = rmiPort;
-   }
-
-   public void setRmiBindAddress(String rmiBindAddress)
-   {
-      this.rmiBindAddress = rmiBindAddress;
-   }
-
-   private class ServerActivateCallback implements ActivateCallback
-   {
-      private boolean activated = false;
-
-      @Override
-      public synchronized void preActivate()
-      {
-         if (activated)
-         {
-            return;
-         }
-         try
-         {
-            jndiServer = new Main();
-            namingBean = new NamingBeanImpl();
-            jndiServer.setNamingInfo(namingBean);
-            executor = Executors.newCachedThreadPool();
-            jndiServer.setLookupExector(executor);
-            jndiServer.setPort(port);
-            jndiServer.setBindAddress(bindAddress);
-            jndiServer.setRmiPort(rmiPort);
-            jndiServer.setRmiBindAddress(rmiBindAddress);
-            namingBean.start();
-            jndiServer.start();
-         }
-         catch (Exception e)
-         {
-            ActiveMQServerLogger.LOGGER.unableToStartNamingServer(e);
-         }
-
-         activated = true;
-      }
-
-      @Override
-      public void activated()
-      {
-
-      }
-
-      @Override
-      public synchronized void deActivate()
-      {
-         if (!activated)
-         {
-            return;
-         }
-         if (jndiServer != null)
-         {
-            try
-            {
-               jndiServer.stop();
-            }
-            catch (Exception e)
-            {
-               ActiveMQServerLogger.LOGGER.unableToStopNamingServer(e);
-            }
-         }
-         if (namingBean != null)
-         {
-            namingBean.stop();
-         }
-         if (executor != null)
-         {
-            executor.shutdown();
-         }
-         activated = false;
-      }
-
-      @Override
-      public void activationComplete()
-      {
-
-      }
-   }
-}

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-jms-server/src/main/resources/schema/activemq-jms.xsd
----------------------------------------------------------------------
diff --git a/activemq-jms-server/src/main/resources/schema/activemq-jms.xsd b/activemq-jms-server/src/main/resources/schema/activemq-jms.xsd
index 7367b15..b3d2cdf 100644
--- a/activemq-jms-server/src/main/resources/schema/activemq-jms.xsd
+++ b/activemq-jms-server/src/main/resources/schema/activemq-jms.xsd
@@ -9,259 +9,37 @@
             version="1.0">
 
    <xsd:element name="configuration" amq:schema="activemq-jms-configuration">
-   	<xsd:complexType>
-   	  <xsd:sequence>
+      <xsd:complexType>
+         <xsd:sequence>
             <xsd:element name="jmx-domain" type="xsd:string" default="org.apache.activemq"
                          minOccurs="0" maxOccurs="1"/>
-   	    <xsd:element ref="connection-factory" maxOccurs="unbounded" minOccurs="0"/>
-   	    <xsd:choice maxOccurs="unbounded" minOccurs="0">
-   	      <xsd:element ref="queue" maxOccurs="1" minOccurs="1"/>
-              <xsd:element ref="topic" maxOccurs="1" minOccurs="1"/>
+            <xsd:choice maxOccurs="unbounded" minOccurs="0">
+               <xsd:element ref="queue" maxOccurs="1" minOccurs="1"/>
+               <xsd:element ref="topic" maxOccurs="1" minOccurs="1"/>
             </xsd:choice>
-          </xsd:sequence>
-   	</xsd:complexType>
+         </xsd:sequence>
+      </xsd:complexType>
    </xsd:element>
 
-   <xsd:element name="connection-factory">
-        <xsd:annotation amq:linkend="using-jms.server.configuration">
-          <xsd:documentation>a list of connection factories to create and add to
-          JNDI</xsd:documentation>
-        </xsd:annotation>
-   	<xsd:complexType>
-          <xsd:all>
-            <xsd:element name="xa" type="xsd:boolean" default="false" maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:linkend="using-jms.configure.factory.types"
-                              amq:id="configuration.connection-factory.signature.xa">
-                <xsd:documentation>Whether this is an XA connection factory</xsd:documentation>
-              </xsd:annotation>
-            </xsd:element>
-            <xsd:element name="discovery-group-ref" type="discovery-group-refType" maxOccurs="1" minOccurs="0">
-            </xsd:element>
+   <xsd:element name="queue" type="queueType"></xsd:element>
 
-            <xsd:element name="connectors" maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:linkend="clusters">
-                <xsd:documentation>A sequence of connectors used by the connection factory
-                </xsd:documentation>
-              </xsd:annotation>
-            <xsd:complexType>
-                <xsd:sequence>
-                  <xsd:element name="connector-ref" maxOccurs="unbounded" minOccurs="1">
-                    <xsd:annotation>
-                      <xsd:documentation>A connector reference
-                      </xsd:documentation>
-                    </xsd:annotation>
-                    <xsd:complexType>
-                      <xsd:attribute name="connector-name" type="xsd:string" use="required">
-                        <xsd:annotation>
-                          <xsd:documentation>Name of the connector to connect to the live server
-                          </xsd:documentation>
-                        </xsd:annotation>
-                      </xsd:attribute>
-                    </xsd:complexType>
-                  </xsd:element>
-                </xsd:sequence>
-              </xsd:complexType>
-              </xsd:element>
-
-            <xsd:element name="entries" maxOccurs="1" minOccurs="0">
-              <xsd:complexType>
-                <xsd:sequence>
-                  <xsd:element name="entry" type="entryType" maxOccurs="unbounded" minOccurs="1">
-                  </xsd:element>
-                </xsd:sequence>
-              </xsd:complexType>
-            </xsd:element>
-
-            <xsd:element name="client-failure-check-period" type="xsd:long" default="30000"
-                         maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:id="configuration.connection-factory.client-failure-check-period"
-                              amq:linkend="dead.connections" amq:default="(ms)">
-                <xsd:documentation>
-                  the period (in ms) after which the client will consider the connection failed
-                  after not receiving packets from the server. -1 disables this setting.
-                </xsd:documentation>
-              </xsd:annotation>
-            </xsd:element>
-
-            <xsd:element name="connection-ttl" type="xsd:long" maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:id="configuration.connection-factory.connection-ttl"
-                              amq:linkend="dead.connections">
-                <xsd:documentation>the time to live (in ms) for connections
-                </xsd:documentation>
-              </xsd:annotation>
-            </xsd:element>
-
-            <xsd:element name="call-timeout" type="xsd:long" default="30000"
-                         maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:id="configuration.connection-factory.call-timeout">
-                <xsd:documentation>
-                  the timeout (in ms) for remote calls
-                </xsd:documentation>
-              </xsd:annotation>
-            </xsd:element>
-   			 <xsd:element name="call-failover-timeout" type="xsd:long"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="consumer-window-size" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="consumer-max-rate" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="confirmation-window-size" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="producer-window-size" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="producer-max-rate" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="cache-large-message-client" type="xsd:boolean"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="min-large-message-size" type="xsd:long"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="compress-large-messages" type="xsd:boolean"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-
-            <xsd:element name="client-id" type="xsd:string" maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:id="configuration.connection-factory.client-id"
-                              amq:linkend="using-jms.clientid">
-                <xsd:documentation>
-                  the pre-configured client ID for the connection factory
-                </xsd:documentation>
-              </xsd:annotation>
-            </xsd:element>
-
-            <xsd:element name="dups-ok-batch-size" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="transaction-batch-size" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-         <xsd:element name="block-on-acknowledge" type="xsd:boolean" default="false"
-                      maxOccurs="1" minOccurs="0">
-           <xsd:annotation amq:linkend="send-guarantees.nontrans.acks"
-                           amq:id="configuration.connection-factory.block-on-acknowledge">
-             <xsd:documentation>
-               whether or not messages are acknowledged synchronously
-             </xsd:documentation>
-           </xsd:annotation>
-         </xsd:element>
-         <xsd:element name="block-on-non-durable-send" type="xsd:boolean" default="false"
-                      maxOccurs="1" minOccurs="0">
-           <xsd:annotation amq:id="configuration.connection-factory.block-on-non-durable-send"
-                           amq:linkend="non-transactional-sends">
-             <xsd:documentation>
-               whether or not non-durable messages are sent synchronously
-             </xsd:documentation>
-           </xsd:annotation>
-         </xsd:element>
-            <xsd:element name="block-on-durable-send" type="xsd:boolean" default="true"
-                         maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:id="configuration.connection-factory.block-on-durable-send"
-                              amq:linkend="non-transactional-sends">
-                <xsd:documentation>
-                  whether or not durable messages are sent synchronously
-                </xsd:documentation>
-              </xsd:annotation>
-            </xsd:element>
-            <xsd:element name="auto-group" type="xsd:boolean" default="false" maxOccurs="1" minOccurs="0">
-              <xsd:annotation amq:id="configuration.connection-factory.auto-group"
-                              amq:linkend="message-grouping.jmsconfigure">
-                <xsd:documentation>whether or not message grouping is automatically used
-                </xsd:documentation>
-              </xsd:annotation>
-            </xsd:element>
-            <xsd:element name="pre-acknowledge" type="xsd:boolean"
-   				maxOccurs="1" minOccurs="0">
-   			</xsd:element>
-            <xsd:element name="retry-interval" type="xsd:long"
-   				maxOccurs="1" minOccurs="0">
-   			</xsd:element>
-   			<xsd:element name="retry-interval-multiplier" type="xsd:float"
-   				maxOccurs="1" minOccurs="0">
-   			</xsd:element>
-   			<xsd:element name="max-retry-interval" type="xsd:long"
-   				maxOccurs="1" minOccurs="0">
-   			</xsd:element>
-            <xsd:element name="reconnect-attempts" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="failover-on-initial-connection" type="xsd:boolean"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="failover-on-server-shutdown" type="xsd:boolean"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="connection-load-balancing-policy-class-name" type="xsd:string"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="use-global-pools" type="xsd:boolean"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="scheduled-thread-pool-max-size" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="thread-pool-max-size" type="xsd:int"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="group-id" type="xsd:string"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-            <xsd:element name="ha" type="xsd:boolean"
-                maxOccurs="1" minOccurs="0">
-            </xsd:element>
-   		</xsd:all>
-   		<xsd:attribute name="name" type="xsd:string"></xsd:attribute>
-   		<xsd:attribute name="signature" type="xsd:string">
-                  <xsd:annotation amq:id="configuration.connection-factory.signature"
-                                  amq:linkend="using-jms.configure.factory.types"
-                                  amq:default="generic"> <!-- XXX -->
-                    <xsd:documentation>Type of connection factory</xsd:documentation>
-                  </xsd:annotation>
-                </xsd:attribute>
-   	</xsd:complexType>
-   </xsd:element>
-
-    <xsd:complexType name="entryType">
-    	<xsd:attribute name="name" type="xsd:string" use="required"></xsd:attribute>
-    </xsd:complexType>
-
-    <xsd:complexType name="discovery-group-refType">
-    	<xsd:attribute name="discovery-group-name" type="xsd:string" use="required">
-          <xsd:annotation>
-          <xsd:documentation>
-            Name of discovery group used by this connection factory
-          </xsd:documentation>
-          </xsd:annotation>
-        </xsd:attribute>
-    </xsd:complexType>
-
-    <xsd:element name="queue" type="queueType"></xsd:element>
-
-    <xsd:element name="topic" type="topicType"></xsd:element>
+   <xsd:element name="topic" type="topicType"></xsd:element>
 
    <xsd:complexType name="queueType">
-    	<xsd:sequence>
-    		<xsd:element name="entry" type="entryType" maxOccurs="unbounded" minOccurs="1"></xsd:element>
-          <xsd:element name="selector" maxOccurs="1" minOccurs="0">
-                <xsd:complexType>
-                   <xsd:attribute name="string" type="xsd:string" use="required"></xsd:attribute>
-                </xsd:complexType>
-            </xsd:element>
-            <xsd:element name="durable" type="xsd:boolean" maxOccurs="1" minOccurs="0"></xsd:element>
-    	</xsd:sequence>
-    	<xsd:attribute name="name" type="xsd:string" use="required"></xsd:attribute>
-    </xsd:complexType>
-
-    <xsd:complexType name="topicType">
-    	<xsd:sequence>
-    		<xsd:element name="entry" type="entryType" maxOccurs="unbounded" minOccurs="1"></xsd:element>
-    	</xsd:sequence>
-    	<xsd:attribute name="name" type="xsd:string" use="required"></xsd:attribute>
-    </xsd:complexType>
+      <xsd:sequence>
+         <xsd:element name="selector" maxOccurs="1" minOccurs="0">
+            <xsd:complexType>
+               <xsd:attribute name="string" type="xsd:string" use="required"></xsd:attribute>
+            </xsd:complexType>
+         </xsd:element>
+         <xsd:element name="durable" type="xsd:boolean" maxOccurs="1" minOccurs="0"></xsd:element>
+      </xsd:sequence>
+      <xsd:attribute name="name" type="xsd:string" use="required"></xsd:attribute>
+   </xsd:complexType>
+
+   <xsd:complexType name="topicType">
+      <xsd:sequence>
+      </xsd:sequence>
+      <xsd:attribute name="name" type="xsd:string" use="required"></xsd:attribute>
+   </xsd:complexType>
 </xsd:schema>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-ra/pom.xml
----------------------------------------------------------------------
diff --git a/activemq-ra/pom.xml b/activemq-ra/pom.xml
index c027026..c1fca05 100644
--- a/activemq-ra/pom.xml
+++ b/activemq-ra/pom.xml
@@ -46,6 +46,13 @@
          <artifactId>activemq-jms-server</artifactId>
          <version>${project.version}</version>
          <scope>provided</scope>
+         <exclusions>
+            <exclusion>
+               <!-- exclude JCA 1.5 spec here so geronimo dependency will be used -->
+               <groupId>org.jboss.spec.javax.resource</groupId>
+               <artifactId>jboss-connector-api_1.5_spec</artifactId>
+            </exclusion>
+         </exclusions>
       </dependency>
       <dependency>
          <groupId>org.apache.geronimo.specs</groupId>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-rest/src/main/java/org/apache/activemq/rest/integration/EmbeddedRestActiveMQJMS.java
----------------------------------------------------------------------
diff --git a/activemq-rest/src/main/java/org/apache/activemq/rest/integration/EmbeddedRestActiveMQJMS.java b/activemq-rest/src/main/java/org/apache/activemq/rest/integration/EmbeddedRestActiveMQJMS.java
index 4014030..ee48d51 100644
--- a/activemq-rest/src/main/java/org/apache/activemq/rest/integration/EmbeddedRestActiveMQJMS.java
+++ b/activemq-rest/src/main/java/org/apache/activemq/rest/integration/EmbeddedRestActiveMQJMS.java
@@ -37,4 +37,8 @@ public class EmbeddedRestActiveMQJMS extends EmbeddedRestActiveMQ
       return ((EmbeddedJMS) embeddedActiveMQ).getRegistry();
    }
 
+   public EmbeddedJMS getEmbeddedJMS()
+   {
+      return (EmbeddedJMS) embeddedActiveMQ;
+   }
 }

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-rest/src/main/java/org/apache/activemq/rest/queue/QueueDestinationsResource.java
----------------------------------------------------------------------
diff --git a/activemq-rest/src/main/java/org/apache/activemq/rest/queue/QueueDestinationsResource.java b/activemq-rest/src/main/java/org/apache/activemq/rest/queue/QueueDestinationsResource.java
index 259826e..0358db1 100644
--- a/activemq-rest/src/main/java/org/apache/activemq/rest/queue/QueueDestinationsResource.java
+++ b/activemq-rest/src/main/java/org/apache/activemq/rest/queue/QueueDestinationsResource.java
@@ -101,13 +101,6 @@ public class QueueDestinationsResource
             {
             }
          }
-         if (queue.getBindings() != null && queue.getBindings().length > 0 && manager.getRegistry() != null)
-         {
-            for (String binding : queue.getBindings())
-            {
-               manager.getRegistry().bind(binding, activeMQQueue);
-            }
-         }
          URI uri = uriInfo.getRequestUriBuilder().path(queueName).build();
          return Response.created(uri).build();
       }

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-rest/src/main/java/org/apache/activemq/rest/topic/TopicDestinationsResource.java
----------------------------------------------------------------------
diff --git a/activemq-rest/src/main/java/org/apache/activemq/rest/topic/TopicDestinationsResource.java b/activemq-rest/src/main/java/org/apache/activemq/rest/topic/TopicDestinationsResource.java
index fa3415b..8ab2a0e 100644
--- a/activemq-rest/src/main/java/org/apache/activemq/rest/topic/TopicDestinationsResource.java
+++ b/activemq-rest/src/main/java/org/apache/activemq/rest/topic/TopicDestinationsResource.java
@@ -95,13 +95,6 @@ public class TopicDestinationsResource
             {
             }
          }
-         if (topic.getBindings() != null && topic.getBindings().length > 0 && manager.getRegistry() != null)
-         {
-            for (String binding : topic.getBindings())
-            {
-               manager.getRegistry().bind(binding, activeMQTopic);
-            }
-         }
          URI uri = uriInfo.getRequestUriBuilder().path(topicName).build();
          return Response.created(uri).build();
       }

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-rest/src/test/java/org/apache/activemq/rest/test/EmbeddedTest.java
----------------------------------------------------------------------
diff --git a/activemq-rest/src/test/java/org/apache/activemq/rest/test/EmbeddedTest.java b/activemq-rest/src/test/java/org/apache/activemq/rest/test/EmbeddedTest.java
index da0d9ea..1ab39d4 100644
--- a/activemq-rest/src/test/java/org/apache/activemq/rest/test/EmbeddedTest.java
+++ b/activemq-rest/src/test/java/org/apache/activemq/rest/test/EmbeddedTest.java
@@ -23,7 +23,10 @@ import javax.jms.MessageProducer;
 import javax.jms.ObjectMessage;
 import javax.jms.Session;
 import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.List;
 
+import org.apache.activemq.api.jms.JMSFactoryType;
 import org.apache.activemq.rest.HttpHeaderProperty;
 import org.apache.activemq.rest.integration.EmbeddedRestActiveMQJMS;
 import org.apache.activemq.spi.core.naming.BindingRegistry;
@@ -49,6 +52,9 @@ public class EmbeddedTest
       server = new EmbeddedRestActiveMQJMS();
       server.getManager().setConfigResourcePath("activemq-rest.xml");
       server.start();
+      List<String> connectors = new ArrayList<>();
+      connectors.add("in-vm");
+      server.getEmbeddedJMS().getJMSServerManager().createConnectionFactory("ConnectionFactory", false, JMSFactoryType.CF, connectors, "ConnectionFactory");
    }
 
    @AfterClass
@@ -61,10 +67,10 @@ public class EmbeddedTest
    public static void publish(String destination, Serializable object, String contentType) throws Exception
    {
       BindingRegistry reg = server.getRegistry();
-      Destination dest = (Destination) reg.lookup(destination);
       ConnectionFactory factory = (ConnectionFactory) reg.lookup("ConnectionFactory");
       Connection conn = factory.createConnection();
       Session session = conn.createSession(false, Session.AUTO_ACKNOWLEDGE);
+      Destination dest = session.createQueue(destination);
 
       try
       {
@@ -109,7 +115,7 @@ public class EmbeddedTest
          TransformTest.Order order = new TransformTest.Order();
          order.setName("1");
          order.setAmount("$5.00");
-         publish("/queue/exampleQueue", order, null);
+         publish("exampleQueue", order, null);
 
          ClientResponse<?> res = consumeNext.request().header("Accept-Wait", "2").accept("application/xml").post(String.class);
          Assert.assertEquals(200, res.getStatus());
@@ -126,7 +132,7 @@ public class EmbeddedTest
          TransformTest.Order order = new TransformTest.Order();
          order.setName("1");
          order.setAmount("$5.00");
-         publish("/queue/exampleQueue", order, null);
+         publish("exampleQueue", order, null);
 
          ClientResponse<?> res = consumeNext.request().header("Accept-Wait", "2").accept("application/json").post(String.class);
          Assert.assertEquals(200, res.getStatus());
@@ -143,7 +149,7 @@ public class EmbeddedTest
          TransformTest.Order order = new TransformTest.Order();
          order.setName("2");
          order.setAmount("$15.00");
-         publish("/queue/exampleQueue", order, "application/xml");
+         publish("exampleQueue", order, "application/xml");
 
          ClientResponse<?> res = consumeNext.request().header("Accept-Wait", "2").post(String.class);
          Assert.assertEquals(200, res.getStatus());

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/activemq-rest/src/test/resources/activemq-jms.xml
----------------------------------------------------------------------
diff --git a/activemq-rest/src/test/resources/activemq-jms.xml b/activemq-rest/src/test/resources/activemq-jms.xml
index bce97ab..3758989 100644
--- a/activemq-rest/src/test/resources/activemq-jms.xml
+++ b/activemq-rest/src/test/resources/activemq-jms.xml
@@ -1,19 +1,8 @@
 <configuration xmlns="urn:activemq"
                xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
                xsi:schemaLocation="urn:activemq /schema/activemq-jms.xsd">
-    <!--the connection factory used by the example-->
-    <connection-factory name="ConnectionFactory">
-        <connectors>
-            <connector-ref connector-name="in-vm"/>
-        </connectors>
-        <entries>
-            <entry name="ConnectionFactory"/>
-        </entries>
-    </connection-factory>
 
     <!--the queue used by the example-->
-    <queue name="exampleQueue">
-        <entry name="/queue/exampleQueue"/>
-    </queue>
+    <queue name="exampleQueue"/>
 
 </configuration>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/pom.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/pom.xml b/distribution/activemq/pom.xml
index c0e5845..7911837 100644
--- a/distribution/activemq/pom.xml
+++ b/distribution/activemq/pom.xml
@@ -102,11 +102,6 @@
         <artifactId>activemq-aerogear-integration</artifactId>
         <version>${project.version}</version>
      </dependency>
-     <dependency>
-        <groupId>org.apache.activemq</groupId>
-        <artifactId>jnp-client</artifactId>
-        <version>${project.version}</version>
-     </dependency>
       <dependency>
          <groupId>org.apache.activemq</groupId>
          <artifactId>activemq-web</artifactId>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/assembly/dep.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/assembly/dep.xml b/distribution/activemq/src/main/assembly/dep.xml
index a4c17ac..088ae95 100644
--- a/distribution/activemq/src/main/assembly/dep.xml
+++ b/distribution/activemq/src/main/assembly/dep.xml
@@ -33,7 +33,6 @@
             <include>org.apache.activemq.rest:activemq-rest</include>
             <!-- dependencies -->
             <include>org.jboss.spec.javax.jms:jboss-jms-api_2.0_spec</include>
-            <include>org.jboss.naming:jnpserver</include>
             <include>org.jboss.logmanager:jboss-logmanager</include>
             <include>org.jboss:jboss-common-core</include>
             <include>io.netty:netty-all</include>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/bin/activemq
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/bin/activemq b/distribution/activemq/src/main/resources/bin/activemq
index 1e632d5..d8e01f1 100755
--- a/distribution/activemq/src/main/resources/bin/activemq
+++ b/distribution/activemq/src/main/resources/bin/activemq
@@ -81,7 +81,7 @@ for i in `ls $ACTIVEMQ_HOME/lib/*.jar`; do
 done
 
 
-JAVA_ARGS="-XX:+UseParallelGC -XX:+AggressiveOpts -XX:+UseFastAccessorMethods -Xms512M -Xmx1024M -Djava.naming.factory.initial=org.jnp.interfaces.NamingContextFactory -Djava.naming.factory.url.pkgs=org.jboss.naming:org.jnp.interfaces -Dactivemq.home=$ACTIVEMQ_HOME -Ddata.dir=$ACTIVEMQ_HOME/data -Djava.util.logging.manager=org.jboss.logmanager.LogManager -Dlogging.configuration=file:$ACTIVEMQ_HOME/config/logging.properties -Djava.library.path=$ACTIVEMQ_HOME/bin/lib/linux-i686:$ACTIVEMQ_HOME/bin/lib/linux-x86_64"
-#JAVA_ARGS="-agentlib:jdwp=transport=dt_socket,server=y,suspend=y,address=5005 -Djava.naming.factory.initial=org.jnp.interfaces.NamingContextFactory -Djava.naming.factory.url.pkgs=org.jboss.naming:org.jnp.interfaces"
+JAVA_ARGS="-XX:+UseParallelGC -XX:+AggressiveOpts -XX:+UseFastAccessorMethods -Xms512M -Xmx1024M -Dactivemq.home=$ACTIVEMQ_HOME -Ddata.dir=$ACTIVEMQ_HOME/data -Djava.util.logging.manager=org.jboss.logmanager.LogManager -Dlogging.configuration=file:$ACTIVEMQ_HOME/config/logging.properties -Djava.library.path=$ACTIVEMQ_HOME/bin/lib/linux-i686:$ACTIVEMQ_HOME/bin/lib/linux-x86_64"
+#JAVA_ARGS="-agentlib:jdwp=transport=dt_socket,server=y,suspend=y,address=5005"
 
 exec "$JAVACMD" $JAVA_ARGS -classpath $CLASSPATH org.apache.activemq.cli.ActiveMQ $@
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/bin/activemq.cmd
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/bin/activemq.cmd b/distribution/activemq/src/main/resources/bin/activemq.cmd
index 32dbb36..3a0a4f9 100755
--- a/distribution/activemq/src/main/resources/bin/activemq.cmd
+++ b/distribution/activemq/src/main/resources/bin/activemq.cmd
@@ -31,7 +31,7 @@ echo.
 
 :RUN_JAVA
 
-if "%JVM_FLAGS%" == "" set JVM_FLAGS=-XX:+UseParallelGC -XX:+AggressiveOpts -XX:+UseFastAccessorMethods -Xms512M -Xmx1024M -Djava.naming.factory.initial=org.jnp.interfaces.NamingContextFactory -Djava.naming.factory.url.pkgs=org.jboss.naming:org.jnp.interfaces -Dactivemq.home=$ACTIVEMQ_HOME -Ddata.dir=$ACTIVEMQ_HOME/data -Djava.util.logging.manager=org.jboss.logmanager.LogManager -Dlogging.configuration="file:%ACTIVEMQ_HOME%\config\logging.properties" -Djava.library.path="%ACTIVEMQ_HOME%/bin/lib/linux-i686:%ACTIVEMQ_HOME%/bin/lib/linux-x86_64"
+if "%JVM_FLAGS%" == "" set JVM_FLAGS=-XX:+UseParallelGC -XX:+AggressiveOpts -XX:+UseFastAccessorMethods -Xms512M -Xmx1024M -Dactivemq.home=$ACTIVEMQ_HOME -Ddata.dir=$ACTIVEMQ_HOME/data -Djava.util.logging.manager=org.jboss.logmanager.LogManager -Dlogging.configuration="file:%ACTIVEMQ_HOME%\config\logging.properties" -Djava.library.path="%ACTIVEMQ_HOME%/bin/lib/linux-i686:%ACTIVEMQ_HOME%/bin/lib/linux-x86_64"
 
 if "x%ACTIVEMQ_OPTS%" == "x" goto noACTIVEMQ_OPTS
   set JVM_FLAGS=%JVM_FLAGS% %ACTIVEMQ_OPTS%

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/clustered/activemq-jms.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/clustered/activemq-jms.xml b/distribution/activemq/src/main/resources/config/clustered/activemq-jms.xml
index d1b456b..ccdc8bd 100644
--- a/distribution/activemq/src/main/resources/config/clustered/activemq-jms.xml
+++ b/distribution/activemq/src/main/resources/config/clustered/activemq-jms.xml
@@ -2,52 +2,8 @@
             xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
             xsi:schemaLocation="urn:activemq /schema/activemq-jms.xsd">
 
-   <connection-factory name="NettyXAConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/XAConnectionFactory"/>
-      </entries>
-   </connection-factory>
+   <queue name="DLQ"/>
    
-   <connection-factory name="NettyConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/ConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/XAThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/ThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-
-   <queue name="DLQ">
-      <entry name="/queue/DLQ"/>
-   </queue>
-   
-   <queue name="ExpiryQueue">
-      <entry name="/queue/ExpiryQueue"/>
-   </queue>
+   <queue name="ExpiryQueue"/>
 
 </configuration>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/clustered/jndi.properties
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/clustered/jndi.properties b/distribution/activemq/src/main/resources/config/clustered/jndi.properties
deleted file mode 100644
index e2a9832..0000000
--- a/distribution/activemq/src/main/resources/config/clustered/jndi.properties
+++ /dev/null
@@ -1,2 +0,0 @@
-java.naming.factory.initial=org.jnp.interfaces.NamingContextFactory
-java.naming.factory.url.pkgs=org.jboss.naming:org.jnp.interfaces
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/non-clustered/activemq-jms.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/non-clustered/activemq-jms.xml b/distribution/activemq/src/main/resources/config/non-clustered/activemq-jms.xml
index d1b456b..ccdc8bd 100644
--- a/distribution/activemq/src/main/resources/config/non-clustered/activemq-jms.xml
+++ b/distribution/activemq/src/main/resources/config/non-clustered/activemq-jms.xml
@@ -2,52 +2,8 @@
             xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
             xsi:schemaLocation="urn:activemq /schema/activemq-jms.xsd">
 
-   <connection-factory name="NettyXAConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/XAConnectionFactory"/>
-      </entries>
-   </connection-factory>
+   <queue name="DLQ"/>
    
-   <connection-factory name="NettyConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/ConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/XAThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/ThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-
-   <queue name="DLQ">
-      <entry name="/queue/DLQ"/>
-   </queue>
-   
-   <queue name="ExpiryQueue">
-      <entry name="/queue/ExpiryQueue"/>
-   </queue>
+   <queue name="ExpiryQueue"/>
 
 </configuration>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/non-clustered/jndi.properties
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/non-clustered/jndi.properties b/distribution/activemq/src/main/resources/config/non-clustered/jndi.properties
deleted file mode 100644
index e2a9832..0000000
--- a/distribution/activemq/src/main/resources/config/non-clustered/jndi.properties
+++ /dev/null
@@ -1,2 +0,0 @@
-java.naming.factory.initial=org.jnp.interfaces.NamingContextFactory
-java.naming.factory.url.pkgs=org.jboss.naming:org.jnp.interfaces
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/replicated/activemq-configuration.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/replicated/activemq-configuration.xml b/distribution/activemq/src/main/resources/config/replicated/activemq-configuration.xml
index 5f41085..a7a756e 100644
--- a/distribution/activemq/src/main/resources/config/replicated/activemq-configuration.xml
+++ b/distribution/activemq/src/main/resources/config/replicated/activemq-configuration.xml
@@ -3,7 +3,7 @@
                xsi:schemaLocation="urn:activemq /schema/activemq-configuration.xsd">
    <!--
    if you want to run this as a backup on different ports you would need to set the following variable
-   export CLUSTER_PROPS="-Djnp.port=1199 -Djnp.rmiPort=1198 -Djnp.host=localhost -Dactivemq.remoting.netty.host=localhost -Dactivemq.remoting.netty.port=5545 -Dactivemq.remoting.netty.batch.port=5555 -Dactivemq.backup=true"
+   export CLUSTER_PROPS="-Dactivemq.remoting.netty.host=localhost -Dactivemq.remoting.netty.port=5545 -Dactivemq.remoting.netty.batch.port=5555 -Dactivemq.backup=true"
    -->
 
    <paging-directory>${data.dir:../data}/paging</paging-directory>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/replicated/activemq-jms.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/replicated/activemq-jms.xml b/distribution/activemq/src/main/resources/config/replicated/activemq-jms.xml
index d1b456b..ccdc8bd 100644
--- a/distribution/activemq/src/main/resources/config/replicated/activemq-jms.xml
+++ b/distribution/activemq/src/main/resources/config/replicated/activemq-jms.xml
@@ -2,52 +2,8 @@
             xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
             xsi:schemaLocation="urn:activemq /schema/activemq-jms.xsd">
 
-   <connection-factory name="NettyXAConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/XAConnectionFactory"/>
-      </entries>
-   </connection-factory>
+   <queue name="DLQ"/>
    
-   <connection-factory name="NettyConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/ConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/XAThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/ThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-
-   <queue name="DLQ">
-      <entry name="/queue/DLQ"/>
-   </queue>
-   
-   <queue name="ExpiryQueue">
-      <entry name="/queue/ExpiryQueue"/>
-   </queue>
+   <queue name="ExpiryQueue"/>
 
 </configuration>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/replicated/jndi.properties
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/replicated/jndi.properties b/distribution/activemq/src/main/resources/config/replicated/jndi.properties
deleted file mode 100644
index e2a9832..0000000
--- a/distribution/activemq/src/main/resources/config/replicated/jndi.properties
+++ /dev/null
@@ -1,2 +0,0 @@
-java.naming.factory.initial=org.jnp.interfaces.NamingContextFactory
-java.naming.factory.url.pkgs=org.jboss.naming:org.jnp.interfaces
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/shared-store/activemq-configuration.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/shared-store/activemq-configuration.xml b/distribution/activemq/src/main/resources/config/shared-store/activemq-configuration.xml
index e738d2f..e5820e1 100644
--- a/distribution/activemq/src/main/resources/config/shared-store/activemq-configuration.xml
+++ b/distribution/activemq/src/main/resources/config/shared-store/activemq-configuration.xml
@@ -3,7 +3,7 @@
                xsi:schemaLocation="urn:activemq /schema/activemq-configuration.xsd">
    <!--
    if you want to run this as a backup on different ports you would need to set the following variable
-   export CLUSTER_PROPS="-Djnp.port=1199 -Djnp.rmiPort=1198 -Djnp.host=localhost -Dactivemq.remoting.netty.host=localhost -Dactivemq.remoting.netty.port=5545 -Dactivemq.remoting.netty.batch.port=5555 -Dactivemq.backup=true"
+   export CLUSTER_PROPS="-Dactivemq.remoting.netty.host=localhost -Dactivemq.remoting.netty.port=5545 -Dactivemq.remoting.netty.batch.port=5555 -Dactivemq.backup=true"
    -->
 
    <paging-directory>${data.dir:../data}/paging</paging-directory>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/shared-store/activemq-jms.xml
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/shared-store/activemq-jms.xml b/distribution/activemq/src/main/resources/config/shared-store/activemq-jms.xml
index d1b456b..ccdc8bd 100644
--- a/distribution/activemq/src/main/resources/config/shared-store/activemq-jms.xml
+++ b/distribution/activemq/src/main/resources/config/shared-store/activemq-jms.xml
@@ -2,52 +2,8 @@
             xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
             xsi:schemaLocation="urn:activemq /schema/activemq-jms.xsd">
 
-   <connection-factory name="NettyXAConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/XAConnectionFactory"/>
-      </entries>
-   </connection-factory>
+   <queue name="DLQ"/>
    
-   <connection-factory name="NettyConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty"/>
-      </connectors>
-      <entries>
-         <entry name="/ConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>true</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/XAThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-   
-   <connection-factory name="NettyThroughputConnectionFactory">
-      <xa>false</xa>
-      <connectors>
-         <connector-ref connector-name="netty-throughput"/>
-      </connectors>
-      <entries>
-         <entry name="/ThroughputConnectionFactory"/>
-      </entries>
-   </connection-factory>
-
-   <queue name="DLQ">
-      <entry name="/queue/DLQ"/>
-   </queue>
-   
-   <queue name="ExpiryQueue">
-      <entry name="/queue/ExpiryQueue"/>
-   </queue>
+   <queue name="ExpiryQueue"/>
 
 </configuration>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/activemq/src/main/resources/config/shared-store/jndi.properties
----------------------------------------------------------------------
diff --git a/distribution/activemq/src/main/resources/config/shared-store/jndi.properties b/distribution/activemq/src/main/resources/config/shared-store/jndi.properties
deleted file mode 100644
index e2a9832..0000000
--- a/distribution/activemq/src/main/resources/config/shared-store/jndi.properties
+++ /dev/null
@@ -1,2 +0,0 @@
-java.naming.factory.initial=org.jnp.interfaces.NamingContextFactory
-java.naming.factory.url.pkgs=org.jboss.naming:org.jnp.interfaces
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/jnp-client/pom.xml
----------------------------------------------------------------------
diff --git a/distribution/jnp-client/pom.xml b/distribution/jnp-client/pom.xml
deleted file mode 100644
index 122880c..0000000
--- a/distribution/jnp-client/pom.xml
+++ /dev/null
@@ -1,75 +0,0 @@
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-   <modelVersion>4.0.0</modelVersion>
-
-
-   <parent>
-      <groupId>org.apache.activemq</groupId>
-      <artifactId>activemq-distribution</artifactId>
-      <version>6.0.0-SNAPSHOT</version>
-   </parent>
-
-   <artifactId>jnp-client</artifactId>
-   <packaging>jar</packaging>
-   <name>JBoss jnp client jar</name>
-
-   <dependencies>
-      <dependency>
-          <groupId>org.jboss.naming</groupId>
-          <artifactId>jnpserver</artifactId>
-      </dependency>
-      <dependency>
-            <groupId>org.jboss.logging</groupId>
-            <artifactId>jboss-logging</artifactId>
-        </dependency>
-   </dependencies>
-
-   <build>
-      <resources>
-         <resource>
-            <directory>src/main/resources</directory>
-            <filtering>true</filtering>
-         </resource>
-      </resources>
-      <plugins>
-         <plugin>
-            <groupId>org.apache.maven.plugins</groupId>
-            <artifactId>maven-shade-plugin</artifactId>
-            <executions>
-               <execution>
-                  <phase>package</phase>
-                  <goals>
-                     <goal>shade</goal>
-                  </goals>
-                  <configuration>
-                     <artifactSet>
-                        <includes>
-                           <include>org.jboss.naming:jnpserver</include>
-                           <artifact>org.jboss.logging:jboss-logging</artifact>
-                        </includes>
-                     </artifactSet>
-                     <filters>
-                        <filter>
-                           <artifact>org.jboss.naming:jnpserver</artifact>
-                           <includes>
-                              <include>org/jnp/interfaces/**/*.class</include>
-                              <include>org/jboss/naming/**/*.class</include>
-                              <include>org/jnp/server/NamingServer_Stub.class</include>
-                           </includes>
-                        </filter>
-                        <filter>
-                           <artifact>org.jboss.logging:jboss-logging</artifact>
-                           <includes>
-                              <include>org/jboss/logging/**/*.class</include>
-                           </includes>
-                        </filter>
-                     </filters>
-                  </configuration>
-               </execution>
-
-            </executions>
-         </plugin>
-      </plugins>
-   </build>
-
-</project>

http://git-wip-us.apache.org/repos/asf/activemq-6/blob/e6a3d3a0/distribution/pom.xml
----------------------------------------------------------------------
diff --git a/distribution/pom.xml b/distribution/pom.xml
index 143b72f..6e0c42b 100644
--- a/distribution/pom.xml
+++ b/distribution/pom.xml
@@ -23,17 +23,12 @@
            <artifactId>jboss-jms-api_2.0_spec</artifactId>
        </dependency>
       <dependency>
-          <groupId>org.jboss.naming</groupId>
-          <artifactId>jnpserver</artifactId>
-      </dependency>
-      <dependency>
           <groupId>io.netty</groupId>
           <artifactId>netty-all</artifactId>
       </dependency>
    </dependencies>
 
    <modules>
-      <module>jnp-client</module>
       <module>activemq</module>
    </modules>