You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2019/11/21 18:12:48 UTC

[camel] branch master updated: CAMEL-14204: Remove old cruft from camel-activemq which we dont want to have anymore. And not in use really.

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

davsclaus pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/camel.git


The following commit(s) were added to refs/heads/master by this push:
     new 702b06c  CAMEL-14204: Remove old cruft from camel-activemq which we dont want to have anymore. And not in use really.
702b06c is described below

commit 702b06ce3d981de270ff5312ba7995e903ef7c3f
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Thu Nov 21 19:12:28 2019 +0100

    CAMEL-14204: Remove old cruft from camel-activemq which we dont want to have anymore. And not in use really.
---
 .../src/main/docs/activemq-component.adoc          |   3 +-
 .../component/activemq/ActiveMQComponent.java      |  75 ++-------
 .../component/activemq/ActiveMQConfiguration.java  |   3 -
 .../camel/component/activemq/CamelConnection.java  |  46 ------
 .../component/activemq/CamelConnectionFactory.java |  57 -------
 .../camel/component/activemq/CamelDestination.java | 173 --------------------
 .../component/activemq/CamelEndpointLoader.java    | 176 ---------------------
 .../component/activemq/CamelMessageConsumer.java   | 176 ---------------------
 .../component/activemq/CamelMessageProducer.java   | 106 -------------
 .../camel/component/activemq/CamelQueue.java       |  50 ------
 .../component/activemq/CamelQueueReceiver.java     |  49 ------
 .../camel/component/activemq/CamelQueueSender.java |  96 -----------
 .../component/activemq/CamelShutdownHook.java      |  73 ---------
 .../camel/component/activemq/CamelTopic.java       |  50 ------
 .../component/activemq/CamelTopicPublisher.java    | 156 ------------------
 .../component/activemq/CamelTopicSubscriber.java   |  65 --------
 .../activemq/converter/ActiveMQConverter.java      |   4 +-
 .../converter/ActiveMQMessageConverter.java        |   3 -
 .../activemq/AutoExposeQueuesInCamelTest.java      | 102 ------------
 .../activemq/BrokerPreShutdownHookTest.java        |  79 ---------
 .../activemq/CamelJmsRequestReplyNobTest.java      | 114 -------------
 .../camel/component/activemq/CamelJmsTest.java     | 106 -------------
 .../camel/component/activemq/requestReply.xml      |  78 ---------
 .../org/apache/camel/component/activemq/spring.xml |  51 ------
 .../springboot/ActiveMQComponentConfiguration.java |  14 --
 25 files changed, 15 insertions(+), 1890 deletions(-)

diff --git a/components/camel-activemq/src/main/docs/activemq-component.adoc b/components/camel-activemq/src/main/docs/activemq-component.adoc
index dcea7a7..2b19976 100644
--- a/components/camel-activemq/src/main/docs/activemq-component.adoc
+++ b/components/camel-activemq/src/main/docs/activemq-component.adoc
@@ -48,7 +48,7 @@ activemq:foo
 == Component options
 
 // component options: START
-The ActiveMQ component supports 87 options, which are listed below.
+The ActiveMQ component supports 86 options, which are listed below.
 
 
 
@@ -57,7 +57,6 @@ The ActiveMQ component supports 87 options, which are listed below.
 | Name | Description | Default | Type
 | *brokerURL* (common) | Sets the broker URL to use to connect to ActiveMQ |  | String
 | *trustAllPackages* (common) | Define if all Java packages are trusted or not (for Java object JMS message types). Notice its not recommended practice to send Java serialized objects over network. Setting this to true can expose security risks, so use this with care. | false | boolean
-| *exposeAllQueues* (advanced) | If enabled this will cause all Queues in the ActiveMQ broker to be eagerly populated into the CamelContext so that they can be easily browsed by any Camel tooling. This option is disabled by default. | false | boolean
 | *usePooledConnection* (common) | Enables or disables whether a PooledConnectionFactory will be used so that when messages are sent to ActiveMQ from outside of a message consuming thread, pooling will be used rather than the default with the Spring JmsTemplate which will create a new connection, session, producer for each message then close them all down again. The default value is true. | false | boolean
 | *useSingleConnection* (common) | Enables or disables whether a Spring SingleConnectionFactory will be used so that when messages are sent to ActiveMQ from outside of a message consuming thread, pooling will be used rather than the default with the Spring JmsTemplate which will create a new connection, session, producer for each message then close them all down again. The default value is false and a pooled connection is used by default. | false | boolean
 | *configuration* (common) | Configuration of ActiveMQ |  | JmsConfiguration
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java
index e6fc1f7..0d994d4 100644
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java
+++ b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java
@@ -19,39 +19,26 @@ package org.apache.camel.component.activemq;
 import java.net.URISyntaxException;
 import java.util.Map;
 import java.util.concurrent.CopyOnWriteArrayList;
-import javax.jms.Connection;
 
-import org.apache.activemq.EnhancedConnection;
 import org.apache.activemq.Service;
-import org.apache.activemq.advisory.DestinationSource;
 import org.apache.camel.CamelContext;
 import org.apache.camel.RuntimeCamelException;
 import org.apache.camel.component.jms.JmsComponent;
 import org.apache.camel.component.jms.JmsConfiguration;
-import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.annotations.Component;
 import org.apache.camel.util.ObjectHelper;
 import org.apache.camel.util.PropertiesHelper;
 import org.apache.camel.util.URISupport;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
 import org.springframework.jms.connection.SingleConnectionFactory;
 import org.springframework.jms.core.JmsTemplate;
 
 /**
- * The <a href="http://activemq.apache.org/camel/activemq.html">ActiveMQ
- * Component</a>
+ * The ActiveMQ Component.
  */
 @Component("activemq")
 public class ActiveMQComponent extends JmsComponent {
-    private static final transient Logger LOG = LoggerFactory.getLogger(ActiveMQComponent.class);
-    private volatile DestinationSource source;
-    private volatile EnhancedConnection connection;
-    private volatile CamelEndpointLoader endpointLoader;
     private final CopyOnWriteArrayList<SingleConnectionFactory> singleConnectionFactoryList = new CopyOnWriteArrayList<>();
     private final CopyOnWriteArrayList<Service> pooledConnectionFactoryServiceList = new CopyOnWriteArrayList<>();
-    @Metadata(label = "advanced")
-    private boolean exposeAllQueues;
 
     public ActiveMQComponent() {
     }
@@ -112,19 +99,6 @@ public class ActiveMQComponent extends JmsComponent {
         }
     }
 
-    public boolean isExposeAllQueues() {
-        return exposeAllQueues;
-    }
-
-    /**
-     * If enabled this will cause all Queues in the ActiveMQ broker to be
-     * eagerly populated into the CamelContext so that they can be easily
-     * browsed by any Camel tooling. This option is disabled by default.
-     */
-    public void setExposeAllQueues(boolean exposeAllQueues) {
-        this.exposeAllQueues = exposeAllQueues;
-    }
-
     /**
      * Enables or disables whether a PooledConnectionFactory will be used so
      * that when messages are sent to ActiveMQ from outside of a message
@@ -190,12 +164,6 @@ public class ActiveMQComponent extends JmsComponent {
     protected void doStart() throws Exception {
         super.doStart();
 
-        if (isExposeAllQueues()) {
-            createDestinationSource();
-            endpointLoader = new CamelEndpointLoader(getCamelContext(), source);
-            endpointLoader.afterPropertiesSet();
-        }
-
         // use OriginalDestinationPropagateStrategy by default if no custom
         // strategy has been set
         if (getMessageCreatedStrategy() == null) {
@@ -203,43 +171,26 @@ public class ActiveMQComponent extends JmsComponent {
         }
     }
 
-    protected void createDestinationSource() {
-        try {
-            if (source == null) {
-                if (connection == null) {
-                    Connection value = getConfiguration().getOrCreateConnectionFactory().createConnection();
-                    if (value instanceof EnhancedConnection) {
-                        connection = (EnhancedConnection)value;
-                    } else {
-                        throw new IllegalArgumentException("Created JMS Connection is not an EnhancedConnection: " + value);
-                    }
-                    connection.start();
-                }
-                source = connection.getDestinationSource();
-            }
-        } catch (Throwable t) {
-            LOG.info("Can't get destination source, endpoint completer will not work", t);
-        }
-    }
-
     @Override
     protected void doStop() throws Exception {
-        if (source != null) {
-            source.stop();
-            source = null;
-        }
-        if (connection != null) {
-            connection.close();
-            connection = null;
-        }
         for (Service s : pooledConnectionFactoryServiceList) {
-            s.stop();
+            try {
+                s.stop();
+            } catch (Throwable e) {
+                // ignore
+            }
         }
         pooledConnectionFactoryServiceList.clear();
+
         for (SingleConnectionFactory s : singleConnectionFactoryList) {
-            s.destroy();
+            try {
+                s.destroy();
+            } catch (Throwable e) {
+                // ignore
+            }
         }
         singleConnectionFactoryList.clear();
+
         super.doStop();
     }
 
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQConfiguration.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQConfiguration.java
index 4bf3627..f168baf 100644
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQConfiguration.java
+++ b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQConfiguration.java
@@ -30,9 +30,6 @@ import org.springframework.jms.connection.SingleConnectionFactory;
 import org.springframework.jms.core.JmsTemplate;
 import org.springframework.transaction.PlatformTransactionManager;
 
-/**
- *
- */
 public class ActiveMQConfiguration extends JmsConfiguration {
     private ActiveMQComponent activeMQComponent;
     private String brokerURL = ActiveMQConnectionFactory.DEFAULT_BROKER_URL;
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelConnection.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelConnection.java
deleted file mode 100644
index e150783..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelConnection.java
+++ /dev/null
@@ -1,46 +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.camel.component.activemq;
-
-import org.apache.activemq.ActiveMQConnection;
-import org.apache.activemq.management.JMSStatsImpl;
-import org.apache.activemq.transport.Transport;
-import org.apache.activemq.util.IdGenerator;
-import org.apache.camel.CamelContext;
-import org.apache.camel.CamelContextAware;
-
-/**
- * 
- */
-public class CamelConnection extends ActiveMQConnection implements CamelContextAware {
-
-    private CamelContext camelContext;
-
-    protected CamelConnection(Transport transport, IdGenerator clientIdGenerator, IdGenerator connectionIdGenerator, JMSStatsImpl factoryStats) throws Exception {
-        super(transport, clientIdGenerator, connectionIdGenerator, factoryStats);
-    }
-
-    @Override
-    public CamelContext getCamelContext() {
-        return camelContext;
-    }
-
-    @Override
-    public void setCamelContext(CamelContext camelContext) {
-        this.camelContext = camelContext;
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelConnectionFactory.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelConnectionFactory.java
deleted file mode 100644
index 9b5f98d..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelConnectionFactory.java
+++ /dev/null
@@ -1,57 +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.camel.component.activemq;
-
-import org.apache.activemq.management.JMSStatsImpl;
-import org.apache.activemq.spring.ActiveMQConnectionFactory;
-import org.apache.activemq.transport.Transport;
-import org.apache.camel.CamelContext;
-import org.apache.camel.CamelContextAware;
-
-/**
- * A JMS ConnectionFactory which resolves non-JMS destinations or instances of
- * {@link CamelDestination} to use the {@link CamelContext} to perform smart
- * routing etc
- */
-public class CamelConnectionFactory extends ActiveMQConnectionFactory implements CamelContextAware {
-    private CamelContext camelContext;
-
-    public CamelConnectionFactory() {
-    }
-
-    @Override
-    public CamelContext getCamelContext() {
-        return camelContext;
-    }
-
-    @Override
-    public void setCamelContext(CamelContext camelContext) {
-        this.camelContext = camelContext;
-    }
-
-    // Implementation methods
-    // -----------------------------------------------------------------------
-    @Override
-    protected CamelConnection createActiveMQConnection(Transport transport, JMSStatsImpl stats) throws Exception {
-        CamelConnection connection = new CamelConnection(transport, getClientIdGenerator(), getConnectionIdGenerator(), stats);
-        CamelContext context = getCamelContext();
-        if (context != null) {
-            connection.setCamelContext(context);
-        }
-        return connection;
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelDestination.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelDestination.java
deleted file mode 100644
index 50b938b..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelDestination.java
+++ /dev/null
@@ -1,173 +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.camel.component.activemq;
-
-import javax.jms.JMSException;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageProducer;
-import javax.jms.QueueReceiver;
-import javax.jms.QueueSender;
-import javax.jms.TopicPublisher;
-import javax.jms.TopicSubscriber;
-
-import org.apache.activemq.ActiveMQConnection;
-import org.apache.activemq.ActiveMQSession;
-import org.apache.activemq.CustomDestination;
-import org.apache.camel.CamelContext;
-import org.apache.camel.CamelContextAware;
-import org.apache.camel.Endpoint;
-import org.apache.camel.component.jms.JmsBinding;
-import org.apache.camel.component.jms.JmsEndpoint;
-
-/**
- * 
- */
-public class CamelDestination implements CustomDestination, CamelContextAware {
-    private String uri;
-    private Endpoint endpoint;
-    private CamelContext camelContext;
-    // add in dummy endpoint pending camel release with
-    // https://issues.apache.org/activemq/browse/CAMEL-1982
-    private JmsBinding binding = new JmsBinding(new JmsEndpoint());
-
-    public CamelDestination() {
-    }
-
-    public CamelDestination(String uri) {
-        this.uri = uri;
-    }
-
-    @Override
-    public String toString() {
-        return uri.toString();
-    }
-
-    // CustomDestination interface
-    // -----------------------------------------------------------------------
-    @Override
-    public MessageConsumer createConsumer(ActiveMQSession session, String messageSelector) {
-        return createConsumer(session, messageSelector, false);
-    }
-
-    @Override
-    public MessageConsumer createConsumer(ActiveMQSession session, String messageSelector, boolean noLocal) {
-        return new CamelMessageConsumer(this, resolveEndpoint(session), session, messageSelector, noLocal);
-    }
-
-    @Override
-    public TopicSubscriber createSubscriber(ActiveMQSession session, String messageSelector, boolean noLocal) {
-        return createDurableSubscriber(session, null, messageSelector, noLocal);
-    }
-
-    @Override
-    public TopicSubscriber createDurableSubscriber(ActiveMQSession session, String name, String messageSelector, boolean noLocal) {
-        throw new UnsupportedOperationException("This destination is not a Topic: " + this);
-    }
-
-    @Override
-    public QueueReceiver createReceiver(ActiveMQSession session, String messageSelector) {
-        throw new UnsupportedOperationException("This destination is not a Queue: " + this);
-    }
-
-    // Producers
-    // -----------------------------------------------------------------------
-    @Override
-    public MessageProducer createProducer(ActiveMQSession session) throws JMSException {
-        return new CamelMessageProducer(this, resolveEndpoint(session), session);
-    }
-
-    @Override
-    public TopicPublisher createPublisher(ActiveMQSession session) throws JMSException {
-        throw new UnsupportedOperationException("This destination is not a Topic: " + this);
-    }
-
-    @Override
-    public QueueSender createSender(ActiveMQSession session) throws JMSException {
-        throw new UnsupportedOperationException("This destination is not a Queue: " + this);
-    }
-
-    // Properties
-    // -----------------------------------------------------------------------
-
-    public String getUri() {
-        return uri;
-    }
-
-    public void setUri(String uri) {
-        this.uri = uri;
-    }
-
-    public Endpoint getEndpoint() {
-        return endpoint;
-    }
-
-    public void setEndpoint(Endpoint endpoint) {
-        this.endpoint = endpoint;
-    }
-
-    @Override
-    public CamelContext getCamelContext() {
-        return camelContext;
-    }
-
-    @Override
-    public void setCamelContext(CamelContext camelContext) {
-        this.camelContext = camelContext;
-    }
-
-    public JmsBinding getBinding() {
-        return binding;
-    }
-
-    public void setBinding(JmsBinding binding) {
-        this.binding = binding;
-    }
-
-    // Implementation methods
-    // -----------------------------------------------------------------------
-
-    /**
-     * Resolves the Camel Endpoint for this destination
-     *
-     * @return
-     */
-    protected Endpoint resolveEndpoint(ActiveMQSession session) {
-        Endpoint answer = getEndpoint();
-        if (answer == null) {
-            answer = resolveCamelContext(session).getEndpoint(getUri());
-            if (answer == null) {
-                throw new IllegalArgumentException("No endpoint could be found for URI: " + getUri());
-            }
-        }
-        return answer;
-    }
-
-    protected CamelContext resolveCamelContext(ActiveMQSession session) {
-        CamelContext answer = getCamelContext();
-        if (answer == null) {
-            ActiveMQConnection connection = session.getConnection();
-            if (connection instanceof CamelConnection) {
-                CamelConnection camelConnection = (CamelConnection)connection;
-                answer = camelConnection.getCamelContext();
-            }
-        }
-        if (answer == null) {
-            throw new IllegalArgumentException("No CamelContext has been configured");
-        }
-        return answer;
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelEndpointLoader.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelEndpointLoader.java
deleted file mode 100644
index 3ad912e..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelEndpointLoader.java
+++ /dev/null
@@ -1,176 +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.camel.component.activemq;
-
-import java.util.Set;
-
-import javax.annotation.PostConstruct;
-
-import org.apache.activemq.advisory.DestinationEvent;
-import org.apache.activemq.advisory.DestinationListener;
-import org.apache.activemq.advisory.DestinationSource;
-import org.apache.activemq.command.ActiveMQDestination;
-import org.apache.activemq.command.ActiveMQQueue;
-import org.apache.activemq.command.ActiveMQTopic;
-import org.apache.camel.CamelContext;
-import org.apache.camel.CamelContextAware;
-import org.apache.camel.Endpoint;
-import org.apache.camel.component.jms.JmsEndpoint;
-import org.apache.camel.component.jms.JmsQueueEndpoint;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * A helper bean which populates a {@link CamelContext} with ActiveMQ Queue
- * endpoints
- *
- * @org.apache.xbean.XBean
- */
-public class CamelEndpointLoader implements CamelContextAware {
-    private static final transient Logger LOG = LoggerFactory.getLogger(CamelEndpointLoader.class);
-    DestinationSource source;
-    private CamelContext camelContext;
-    private ActiveMQComponent component;
-
-    public CamelEndpointLoader() {
-    }
-
-    public CamelEndpointLoader(CamelContext camelContext, DestinationSource source) {
-        this.camelContext = camelContext;
-        this.source = source;
-    }
-
-    /**
-     * JSR-250 callback wrapper; converts checked exceptions to runtime
-     * exceptions delegates to afterPropertiesSet, done to prevent backwards
-     * incompatible signature change fix: AMQ-4676
-     */
-    @PostConstruct
-    private void postConstruct() {
-        try {
-            afterPropertiesSet();
-        } catch (Exception ex) {
-            throw new RuntimeException(ex);
-        }
-    }
-
-    /**
-     * @throws Exception
-     * @org.apache.xbean.InitMethod
-     */
-    public void afterPropertiesSet() throws Exception {
-        if (source != null) {
-            source.setDestinationListener(new DestinationListener() {
-                @Override
-                public void onDestinationEvent(DestinationEvent event) {
-                    try {
-                        ActiveMQDestination destination = event.getDestination();
-                        if (destination instanceof ActiveMQQueue) {
-                            ActiveMQQueue queue = (ActiveMQQueue)destination;
-                            if (event.isAddOperation()) {
-                                addQueue(queue);
-                            } else {
-                                removeQueue(queue);
-                            }
-                        } else if (destination instanceof ActiveMQTopic) {
-                            ActiveMQTopic topic = (ActiveMQTopic)destination;
-                            if (event.isAddOperation()) {
-                                addTopic(topic);
-                            } else {
-                                removeTopic(topic);
-                            }
-                        }
-                    } catch (Exception e) {
-                        LOG.warn("Caught: " + e, e);
-                    }
-                }
-            });
-
-            Set<ActiveMQQueue> queues = source.getQueues();
-            for (ActiveMQQueue queue : queues) {
-                addQueue(queue);
-            }
-
-            Set<ActiveMQTopic> topics = source.getTopics();
-            for (ActiveMQTopic topic : topics) {
-                addTopic(topic);
-            }
-        }
-    }
-
-    // Properties
-    // -------------------------------------------------------------------------
-    @Override
-    public CamelContext getCamelContext() {
-        return camelContext;
-    }
-
-    @Override
-    public void setCamelContext(CamelContext camelContext) {
-        this.camelContext = camelContext;
-    }
-
-    public ActiveMQComponent getComponent() {
-        if (component == null) {
-            component = camelContext.getComponent("activemq", ActiveMQComponent.class);
-        }
-        return component;
-    }
-
-    public void setComponent(ActiveMQComponent component) {
-        this.component = component;
-    }
-
-    // Implementation methods
-    // -------------------------------------------------------------------------
-
-    protected void addQueue(ActiveMQQueue queue) throws Exception {
-        String queueUri = getQueueUri(queue);
-        ActiveMQComponent jmsComponent = getComponent();
-        Endpoint endpoint = new JmsQueueEndpoint(queueUri, jmsComponent, queue.getPhysicalName(), jmsComponent.getConfiguration());
-        camelContext.addEndpoint(queueUri, endpoint);
-    }
-
-    protected String getQueueUri(ActiveMQQueue queue) {
-        return "activemq:" + queue.getPhysicalName();
-    }
-
-    protected void removeQueue(ActiveMQQueue queue) throws Exception {
-        String queueUri = getQueueUri(queue);
-        // lur cache of endpoints so they will disappear in time
-        // this feature needs a new component api - list available endpoints
-        camelContext.removeEndpoints(queueUri);
-    }
-
-    protected void addTopic(ActiveMQTopic topic) throws Exception {
-        String topicUri = getTopicUri(topic);
-        ActiveMQComponent jmsComponent = getComponent();
-        Endpoint endpoint = new JmsEndpoint(topicUri, jmsComponent, topic.getPhysicalName(), true, jmsComponent.getConfiguration());
-        camelContext.addEndpoint(topicUri, endpoint);
-    }
-
-    protected String getTopicUri(ActiveMQTopic topic) {
-        return "activemq:topic:" + topic.getPhysicalName();
-    }
-
-    protected void removeTopic(ActiveMQTopic topic) throws Exception {
-        String topicUri = getTopicUri(topic);
-        // lur cache of endpoints so they will disappear in time
-        // this feature needs a new component api - list available endpoints
-        camelContext.removeEndpoints(topicUri);
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelMessageConsumer.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelMessageConsumer.java
deleted file mode 100644
index c254316..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelMessageConsumer.java
+++ /dev/null
@@ -1,176 +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.camel.component.activemq;
-
-import javax.jms.IllegalStateException;
-import javax.jms.JMSException;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageListener;
-
-import org.apache.activemq.ActiveMQSession;
-import org.apache.activemq.util.JMSExceptionSupport;
-import org.apache.camel.Consumer;
-import org.apache.camel.Endpoint;
-import org.apache.camel.Exchange;
-import org.apache.camel.PollingConsumer;
-import org.apache.camel.Processor;
-
-/**
- * A JMS {@link javax.jms.MessageConsumer} which consumes message exchanges from
- * a Camel {@link Endpoint}
- */
-public class CamelMessageConsumer implements MessageConsumer {
-    private final CamelDestination destination;
-    private final Endpoint endpoint;
-    private final ActiveMQSession session;
-    private final String messageSelector;
-    private final boolean noLocal;
-    private MessageListener messageListener;
-    private Consumer consumer;
-    private PollingConsumer pollingConsumer;
-    private boolean closed;
-
-    public CamelMessageConsumer(CamelDestination destination, Endpoint endpoint, ActiveMQSession session, String messageSelector, boolean noLocal) {
-        this.destination = destination;
-        this.endpoint = endpoint;
-        this.session = session;
-        this.messageSelector = messageSelector;
-        this.noLocal = noLocal;
-    }
-
-    @Override
-    public void close() throws JMSException {
-        if (!closed) {
-            closed = true;
-            try {
-                if (consumer != null) {
-                    consumer.stop();
-                }
-                if (pollingConsumer != null) {
-                    pollingConsumer.stop();
-                }
-            } catch (Exception e) {
-                throw JMSExceptionSupport.create(e);
-            }
-        }
-    }
-
-    @Override
-    public MessageListener getMessageListener() throws JMSException {
-        return messageListener;
-    }
-
-    @Override
-    public void setMessageListener(MessageListener messageListener) throws JMSException {
-        this.messageListener = messageListener;
-        if (messageListener != null && consumer == null) {
-            consumer = createConsumer();
-        }
-    }
-
-    @Override
-    public Message receive() throws JMSException {
-        Exchange exchange = getPollingConsumer().receive();
-        return createMessage(exchange);
-    }
-
-    @Override
-    public Message receive(long timeoutMillis) throws JMSException {
-        Exchange exchange = getPollingConsumer().receive(timeoutMillis);
-        return createMessage(exchange);
-    }
-
-    @Override
-    public Message receiveNoWait() throws JMSException {
-        Exchange exchange = getPollingConsumer().receiveNoWait();
-        return createMessage(exchange);
-    }
-
-    // Properties
-    // -----------------------------------------------------------------------
-
-    public CamelDestination getDestination() {
-        return destination;
-    }
-
-    public Endpoint getEndpoint() {
-        return endpoint;
-    }
-
-    @Override
-    public String getMessageSelector() {
-        return messageSelector;
-    }
-
-    public boolean isNoLocal() {
-        return noLocal;
-    }
-
-    public ActiveMQSession getSession() {
-        return session;
-    }
-
-    // Implementation methods
-    // -----------------------------------------------------------------------
-
-    protected PollingConsumer getPollingConsumer() throws JMSException {
-        try {
-            if (pollingConsumer == null) {
-                pollingConsumer = endpoint.createPollingConsumer();
-                pollingConsumer.start();
-            }
-            return pollingConsumer;
-        } catch (JMSException e) {
-            throw e;
-        } catch (Exception e) {
-            throw JMSExceptionSupport.create(e);
-        }
-    }
-
-    protected Message createMessage(Exchange exchange) throws JMSException {
-        if (exchange != null) {
-            Message message = destination.getBinding().makeJmsMessage(exchange, session);
-            return message;
-        } else {
-            return null;
-        }
-    }
-
-    protected Consumer createConsumer() throws JMSException {
-        try {
-            Consumer answer = endpoint.createConsumer(new Processor() {
-                public void process(Exchange exchange) throws Exception {
-                    Message message = createMessage(exchange);
-                    getMessageListener().onMessage(message);
-                }
-            });
-            answer.start();
-            return answer;
-        } catch (JMSException e) {
-            throw e;
-        } catch (Exception e) {
-            throw JMSExceptionSupport.create(e);
-        }
-    }
-
-    protected void checkClosed() throws javax.jms.IllegalStateException {
-        if (closed) {
-            throw new IllegalStateException("The producer is closed");
-        }
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelMessageProducer.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelMessageProducer.java
deleted file mode 100644
index e7065ef..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelMessageProducer.java
+++ /dev/null
@@ -1,106 +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.camel.component.activemq;
-
-import javax.jms.Destination;
-import javax.jms.IllegalStateException;
-import javax.jms.JMSException;
-import javax.jms.Message;
-
-import org.apache.activemq.ActiveMQMessageProducerSupport;
-import org.apache.activemq.ActiveMQSession;
-import org.apache.activemq.util.JMSExceptionSupport;
-import org.apache.camel.Endpoint;
-import org.apache.camel.Exchange;
-import org.apache.camel.ExchangePattern;
-import org.apache.camel.Producer;
-import org.apache.camel.component.jms.JmsMessage;
-import org.apache.camel.util.ObjectHelper;
-
-/**
- * A JMS {@link javax.jms.MessageProducer} which sends message exchanges to a
- * Camel {@link Endpoint}
- */
-public class CamelMessageProducer extends ActiveMQMessageProducerSupport {
-
-    protected Producer producer;
-
-    private final CamelDestination destination;
-    private final Endpoint endpoint;
-    private boolean closed;
-
-    public CamelMessageProducer(CamelDestination destination, Endpoint endpoint, ActiveMQSession session) throws JMSException {
-        super(session);
-        this.destination = destination;
-        this.endpoint = endpoint;
-        try {
-            this.producer = endpoint.createProducer();
-        } catch (JMSException e) {
-            throw e;
-        } catch (Exception e) {
-            throw JMSExceptionSupport.create(e);
-        }
-    }
-
-    @Override
-    public CamelDestination getDestination() throws JMSException {
-        return destination;
-    }
-
-    public Endpoint getEndpoint() {
-        return endpoint;
-    }
-
-    @Override
-    public void close() throws JMSException {
-        if (!closed) {
-            closed = true;
-            try {
-                producer.stop();
-            } catch (Exception e) {
-                throw JMSExceptionSupport.create(e);
-            }
-        }
-    }
-
-    @Override
-    public void send(Destination destination, Message message, int deliveryMode, int priority, long timeToLive) throws JMSException {
-        CamelDestination camelDestination = null;
-        if (ObjectHelper.equal(destination, this.destination)) {
-            camelDestination = this.destination;
-        } else {
-            // TODO support any CamelDestination?
-            throw new IllegalArgumentException("Invalid destination setting: " + destination + " when expected: " + this.destination);
-        }
-        try {
-            Exchange exchange = endpoint.createExchange(ExchangePattern.InOnly);
-            exchange.setIn(new JmsMessage(exchange, message, null, camelDestination.getBinding()));
-            producer.process(exchange);
-        } catch (JMSException e) {
-            throw e;
-        } catch (Exception e) {
-            throw JMSExceptionSupport.create(e);
-        }
-    }
-
-    @Override
-    protected void checkClosed() throws IllegalStateException {
-        if (closed) {
-            throw new IllegalStateException("The producer is closed");
-        }
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueue.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueue.java
deleted file mode 100644
index 7effa06..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueue.java
+++ /dev/null
@@ -1,50 +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.camel.component.activemq;
-
-import javax.jms.JMSException;
-import javax.jms.Queue;
-import javax.jms.QueueReceiver;
-import javax.jms.QueueSender;
-
-import org.apache.activemq.ActiveMQSession;
-
-/**
- * A JMS {@link Queue} object which refers to a Camel endpoint
- */
-public class CamelQueue extends CamelDestination implements Queue {
-
-    public CamelQueue(String uri) {
-        super(uri);
-    }
-
-    @Override
-    public String getQueueName() throws JMSException {
-        return getUri();
-    }
-
-    @Override
-    public QueueSender createSender(ActiveMQSession session) throws JMSException {
-        return new CamelQueueSender(this, resolveEndpoint(session), session);
-    }
-
-    @Override
-    public QueueReceiver createReceiver(ActiveMQSession session, String messageSelector) {
-        return new CamelQueueReceiver(this, resolveEndpoint(session), session, messageSelector);
-    }
-
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueueReceiver.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueueReceiver.java
deleted file mode 100644
index 0ab08cf..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueueReceiver.java
+++ /dev/null
@@ -1,49 +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.camel.component.activemq;
-
-import javax.jms.JMSException;
-import javax.jms.Queue;
-import javax.jms.QueueReceiver;
-
-import org.apache.activemq.ActiveMQSession;
-import org.apache.camel.Endpoint;
-
-/**
- * A JMS {@link javax.jms.QueueReceiver} which consumes message exchanges from a
- * Camel {@link org.apache.camel.Endpoint}
- */
-public class CamelQueueReceiver extends CamelMessageConsumer implements QueueReceiver {
-
-    public CamelQueueReceiver(CamelQueue destination, Endpoint endpoint, ActiveMQSession session, String name) {
-        super(destination, endpoint, session, null, false);
-    }
-
-    /**
-     * Gets the <CODE>Queue</CODE> associated with this queue receiver.
-     *
-     * @return this receiver's <CODE>Queue</CODE>
-     * @throws JMSException if the JMS provider fails to get the queue for this
-     *             queue receiver due to some internal error.
-     */
-
-    @Override
-    public Queue getQueue() throws JMSException {
-        checkClosed();
-        return (Queue)super.getDestination();
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueueSender.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueueSender.java
deleted file mode 100644
index fd0d075..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelQueueSender.java
+++ /dev/null
@@ -1,96 +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.camel.component.activemq;
-
-import javax.jms.JMSException;
-import javax.jms.Message;
-import javax.jms.Queue;
-import javax.jms.QueueSender;
-
-import org.apache.activemq.ActiveMQSession;
-import org.apache.camel.Endpoint;
-
-/**
- * A JMS {@link javax.jms.QueueSender} which sends message exchanges to a Camel
- * {@link org.apache.camel.Endpoint}
- */
-public class CamelQueueSender extends CamelMessageProducer implements QueueSender {
-
-    public CamelQueueSender(CamelQueue destination, Endpoint endpoint, ActiveMQSession session) throws JMSException {
-        super(destination, endpoint, session);
-    }
-
-    /**
-     * Gets the queue associated with this <CODE>QueueSender</CODE>.
-     * 
-     * @return this sender's queue
-     * @throws JMSException if the JMS provider fails to get the queue for this
-     *             <CODE>QueueSender</CODE> due to some internal error.
-     */
-
-    @Override
-    public Queue getQueue() throws JMSException {
-        return (Queue)super.getDestination();
-    }
-
-    /**
-     * Sends a message to a queue for an unidentified message producer. Uses the
-     * <CODE>QueueSender</CODE>'s default delivery mode, priority, and time to
-     * live.
-     * <p/>
-     * <p/>
-     * Typically, a message producer is assigned a queue at creation time;
-     * however, the JMS API also supports unidentified message producers, which
-     * require that the queue be supplied every time a message is sent.
-     * 
-     * @param queue the queue to send this message to
-     * @param message the message to send
-     * @throws JMSException if the JMS provider fails to send the message due to
-     *             some internal error.
-     * @see javax.jms.MessageProducer#getDeliveryMode()
-     * @see javax.jms.MessageProducer#getTimeToLive()
-     * @see javax.jms.MessageProducer#getPriority()
-     */
-
-    @Override
-    public void send(Queue queue, Message message) throws JMSException {
-        super.send(queue, message);
-    }
-
-    /**
-     * Sends a message to a queue for an unidentified message producer,
-     * specifying delivery mode, priority and time to live.
-     * <p/>
-     * <p/>
-     * Typically, a message producer is assigned a queue at creation time;
-     * however, the JMS API also supports unidentified message producers, which
-     * require that the queue be supplied every time a message is sent.
-     * 
-     * @param queue the queue to send this message to
-     * @param message the message to send
-     * @param deliveryMode the delivery mode to use
-     * @param priority the priority for this message
-     * @param timeToLive the message's lifetime (in milliseconds)
-     * @throws JMSException if the JMS provider fails to send the message due to
-     *             some internal error.
-     */
-
-    @Override
-    public void send(Queue queue, Message message, int deliveryMode, int priority, long timeToLive) throws JMSException {
-        super.send(queue, message, deliveryMode, priority, timeToLive);
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelShutdownHook.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelShutdownHook.java
deleted file mode 100644
index 3518c2d..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelShutdownHook.java
+++ /dev/null
@@ -1,73 +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.camel.component.activemq;
-
-import org.apache.activemq.broker.BrokerService;
-import org.apache.camel.CamelContext;
-import org.apache.camel.CamelContextAware;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.springframework.beans.factory.annotation.Autowired;
-
-/**
- * A shutdown hook that can be used to shutdown {@link CamelContext} before the
- * ActiveMQ broker is shut down. This is sometimes important as if the broker is
- * shutdown before Camel there could be a loss of data due to inflight exchanges
- * not yet completed.
- * <p>
- * This hook can be added to ActiveMQ configuration ({@code activemq.xml}) as in
- * the following example:
- * <p>
- * <code>
- * &lt;bean xmlns=&quot;http://www.springframework.org/schema/beans&quot; class=&quot;org.apache.activemq.camel.CamelShutdownHook&quot; /&gt;
- * </code>
- */
-public final class CamelShutdownHook implements Runnable, CamelContextAware {
-
-    private static final Logger LOG = LoggerFactory.getLogger(CamelShutdownHook.class);
-
-    private CamelContext camelContext;
-
-    @Autowired
-    public CamelShutdownHook(final BrokerService brokerService) {
-        brokerService.addPreShutdownHook(this);
-    }
-
-    @Override
-    public CamelContext getCamelContext() {
-        return camelContext;
-    }
-
-    @Override
-    public void run() {
-        if (camelContext != null) {
-            try {
-                camelContext.stop();
-            } catch (final Exception e) {
-                LOG.warn("Unable to stop CamelContext", e);
-            }
-        } else {
-            LOG.warn("Unable to stop CamelContext, no CamelContext was set!");
-        }
-    }
-
-    @Override
-    public void setCamelContext(final CamelContext camelContext) {
-        this.camelContext = camelContext;
-    }
-
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopic.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopic.java
deleted file mode 100644
index 31daca1..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopic.java
+++ /dev/null
@@ -1,50 +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.camel.component.activemq;
-
-import javax.jms.JMSException;
-import javax.jms.Topic;
-import javax.jms.TopicPublisher;
-import javax.jms.TopicSubscriber;
-
-import org.apache.activemq.ActiveMQSession;
-
-/**
- * A JMS {@link javax.jms.Topic} object which refers to a Camel endpoint
- */
-public class CamelTopic extends CamelDestination implements Topic {
-
-    public CamelTopic(String uri) {
-        super(uri);
-    }
-
-    @Override
-    public String getTopicName() throws JMSException {
-        return getUri();
-    }
-
-    @Override
-    public TopicPublisher createPublisher(ActiveMQSession session) throws JMSException {
-        return new CamelTopicPublisher(this, resolveEndpoint(session), session);
-    }
-
-    @Override
-    public TopicSubscriber createDurableSubscriber(ActiveMQSession session, String name, String messageSelector, boolean noLocal) {
-        return new CamelTopicSubscriber(this, resolveEndpoint(session), session, name, messageSelector, noLocal);
-    }
-
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopicPublisher.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopicPublisher.java
deleted file mode 100644
index 2ff0c67..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopicPublisher.java
+++ /dev/null
@@ -1,156 +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.camel.component.activemq;
-
-import javax.jms.JMSException;
-import javax.jms.Message;
-import javax.jms.Topic;
-import javax.jms.TopicPublisher;
-
-import org.apache.activemq.ActiveMQSession;
-import org.apache.camel.Endpoint;
-
-/**
- * A JMS {@link javax.jms.TopicPublisher} which sends message exchanges to a
- * Camel {@link Endpoint}
- */
-public class CamelTopicPublisher extends CamelMessageProducer implements TopicPublisher {
-
-    public CamelTopicPublisher(CamelTopic destination, Endpoint endpoint, ActiveMQSession session) throws JMSException {
-        super(destination, endpoint, session);
-    }
-
-    /**
-     * Gets the topic associated with this <CODE>TopicPublisher</CODE>.
-     *
-     * @return this publisher's topic
-     * @throws JMSException if the JMS provider fails to get the topic for this
-     *             <CODE>TopicPublisher</CODE> due to some internal error.
-     */
-
-    @Override
-    public Topic getTopic() throws JMSException {
-        return (Topic)super.getDestination();
-    }
-
-    /**
-     * Publishes a message to the topic. Uses the <CODE>TopicPublisher</CODE>'s
-     * default delivery mode, priority, and time to live.
-     *
-     * @param message the message to publish
-     * @throws JMSException if the JMS provider fails to publish the message due
-     *             to some internal error.
-     * @throws javax.jms.MessageFormatException if an invalid message is
-     *             specified.
-     * @throws javax.jms.InvalidDestinationException if a client uses this
-     *             method with a <CODE>TopicPublisher
-     *                                     </CODE> with an invalid topic.
-     * @throws java.lang.UnsupportedOperationException if a client uses this
-     *             method with a <CODE>TopicPublisher
-     *                                     </CODE> that did not specify a topic
-     *             at creation time.
-     * @see javax.jms.MessageProducer#getDeliveryMode()
-     * @see javax.jms.MessageProducer#getTimeToLive()
-     * @see javax.jms.MessageProducer#getPriority()
-     */
-
-    @Override
-    public void publish(Message message) throws JMSException {
-        super.send(message);
-    }
-
-    /**
-     * Publishes a message to the topic, specifying delivery mode, priority, and
-     * time to live.
-     *
-     * @param message the message to publish
-     * @param deliveryMode the delivery mode to use
-     * @param priority the priority for this message
-     * @param timeToLive the message's lifetime (in milliseconds)
-     * @throws JMSException if the JMS provider fails to publish the message due
-     *             to some internal error.
-     * @throws javax.jms.MessageFormatException if an invalid message is
-     *             specified.
-     * @throws javax.jms.InvalidDestinationException if a client uses this
-     *             method with a <CODE>TopicPublisher
-     *                                     </CODE> with an invalid topic.
-     * @throws java.lang.UnsupportedOperationException if a client uses this
-     *             method with a <CODE>TopicPublisher
-     *                                     </CODE> that did not specify a topic
-     *             at creation time.
-     */
-
-    @Override
-    public void publish(Message message, int deliveryMode, int priority, long timeToLive) throws JMSException {
-        super.send(message, deliveryMode, priority, timeToLive);
-    }
-
-    /**
-     * Publishes a message to a topic for an unidentified message producer. Uses
-     * the <CODE>TopicPublisher</CODE>'s default delivery mode, priority, and
-     * time to live.
-     * <p/>
-     * <P>
-     * Typically, a message producer is assigned a topic at creation time;
-     * however, the JMS API also supports unidentified message producers, which
-     * require that the topic be supplied every time a message is published.
-     *
-     * @param topic the topic to publish this message to
-     * @param message the message to publish
-     * @throws JMSException if the JMS provider fails to publish the message due
-     *             to some internal error.
-     * @throws javax.jms.MessageFormatException if an invalid message is
-     *             specified.
-     * @throws javax.jms.InvalidDestinationException if a client uses this
-     *             method with an invalid topic.
-     * @see javax.jms.MessageProducer#getDeliveryMode()
-     * @see javax.jms.MessageProducer#getTimeToLive()
-     * @see javax.jms.MessageProducer#getPriority()
-     */
-
-    @Override
-    public void publish(Topic topic, Message message) throws JMSException {
-        super.send(topic, message);
-    }
-
-    /**
-     * Publishes a message to a topic for an unidentified message producer,
-     * specifying delivery mode, priority and time to live.
-     * <p/>
-     * <P>
-     * Typically, a message producer is assigned a topic at creation time;
-     * however, the JMS API also supports unidentified message producers, which
-     * require that the topic be supplied every time a message is published.
-     *
-     * @param topic the topic to publish this message to
-     * @param message the message to publish
-     * @param deliveryMode the delivery mode to use
-     * @param priority the priority for this message
-     * @param timeToLive the message's lifetime (in milliseconds)
-     * @throws JMSException if the JMS provider fails to publish the message due
-     *             to some internal error.
-     * @throws javax.jms.MessageFormatException if an invalid message is
-     *             specified.
-     * @throws javax.jms.InvalidDestinationException if a client uses this
-     *             method with an invalid topic.
-     */
-
-    @Override
-    public void publish(Topic topic, Message message, int deliveryMode, int priority, long timeToLive) throws JMSException {
-        super.send(topic, message, deliveryMode, priority, timeToLive);
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopicSubscriber.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopicSubscriber.java
deleted file mode 100644
index 9e1f846..0000000
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/CamelTopicSubscriber.java
+++ /dev/null
@@ -1,65 +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.camel.component.activemq;
-
-import javax.jms.JMSException;
-import javax.jms.Topic;
-import javax.jms.TopicSubscriber;
-
-import org.apache.activemq.ActiveMQSession;
-import org.apache.camel.Endpoint;
-
-/**
- * A JMS {@link javax.jms.TopicSubscriber} which consumes message exchanges from
- * a Camel {@link Endpoint}
- */
-public class CamelTopicSubscriber extends CamelMessageConsumer implements TopicSubscriber {
-
-    public CamelTopicSubscriber(CamelTopic destination, Endpoint endpoint, ActiveMQSession session, String name, String messageSelector, boolean noLocal) {
-        super(destination, endpoint, session, messageSelector, noLocal);
-    }
-
-    /**
-     * Gets the <CODE>Topic</CODE> associated with this subscriber.
-     *
-     * @return this subscriber's <CODE>Topic</CODE>
-     * @throws javax.jms.JMSException if the JMS provider fails to get the topic
-     *             for this topic subscriber due to some internal error.
-     */
-
-    @Override
-    public Topic getTopic() throws JMSException {
-        checkClosed();
-        return (Topic)super.getDestination();
-    }
-
-    /**
-     * Gets the <CODE>NoLocal</CODE> attribute for this subscriber. The default
-     * value for this attribute is false.
-     *
-     * @return true if locally published messages are being inhibited
-     * @throws JMSException if the JMS provider fails to get the <CODE>NoLocal
-     *                      </CODE> attribute for this topic subscriber due to
-     *             some internal error.
-     */
-
-    @Override
-    public boolean getNoLocal() throws JMSException {
-        checkClosed();
-        return super.isNoLocal();
-    }
-}
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQConverter.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQConverter.java
index 6358425..a9733f7 100644
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQConverter.java
+++ b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQConverter.java
@@ -19,11 +19,9 @@ package org.apache.camel.component.activemq.converter;
 import org.apache.activemq.command.ActiveMQDestination;
 import org.apache.camel.Converter;
 
-/**
- * 
- */
 @Converter(generateLoader = true)
 public class ActiveMQConverter {
+
     /**
      * Converts a URL in ActiveMQ syntax to a destination such as to support
      * "queue://foo.bar" or 'topic://bar.whatnot". Things default to queues if
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQMessageConverter.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQMessageConverter.java
index a232636..fcd3111 100644
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQMessageConverter.java
+++ b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/converter/ActiveMQMessageConverter.java
@@ -30,9 +30,6 @@ import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.component.jms.JmsBinding;
 
-/**
- * 
- */
 @Converter(generateLoader = true)
 public class ActiveMQMessageConverter {
     private JmsBinding binding = new JmsBinding();
diff --git a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/AutoExposeQueuesInCamelTest.java b/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/AutoExposeQueuesInCamelTest.java
deleted file mode 100644
index 671502d..0000000
--- a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/AutoExposeQueuesInCamelTest.java
+++ /dev/null
@@ -1,102 +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.camel.component.activemq;
-
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.List;
-
-import org.apache.activemq.EmbeddedBrokerTestSupport;
-import org.apache.activemq.broker.BrokerService;
-import org.apache.activemq.command.ActiveMQDestination;
-import org.apache.activemq.command.ActiveMQQueue;
-import org.apache.activemq.command.ActiveMQTopic;
-import org.apache.camel.CamelContext;
-import org.apache.camel.Endpoint;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.apache.camel.spi.BrowsableEndpoint;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Shows that we can see the queues inside ActiveMQ via Camel by enabling the
- * {@link ActiveMQComponent#setExposeAllQueues(boolean)} flag
- */
-public class AutoExposeQueuesInCamelTest extends EmbeddedBrokerTestSupport {
-    private static final transient Logger LOG = LoggerFactory.getLogger(AutoExposeQueuesInCamelTest.class);
-
-    protected ActiveMQQueue sampleQueue = new ActiveMQQueue("foo.bar");
-    protected ActiveMQTopic sampleTopic = new ActiveMQTopic("cheese");
-
-    protected CamelContext camelContext = new DefaultCamelContext();
-    ActiveMQComponent component;
-
-    public void testWorks() throws Exception {
-        Thread.sleep(2000);
-        LOG.debug("Looking for endpoints...");
-        broker.getAdminView().addQueue("runtime");
-
-        Thread.sleep(1000);
-        // Changed from using CamelContextHelper.getSingletonEndpoints here
-        // because JMS Endpoints in Camel
-        // are always non-singleton
-        List<BrowsableEndpoint> endpoints = getEndpoints(camelContext, BrowsableEndpoint.class);
-        for (BrowsableEndpoint endpoint : endpoints) {
-            LOG.debug("Endpoint: " + endpoint);
-        }
-        assertEquals("Should have found an endpoint: " + endpoints, 2, endpoints.size());
-    }
-
-    public <T> List<T> getEndpoints(CamelContext camelContext, Class<T> type) {
-        List<T> answer = new ArrayList<>();
-        Collection<Endpoint> endpoints = camelContext.getEndpoints();
-        for (Endpoint endpoint : endpoints) {
-            if (type.isInstance(endpoint)) {
-                T value = type.cast(endpoint);
-                answer.add(value);
-            }
-        }
-        return answer;
-    }
-
-    @Override
-    protected void setUp() throws Exception {
-        super.setUp();
-
-        // lets configure the ActiveMQ component for Camel
-        component = new ActiveMQComponent();
-        component.setBrokerURL(bindAddress);
-        component.setExposeAllQueues(true);
-
-        camelContext.addComponent("activemq", component);
-        camelContext.start();
-    }
-
-    @Override
-    protected void tearDown() throws Exception {
-        camelContext.stop();
-        super.tearDown();
-    }
-
-    @Override
-    protected BrokerService createBroker() throws Exception {
-        BrokerService broker = super.createBroker();
-        broker.setDestinations(new ActiveMQDestination[] {sampleQueue, sampleTopic});
-        return broker;
-    }
-
-}
diff --git a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/BrokerPreShutdownHookTest.java b/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/BrokerPreShutdownHookTest.java
deleted file mode 100644
index e99888d..0000000
--- a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/BrokerPreShutdownHookTest.java
+++ /dev/null
@@ -1,79 +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.camel.component.activemq;
-
-import org.apache.activemq.broker.BrokerService;
-import org.apache.camel.Exchange;
-import org.apache.camel.Processor;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.junit.Test;
-
-import static org.junit.Assert.assertTrue;
-
-public class BrokerPreShutdownHookTest {
-
-    static class TestProcessor implements Processor {
-
-        boolean messageReceived;
-
-        @Override
-        public void process(final Exchange exchange) throws Exception {
-            messageReceived = true;
-        }
-    }
-
-    @Test
-    public void testShouldCleanlyShutdownCamelBeforeStoppingBroker() throws Exception {
-        final BrokerService broker = new BrokerService();
-        broker.setBrokerName("testBroker");
-        broker.setUseJmx(true);
-        broker.setPersistent(false);
-        broker.addConnector("vm://testBroker");
-
-        final DefaultCamelContext camel = new DefaultCamelContext();
-        camel.setName("test-camel");
-
-        final CamelShutdownHook hook = new CamelShutdownHook(broker);
-        hook.setCamelContext(camel);
-
-        broker.start();
-
-        camel.addComponent("testq", ActiveMQComponent.activeMQComponent("vm://testBroker?create=false"));
-
-        final TestProcessor processor = new TestProcessor();
-        camel.addRoutes(new RouteBuilder() {
-            @Override
-            public void configure() throws Exception {
-                from("testq:test.in").delay(200).process(processor);
-            }
-        });
-        camel.start();
-
-        final ProducerTemplate producer = camel.createProducerTemplate();
-        producer.sendBody("testq:test.in", "Hi!");
-        producer.stop();
-
-        broker.stop();
-
-        assertTrue("Message should be received", processor.messageReceived);
-        assertTrue("Camel context should be stopped", camel.isStopped());
-        assertTrue("Broker should be stopped", broker.isStopped());
-
-    }
-}
diff --git a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/CamelJmsRequestReplyNobTest.java b/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/CamelJmsRequestReplyNobTest.java
deleted file mode 100644
index 522d585..0000000
--- a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/CamelJmsRequestReplyNobTest.java
+++ /dev/null
@@ -1,114 +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.camel.component.activemq;
-
-import java.net.URI;
-import java.util.Arrays;
-
-import javax.jms.Connection;
-import javax.jms.ConnectionFactory;
-import javax.jms.Destination;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageProducer;
-import javax.jms.Session;
-import javax.jms.TextMessage;
-
-import org.apache.activemq.broker.BrokerService;
-import org.apache.activemq.command.ActiveMQDestination;
-import org.apache.activemq.command.ActiveMQQueue;
-import org.apache.activemq.network.DiscoveryNetworkConnector;
-import org.apache.camel.test.spring.CamelSpringTestSupport;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.springframework.context.support.AbstractXmlApplicationContext;
-import org.springframework.context.support.ClassPathXmlApplicationContext;
-
-public class CamelJmsRequestReplyNobTest extends CamelSpringTestSupport {
-
-    private static final Logger LOG = LoggerFactory.getLogger(CamelJmsRequestReplyNobTest.class);
-
-    BrokerService consumerBroker;
-    BrokerService producerBroker;
-
-    @Test
-    public void testRoundTrip() throws Exception {
-        Destination destination = getMandatoryBean(Destination.class, "consumeFrom");
-
-        // lets create a message
-        ConnectionFactory factoryCON = getMandatoryBean(ConnectionFactory.class, "CON");
-
-        Connection consumerConnection = factoryCON.createConnection();
-        consumerConnection.start();
-        Session consumerSession = consumerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-
-        LOG.info("Consuming from: " + destination);
-        MessageConsumer consumer = consumerSession.createConsumer(destination);
-
-        // lets create a message
-        ConnectionFactory factoryPRO = getMandatoryBean(ConnectionFactory.class, "PRO");
-
-        Connection producerConnection = factoryPRO.createConnection();
-        producerConnection.start();
-        Session producerSession = producerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-
-        MessageProducer producer = producerSession.createProducer(producerSession.createQueue("incoming1"));
-        Message message = producerSession.createTextMessage("Where are you");
-        message.setStringProperty("foo", "bar");
-        producer.send(message);
-
-        message = consumer.receive(10000);
-        assertNotNull("Should have received a message from destination: " + destination, message);
-
-        TextMessage textMessage = assertIsInstanceOf(TextMessage.class, message);
-        assertEquals("Message body", "If you don't ask me my name, I'm not going to tell you!", textMessage.getText());
-
-    }
-
-    private BrokerService createBroker(String name) throws Exception {
-        BrokerService brokerService = new BrokerService();
-        brokerService.setDeleteAllMessagesOnStartup(true);
-        brokerService.setBrokerName(name);
-        brokerService.setUseJmx(false);
-        brokerService.setPersistent(false);
-        brokerService.addConnector("tcp://0.0.0.0:0");
-        return brokerService;
-    }
-
-    @SuppressWarnings("unchecked")
-    @Override
-    protected AbstractXmlApplicationContext createApplicationContext() {
-        try {
-            consumerBroker = createBroker("CON");
-            producerBroker = createBroker("PRO");
-            DiscoveryNetworkConnector discoveryNetworkConnector = new DiscoveryNetworkConnector();
-            discoveryNetworkConnector.setUri(new URI("static:" + consumerBroker.getTransportConnectorByScheme("tcp").getPublishableConnectString()));
-            discoveryNetworkConnector.setDuplex(true);
-            discoveryNetworkConnector.setNetworkTTL(2);
-            discoveryNetworkConnector.setDynamicallyIncludedDestinations(Arrays.asList(new ActiveMQDestination[] {new ActiveMQQueue("service1")}));
-            discoveryNetworkConnector.setDestinationFilter("ActiveMQ.Advisory.TempQueue,ActiveMQ.Advisory.TempTopic,ActiveMQ.Advisory.Consumer.Queue.>");
-            producerBroker.addNetworkConnector(discoveryNetworkConnector);
-            consumerBroker.start();
-            producerBroker.start();
-
-        } catch (Exception e) {
-            throw new RuntimeException("Failed to start broker", e);
-        }
-        return new ClassPathXmlApplicationContext("org/apache/camel/component/activemq/requestReply.xml");
-    }
-}
diff --git a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/CamelJmsTest.java b/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/CamelJmsTest.java
deleted file mode 100644
index a48e312..0000000
--- a/components/camel-activemq/src/test/java/org/apache/camel/component/activemq/CamelJmsTest.java
+++ /dev/null
@@ -1,106 +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.camel.component.activemq;
-
-import javax.jms.Connection;
-import javax.jms.ConnectionFactory;
-import javax.jms.Destination;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageProducer;
-import javax.jms.ObjectMessage;
-import javax.jms.Session;
-import javax.jms.TextMessage;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.test.spring.CamelSpringTestSupport;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.springframework.context.support.ClassPathXmlApplicationContext;
-
-/**
- * 
- */
-public class CamelJmsTest extends CamelSpringTestSupport {
-
-    private static final Logger LOG = LoggerFactory.getLogger(CamelJmsTest.class);
-
-    protected String expectedBody = "<hello>world!</hello>";
-
-    @Test
-    public void testSendingViaJmsIsReceivedByCamel() throws Exception {
-        MockEndpoint result = resolveMandatoryEndpoint("mock:result", MockEndpoint.class);
-        result.expectedBodiesReceived(expectedBody);
-        result.message(0).header("foo").isEqualTo("bar");
-
-        // lets create a message
-        Destination destination = getMandatoryBean(Destination.class, "sendTo");
-        ConnectionFactory factory = getMandatoryBean(ConnectionFactory.class, "connectionFactory");
-
-        Connection connection = factory.createConnection();
-        connection.start();
-        Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-        MessageProducer producer = session.createProducer(destination);
-
-        // now lets send a message
-        ObjectMessage message = session.createObjectMessage(expectedBody);
-        message.setStringProperty("foo", "bar");
-        producer.send(message);
-
-        result.assertIsSatisfied();
-
-        LOG.info("Received message: " + result.getReceivedExchanges());
-    }
-
-    @Test
-    public void testConsumingViaJMSReceivesMessageFromCamel() throws Exception {
-        // lets create a message
-        Destination destination = getMandatoryBean(Destination.class, "consumeFrom");
-        ConnectionFactory factory = getMandatoryBean(ConnectionFactory.class, "connectionFactory");
-        ProducerTemplate template = getMandatoryBean(ProducerTemplate.class, "camelTemplate");
-        assertNotNull("template is valid", template);
-
-        Connection connection = factory.createConnection();
-        connection.start();
-        Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-
-        LOG.info("Consuming from: " + destination);
-        MessageConsumer consumer = session.createConsumer(destination);
-
-        // now lets send a message
-        template.sendBody("seda:consumer", expectedBody);
-
-        Message message = consumer.receive(5000);
-        assertNotNull("Should have received a message from destination: " + destination, message);
-
-        TextMessage textMessage = assertIsInstanceOf(TextMessage.class, message);
-        assertEquals("Message body", expectedBody, textMessage.getText());
-
-        LOG.info("Received message: " + message);
-    }
-
-    protected int getExpectedRouteCount() {
-        return 0;
-    }
-
-    @Override
-    protected ClassPathXmlApplicationContext createApplicationContext() {
-        return new ClassPathXmlApplicationContext("org/apache/camel/component/activemq/spring.xml");
-    }
-}
diff --git a/components/camel-activemq/src/test/resources/org/apache/camel/component/activemq/requestReply.xml b/components/camel-activemq/src/test/resources/org/apache/camel/component/activemq/requestReply.xml
deleted file mode 100644
index 40f4e5b..0000000
--- a/components/camel-activemq/src/test/resources/org/apache/camel/component/activemq/requestReply.xml
+++ /dev/null
@@ -1,78 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    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.
-
--->
-<beans xmlns="http://www.springframework.org/schema/beans"
-       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:spring="http://camel.apache.org/schema/spring"
-       xsi:schemaLocation="
-       http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.0.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
-    ">
-
-    <camelContext id="camel" xmlns="http://camel.apache.org/schema/spring">
-
-        <route id="initial-consume-reply1">
-            <from uri="amqPRO:queue:incoming1"/>
-            <to uri="amqPRO:queue:service1?replyToType=Temporary&amp;requestTimeout=35000" pattern="InOut"/>
-            <log message="After inOut via temp: body ${body}"/>
-            <to uri="seda:consumer"/>
-        </route>
-
-        <route id="consume-process-reply1">
-            <from uri="amqCON:queue:service1"/>
-            <choice>
-                <when>
-                    <simple>${body} contains 'What is your name?'</simple>
-                    <transform>
-                        <simple>bobbie!</simple>
-                    </transform>
-                </when>
-                <otherwise>
-                    <transform>
-                        <simple>If you don't ask me my name, I'm not going to tell you!</simple>
-                    </transform>
-                </otherwise>
-            </choice>
-            <log message="${body}"/>
-        </route>
-    </camelContext>
-
-    <bean id="CON" class="org.apache.activemq.spring.ActiveMQConnectionFactory">
-        <property name="brokerURL" value="vm://CON?create=false"/>
-    </bean>
-
-    <bean id="PRO" class="org.apache.activemq.spring.ActiveMQConnectionFactory">
-        <property name="brokerURL" value="vm://PRO??create=false"/>
-    </bean>
-
-    <bean id="consumeFrom" class="org.apache.camel.component.activemq.CamelDestination">
-        <property name="uri" value="seda:consumer"/>
-    </bean>
-
-    <bean id="camelTemplate" class="org.apache.camel.spring.CamelProducerTemplateFactoryBean"/>
-
-    <bean id="amqPRO" class="org.apache.camel.component.activemq.ActiveMQComponent">
-        <property name="brokerURL" value="vm://PRO?create=false"></property>
-    </bean>
-
-    <bean id="amqCON" class="org.apache.camel.component.activemq.ActiveMQComponent">
-        <property name="brokerURL" value="vm://CON?create=false"></property>
-    </bean>
-
-
-</beans>
diff --git a/components/camel-activemq/src/test/resources/org/apache/camel/component/activemq/spring.xml b/components/camel-activemq/src/test/resources/org/apache/camel/component/activemq/spring.xml
deleted file mode 100644
index 2c83301..0000000
--- a/components/camel-activemq/src/test/resources/org/apache/camel/component/activemq/spring.xml
+++ /dev/null
@@ -1,51 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    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.
-
--->
-<beans xmlns="http://www.springframework.org/schema/beans"
-       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-       xsi:schemaLocation="
-       http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.0.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd
-    ">
-
-  <!-- START SNIPPET: example -->
-  <camelContext id="camel" xmlns="http://camel.apache.org/schema/spring"/>
-
-  <bean id="connectionFactory" class="org.apache.activemq.spring.ActiveMQConnectionFactory">
-    <property name="brokerURL" value="vm://localhost?broker.persistent=false"/>
-  </bean>
-
-  <bean id="sendTo" class="org.apache.camel.component.activemq.CamelDestination">
-    <property name="uri" value="mock:result"/>
-  </bean>
-
-  <bean id="consumeFrom" class="org.apache.camel.component.activemq.CamelDestination">
-    <property name="uri" value="seda:consumer"/>
-  </bean>
-
-  <bean id="camelTemplate" class="org.apache.camel.spring.CamelProducerTemplateFactoryBean"/>
-  <!-- END SNIPPET: example -->
-
-<!--
-  <bean id="connectionFactory" class="org.apache.camel.jms.CamelConnectionFactory">
-    <property name="brokerURL" value="vm://localhost?broker.persistent=false"/>
-  </bean>
--->
-
-</beans>
diff --git a/platforms/spring-boot/components-starter/camel-activemq-starter/src/main/java/org/apache/camel/component/activemq/springboot/ActiveMQComponentConfiguration.java b/platforms/spring-boot/components-starter/camel-activemq-starter/src/main/java/org/apache/camel/component/activemq/springboot/ActiveMQComponentConfiguration.java
index f416dfc..fb91826 100644
--- a/platforms/spring-boot/components-starter/camel-activemq-starter/src/main/java/org/apache/camel/component/activemq/springboot/ActiveMQComponentConfiguration.java
+++ b/platforms/spring-boot/components-starter/camel-activemq-starter/src/main/java/org/apache/camel/component/activemq/springboot/ActiveMQComponentConfiguration.java
@@ -53,12 +53,6 @@ public class ActiveMQComponentConfiguration
      */
     private Boolean trustAllPackages = false;
     /**
-     * If enabled this will cause all Queues in the ActiveMQ broker to be
-     * eagerly populated into the CamelContext so that they can be easily
-     * browsed by any Camel tooling. This option is disabled by default.
-     */
-    private Boolean exposeAllQueues = false;
-    /**
      * Enables or disables whether a PooledConnectionFactory will be used so
      * that when messages are sent to ActiveMQ from outside of a message
      * consuming thread, pooling will be used rather than the default with the
@@ -690,14 +684,6 @@ public class ActiveMQComponentConfiguration
         this.trustAllPackages = trustAllPackages;
     }
 
-    public Boolean getExposeAllQueues() {
-        return exposeAllQueues;
-    }
-
-    public void setExposeAllQueues(Boolean exposeAllQueues) {
-        this.exposeAllQueues = exposeAllQueues;
-    }
-
     public Boolean getUsePooledConnection() {
         return usePooledConnection;
     }