You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by or...@apache.org on 2022/04/05 15:01:20 UTC

[camel] branch main updated: CAMEL-17879: remove deprecated legacy XML code from camel-cdi

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

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


The following commit(s) were added to refs/heads/main by this push:
     new 8030077b457 CAMEL-17879: remove deprecated legacy XML code from camel-cdi
8030077b457 is described below

commit 8030077b457b30e8eeef89fe1640a9321c440bd9
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Tue Apr 5 14:56:01 2022 +0200

    CAMEL-17879: remove deprecated legacy XML code from camel-cdi
---
 components/camel-cdi/pom.xml                       |   12 -
 components/camel-cdi/src/main/docs/cdi.adoc        |   79 --
 .../org/apache/camel/cdi/CdiCamelExtension.java    |   24 -
 .../org/apache/camel/cdi/XmlCdiBeanFactory.java    |  462 --------
 .../org/apache/camel/cdi/XmlCdiJaxbContexts.java   |   46 -
 .../camel/cdi/XmlErrorHandlerFactoryBean.java      |  142 ---
 .../camel/cdi/XmlFactoryBeanInjectionTarget.java   |   58 -
 .../cdi/xml/ApplicationContextFactoryBean.java     |  128 ---
 .../org/apache/camel/cdi/xml/BeanManagerAware.java |   26 -
 .../apache/camel/cdi/xml/BeanManagerHelper.java    |   39 -
 .../camel/cdi/xml/CamelContextFactoryBean.java     | 1121 --------------------
 .../camel/cdi/xml/ConsumerTemplateFactoryBean.java |   53 -
 .../cdi/xml/ContextScanRouteBuilderFinder.java     |   86 --
 .../apache/camel/cdi/xml/EndpointFactoryBean.java  |   54 -
 .../camel/cdi/xml/ErrorHandlerDefinition.java      |  199 ----
 .../org/apache/camel/cdi/xml/ErrorHandlerType.java |   58 -
 .../org/apache/camel/cdi/xml/ImportDefinition.java |   43 -
 .../cdi/xml/PackageScanRouteBuilderFinder.java     |   94 --
 .../camel/cdi/xml/ProducerTemplateFactoryBean.java |   62 --
 .../camel/cdi/xml/RedeliveryPolicyFactoryBean.java |   54 -
 .../camel/cdi/xml/RestContextDefinition.java       |   45 -
 .../xml/RouteConfigurationContextDefinition.java   |   45 -
 .../camel/cdi/xml/RouteContextDefinition.java      |   45 -
 .../cdi/xml/RouteTemplateContextDefinition.java    |   45 -
 .../camel/cdi/xml/ThreadPoolFactoryBean.java       |   53 -
 .../org/apache/camel/cdi/xml/package-info.java     |   23 -
 .../src/main/resources/META-INF/beans.xml          |    6 +-
 .../org/apache/camel/cdi/test/XmlBeansTest.java    |   76 --
 .../camel/cdi/test/XmlConsumerTemplateTest.java    |   87 --
 .../org/apache/camel/cdi/test/XmlEndpointTest.java |  109 --
 .../camel/cdi/test/XmlErrorHandlerPolicyTest.java  |  137 ---
 .../apache/camel/cdi/test/XmlErrorHandlerTest.java |  103 --
 .../camel/cdi/test/XmlProducerTemplateTest.java    |   93 --
 .../camel/cdi/test/XmlPropertyPlaceholderTest.java |   60 --
 .../apache/camel/cdi/test/XmlRestContextTest.java  |  103 --
 .../camel/cdi/test/XmlRouteConfigurationTest.java  |   77 --
 .../camel/cdi/test/XmlRouteContextImportTest.java  |   97 --
 .../cdi/test/XmlRouteContextResourceTest.java      |   80 --
 .../test/XmlRouteTemplateContextImportTest.java    |   85 --
 .../camel/cdi/test/XmlRoutesDefinitionTest.java    |   74 --
 .../cdi/test/XmlServiceCallConfigurationTest.java  |   82 --
 .../cdi/test/XmlTemplatedRoutesDefinitionTest.java |   74 --
 .../camel/cdi/test/XmlThreadPoolProfileTest.java   |   79 --
 .../apache/camel/cdi/test/XmlThreadPoolTest.java   |   76 --
 .../src/test/resources/camel-context-beans.xml     |   36 -
 .../src/test/resources/camel-context-consumer.xml  |   32 -
 .../src/test/resources/camel-context-endpoint.xml  |   35 -
 .../camel-context-errorHandler-policy.xml          |   48 -
 .../test/resources/camel-context-errorHandler.xml  |   51 -
 .../src/test/resources/camel-context-export.xml    |   31 -
 .../src/test/resources/camel-context-multiples.xml |   39 -
 .../src/test/resources/camel-context-producer.xml  |   32 -
 .../test/resources/camel-context-properties.xml    |   27 -
 .../src/test/resources/camel-context-proxy.xml     |   36 -
 .../test/resources/camel-context-restContext.xml   |   31 -
 .../resources/camel-context-restContextRef.xml     |   35 -
 .../resources/camel-context-routeConfiguration.xml |   49 -
 .../test/resources/camel-context-routeContext.xml  |   32 -
 .../camel-context-routeContextRef-import.xml       |   41 -
 .../resources/camel-context-routeContextRef.xml    |   42 -
 ...amel-context-routeContextTemplateRef-import.xml |   33 -
 .../camel-context-routeTemplateContext.xml         |   38 -
 .../src/test/resources/camel-context-routes.xml    |   30 -
 .../camel-context-service-call-configuration.xml   |   54 -
 .../resources/camel-context-templated-routes.xml   |   43 -
 .../test/resources/camel-context-threadPool.xml    |   42 -
 .../resources/camel-context-threadPoolProfile.xml  |   41 -
 67 files changed, 1 insertion(+), 5471 deletions(-)

diff --git a/components/camel-cdi/pom.xml b/components/camel-cdi/pom.xml
index 64373512db0..385d39c4a71 100644
--- a/components/camel-cdi/pom.xml
+++ b/components/camel-cdi/pom.xml
@@ -84,18 +84,6 @@
             <optional>true</optional>
         </dependency>
 
-        <!-- deprecated xml -->
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-core-xml</artifactId>
-            <optional>true</optional>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-xml-jaxb</artifactId>
-            <optional>true</optional>
-        </dependency>
-
         <!-- test dependencies -->
         <dependency>
             <groupId>org.apache.camel</groupId>
diff --git a/components/camel-cdi/src/main/docs/cdi.adoc b/components/camel-cdi/src/main/docs/cdi.adoc
index d7da77ce61f..1a4bc0211dd 100644
--- a/components/camel-cdi/src/main/docs/cdi.adoc
+++ b/components/camel-cdi/src/main/docs/cdi.adoc
@@ -612,85 +612,6 @@ endpoint instances and the observer methods as the CDI container doesn't
 have any ways of discovering the Camel context model during the
 deployment phase.
 
-== Camel XML configuration import (deprecated)
-
-WARNING: Using Camel XML in camel-cdi is deprecated and will be removed in the future.
-
-While CDI favors a typesafe dependency injection mechanism, it may be
-useful to reuse existing Camel XML configuration files into a Camel CDI
-application. In other use cases, it might be handy to rely on the Camel
-XML DSL to configure its Camel context(s).
-
-You can use the `@ImportResource` annotation that's provided by Camel
-CDI on any CDI beans and Camel CDI will automatically load the Camel XML
-configuration at the specified locations, e.g.:
-
-[source,java]
-----
-@ImportResource("camel-context.xml")
-class MyBean {
-}
-----
-
-Camel CDI will load the resources at the specified locations from the
-classpath (other protocols may be added in the future).
-
-Every `CamelContext` elements and other Camel _primitives_ from the
-imported resources are automatically deployed as CDI beans during the
-container bootstrap so that they benefit from the auto-configuration
-provided by Camel CDI and become available for injection at runtime. If
-such an element has an explicit `id` attribute set, the corresponding
-CDI bean is qualified with the `@Named` qualifier, e.g., given the
-following Camel XML configuration:
-
-[source,xml]
-----
-<camelContext id="foo">
-    <endpoint id="bar" uri="seda:inbound">
-        <property key="queue" value="#queue"/>
-        <property key="concurrentConsumers" value="10"/>
-    </endpoint>
-<camelContext/>
-----
-
-The corresponding CDI beans are automatically deployed and can be
-injected, e.g.:
-
-[source,java]
-----
-@Inject
-CamelContext context;
-
-@Inject
-@Named("bar")
-Endpoint endpoint;
-----
-
-Conversely, CDI beans deployed in the application can be referred to
-from the Camel XML configuration, usually using the `ref` attribute,
-e.g., given the following bean declared:
-
-[source,java]
-----
-@Produces
-@Named("baz")
-Processor processor = exchange -> exchange.getIn().setHeader("qux", "quux");
-----
-
-A reference to that bean can be declared in the imported Camel XML
-configuration, e.g.:
-
-[source,xml]
-----
-<camelContext id="foo">
-    <route>
-        <from uri="..."/>
-        <process ref="baz"/>
-    </route>
-<camelContext/>
-----
-
-
 == Transaction support
 
 NOTE: You must add camel-cdi-jta JAR as dependency for Camel CDI transaction support.
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/CdiCamelExtension.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/CdiCamelExtension.java
index af84376795c..0953d9de5f8 100644
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/CdiCamelExtension.java
+++ b/components/camel-cdi/src/main/java/org/apache/camel/cdi/CdiCamelExtension.java
@@ -95,7 +95,6 @@ import static org.apache.camel.cdi.CdiSpiHelper.hasAnnotation;
 import static org.apache.camel.cdi.CdiSpiHelper.hasType;
 import static org.apache.camel.cdi.CdiSpiHelper.isAnnotationType;
 import static org.apache.camel.cdi.Excluded.EXCLUDED;
-import static org.apache.camel.cdi.ResourceHelper.getResource;
 import static org.apache.camel.cdi.Startup.Literal.STARTUP;
 
 public class CdiCamelExtension implements Extension {
@@ -252,29 +251,6 @@ public class CdiCamelExtension implements Extension {
         // The set of extra Camel CDI beans
         Set<SyntheticBean<?>> extraBeans = new HashSet<>();
 
-        // Add beans from Camel XML resources
-        for (Map.Entry<AnnotatedType<?>, ImportResource> entry : resources.entrySet()) {
-            AnnotatedType<?> annotatedType = entry.getKey();
-            XmlCdiBeanFactory factory = XmlCdiBeanFactory.with(manager, environment, this);
-            ImportResource resource = entry.getValue();
-            for (String path : resource.value()) {
-                try {
-                    extraBeans.addAll(factory.beansFrom(path, annotatedType));
-                } catch (NoClassDefFoundError cause) {
-                    if (cause.getMessage().contains("AbstractCamelContextFactoryBean")) {
-                        logger.error("Importing Camel XML requires to have the 'camel-core-xml' dependency in the classpath!");
-                    }
-                    throw cause;
-                } catch (Exception cause) {
-                    abd.addDefinitionError(
-                            new InjectionException(
-                                    "Error while importing resource ["
-                                                   + getResource(path, annotatedType.getJavaClass().getClassLoader()) + "]",
-                                    cause));
-                }
-            }
-        }
-
         // Camel contexts from the imported Camel XML
         concat(cdiBeans.stream(), extraBeans.stream())
                 .filter(hasType(CamelContext.class))
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlCdiBeanFactory.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlCdiBeanFactory.java
deleted file mode 100644
index 705429e57ce..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlCdiBeanFactory.java
+++ /dev/null
@@ -1,462 +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.cdi;
-
-import java.io.IOException;
-import java.io.InputStream;
-import java.lang.annotation.Annotation;
-import java.net.URL;
-import java.util.HashSet;
-import java.util.List;
-import java.util.Set;
-import java.util.stream.Stream;
-
-import javax.enterprise.inject.Any;
-import javax.enterprise.inject.CreationException;
-import javax.enterprise.inject.Default;
-import javax.enterprise.inject.Vetoed;
-import javax.enterprise.inject.spi.AnnotatedType;
-import javax.enterprise.inject.spi.Bean;
-import javax.enterprise.inject.spi.BeanManager;
-import javax.xml.bind.JAXBException;
-
-import org.apache.camel.cdi.xml.ApplicationContextFactoryBean;
-import org.apache.camel.cdi.xml.BeanManagerAware;
-import org.apache.camel.cdi.xml.CamelContextFactoryBean;
-import org.apache.camel.cdi.xml.ErrorHandlerDefinition;
-import org.apache.camel.cdi.xml.ErrorHandlerType;
-import org.apache.camel.cdi.xml.ImportDefinition;
-import org.apache.camel.cdi.xml.RestContextDefinition;
-import org.apache.camel.cdi.xml.RouteConfigurationContextDefinition;
-import org.apache.camel.cdi.xml.RouteContextDefinition;
-import org.apache.camel.cdi.xml.RouteTemplateContextDefinition;
-import org.apache.camel.core.xml.AbstractCamelFactoryBean;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.apache.camel.model.IdentifiedType;
-import org.apache.camel.model.OptionalIdentifiedDefinition;
-import org.apache.camel.model.RouteConfigurationDefinition;
-import org.apache.camel.model.RouteDefinition;
-import org.apache.camel.model.RouteTemplateDefinition;
-import org.apache.camel.model.RoutesDefinition;
-import org.apache.camel.model.rest.RestDefinition;
-import org.apache.camel.util.ObjectHelper;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-import static java.lang.String.format;
-import static java.util.Collections.*;
-import static java.util.Objects.requireNonNull;
-import static java.util.stream.Collectors.toSet;
-import static org.apache.camel.cdi.ApplicationScopedLiteral.APPLICATION_SCOPED;
-import static org.apache.camel.cdi.CdiSpiHelper.createCamelContextWithTCCL;
-import static org.apache.camel.cdi.ResourceHelper.getResource;
-import static org.apache.camel.util.ObjectHelper.isNotEmpty;
-
-@Vetoed
-@Deprecated
-final class XmlCdiBeanFactory {
-
-    private final Logger logger = LoggerFactory.getLogger(XmlCdiBeanFactory.class);
-
-    private final BeanManager manager;
-
-    private final CdiCamelEnvironment environment;
-
-    private final CdiCamelExtension extension;
-
-    private XmlCdiBeanFactory(BeanManager manager, CdiCamelEnvironment environment, CdiCamelExtension extension) {
-        this.manager = manager;
-        this.environment = environment;
-        this.extension = extension;
-    }
-
-    static XmlCdiBeanFactory with(BeanManager manager, CdiCamelEnvironment environment, CdiCamelExtension extension) {
-        return new XmlCdiBeanFactory(manager, environment, extension);
-    }
-
-    Set<SyntheticBean<?>> beansFrom(String path, AnnotatedType<?> annotatedType) throws JAXBException, IOException {
-        URL url = getResource(path, annotatedType.getJavaClass().getClassLoader());
-        if (url == null) {
-            logger.warn("Unable to locate resource [{}] for import!", path);
-            return emptySet();
-        }
-        return beansFrom(url, annotatedType);
-    }
-
-    Set<SyntheticBean<?>> beansFrom(URL url, AnnotatedType<?> annotatedType) throws JAXBException, IOException {
-        try (InputStream xml = url.openStream()) {
-            Object node = XmlCdiJaxbContexts.CAMEL_CDI.instance()
-                    .createUnmarshaller()
-                    .unmarshal(xml);
-            if (node instanceof RoutesDefinition) {
-                RoutesDefinition routes = (RoutesDefinition) node;
-                return singleton(routesDefinitionBean(routes, url));
-            } else if (node instanceof ApplicationContextFactoryBean) {
-                ApplicationContextFactoryBean app = (ApplicationContextFactoryBean) node;
-                Set<SyntheticBean<?>> beans = new HashSet<>();
-                for (CamelContextFactoryBean factory : app.getContexts()) {
-                    SyntheticBean<?> bean = camelContextBean(factory, url, annotatedType);
-                    beans.add(bean);
-                    beans.addAll(camelContextBeans(factory, bean, url));
-                }
-                for (ErrorHandlerDefinition definition : app.getErrorHandlers()) {
-                    beans.add(errorHandlerBean(definition, url));
-                }
-                for (ImportDefinition definition : app.getImports()) {
-                    // Get the base URL as imports are relative to this
-                    String path = url.getFile().substring(0, url.getFile().lastIndexOf('/'));
-                    String base = url.getProtocol() + "://" + url.getHost() + path;
-                    beans.addAll(beansFrom(base + "/" + definition.getResource(), annotatedType));
-                }
-                for (RestContextDefinition factory : app.getRestContexts()) {
-                    beans.add(restContextBean(factory, url));
-                }
-                for (RouteContextDefinition factory : app.getRouteContexts()) {
-                    beans.add(routeContextBean(factory, url));
-                }
-                for (RouteConfigurationContextDefinition factory : app.getRouteConfigurationContexts()) {
-                    beans.add(routeConfigurationContextBean(factory, url));
-                }
-                for (RouteTemplateContextDefinition factory : app.getRouteTemplateContexts()) {
-                    beans.add(routeTemplateContextBean(factory, url));
-                }
-                for (AbstractCamelFactoryBean<?> factory : app.getBeans()) {
-                    if (hasId(factory)) {
-                        beans.add(camelContextBean(null, factory, url));
-                    }
-                }
-                return beans;
-            } else if (node instanceof CamelContextFactoryBean) {
-                CamelContextFactoryBean factory = (CamelContextFactoryBean) node;
-                Set<SyntheticBean<?>> beans = new HashSet<>();
-                SyntheticBean<?> bean = camelContextBean(factory, url, annotatedType);
-                beans.add(bean);
-                beans.addAll(camelContextBeans(factory, bean, url));
-                return beans;
-            } else if (node instanceof RestContextDefinition) {
-                RestContextDefinition factory = (RestContextDefinition) node;
-                return singleton(restContextBean(factory, url));
-            } else if (node instanceof RouteContextDefinition) {
-                RouteContextDefinition factory = (RouteContextDefinition) node;
-                return singleton(routeContextBean(factory, url));
-            } else if (node instanceof RouteTemplateContextDefinition) {
-                RouteTemplateContextDefinition factory = (RouteTemplateContextDefinition) node;
-                return singleton(routeTemplateContextBean(factory, url));
-            }
-        }
-        return emptySet();
-    }
-
-    private SyntheticBean<?> camelContextBean(CamelContextFactoryBean factory, URL url, AnnotatedType annotatedType) {
-        Set<Annotation> annotations = new HashSet<>();
-        annotations.add(Any.Literal.INSTANCE);
-        if (hasId(factory)) {
-            addAll(annotations, NamedLiteral.of(factory.getId()));
-        } else {
-            annotations.add(Default.Literal.INSTANCE);
-            factory.setImplicitId(true);
-            factory.setId(new CdiCamelContextNameStrategy().getNextName());
-        }
-
-        annotations.add(APPLICATION_SCOPED);
-        SyntheticAnnotated annotated = new SyntheticAnnotated(
-                DefaultCamelContext.class,
-                manager.createAnnotatedType(DefaultCamelContext.class).getTypeClosure(),
-                annotatedType.getJavaClass(),
-                annotations);
-
-        return new SyntheticBean<>(
-                manager, annotated, DefaultCamelContext.class,
-                environment.camelContextInjectionTarget(
-                        new SyntheticInjectionTarget<>(() -> {
-                            DefaultCamelContext context = createCamelContextWithTCCL(DefaultCamelContext::new, annotated);
-                            factory.setContext(context);
-                            factory.setBeanManager(manager);
-                            return context;
-                        }, context -> {
-                            try {
-                                factory.afterPropertiesSet();
-                            } catch (Exception cause) {
-                                throw new CreationException(cause);
-                            }
-                        }),
-                        annotated, manager, extension),
-                bean -> "imported Camel context with "
-                        + (factory.isImplicitId() ? "implicit " : "")
-                        + "id [" + factory.getId() + "] "
-                        + "from resource [" + url + "] "
-                        + "with qualifiers " + bean.getQualifiers());
-    }
-
-    private Set<SyntheticBean<?>> camelContextBeans(CamelContextFactoryBean factory, Bean<?> context, URL url) {
-        Set<SyntheticBean<?>> beans = new HashSet<>();
-
-        // TODO: WARN log if the definition doesn't have an id
-        if (factory.getBeansFactory() != null) {
-            factory.getBeansFactory().stream()
-                    .filter(XmlCdiBeanFactory::hasId)
-                    .map(bean -> camelContextBean(context, bean, url))
-                    .forEach(beans::add);
-        }
-
-        // TODO: define in beans
-        if (factory.getEndpoints() != null) {
-            factory.getEndpoints().stream()
-                    .filter(XmlCdiBeanFactory::hasId)
-                    .map(endpoint -> camelContextBean(context, endpoint, url))
-                    .forEach(beans::add);
-        }
-
-        if (factory.getErrorHandlers() != null) {
-            factory.getErrorHandlers().stream()
-                    .filter(XmlCdiBeanFactory::hasId)
-                    .map(handler -> errorHandlerBean(handler, url))
-                    .forEach(beans::add);
-        }
-
-        // TODO: define in beans
-        if (factory.getRedeliveryPolicies() != null) {
-            factory.getRedeliveryPolicies().stream()
-                    .filter(XmlCdiBeanFactory::hasId)
-                    .map(policy -> camelContextBean(context, policy, url))
-                    .forEach(beans::add);
-        }
-
-        return beans;
-    }
-
-    private SyntheticBean<?> camelContextBean(Bean<?> context, AbstractCamelFactoryBean<?> factory, URL url) {
-        if (factory instanceof BeanManagerAware) {
-            ((BeanManagerAware) factory).setBeanManager(manager);
-        }
-
-        Set<Annotation> annotations = new HashSet<>();
-        annotations.add(Any.Literal.INSTANCE);
-        annotations.add(hasId(factory) ? NamedLiteral.of(factory.getId()) : Default.Literal.INSTANCE);
-
-        // TODO: should that be @Singleton to enable injection points with bean instance type?
-        if (factory.isSingleton()) {
-            annotations.add(APPLICATION_SCOPED);
-        }
-
-        return new SyntheticBean<>(
-                manager,
-                new SyntheticAnnotated(
-                        factory.getObjectType(),
-                        manager.createAnnotatedType(factory.getObjectType()).getTypeClosure(),
-                        annotations),
-                factory.getObjectType(),
-                new XmlFactoryBeanInjectionTarget<>(manager, factory, context),
-                bean -> "imported bean [" + factory.getId() + "] "
-                        + "from resource [" + url + "] "
-                        + "with qualifiers " + bean.getQualifiers());
-    }
-
-    private SyntheticBean<?> restContextBean(RestContextDefinition definition, URL url) {
-        requireNonNull(definition.getId(),
-                () -> format("Missing [%s] attribute for imported bean [%s] from resource [%s]",
-                        "id", "restContext", url));
-
-        return new SyntheticBean<>(
-                manager,
-                new SyntheticAnnotated(
-                        List.class,
-                        Stream.of(List.class, new ListParameterizedType(RestDefinition.class))
-                                .collect(toSet()),
-                        Any.Literal.INSTANCE, NamedLiteral.of(definition.getId())),
-                List.class,
-                new SyntheticInjectionTarget<>(definition::getRests), bean -> "imported rest context with "
-                                                                              + "id [" + definition.getId() + "] "
-                                                                              + "from resource [" + url + "] "
-                                                                              + "with qualifiers " + bean.getQualifiers());
-    }
-
-    private SyntheticBean<?> routeTemplateContextBean(RouteTemplateContextDefinition definition, URL url) {
-        requireNonNull(definition.getId(),
-                () -> format("Missing [%s] attribute for imported bean [%s] from resource [%s]",
-                        "id", "routeContext", url));
-
-        return new SyntheticBean<>(
-                manager,
-                new SyntheticAnnotated(
-                        List.class,
-                        Stream.of(List.class, new ListParameterizedType(RouteTemplateDefinition.class))
-                                .collect(toSet()),
-                        Any.Literal.INSTANCE, NamedLiteral.of(definition.getId())),
-                List.class,
-                new SyntheticInjectionTarget<>(definition::getRouteTemplates), bean -> "imported route template context with "
-                                                                                       + "id [" + definition.getId() + "] "
-                                                                                       + "from resource [" + url + "] "
-                                                                                       + "with qualifiers "
-                                                                                       + bean.getQualifiers());
-    }
-
-    private SyntheticBean<?> routeConfigurationContextBean(RouteConfigurationContextDefinition definition, URL url) {
-        requireNonNull(definition.getId(),
-                () -> format("Missing [%s] attribute for imported bean [%s] from resource [%s]",
-                        "id", "routeContext", url));
-
-        return new SyntheticBean<>(
-                manager,
-                new SyntheticAnnotated(
-                        List.class,
-                        Stream.of(List.class, new ListParameterizedType(RouteConfigurationDefinition.class))
-                                .collect(toSet()),
-                        Any.Literal.INSTANCE, NamedLiteral.of(definition.getId())),
-                List.class,
-                new SyntheticInjectionTarget<>(definition::getRouteConfigurations),
-                bean -> "imported route configuration context with "
-                        + "id [" + definition.getId() + "] "
-                        + "from resource [" + url + "] "
-                        + "with qualifiers "
-                        + bean.getQualifiers());
-    }
-
-    private SyntheticBean<?> routeContextBean(RouteContextDefinition definition, URL url) {
-        requireNonNull(definition.getId(),
-                () -> format("Missing [%s] attribute for imported bean [%s] from resource [%s]",
-                        "id", "routeContext", url));
-
-        return new SyntheticBean<>(
-                manager,
-                new SyntheticAnnotated(
-                        List.class,
-                        Stream.of(List.class, new ListParameterizedType(RouteDefinition.class))
-                                .collect(toSet()),
-                        Any.Literal.INSTANCE, NamedLiteral.of(definition.getId())),
-                List.class,
-                new SyntheticInjectionTarget<>(definition::getRoutes), bean -> "imported route context with "
-                                                                               + "id [" + definition.getId() + "] "
-                                                                               + "from resource [" + url + "] "
-                                                                               + "with qualifiers " + bean.getQualifiers());
-    }
-
-    private SyntheticBean<?> routesDefinitionBean(RoutesDefinition definition, URL url) {
-        return new SyntheticBean<>(
-                manager,
-                // TODO: should be @Named if the id is set
-                new SyntheticAnnotated(
-                        RoutesDefinition.class,
-                        manager.createAnnotatedType(RoutesDefinition.class).getTypeClosure(),
-                        Any.Literal.INSTANCE, Default.Literal.INSTANCE),
-                RoutesDefinition.class,
-                new SyntheticInjectionTarget<>(() -> definition), bean -> "imported routes definition "
-                                                                          + (hasId(definition)
-                                                                                  ? "[" + definition.getId() + "] " : "")
-                                                                          + "from resource [" + url + "]");
-    }
-
-    private SyntheticBean<?> errorHandlerBean(ErrorHandlerDefinition definition, URL url) {
-        ErrorHandlerType type = definition.getType();
-
-        // Validate attributes according to type
-        if (isNotEmpty(definition.getDeadLetterUri())
-                && !type.equals(ErrorHandlerType.DeadLetterChannel)) {
-            throw attributeNotSupported("deadLetterUri", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getDeadLetterHandleNewException())
-                && !type.equals(ErrorHandlerType.DeadLetterChannel)) {
-            throw attributeNotSupported("deadLetterHandleNewException", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getTransactionTemplateRef())
-                && !type.equals(ErrorHandlerType.TransactionErrorHandler)) {
-            throw attributeNotSupported("transactionTemplateRef", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getTransactionManagerRef())
-                && !type.equals(ErrorHandlerType.TransactionErrorHandler)) {
-            throw attributeNotSupported("transactionManagerRef", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getRollbackLoggingLevel())
-                && !type.equals(ErrorHandlerType.TransactionErrorHandler)) {
-            throw attributeNotSupported("rollbackLoggingLevel", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getUseOriginalMessage())
-                && type.equals(ErrorHandlerType.NoErrorHandler)) {
-            throw attributeNotSupported("useOriginalMessage", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getUseOriginalBody())
-                && type.equals(ErrorHandlerType.NoErrorHandler)) {
-            throw attributeNotSupported("useOriginalBody", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getOnRedeliveryRef())
-                && type.equals(ErrorHandlerType.NoErrorHandler)) {
-            throw attributeNotSupported("onRedeliveryRef", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getOnExceptionOccurredRef())
-                && type.equals(ErrorHandlerType.NoErrorHandler)) {
-            throw attributeNotSupported("onExceptionOccurredRef", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getOnPrepareFailureRef())
-                && (type.equals(ErrorHandlerType.TransactionErrorHandler)
-                        || type.equals(ErrorHandlerType.NoErrorHandler))) {
-            throw attributeNotSupported("onPrepareFailureRef", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getRetryWhileRef())
-                && type.equals(ErrorHandlerType.NoErrorHandler)) {
-            throw attributeNotSupported("retryWhileRef", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getOnRedeliveryRef())
-                && type.equals(ErrorHandlerType.NoErrorHandler)) {
-            throw attributeNotSupported("redeliveryPolicyRef", type, definition.getId());
-        }
-
-        if (isNotEmpty(definition.getExecutorServiceRef())
-                && type.equals(ErrorHandlerType.NoErrorHandler)) {
-            throw attributeNotSupported("executorServiceRef", type, definition.getId());
-        }
-
-        String fqn = type.getTypeAsClass();
-        final Class<?> clazz = ObjectHelper.loadClass(fqn);
-
-        return new XmlErrorHandlerFactoryBean(
-                manager,
-                new SyntheticAnnotated(
-                        clazz,
-                        manager.createAnnotatedType(clazz).getTypeClosure(),
-                        Any.Literal.INSTANCE, NamedLiteral.of(definition.getId())),
-                clazz, bean -> "imported error handler with "
-                               + "id [" + definition.getId() + "] "
-                               + "from resource [" + url + "] "
-                               + "with qualifiers " + bean.getQualifiers(),
-                definition);
-    }
-
-    private static CreationException attributeNotSupported(String attribute, ErrorHandlerType type, String id) {
-        return new CreationException(
-                format("Attribute [%s] is not supported by error handler type [%s], in error handler with id [%s]",
-                        attribute, type, id));
-    }
-
-    private static <T extends IdentifiedType> boolean hasId(T type) {
-        return isNotEmpty(type.getId());
-    }
-
-    private static <T extends OptionalIdentifiedDefinition<T>> boolean hasId(T type) {
-        return isNotEmpty(type.getId());
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlCdiJaxbContexts.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlCdiJaxbContexts.java
deleted file mode 100644
index c75055af684..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlCdiJaxbContexts.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.cdi;
-
-import java.util.Arrays;
-
-import javax.xml.bind.JAXBContext;
-import javax.xml.bind.JAXBException;
-
-import org.apache.camel.cdi.xml.ApplicationContextFactoryBean;
-import org.apache.camel.model.Constants;
-
-@Deprecated
-enum XmlCdiJaxbContexts {
-
-    CAMEL_CDI(Constants.JAXB_CONTEXT_PACKAGES, ApplicationContextFactoryBean.class.getPackage().getName());
-
-    private final JAXBContext context;
-
-    XmlCdiJaxbContexts(String... packages) {
-        try {
-            context = JAXBContext.newInstance(String.join(":", packages));
-        } catch (JAXBException cause) {
-            throw new IllegalStateException(
-                    "Error while creating JAXB context for packages " + Arrays.toString(packages), cause);
-        }
-    }
-
-    JAXBContext instance() {
-        return context;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlErrorHandlerFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlErrorHandlerFactoryBean.java
deleted file mode 100644
index a36f8b11242..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlErrorHandlerFactoryBean.java
+++ /dev/null
@@ -1,142 +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.cdi;
-
-import java.util.function.Function;
-
-import javax.enterprise.context.spi.CreationalContext;
-import javax.enterprise.inject.CreationException;
-import javax.enterprise.inject.UnsatisfiedResolutionException;
-import javax.enterprise.inject.Vetoed;
-import javax.enterprise.inject.spi.Bean;
-import javax.enterprise.inject.spi.BeanManager;
-
-import org.apache.camel.Processor;
-import org.apache.camel.builder.DefaultErrorHandlerBuilder;
-import org.apache.camel.builder.ErrorHandlerBuilder;
-import org.apache.camel.cdi.xml.ErrorHandlerDefinition;
-import org.apache.camel.cdi.xml.RedeliveryPolicyFactoryBean;
-import org.apache.camel.processor.errorhandler.RedeliveryPolicy;
-import org.apache.camel.util.ObjectHelper;
-
-import static java.lang.Boolean.parseBoolean;
-import static java.lang.String.format;
-import static java.util.Objects.nonNull;
-import static org.apache.camel.cdi.BeanManagerHelper.getReferenceByName;
-import static org.apache.camel.util.ObjectHelper.isNotEmpty;
-
-@Vetoed
-@Deprecated
-final class XmlErrorHandlerFactoryBean extends SyntheticBean<ErrorHandlerBuilder> {
-
-    private final BeanManager manager;
-
-    private final ErrorHandlerDefinition handler;
-
-    XmlErrorHandlerFactoryBean(BeanManager manager, SyntheticAnnotated annotated, Class<?> type,
-                               Function<Bean<ErrorHandlerBuilder>, String> toString, ErrorHandlerDefinition handler) {
-        super(manager, annotated, type, null, toString);
-        this.manager = manager;
-        this.handler = handler;
-    }
-
-    @Override
-    public ErrorHandlerBuilder create(CreationalContext<ErrorHandlerBuilder> creationalContext) {
-        try {
-            String fqn = handler.getType().getTypeAsClass();
-            Class<?> clazz = ObjectHelper.loadClass(fqn);
-            ErrorHandlerBuilder builder = (ErrorHandlerBuilder) clazz.newInstance();
-
-            switch (handler.getType()) {
-                case DefaultErrorHandler:
-                case DeadLetterChannel:
-                    setProperties((DefaultErrorHandlerBuilder) builder);
-                    break;
-                case NoErrorHandler:
-                    // No configuration required
-                    break;
-                case TransactionErrorHandler:
-                    break;
-                default:
-                    break;
-            }
-
-            return builder;
-        } catch (Exception cause) {
-            throw new CreationException("Error while creating instance for " + this, cause);
-        }
-    }
-
-    @Override
-    public void destroy(ErrorHandlerBuilder instance, CreationalContext<ErrorHandlerBuilder> creationalContext) {
-        // NOOP
-    }
-
-    private void setProperties(DefaultErrorHandlerBuilder builder) throws Exception {
-        if (nonNull(handler.getDeadLetterHandleNewException())) {
-            builder.setDeadLetterHandleNewException(Boolean.parseBoolean(handler.getDeadLetterHandleNewException()));
-        }
-        builder.setDeadLetterUri(handler.getDeadLetterUri());
-        builder.setExecutorServiceRef(handler.getExecutorServiceRef());
-        builder.setRetryWhileRef(handler.getRetryWhileRef());
-        if (nonNull(handler.getUseOriginalMessage())) {
-            builder.setUseOriginalMessage(parseBoolean(handler.getUseOriginalMessage()));
-        }
-        if (nonNull(handler.getUseOriginalBody())) {
-            builder.setUseOriginalBody(Boolean.parseBoolean(handler.getUseOriginalBody()));
-        }
-
-        if (isNotEmpty(handler.getOnExceptionOccurredRef())) {
-            Processor processor = getReferenceByName(manager, handler.getOnExceptionOccurredRef(), Processor.class)
-                    .orElseThrow(() -> new UnsatisfiedResolutionException(
-                            format("No bean with name [%s] to satisfy attribute [%s]",
-                                    handler.getOnPrepareFailureRef(), "onExceptionOccurredRef")));
-            builder.setOnExceptionOccurred(processor);
-        }
-
-        if (isNotEmpty(handler.getOnPrepareFailureRef())) {
-            Processor processor = getReferenceByName(manager, handler.getOnPrepareFailureRef(), Processor.class)
-                    .orElseThrow(() -> new UnsatisfiedResolutionException(
-                            format("No bean with name [%s] to satisfy attribute [%s]",
-                                    handler.getOnPrepareFailureRef(), "onPrepareFailureRef")));
-            builder.setOnPrepareFailure(processor);
-        }
-
-        if (isNotEmpty(handler.getOnRedeliveryRef())) {
-            Processor processor = getReferenceByName(manager, handler.getOnRedeliveryRef(), Processor.class)
-                    .orElseThrow(() -> new UnsatisfiedResolutionException(
-                            format("No bean with name [%s] to satisfy attribute [%s]",
-                                    handler.getOnPrepareFailureRef(), "onRedeliveryRef")));
-            builder.setOnRedelivery(processor);
-        }
-
-        if (nonNull(handler.getRedeliveryPolicy())) {
-            RedeliveryPolicyFactoryBean policy = handler.getRedeliveryPolicy();
-            policy.setBeanManager(manager);
-            builder.setRedeliveryPolicy(policy.getObject());
-        }
-
-        if (isNotEmpty(handler.getRedeliveryPolicyRef())) {
-            RedeliveryPolicy policy = getReferenceByName(manager, handler.getRedeliveryPolicyRef(), RedeliveryPolicy.class)
-                    .orElseThrow(() -> new UnsatisfiedResolutionException(
-                            format("No bean with name [%s] to satisfy attribute [%s]",
-                                    handler.getRedeliveryPolicyRef(), "redeliveryPolicyRef")));
-            builder.setRedeliveryPolicy(policy);
-        }
-    }
-
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlFactoryBeanInjectionTarget.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlFactoryBeanInjectionTarget.java
deleted file mode 100644
index 172a6518906..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/XmlFactoryBeanInjectionTarget.java
+++ /dev/null
@@ -1,58 +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.cdi;
-
-import javax.enterprise.inject.CreationException;
-import javax.enterprise.inject.InjectionException;
-import javax.enterprise.inject.Vetoed;
-import javax.enterprise.inject.spi.Bean;
-import javax.enterprise.inject.spi.BeanManager;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.core.xml.AbstractCamelFactoryBean;
-
-import static org.apache.camel.cdi.BeanManagerHelper.getReference;
-import static org.apache.camel.util.ObjectHelper.isEmpty;
-
-@Vetoed
-@Deprecated
-final class XmlFactoryBeanInjectionTarget<T> extends SyntheticInjectionTarget<T> {
-
-    XmlFactoryBeanInjectionTarget(BeanManager manager, AbstractCamelFactoryBean<T> factory, Bean<?> context) {
-        super(
-              () -> {
-                  try {
-                      if (isEmpty(factory.getCamelContextId()) && context != null) {
-                          factory.setCamelContext(getReference(manager, CamelContext.class, context));
-                      }
-                      factory.afterPropertiesSet();
-                      return factory.getObject();
-                  } catch (Exception cause) {
-                      throw new CreationException(cause);
-                  }
-              },
-              i -> {
-              },
-              i -> {
-                  try {
-                      factory.destroy();
-                  } catch (Exception cause) {
-                      throw new InjectionException(cause);
-                  }
-              });
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ApplicationContextFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ApplicationContextFactoryBean.java
deleted file mode 100644
index 54aea4de427..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ApplicationContextFactoryBean.java
+++ /dev/null
@@ -1,128 +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.cdi.xml;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElements;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.core.xml.AbstractCamelFactoryBean;
-
-@XmlRootElement(name = "beans", namespace = "http://www.springframework.org/schema/beans")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class ApplicationContextFactoryBean {
-
-    @XmlElement(name = "camelContext")
-    private List<CamelContextFactoryBean> contexts = new ArrayList<>();
-
-    @XmlElement(name = "errorHandler")
-    private List<ErrorHandlerDefinition> errorHandlers = new ArrayList<>();
-
-    @XmlElement(name = "import")
-    private List<ImportDefinition> imports = new ArrayList<>();
-
-    @XmlElement(name = "routeConfigurationContext")
-    private List<RouteConfigurationContextDefinition> routeConfigurationContexts = new ArrayList<>();
-
-    @XmlElement(name = "restContext")
-    private List<RestContextDefinition> restContexts = new ArrayList<>();
-
-    @XmlElement(name = "routeTemplateContext")
-    private List<RouteTemplateContextDefinition> routeTemplateContexts = new ArrayList<>();
-
-    @XmlElement(name = "routeContext")
-    private List<RouteContextDefinition> routeContexts = new ArrayList<>();
-
-    @XmlElements({
-            @XmlElement(name = "consumerTemplate", type = ConsumerTemplateFactoryBean.class),
-            @XmlElement(name = "endpoint", type = EndpointFactoryBean.class),
-            @XmlElement(name = "redeliveryPolicyProfile", type = RedeliveryPolicyFactoryBean.class),
-            @XmlElement(name = "template", type = ProducerTemplateFactoryBean.class),
-            @XmlElement(name = "threadPool", type = ThreadPoolFactoryBean.class)
-    })
-    private List<AbstractCamelFactoryBean<?>> beans = new ArrayList<>();
-
-    public List<CamelContextFactoryBean> getContexts() {
-        return contexts;
-    }
-
-    public void setContexts(List<CamelContextFactoryBean> contexts) {
-        this.contexts = contexts;
-    }
-
-    public List<ErrorHandlerDefinition> getErrorHandlers() {
-        return errorHandlers;
-    }
-
-    public void setErrorHandlers(List<ErrorHandlerDefinition> errorHandlers) {
-        this.errorHandlers = errorHandlers;
-    }
-
-    public List<ImportDefinition> getImports() {
-        return imports;
-    }
-
-    public void setImports(List<ImportDefinition> imports) {
-        this.imports = imports;
-    }
-
-    public List<RestContextDefinition> getRestContexts() {
-        return restContexts;
-    }
-
-    public void setRestContexts(List<RestContextDefinition> restContexts) {
-        this.restContexts = restContexts;
-    }
-
-    public List<RouteContextDefinition> getRouteContexts() {
-        return routeContexts;
-    }
-
-    public void setRouteContexts(List<RouteContextDefinition> routeContexts) {
-        this.routeContexts = routeContexts;
-    }
-
-    public List<RouteConfigurationContextDefinition> getRouteConfigurationContexts() {
-        return routeConfigurationContexts;
-    }
-
-    public void setRouteConfigurationContexts(List<RouteConfigurationContextDefinition> routeConfigurationContexts) {
-        this.routeConfigurationContexts = routeConfigurationContexts;
-    }
-
-    public List<RouteTemplateContextDefinition> getRouteTemplateContexts() {
-        return routeTemplateContexts;
-    }
-
-    public void setRouteTemplateContexts(List<RouteTemplateContextDefinition> routeTemplateContexts) {
-        this.routeTemplateContexts = routeTemplateContexts;
-    }
-
-    public List<AbstractCamelFactoryBean<?>> getBeans() {
-        return beans;
-    }
-
-    public void setBeans(List<AbstractCamelFactoryBean<?>> beans) {
-        this.beans = beans;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/BeanManagerAware.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/BeanManagerAware.java
deleted file mode 100644
index cb13a016f84..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/BeanManagerAware.java
+++ /dev/null
@@ -1,26 +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.cdi.xml;
-
-import javax.enterprise.inject.spi.BeanManager;
-
-@Deprecated
-public interface BeanManagerAware {
-
-    void setBeanManager(BeanManager manager);
-
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/BeanManagerHelper.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/BeanManagerHelper.java
deleted file mode 100644
index 05253c98fa1..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/BeanManagerHelper.java
+++ /dev/null
@@ -1,39 +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.cdi.xml;
-
-import javax.enterprise.inject.spi.Bean;
-import javax.enterprise.inject.spi.BeanManager;
-
-import org.apache.camel.CamelContext;
-
-@Deprecated
-final class BeanManagerHelper {
-
-    private BeanManagerHelper() {
-    }
-
-    static CamelContext getCamelContextById(BeanManager manager, String camelContextId) {
-        Bean<?> bean = manager.resolve(manager.getBeans(camelContextId));
-        return (CamelContext) manager.getReference(bean, CamelContext.class, manager.createCreationalContext(bean));
-    }
-
-    static CamelContext getDefaultCamelContext(BeanManager manager) {
-        Bean<?> bean = manager.resolve(manager.getBeans(CamelContext.class));
-        return (CamelContext) manager.getReference(bean, CamelContext.class, manager.createCreationalContext(bean));
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/CamelContextFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/CamelContextFactoryBean.java
deleted file mode 100644
index 97cb8d27c0b..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/CamelContextFactoryBean.java
+++ /dev/null
@@ -1,1121 +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.cdi.xml;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.enterprise.inject.spi.Bean;
-import javax.enterprise.inject.spi.BeanManager;
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlAttribute;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElements;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlTransient;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.LoggingLevel;
-import org.apache.camel.RoutesBuilder;
-import org.apache.camel.ShutdownRoute;
-import org.apache.camel.ShutdownRunningTask;
-import org.apache.camel.StartupSummaryLevel;
-import org.apache.camel.TypeConverterExists;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.core.xml.AbstractCamelContextFactoryBean;
-import org.apache.camel.core.xml.AbstractCamelFactoryBean;
-import org.apache.camel.core.xml.CamelJMXAgentDefinition;
-import org.apache.camel.core.xml.CamelPropertyPlaceholderDefinition;
-import org.apache.camel.core.xml.CamelRouteControllerDefinition;
-import org.apache.camel.core.xml.CamelStreamCachingStrategyDefinition;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.apache.camel.model.ContextScanDefinition;
-import org.apache.camel.model.FaultToleranceConfigurationDefinition;
-import org.apache.camel.model.GlobalOptionsDefinition;
-import org.apache.camel.model.InterceptDefinition;
-import org.apache.camel.model.InterceptFromDefinition;
-import org.apache.camel.model.InterceptSendToEndpointDefinition;
-import org.apache.camel.model.OnCompletionDefinition;
-import org.apache.camel.model.OnExceptionDefinition;
-import org.apache.camel.model.PackageScanDefinition;
-import org.apache.camel.model.Resilience4jConfigurationDefinition;
-import org.apache.camel.model.RestContextRefDefinition;
-import org.apache.camel.model.RouteBuilderDefinition;
-import org.apache.camel.model.RouteConfigurationContextRefDefinition;
-import org.apache.camel.model.RouteConfigurationDefinition;
-import org.apache.camel.model.RouteContextRefDefinition;
-import org.apache.camel.model.RouteDefinition;
-import org.apache.camel.model.RouteTemplateContextRefDefinition;
-import org.apache.camel.model.RouteTemplateDefinition;
-import org.apache.camel.model.TemplatedRouteDefinition;
-import org.apache.camel.model.ThreadPoolProfileDefinition;
-import org.apache.camel.model.cloud.ServiceCallConfigurationDefinition;
-import org.apache.camel.model.dataformat.DataFormatsDefinition;
-import org.apache.camel.model.rest.RestConfigurationDefinition;
-import org.apache.camel.model.rest.RestDefinition;
-import org.apache.camel.model.transformer.TransformersDefinition;
-import org.apache.camel.model.validator.ValidatorsDefinition;
-import org.apache.camel.spi.Metadata;
-import org.apache.camel.spi.PackageScanFilter;
-
-@XmlRootElement(name = "camelContext")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class CamelContextFactoryBean extends AbstractCamelContextFactoryBean<DefaultCamelContext> implements BeanManagerAware {
-
-    @XmlAttribute(name = "depends-on")
-    private String dependsOn;
-
-    @XmlAttribute
-    @Metadata(defaultValue = "Default")
-    private StartupSummaryLevel startupSummaryLevel;
-
-    @XmlAttribute
-    private String trace;
-
-    @XmlAttribute
-    private String backlogTrace;
-
-    @XmlAttribute
-    private String tracePattern;
-
-    @XmlAttribute
-    private String traceLoggingFormat;
-
-    @XmlAttribute
-    private String debug;
-
-    @XmlAttribute
-    private String messageHistory;
-
-    @XmlAttribute
-    private String sourceLocationEnabled;
-
-    @XmlAttribute
-    private String logMask;
-
-    @XmlAttribute
-    private String logExhaustedMessageBody;
-
-    @XmlAttribute
-    private String streamCache;
-
-    @XmlAttribute
-    private String delayer;
-
-    @XmlAttribute
-    private String errorHandlerRef;
-
-    @XmlAttribute
-    private String autoStartup;
-
-    @XmlAttribute
-    private String shutdownEager;
-
-    @XmlAttribute
-    private String dumpRoutes;
-
-    @XmlAttribute
-    private String useMDCLogging;
-
-    @XmlAttribute
-    private String mdcLoggingKeysPattern;
-
-    @XmlAttribute
-    private String useDataType;
-
-    @XmlAttribute
-    private String useBreadcrumb;
-
-    @XmlAttribute
-    @Metadata(defaultValue = "true")
-    private String beanPostProcessorEnabled;
-
-    @XmlAttribute
-    private String allowUseOriginalMessage;
-
-    @XmlAttribute
-    private String caseInsensitiveHeaders;
-
-    @XmlAttribute
-    private String autowiredEnabled;
-
-    @XmlAttribute
-    private String runtimeEndpointRegistryEnabled;
-
-    @XmlAttribute
-    private String managementNamePattern;
-
-    @XmlAttribute
-    private String threadNamePattern;
-
-    @XmlAttribute
-    private ShutdownRoute shutdownRoute;
-
-    @XmlAttribute
-    private ShutdownRunningTask shutdownRunningTask;
-
-    @XmlAttribute
-    private String loadTypeConverters;
-
-    @XmlAttribute
-    private String typeConverterStatisticsEnabled;
-
-    @XmlAttribute
-    private String loadHealthChecks;
-
-    @XmlAttribute
-    private String inflightRepositoryBrowseEnabled;
-
-    @XmlAttribute
-    private TypeConverterExists typeConverterExists;
-
-    @XmlAttribute
-    private LoggingLevel typeConverterExistsLoggingLevel;
-
-    @XmlElement(name = "globalOptions")
-    private GlobalOptionsDefinition globalOptions;
-
-    @XmlElement(name = "propertyPlaceholder", type = CamelPropertyPlaceholderDefinition.class)
-    private CamelPropertyPlaceholderDefinition camelPropertyPlaceholder;
-
-    @XmlElement(name = "package")
-    private String[] packages = {};
-
-    @XmlElement(name = "packageScan", type = PackageScanDefinition.class)
-    private PackageScanDefinition packageScan;
-
-    @XmlElement(name = "contextScan", type = ContextScanDefinition.class)
-    private ContextScanDefinition contextScan;
-
-    @XmlElement(name = "streamCaching", type = CamelStreamCachingStrategyDefinition.class)
-    private CamelStreamCachingStrategyDefinition camelStreamCachingStrategy;
-
-    @XmlElement(name = "routeController", type = CamelRouteControllerDefinition.class)
-    private CamelRouteControllerDefinition camelRouteController;
-
-    @XmlElement(name = "jmxAgent", type = CamelJMXAgentDefinition.class)
-    private CamelJMXAgentDefinition camelJMXAgent;
-
-    @XmlElements({
-            @XmlElement(name = "consumerTemplate", type = ConsumerTemplateFactoryBean.class),
-            @XmlElement(name = "redeliveryPolicyProfile", type = RedeliveryPolicyFactoryBean.class),
-            @XmlElement(name = "template", type = ProducerTemplateFactoryBean.class),
-            @XmlElement(name = "threadPool", type = ThreadPoolFactoryBean.class) })
-    private List<AbstractCamelFactoryBean<?>> beansFactory;
-
-    @XmlTransient
-    private List<?> beans;
-
-    @XmlElement(name = "defaultServiceCallConfiguration")
-    private ServiceCallConfigurationDefinition defaultServiceCallConfiguration;
-
-    @XmlElement(name = "serviceCallConfiguration", type = ServiceCallConfigurationDefinition.class)
-    private List<ServiceCallConfigurationDefinition> serviceCallConfigurations;
-
-    @XmlElement(name = "defaultResilience4jConfiguration")
-    private Resilience4jConfigurationDefinition defaultResilience4jConfiguration;
-
-    @XmlElement(name = "resilience4jConfiguration", type = Resilience4jConfigurationDefinition.class)
-    private List<Resilience4jConfigurationDefinition> resilience4jConfigurations;
-
-    @XmlElement(name = "defaultFaultToleranceConfiguration")
-    private FaultToleranceConfigurationDefinition defaultFaultToleranceConfiguration;
-
-    @XmlElement(name = "faultToleranceConfiguration", type = FaultToleranceConfigurationDefinition.class)
-    private List<FaultToleranceConfigurationDefinition> faultToleranceConfigurations;
-
-    @XmlElement(name = "errorHandler", type = ErrorHandlerDefinition.class)
-    private List<ErrorHandlerDefinition> errorHandlers;
-
-    @XmlElement(name = "routeConfigurationContextRef")
-    private List<RouteConfigurationContextRefDefinition> routeConfigurationRefs = new ArrayList<>();
-
-    @XmlElement(name = "routeTemplateContextRef")
-    private List<RouteTemplateContextRefDefinition> routeTemplateRefs = new ArrayList<>();
-
-    @XmlElement(name = "routeBuilder")
-    private List<RouteBuilderDefinition> builderRefs = new ArrayList<>();
-
-    @XmlElement(name = "routeContextRef")
-    private List<RouteContextRefDefinition> routeRefs = new ArrayList<>();
-
-    @XmlElement(name = "restContextRef")
-    private List<RestContextRefDefinition> restRefs = new ArrayList<>();
-
-    @XmlElement(name = "threadPoolProfile")
-    private List<ThreadPoolProfileDefinition> threadPoolProfiles;
-
-    @XmlElement(name = "endpoint")
-    private List<EndpointFactoryBean> endpoints;
-
-    @XmlElement(name = "dataFormats")
-    private DataFormatsDefinition dataFormats;
-
-    @XmlElement(name = "transformers")
-    private TransformersDefinition transformers;
-
-    @XmlElement(name = "validators")
-    private ValidatorsDefinition validators;
-
-    @XmlElement(name = "redeliveryPolicyProfile")
-    private List<RedeliveryPolicyFactoryBean> redeliveryPolicies;
-
-    @XmlElement(name = "onException")
-    private List<OnExceptionDefinition> onExceptions = new ArrayList<>();
-
-    @XmlElement(name = "onCompletion")
-    private List<OnCompletionDefinition> onCompletions = new ArrayList<>();
-
-    @XmlElement(name = "intercept")
-    private List<InterceptDefinition> intercepts = new ArrayList<>();
-
-    @XmlElement(name = "interceptFrom")
-    private List<InterceptFromDefinition> interceptFroms = new ArrayList<>();
-
-    @XmlElement(name = "interceptSendToEndpoint")
-    private List<InterceptSendToEndpointDefinition> interceptSendToEndpoints = new ArrayList<>();
-
-    @XmlElement(name = "restConfiguration")
-    private RestConfigurationDefinition restConfiguration;
-
-    @XmlElement(name = "rest")
-    private List<RestDefinition> rests = new ArrayList<>();
-
-    @XmlElement(name = "routeConfiguration")
-    private List<RouteConfigurationDefinition> routeConfigurations = new ArrayList<>();
-
-    @XmlElement(name = "routeTemplate")
-    private List<RouteTemplateDefinition> routeTemplates = new ArrayList<>();
-
-    @XmlElement(name = "templatedRoute")
-    private List<TemplatedRouteDefinition> templatedRoutes = new ArrayList<>();
-
-    @XmlElement(name = "route")
-    private List<RouteDefinition> routes = new ArrayList<>();
-
-    @XmlTransient
-    private DefaultCamelContext context;
-
-    @XmlTransient
-    private BeanManager manager;
-
-    @XmlTransient
-    private boolean implicitId;
-
-    @Override
-    public Class<DefaultCamelContext> getObjectType() {
-        return DefaultCamelContext.class;
-    }
-
-    @Override
-    public void setBeanManager(BeanManager manager) {
-        this.manager = manager;
-    }
-
-    @Override
-    @SuppressWarnings("unchecked")
-    protected <S> S getBeanForType(Class<S> clazz) {
-        Bean<?> bean = manager.resolve(manager.getBeans(clazz));
-        if (bean == null) {
-            return null;
-        }
-
-        return (S) manager.getReference(bean, clazz, manager.createCreationalContext(bean));
-    }
-
-    @Override
-    protected void findRouteBuildersByPackageScan(String[] packages, PackageScanFilter filter, List<RoutesBuilder> builders)
-            throws Exception {
-        // add filter to class resolver which then will filter
-        getContext().getPackageScanClassResolver().addFilter(filter);
-
-        PackageScanRouteBuilderFinder finder = new PackageScanRouteBuilderFinder(
-                getContext(), packages, getContextClassLoaderOnStart(),
-                getContext().getPackageScanClassResolver());
-        finder.appendBuilders(builders);
-
-        // and remove the filter
-        getContext().getPackageScanClassResolver().removeFilter(filter);
-    }
-
-    @Override
-    protected void findRouteBuildersByContextScan(
-            PackageScanFilter filter, boolean includeNonSingletons, List<RoutesBuilder> builders)
-            throws Exception {
-        ContextScanRouteBuilderFinder finder = new ContextScanRouteBuilderFinder(manager, filter, includeNonSingletons);
-        finder.appendBuilders(builders);
-    }
-
-    @Override
-    protected void initBeanPostProcessor(DefaultCamelContext context) {
-        // Already done by Camel CDI injection target
-    }
-
-    @Override
-    protected void postProcessBeforeInit(RouteBuilder builder) {
-        // Already done by Camel CDI injection target
-    }
-
-    @Override
-    protected void initCustomRegistry(DefaultCamelContext context) {
-        // Already done by Camel CDI injection target
-    }
-
-    @Override
-    public void afterPropertiesSet() throws Exception {
-        super.afterPropertiesSet();
-        setupRoutes();
-    }
-
-    @Override
-    public DefaultCamelContext getContext() {
-        return context;
-    }
-
-    public void setContext(DefaultCamelContext context) {
-        this.context = context;
-    }
-
-    @Override
-    public DefaultCamelContext getContext(boolean create) {
-        return context;
-    }
-
-    @Override
-    public List<AbstractCamelFactoryBean<?>> getBeansFactory() {
-        return beansFactory;
-    }
-
-    public void setBeansFactory(List<AbstractCamelFactoryBean<?>> beansFactory) {
-        this.beansFactory = beansFactory;
-    }
-
-    @Override
-    public List<?> getBeans() {
-        return beans;
-    }
-
-    public void setBeans(List<?> beans) {
-        this.beans = beans;
-    }
-
-    @Override
-    public ServiceCallConfigurationDefinition getDefaultServiceCallConfiguration() {
-        return defaultServiceCallConfiguration;
-    }
-
-    public void setDefaultServiceCallConfiguration(ServiceCallConfigurationDefinition defaultServiceCallConfiguration) {
-        this.defaultServiceCallConfiguration = defaultServiceCallConfiguration;
-    }
-
-    @Override
-    public List<ServiceCallConfigurationDefinition> getServiceCallConfigurations() {
-        return serviceCallConfigurations;
-    }
-
-    public void setServiceCallConfigurations(List<ServiceCallConfigurationDefinition> serviceCallConfigurations) {
-        this.serviceCallConfigurations = serviceCallConfigurations;
-    }
-
-    @Override
-    public Resilience4jConfigurationDefinition getDefaultResilience4jConfiguration() {
-        return defaultResilience4jConfiguration;
-    }
-
-    public void setDefaultResilience4jConfiguration(Resilience4jConfigurationDefinition defaultResilience4jConfiguration) {
-        this.defaultResilience4jConfiguration = defaultResilience4jConfiguration;
-    }
-
-    @Override
-    public List<Resilience4jConfigurationDefinition> getResilience4jConfigurations() {
-        return resilience4jConfigurations;
-    }
-
-    public void setResilience4jConfigurations(List<Resilience4jConfigurationDefinition> resilience4jConfigurations) {
-        this.resilience4jConfigurations = resilience4jConfigurations;
-    }
-
-    @Override
-    public FaultToleranceConfigurationDefinition getDefaultFaultToleranceConfiguration() {
-        return defaultFaultToleranceConfiguration;
-    }
-
-    public void setDefaultFaultToleranceConfiguration(
-            FaultToleranceConfigurationDefinition defaultFaultToleranceConfiguration) {
-        this.defaultFaultToleranceConfiguration = defaultFaultToleranceConfiguration;
-    }
-
-    @Override
-    public List<FaultToleranceConfigurationDefinition> getFaultToleranceConfigurations() {
-        return faultToleranceConfigurations;
-    }
-
-    public void setFaultToleranceConfigurations(List<FaultToleranceConfigurationDefinition> faultToleranceConfigurations) {
-        this.faultToleranceConfigurations = faultToleranceConfigurations;
-    }
-
-    @Override
-    public List<RouteDefinition> getRoutes() {
-        return routes;
-    }
-
-    @Override
-    public void setRoutes(List<RouteDefinition> routes) {
-        this.routes = routes;
-    }
-
-    @Override
-    public List<RouteConfigurationDefinition> getRouteConfigurations() {
-        return routeConfigurations;
-    }
-
-    @Override
-    public void setRouteConfigurations(List<RouteConfigurationDefinition> routeConfigurations) {
-        this.routeConfigurations = routeConfigurations;
-    }
-
-    @Override
-    public List<RouteTemplateDefinition> getRouteTemplates() {
-        return routeTemplates;
-    }
-
-    @Override
-    public void setRouteTemplates(List<RouteTemplateDefinition> routeTemplates) {
-        this.routeTemplates = routeTemplates;
-    }
-
-    @Override
-    public List<TemplatedRouteDefinition> getTemplatedRoutes() {
-        return templatedRoutes;
-    }
-
-    @Override
-    public void setTemplatedRoutes(List<TemplatedRouteDefinition> templatedRoutes) {
-        this.templatedRoutes = templatedRoutes;
-    }
-
-    @Override
-    public List<RestDefinition> getRests() {
-        return rests;
-    }
-
-    @Override
-    public void setRests(List<RestDefinition> rests) {
-        this.rests = rests;
-    }
-
-    @Override
-    public RestConfigurationDefinition getRestConfiguration() {
-        return restConfiguration;
-    }
-
-    public void setRestConfiguration(RestConfigurationDefinition restConfiguration) {
-        this.restConfiguration = restConfiguration;
-    }
-
-    @Override
-    public List<EndpointFactoryBean> getEndpoints() {
-        return endpoints;
-    }
-
-    public void setEndpoints(List<EndpointFactoryBean> endpoints) {
-        this.endpoints = endpoints;
-    }
-
-    @Override
-    public List<RedeliveryPolicyFactoryBean> getRedeliveryPolicies() {
-        return redeliveryPolicies;
-    }
-
-    public void setRedeliveryPolicies(List<RedeliveryPolicyFactoryBean> redeliveryPolicies) {
-        this.redeliveryPolicies = redeliveryPolicies;
-    }
-
-    @Override
-    public List<InterceptDefinition> getIntercepts() {
-        return intercepts;
-    }
-
-    public void setIntercepts(List<InterceptDefinition> intercepts) {
-        this.intercepts = intercepts;
-    }
-
-    @Override
-    public List<InterceptFromDefinition> getInterceptFroms() {
-        return interceptFroms;
-    }
-
-    public void setInterceptFroms(List<InterceptFromDefinition> interceptFroms) {
-        this.interceptFroms = interceptFroms;
-    }
-
-    @Override
-    public List<InterceptSendToEndpointDefinition> getInterceptSendToEndpoints() {
-        return interceptSendToEndpoints;
-    }
-
-    public void setInterceptSendToEndpoints(List<InterceptSendToEndpointDefinition> interceptSendToEndpoints) {
-        this.interceptSendToEndpoints = interceptSendToEndpoints;
-    }
-
-    @Override
-    public GlobalOptionsDefinition getGlobalOptions() {
-        return globalOptions;
-    }
-
-    public void setGlobalOptions(GlobalOptionsDefinition globalOptions) {
-        this.globalOptions = globalOptions;
-    }
-
-    @Override
-    public String[] getPackages() {
-        return packages;
-    }
-
-    /**
-     * Sets the package names to be recursively searched for Java classes which extend
-     * {@link org.apache.camel.builder.RouteBuilder} to be auto-wired up to the {@link CamelContext} as a route. Note
-     * that classes are excluded if they are specifically configured in the deployment.
-     * <p/>
-     * A more advanced configuration can be done using
-     * {@link #setPackageScan(org.apache.camel.model.PackageScanDefinition)}
-     *
-     * @param packages the package names which are recursively searched
-     * @see            #setPackageScan(org.apache.camel.model.PackageScanDefinition)
-     */
-    public void setPackages(String[] packages) {
-        this.packages = packages;
-    }
-
-    @Override
-    public PackageScanDefinition getPackageScan() {
-        return packageScan;
-    }
-
-    /**
-     * Sets the package scanning information. Package scanning allows for the automatic discovery of certain camel
-     * classes at runtime for inclusion e.g. {@link org.apache.camel.builder.RouteBuilder} implementations
-     *
-     * @param packageScan the package scan
-     */
-    @Override
-    public void setPackageScan(PackageScanDefinition packageScan) {
-        this.packageScan = packageScan;
-    }
-
-    @Override
-    public ContextScanDefinition getContextScan() {
-        return contextScan;
-    }
-
-    /**
-     * Sets the context scanning information. Context scanning allows for the automatic discovery of Camel routes
-     * runtime for inclusion e.g. {@link org.apache.camel.builder.RouteBuilder} implementations
-     *
-     * @param contextScan the context scan
-     */
-    @Override
-    public void setContextScan(ContextScanDefinition contextScan) {
-        this.contextScan = contextScan;
-    }
-
-    @Override
-    public CamelPropertyPlaceholderDefinition getCamelPropertyPlaceholder() {
-        return camelPropertyPlaceholder;
-    }
-
-    public void setCamelPropertyPlaceholder(CamelPropertyPlaceholderDefinition camelPropertyPlaceholder) {
-        this.camelPropertyPlaceholder = camelPropertyPlaceholder;
-    }
-
-    @Override
-    public CamelStreamCachingStrategyDefinition getCamelStreamCachingStrategy() {
-        return camelStreamCachingStrategy;
-    }
-
-    public void setCamelStreamCachingStrategy(CamelStreamCachingStrategyDefinition camelStreamCachingStrategy) {
-        this.camelStreamCachingStrategy = camelStreamCachingStrategy;
-    }
-
-    @Override
-    public CamelRouteControllerDefinition getCamelRouteController() {
-        return camelRouteController;
-    }
-
-    public void setCamelRouteController(CamelRouteControllerDefinition camelRouteController) {
-        this.camelRouteController = camelRouteController;
-    }
-
-    @Override
-    public StartupSummaryLevel getStartupSummaryLevel() {
-        return startupSummaryLevel;
-    }
-
-    public void setStartupSummaryLevel(StartupSummaryLevel startupSummaryLevel) {
-        this.startupSummaryLevel = startupSummaryLevel;
-    }
-
-    @Override
-    public String getTrace() {
-        return trace;
-    }
-
-    public void setTrace(String trace) {
-        this.trace = trace;
-    }
-
-    @Override
-    public String getBacklogTrace() {
-        return backlogTrace;
-    }
-
-    /**
-     * Sets whether backlog tracing is enabled or not.
-     */
-    public void setBacklogTrace(String backlogTrace) {
-        this.backlogTrace = backlogTrace;
-    }
-
-    @Override
-    public String getTracePattern() {
-        return tracePattern;
-    }
-
-    public void setTracePattern(String tracePattern) {
-        this.tracePattern = tracePattern;
-    }
-
-    @Override
-    public String getTraceLoggingFormat() {
-        return traceLoggingFormat;
-    }
-
-    public void setTraceLoggingFormat(String traceLoggingFormat) {
-        this.traceLoggingFormat = traceLoggingFormat;
-    }
-
-    @Override
-    public String getDebug() {
-        return debug;
-    }
-
-    /**
-     * Sets whether debugging is enabled or not.
-     */
-    public void setDebug(String debug) {
-        this.debug = debug;
-    }
-
-    @Override
-    public String getMessageHistory() {
-        return messageHistory;
-    }
-
-    public void setMessageHistory(String messageHistory) {
-        this.messageHistory = messageHistory;
-    }
-
-    @Override
-    public String getSourceLocationEnabled() {
-        return sourceLocationEnabled;
-    }
-
-    public void setSourceLocationEnabled(String sourceLocationEnabled) {
-        this.sourceLocationEnabled = sourceLocationEnabled;
-    }
-
-    @Override
-    public String getLogMask() {
-        return logMask;
-    }
-
-    public void setLogMask(String logMask) {
-        this.logMask = logMask;
-    }
-
-    @Override
-    public String getLogExhaustedMessageBody() {
-        return logExhaustedMessageBody;
-    }
-
-    public void setLogExhaustedMessageBody(String logExhaustedMessageBody) {
-        this.logExhaustedMessageBody = logExhaustedMessageBody;
-    }
-
-    @Override
-    public String getStreamCache() {
-        return streamCache;
-    }
-
-    public void setStreamCache(String streamCache) {
-        this.streamCache = streamCache;
-    }
-
-    @Override
-    public String getDelayer() {
-        return delayer;
-    }
-
-    public void setDelayer(String delayer) {
-        this.delayer = delayer;
-    }
-
-    @Override
-    public String getAutoStartup() {
-        return autoStartup;
-    }
-
-    public void setAutoStartup(String autoStartup) {
-        this.autoStartup = autoStartup;
-    }
-
-    public String getShutdownEager() {
-        return shutdownEager;
-    }
-
-    public void setShutdownEager(String shutdownEager) {
-        this.shutdownEager = shutdownEager;
-    }
-
-    @Override
-    public String getDumpRoutes() {
-        return dumpRoutes;
-    }
-
-    public void setDumpRoutes(String dumpRoutes) {
-        this.dumpRoutes = dumpRoutes;
-    }
-
-    @Override
-    public String getUseMDCLogging() {
-        return useMDCLogging;
-    }
-
-    public void setUseMDCLogging(String useMDCLogging) {
-        this.useMDCLogging = useMDCLogging;
-    }
-
-    @Override
-    public String getUseDataType() {
-        return useDataType;
-    }
-
-    public void setUseDataType(String useDataType) {
-        this.useDataType = useDataType;
-    }
-
-    @Override
-    public String getUseBreadcrumb() {
-        return useBreadcrumb;
-    }
-
-    public void setUseBreadcrumb(String useBreadcrumb) {
-        this.useBreadcrumb = useBreadcrumb;
-    }
-
-    @Override
-    public String getBeanPostProcessorEnabled() {
-        return beanPostProcessorEnabled;
-    }
-
-    public void setBeanPostProcessorEnabled(String beanPostProcessorEnabled) {
-        this.beanPostProcessorEnabled = beanPostProcessorEnabled;
-    }
-
-    @Override
-    public String getAllowUseOriginalMessage() {
-        return allowUseOriginalMessage;
-    }
-
-    public void setAllowUseOriginalMessage(String allowUseOriginalMessage) {
-        this.allowUseOriginalMessage = allowUseOriginalMessage;
-    }
-
-    @Override
-    public String getCaseInsensitiveHeaders() {
-        return caseInsensitiveHeaders;
-    }
-
-    public void setCaseInsensitiveHeaders(String caseInsensitiveHeaders) {
-        this.caseInsensitiveHeaders = caseInsensitiveHeaders;
-    }
-
-    @Override
-    public String getAutowiredEnabled() {
-        return autowiredEnabled;
-    }
-
-    public void setAutowiredEnabled(String autowiredEnabled) {
-        this.autowiredEnabled = autowiredEnabled;
-    }
-
-    @Override
-    public String getRuntimeEndpointRegistryEnabled() {
-        return runtimeEndpointRegistryEnabled;
-    }
-
-    public void setRuntimeEndpointRegistryEnabled(String runtimeEndpointRegistryEnabled) {
-        this.runtimeEndpointRegistryEnabled = runtimeEndpointRegistryEnabled;
-    }
-
-    @Override
-    public String getManagementNamePattern() {
-        return managementNamePattern;
-    }
-
-    public void setManagementNamePattern(String managementNamePattern) {
-        this.managementNamePattern = managementNamePattern;
-    }
-
-    @Override
-    public String getThreadNamePattern() {
-        return threadNamePattern;
-    }
-
-    public void setThreadNamePattern(String threadNamePattern) {
-        this.threadNamePattern = threadNamePattern;
-    }
-
-    @Override
-    public String getLoadTypeConverters() {
-        return loadTypeConverters;
-    }
-
-    public void setLoadTypeConverters(String loadTypeConverters) {
-        this.loadTypeConverters = loadTypeConverters;
-    }
-
-    @Override
-    public String getTypeConverterStatisticsEnabled() {
-        return typeConverterStatisticsEnabled;
-    }
-
-    public void setTypeConverterStatisticsEnabled(String typeConverterStatisticsEnabled) {
-        this.typeConverterStatisticsEnabled = typeConverterStatisticsEnabled;
-    }
-
-    @Override
-    public String getLoadHealthChecks() {
-        return loadHealthChecks;
-    }
-
-    public void setLoadHealthChecks(String loadHealthChecks) {
-        this.loadHealthChecks = loadHealthChecks;
-    }
-
-    @Override
-    public String getInflightRepositoryBrowseEnabled() {
-        return inflightRepositoryBrowseEnabled;
-    }
-
-    public void setInflightRepositoryBrowseEnabled(String inflightRepositoryBrowseEnabled) {
-        this.inflightRepositoryBrowseEnabled = inflightRepositoryBrowseEnabled;
-    }
-
-    @Override
-    public TypeConverterExists getTypeConverterExists() {
-        return typeConverterExists;
-    }
-
-    public void setTypeConverterExists(TypeConverterExists typeConverterExists) {
-        this.typeConverterExists = typeConverterExists;
-    }
-
-    @Override
-    public LoggingLevel getTypeConverterExistsLoggingLevel() {
-        return typeConverterExistsLoggingLevel;
-    }
-
-    public void setTypeConverterExistsLoggingLevel(LoggingLevel typeConverterExistsLoggingLevel) {
-        this.typeConverterExistsLoggingLevel = typeConverterExistsLoggingLevel;
-    }
-
-    @Override
-    public CamelJMXAgentDefinition getCamelJMXAgent() {
-        return camelJMXAgent;
-    }
-
-    public void setCamelJMXAgent(CamelJMXAgentDefinition agent) {
-        camelJMXAgent = agent;
-    }
-
-    @Override
-    public List<RouteConfigurationContextRefDefinition> getRouteConfigurationRefs() {
-        return routeConfigurationRefs;
-    }
-
-    public void setRouteConfigurationRefs(List<RouteConfigurationContextRefDefinition> routeConfigurationRefs) {
-        this.routeConfigurationRefs = routeConfigurationRefs;
-    }
-
-    @Override
-    public List<RouteTemplateContextRefDefinition> getRouteTemplateRefs() {
-        return routeTemplateRefs;
-    }
-
-    public void setRouteTemplateRefs(List<RouteTemplateContextRefDefinition> routeTemplateRefs) {
-        this.routeTemplateRefs = routeTemplateRefs;
-    }
-
-    @Override
-    public List<RouteBuilderDefinition> getBuilderRefs() {
-        return builderRefs;
-    }
-
-    public void setBuilderRefs(List<RouteBuilderDefinition> builderRefs) {
-        this.builderRefs = builderRefs;
-    }
-
-    @Override
-    public List<RouteContextRefDefinition> getRouteRefs() {
-        return routeRefs;
-    }
-
-    public void setRouteRefs(List<RouteContextRefDefinition> routeRefs) {
-        this.routeRefs = routeRefs;
-    }
-
-    @Override
-    public List<RestContextRefDefinition> getRestRefs() {
-        return restRefs;
-    }
-
-    public void setRestRefs(List<RestContextRefDefinition> restRefs) {
-        this.restRefs = restRefs;
-    }
-
-    @Override
-    public String getErrorHandlerRef() {
-        return errorHandlerRef;
-    }
-
-    public void setErrorHandlerRef(String errorHandlerRef) {
-        this.errorHandlerRef = errorHandlerRef;
-    }
-
-    @Override
-    public DataFormatsDefinition getDataFormats() {
-        return dataFormats;
-    }
-
-    public void setDataFormats(DataFormatsDefinition dataFormats) {
-        this.dataFormats = dataFormats;
-    }
-
-    @Override
-    public TransformersDefinition getTransformers() {
-        return transformers;
-    }
-
-    public void setTransformers(TransformersDefinition transformers) {
-        this.transformers = transformers;
-    }
-
-    @Override
-    public ValidatorsDefinition getValidators() {
-        return validators;
-    }
-
-    public void setValidators(ValidatorsDefinition validators) {
-        this.validators = validators;
-    }
-
-    @Override
-    public List<OnExceptionDefinition> getOnExceptions() {
-        return onExceptions;
-    }
-
-    public void setOnExceptions(List<OnExceptionDefinition> onExceptions) {
-        this.onExceptions = onExceptions;
-    }
-
-    @Override
-    public List<OnCompletionDefinition> getOnCompletions() {
-        return onCompletions;
-    }
-
-    public void setOnCompletions(List<OnCompletionDefinition> onCompletions) {
-        this.onCompletions = onCompletions;
-    }
-
-    @Override
-    public ShutdownRoute getShutdownRoute() {
-        return shutdownRoute;
-    }
-
-    public void setShutdownRoute(ShutdownRoute shutdownRoute) {
-        this.shutdownRoute = shutdownRoute;
-    }
-
-    @Override
-    public ShutdownRunningTask getShutdownRunningTask() {
-        return shutdownRunningTask;
-    }
-
-    public void setShutdownRunningTask(ShutdownRunningTask shutdownRunningTask) {
-        this.shutdownRunningTask = shutdownRunningTask;
-    }
-
-    @Override
-    public List<ThreadPoolProfileDefinition> getThreadPoolProfiles() {
-        return threadPoolProfiles;
-    }
-
-    public void setThreadPoolProfiles(List<ThreadPoolProfileDefinition> threadPoolProfiles) {
-        this.threadPoolProfiles = threadPoolProfiles;
-    }
-
-    @Override
-    public String getDependsOn() {
-        return dependsOn;
-    }
-
-    public void setDependsOn(String dependsOn) {
-        this.dependsOn = dependsOn;
-    }
-
-    public boolean isImplicitId() {
-        return implicitId;
-    }
-
-    public void setImplicitId(boolean implicitId) {
-        this.implicitId = implicitId;
-    }
-
-    public List<ErrorHandlerDefinition> getErrorHandlers() {
-        return errorHandlers;
-    }
-
-    public void setErrorHandlers(List<ErrorHandlerDefinition> errorHandlers) {
-        this.errorHandlers = errorHandlers;
-    }
-
-    public String getMdcLoggingKeysPattern() {
-        return mdcLoggingKeysPattern;
-    }
-
-    public void setMdcLoggingKeysPattern(String mdcLoggingKeysPattern) {
-        this.mdcLoggingKeysPattern = mdcLoggingKeysPattern;
-    }
-
-    @Override
-    public String getMDCLoggingKeysPattern() {
-        return mdcLoggingKeysPattern;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ConsumerTemplateFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ConsumerTemplateFactoryBean.java
deleted file mode 100644
index 9fe83858b04..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ConsumerTemplateFactoryBean.java
+++ /dev/null
@@ -1,53 +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.cdi.xml;
-
-import javax.enterprise.inject.spi.BeanManager;
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlTransient;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.core.xml.AbstractCamelConsumerTemplateFactoryBean;
-
-/**
- * A factory for creating a new {@link org.apache.camel.ConsumerTemplate} instance with a minimum of XML
- */
-@XmlRootElement(name = "consumerTemplate")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class ConsumerTemplateFactoryBean extends AbstractCamelConsumerTemplateFactoryBean implements BeanManagerAware {
-
-    @XmlTransient
-    private BeanManager manager;
-
-    @Override
-    public void setBeanManager(BeanManager manager) {
-        this.manager = manager;
-    }
-
-    @Override
-    protected CamelContext getCamelContextWithId(String camelContextId) {
-        return BeanManagerHelper.getCamelContextById(manager, camelContextId);
-    }
-
-    @Override
-    protected CamelContext discoverDefaultCamelContext() {
-        return BeanManagerHelper.getDefaultCamelContext(manager);
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ContextScanRouteBuilderFinder.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ContextScanRouteBuilderFinder.java
deleted file mode 100644
index 6a293eaec32..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ContextScanRouteBuilderFinder.java
+++ /dev/null
@@ -1,86 +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.cdi.xml;
-
-import java.util.List;
-
-import javax.enterprise.context.ApplicationScoped;
-import javax.enterprise.inject.Any;
-import javax.enterprise.inject.spi.Bean;
-import javax.enterprise.inject.spi.BeanManager;
-import javax.enterprise.util.AnnotationLiteral;
-
-import org.apache.camel.RoutesBuilder;
-import org.apache.camel.spi.PackageScanFilter;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * A helper class which will find all {@link org.apache.camel.builder.RouteBuilder} beans in the {@link BeanManager}.
- */
-@Deprecated
-final class ContextScanRouteBuilderFinder {
-
-    private static final AnnotationLiteral<Any> ANY = new AnnotationLiteral<Any>() {
-    };
-
-    private final Logger logger = LoggerFactory.getLogger(ContextScanRouteBuilderFinder.class);
-
-    private final BeanManager manager;
-
-    private final PackageScanFilter filter;
-
-    private final boolean includeNonSingletons;
-
-    ContextScanRouteBuilderFinder(BeanManager manager, PackageScanFilter filter, boolean includeNonSingletons) {
-        this.manager = manager;
-        this.filter = filter;
-        this.includeNonSingletons = includeNonSingletons;
-    }
-
-    /**
-     * Appends all the {@link org.apache.camel.builder.RouteBuilder} bean instances that can be found in the manager.
-     */
-    void appendBuilders(List<RoutesBuilder> list) {
-        for (Bean<?> bean : manager.getBeans(RoutesBuilder.class, ANY)) {
-            logger.trace("Found RouteBuilder bean {}", bean);
-
-            // certain beans should be ignored
-            if (shouldIgnoreBean(bean)) {
-                logger.debug("Ignoring RouteBuilder {}", bean);
-                continue;
-            }
-
-            if (!isFilteredClass(bean)) {
-                logger.debug("Ignoring filtered RouteBuilder {}", bean);
-                continue;
-            }
-
-            logger.debug("Adding instantiated RouteBuilder {}", bean);
-            Object instance = manager.getReference(bean, RoutesBuilder.class, manager.createCreationalContext(bean));
-            list.add((RoutesBuilder) instance);
-        }
-    }
-
-    private boolean shouldIgnoreBean(Bean<?> bean) {
-        return !includeNonSingletons && !ApplicationScoped.class.equals(bean.getScope());
-    }
-
-    private boolean isFilteredClass(Bean<?> bean) {
-        return filter != null && filter.matches(bean.getBeanClass());
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/EndpointFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/EndpointFactoryBean.java
deleted file mode 100644
index ee267a368ea..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/EndpointFactoryBean.java
+++ /dev/null
@@ -1,54 +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.cdi.xml;
-
-import javax.enterprise.inject.spi.BeanManager;
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlTransient;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.Endpoint;
-import org.apache.camel.core.xml.AbstractCamelEndpointFactoryBean;
-
-/**
- * A factory which instantiates {@link Endpoint} objects
- */
-@XmlRootElement(name = "endpoint")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class EndpointFactoryBean extends AbstractCamelEndpointFactoryBean implements BeanManagerAware {
-
-    @XmlTransient
-    private BeanManager manager;
-
-    @Override
-    public void setBeanManager(BeanManager manager) {
-        this.manager = manager;
-    }
-
-    @Override
-    protected CamelContext getCamelContextWithId(String camelContextId) {
-        return BeanManagerHelper.getCamelContextById(manager, camelContextId);
-    }
-
-    @Override
-    protected CamelContext discoverDefaultCamelContext() {
-        return BeanManagerHelper.getDefaultCamelContext(manager);
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ErrorHandlerDefinition.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ErrorHandlerDefinition.java
deleted file mode 100644
index 9f51888d60e..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ErrorHandlerDefinition.java
+++ /dev/null
@@ -1,199 +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.cdi.xml;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlAttribute;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.model.IdentifiedType;
-
-/**
- * The &lt;errorHandler&gt; tag element.
- */
-@XmlRootElement(name = "errorHandler")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class ErrorHandlerDefinition extends IdentifiedType {
-
-    @XmlAttribute
-    private ErrorHandlerType type = ErrorHandlerType.DefaultErrorHandler;
-
-    @XmlAttribute
-    private String deadLetterUri;
-
-    @XmlAttribute
-    private String deadLetterHandleNewException;
-
-    @XmlAttribute
-    private String rollbackLoggingLevel;
-
-    @XmlAttribute
-    private String useOriginalMessage;
-
-    @XmlAttribute
-    private String useOriginalBody;
-
-    @XmlAttribute
-    private String transactionTemplateRef;
-
-    @XmlAttribute
-    private String transactionManagerRef;
-
-    @XmlAttribute
-    private String onRedeliveryRef;
-
-    @XmlAttribute
-    private String onExceptionOccurredRef;
-
-    @XmlAttribute
-    private String onPrepareFailureRef;
-
-    @XmlAttribute
-    private String retryWhileRef;
-
-    @XmlAttribute
-    private String redeliveryPolicyRef;
-
-    @XmlAttribute
-    private String executorServiceRef;
-
-    @XmlElement
-    private RedeliveryPolicyFactoryBean redeliveryPolicy;
-
-    public ErrorHandlerType getType() {
-        return type;
-    }
-
-    public void setType(ErrorHandlerType type) {
-        this.type = type;
-    }
-
-    public String getDeadLetterUri() {
-        return deadLetterUri;
-    }
-
-    public void setDeadLetterUri(String deadLetterUri) {
-        this.deadLetterUri = deadLetterUri;
-    }
-
-    public String getDeadLetterHandleNewException() {
-        return deadLetterHandleNewException;
-    }
-
-    public void setDeadLetterHandleNewException(String deadLetterHandleNewException) {
-        this.deadLetterHandleNewException = deadLetterHandleNewException;
-    }
-
-    public String getRollbackLoggingLevel() {
-        return rollbackLoggingLevel;
-    }
-
-    public void setRollbackLoggingLevel(String rollbackLoggingLevel) {
-        this.rollbackLoggingLevel = rollbackLoggingLevel;
-    }
-
-    public String getUseOriginalMessage() {
-        return useOriginalMessage;
-    }
-
-    public void setUseOriginalMessage(String useOriginalMessage) {
-        this.useOriginalMessage = useOriginalMessage;
-    }
-
-    public String getUseOriginalBody() {
-        return useOriginalBody;
-    }
-
-    public void setUseOriginalBody(String useOriginalBody) {
-        this.useOriginalBody = useOriginalBody;
-    }
-
-    public String getTransactionTemplateRef() {
-        return transactionTemplateRef;
-    }
-
-    public void setTransactionTemplateRef(String transactionTemplateRef) {
-        this.transactionTemplateRef = transactionTemplateRef;
-    }
-
-    public String getTransactionManagerRef() {
-        return transactionManagerRef;
-    }
-
-    public void setTransactionManagerRef(String transactionManagerRef) {
-        this.transactionManagerRef = transactionManagerRef;
-    }
-
-    public String getOnRedeliveryRef() {
-        return onRedeliveryRef;
-    }
-
-    public void setOnRedeliveryRef(String onRedeliveryRef) {
-        this.onRedeliveryRef = onRedeliveryRef;
-    }
-
-    public String getOnExceptionOccurredRef() {
-        return onExceptionOccurredRef;
-    }
-
-    public void setOnExceptionOccurredRef(String onExceptionOccurredRef) {
-        this.onExceptionOccurredRef = onExceptionOccurredRef;
-    }
-
-    public String getOnPrepareFailureRef() {
-        return onPrepareFailureRef;
-    }
-
-    public void setOnPrepareFailureRef(String onPrepareFailureRef) {
-        this.onPrepareFailureRef = onPrepareFailureRef;
-    }
-
-    public String getRetryWhileRef() {
-        return retryWhileRef;
-    }
-
-    public void setRetryWhileRef(String retryWhileRef) {
-        this.retryWhileRef = retryWhileRef;
-    }
-
-    public String getRedeliveryPolicyRef() {
-        return redeliveryPolicyRef;
-    }
-
-    public void setRedeliveryPolicyRef(String redeliveryPolicyRef) {
-        this.redeliveryPolicyRef = redeliveryPolicyRef;
-    }
-
-    public String getExecutorServiceRef() {
-        return executorServiceRef;
-    }
-
-    public void setExecutorServiceRef(String executorServiceRef) {
-        this.executorServiceRef = executorServiceRef;
-    }
-
-    public RedeliveryPolicyFactoryBean getRedeliveryPolicy() {
-        return redeliveryPolicy;
-    }
-
-    public void setRedeliveryPolicy(RedeliveryPolicyFactoryBean redeliveryPolicy) {
-        this.redeliveryPolicy = redeliveryPolicy;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ErrorHandlerType.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ErrorHandlerType.java
deleted file mode 100644
index 1bd1bc65752..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ErrorHandlerType.java
+++ /dev/null
@@ -1,58 +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.cdi.xml;
-
-import javax.xml.bind.annotation.XmlEnum;
-import javax.xml.bind.annotation.XmlType;
-
-import org.apache.camel.builder.DeadLetterChannelBuilder;
-import org.apache.camel.builder.DefaultErrorHandlerBuilder;
-import org.apache.camel.builder.NoErrorHandlerBuilder;
-
-/**
- * Used to configure the errorHandler type
- */
-@XmlType
-@XmlEnum(String.class)
-@Deprecated
-public enum ErrorHandlerType {
-
-    DefaultErrorHandler,
-    DeadLetterChannel,
-    NoErrorHandler,
-    TransactionErrorHandler;
-
-    /**
-     * Get the type as class FQN name.
-     *
-     * @return the class which represents the selected type.
-     */
-    public String getTypeAsClass() {
-        switch (this) {
-            case DefaultErrorHandler:
-                return DefaultErrorHandlerBuilder.class.getName();
-            case DeadLetterChannel:
-                return DeadLetterChannelBuilder.class.getName();
-            case NoErrorHandler:
-                return NoErrorHandlerBuilder.class.getName();
-            case TransactionErrorHandler:
-                return "org.apache.camel.jta.JtaTransactionErrorHandlerBuilder";
-            default:
-                throw new IllegalArgumentException("Unknown error handler: " + this);
-        }
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ImportDefinition.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ImportDefinition.java
deleted file mode 100644
index 3283110b7c4..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ImportDefinition.java
+++ /dev/null
@@ -1,43 +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.cdi.xml;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlAttribute;
-import javax.xml.bind.annotation.XmlRootElement;
-
-/**
- * The &lt;import&gt; tag element.
- *
- */
-@XmlRootElement(name = "import")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class ImportDefinition {
-
-    @XmlAttribute(required = true)
-    private String resource;
-
-    public String getResource() {
-        return resource;
-    }
-
-    public void setResource(String resource) {
-        this.resource = resource;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/PackageScanRouteBuilderFinder.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/PackageScanRouteBuilderFinder.java
deleted file mode 100644
index 4bcf8468d72..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/PackageScanRouteBuilderFinder.java
+++ /dev/null
@@ -1,94 +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.cdi.xml;
-
-import java.lang.reflect.Modifier;
-import java.util.List;
-import java.util.Map;
-import java.util.Set;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.RoutesBuilder;
-import org.apache.camel.spi.PackageScanClassResolver;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * A helper class which will find all {@link org.apache.camel.builder.RouteBuilder} instances on the classpath.
- */
-@Deprecated
-final class PackageScanRouteBuilderFinder {
-
-    private final Logger logger = LoggerFactory.getLogger(PackageScanRouteBuilderFinder.class);
-
-    private final CamelContext camelContext;
-
-    private final String[] packages;
-
-    private final PackageScanClassResolver resolver;
-
-    PackageScanRouteBuilderFinder(CamelContext camelContext, String[] packages, ClassLoader classLoader,
-                                  PackageScanClassResolver resolver) {
-        this.camelContext = camelContext;
-        this.packages = packages;
-        this.resolver = resolver;
-        resolver.addClassLoader(classLoader);
-    }
-
-    /**
-     * Appends all the {@link org.apache.camel.builder.RouteBuilder} instances that can be found on the classpath
-     */
-    void appendBuilders(List<RoutesBuilder> list) {
-        Set<Class<?>> classes = resolver.findImplementations(RoutesBuilder.class, packages);
-        for (Class<?> aClass : classes) {
-            logger.trace("Found RouteBuilder class: {}", aClass);
-
-            // certain beans should be ignored
-            if (shouldIgnoreBean(aClass)) {
-                logger.debug("Ignoring RouteBuilder class: {}", aClass);
-                continue;
-            }
-
-            if (!isValidClass(aClass)) {
-                logger.debug("Ignoring invalid RouteBuilder class: {}", aClass);
-                continue;
-            }
-
-            // type is valid so create and instantiate the builder
-            @SuppressWarnings("unchecked")
-            RoutesBuilder builder = instantiateBuilder((Class<? extends RoutesBuilder>) aClass);
-
-            logger.debug("Adding instantiated RouteBuilder: {}", builder);
-            list.add(builder);
-        }
-    }
-
-    private boolean shouldIgnoreBean(Class<?> type) {
-        Map<String, ?> beans = camelContext.getRegistry().findByTypeWithName(type);
-        return !(beans == null || beans.isEmpty());
-    }
-
-    private boolean isValidClass(Class<?> type) {
-        return Modifier.isPublic(type.getModifiers())
-                && !Modifier.isAbstract(type.getModifiers())
-                && !type.isInterface();
-    }
-
-    private RoutesBuilder instantiateBuilder(Class<? extends RoutesBuilder> type) {
-        return camelContext.getInjector().newInstance(type);
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ProducerTemplateFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ProducerTemplateFactoryBean.java
deleted file mode 100644
index d7862cf5a51..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ProducerTemplateFactoryBean.java
+++ /dev/null
@@ -1,62 +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.cdi.xml;
-
-import javax.enterprise.inject.spi.BeanManager;
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlTransient;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.core.xml.AbstractCamelProducerTemplateFactoryBean;
-
-/**
- * A factory for creating a new {@link org.apache.camel.ProducerTemplate} instance with a minimum of XML
- */
-@XmlRootElement(name = "template")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class ProducerTemplateFactoryBean extends AbstractCamelProducerTemplateFactoryBean implements BeanManagerAware {
-
-    @XmlTransient
-    private BeanManager manager;
-
-    @Override
-    public void setBeanManager(BeanManager manager) {
-        this.manager = manager;
-    }
-
-    @Override
-    protected CamelContext getCamelContextWithId(String camelContextId) {
-        return BeanManagerHelper.getCamelContextById(manager, camelContextId);
-    }
-
-    @Override
-    protected CamelContext discoverDefaultCamelContext() {
-        return BeanManagerHelper.getDefaultCamelContext(manager);
-    }
-
-    @Override
-    @SuppressWarnings("unchecked")
-    // Work-around as DefaultProducerTemplate does not have a default no-args constructor
-    // which leads to OpenWebBeans being unable to create proxies for the corresponding bean
-    public Class getObjectType() {
-        return ProducerTemplate.class;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RedeliveryPolicyFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RedeliveryPolicyFactoryBean.java
deleted file mode 100644
index 0c25cbe0006..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RedeliveryPolicyFactoryBean.java
+++ /dev/null
@@ -1,54 +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.cdi.xml;
-
-import javax.enterprise.inject.spi.BeanManager;
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlTransient;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.core.xml.AbstractCamelRedeliveryPolicyFactoryBean;
-import org.apache.camel.processor.errorhandler.RedeliveryPolicy;
-
-/**
- * A factory which instantiates {@link RedeliveryPolicy} objects
- */
-@XmlRootElement(name = "redeliveryPolicyProfile")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class RedeliveryPolicyFactoryBean extends AbstractCamelRedeliveryPolicyFactoryBean implements BeanManagerAware {
-
-    @XmlTransient
-    private BeanManager manager;
-
-    @Override
-    public void setBeanManager(BeanManager manager) {
-        this.manager = manager;
-    }
-
-    @Override
-    protected CamelContext getCamelContextWithId(String camelContextId) {
-        return BeanManagerHelper.getCamelContextById(manager, camelContextId);
-    }
-
-    @Override
-    protected CamelContext discoverDefaultCamelContext() {
-        return BeanManagerHelper.getDefaultCamelContext(manager);
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RestContextDefinition.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RestContextDefinition.java
deleted file mode 100644
index 00a24f9061f..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RestContextDefinition.java
+++ /dev/null
@@ -1,45 +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.cdi.xml;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.model.IdentifiedType;
-import org.apache.camel.model.rest.RestDefinition;
-
-@XmlRootElement(name = "restContext")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class RestContextDefinition extends IdentifiedType {
-
-    @XmlElement(name = "rest", required = true)
-    private List<RestDefinition> rests = new ArrayList<>();
-
-    public List<RestDefinition> getRests() {
-        return rests;
-    }
-
-    public void setRests(List<RestDefinition> rests) {
-        this.rests = rests;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteConfigurationContextDefinition.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteConfigurationContextDefinition.java
deleted file mode 100644
index 84880dfde2d..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteConfigurationContextDefinition.java
+++ /dev/null
@@ -1,45 +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.cdi.xml;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.model.IdentifiedType;
-import org.apache.camel.model.RouteConfigurationDefinition;
-
-@XmlRootElement(name = "routeConfigurationContext")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class RouteConfigurationContextDefinition extends IdentifiedType {
-
-    @XmlElement(name = "routeConfiguration", required = true)
-    private List<RouteConfigurationDefinition> routeConfigurations = new ArrayList<>();
-
-    public List<RouteConfigurationDefinition> getRouteConfigurations() {
-        return routeConfigurations;
-    }
-
-    public void setRouteConfigurations(List<RouteConfigurationDefinition> routeConfigurations) {
-        this.routeConfigurations = routeConfigurations;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteContextDefinition.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteContextDefinition.java
deleted file mode 100644
index 0930d8c6ac6..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteContextDefinition.java
+++ /dev/null
@@ -1,45 +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.cdi.xml;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.model.IdentifiedType;
-import org.apache.camel.model.RouteDefinition;
-
-@XmlRootElement(name = "routeContext")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class RouteContextDefinition extends IdentifiedType {
-
-    @XmlElement(name = "route", required = true)
-    private List<RouteDefinition> routes = new ArrayList<>();
-
-    public List<RouteDefinition> getRoutes() {
-        return routes;
-    }
-
-    public void setRoutes(List<RouteDefinition> routes) {
-        this.routes = routes;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteTemplateContextDefinition.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteTemplateContextDefinition.java
deleted file mode 100644
index 5e52b5a7909..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/RouteTemplateContextDefinition.java
+++ /dev/null
@@ -1,45 +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.cdi.xml;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.apache.camel.model.IdentifiedType;
-import org.apache.camel.model.RouteTemplateDefinition;
-
-@XmlRootElement(name = "routeTemplateContext")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class RouteTemplateContextDefinition extends IdentifiedType {
-
-    @XmlElement(name = "routeTemplate", required = true)
-    private List<RouteTemplateDefinition> routeTemplates = new ArrayList<>();
-
-    public List<RouteTemplateDefinition> getRouteTemplates() {
-        return routeTemplates;
-    }
-
-    public void setRouteTemplates(List<RouteTemplateDefinition> routeTemplates) {
-        this.routeTemplates = routeTemplates;
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ThreadPoolFactoryBean.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ThreadPoolFactoryBean.java
deleted file mode 100644
index 181a701dd0b..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/ThreadPoolFactoryBean.java
+++ /dev/null
@@ -1,53 +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.cdi.xml;
-
-import javax.enterprise.inject.spi.BeanManager;
-import javax.xml.bind.annotation.XmlAccessType;
-import javax.xml.bind.annotation.XmlAccessorType;
-import javax.xml.bind.annotation.XmlRootElement;
-import javax.xml.bind.annotation.XmlTransient;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.core.xml.AbstractCamelThreadPoolFactoryBean;
-
-/**
- * A factory which instantiates {@link java.util.concurrent.ExecutorService} objects.
- */
-@XmlRootElement(name = "threadPool")
-@XmlAccessorType(XmlAccessType.FIELD)
-@Deprecated
-public class ThreadPoolFactoryBean extends AbstractCamelThreadPoolFactoryBean implements BeanManagerAware {
-
-    @XmlTransient
-    private BeanManager manager;
-
-    @Override
-    public void setBeanManager(BeanManager manager) {
-        this.manager = manager;
-    }
-
-    @Override
-    protected CamelContext getCamelContextWithId(String camelContextId) {
-        return BeanManagerHelper.getCamelContextById(manager, camelContextId);
-    }
-
-    @Override
-    protected CamelContext discoverDefaultCamelContext() {
-        return BeanManagerHelper.getDefaultCamelContext(manager);
-    }
-}
diff --git a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/package-info.java b/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/package-info.java
deleted file mode 100644
index 3573fe2af79..00000000000
--- a/components/camel-cdi/src/main/java/org/apache/camel/cdi/xml/package-info.java
+++ /dev/null
@@ -1,23 +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.
- */
-/**
- * The JAXB POJOs for the <a href="http://camel.apache.org/xml-configuration.html">XML Configuration</a> of the routing
- * rules.
- */
-@javax.xml.bind.annotation.XmlSchema(namespace = "http://camel.apache.org/schema/spring",
-                                     elementFormDefault = javax.xml.bind.annotation.XmlNsForm.QUALIFIED)
-package org.apache.camel.cdi.xml;
diff --git a/components/camel-cdi/src/main/resources/META-INF/beans.xml b/components/camel-cdi/src/main/resources/META-INF/beans.xml
index 809508ce98b..0e3dd95de90 100644
--- a/components/camel-cdi/src/main/resources/META-INF/beans.xml
+++ b/components/camel-cdi/src/main/resources/META-INF/beans.xml
@@ -24,10 +24,6 @@
             <if-class-not-available name="javax.transaction.Transaction"/>
         </exclude>
         <exclude name="org.apache.camel.cdi.xml.*"/>
-        <exclude name="org.apache.camel.cdi.XmlCdiBeanFactory"/>
-        <exclude name="org.apache.camel.cdi.XmlCdiJaxbContexts"/>
-        <exclude name="org.apache.camel.cdi.XmlErrorHandlerFactoryBean"/>
-        <exclude name="org.apache.camel.cdi.XmlFactoryBeanInjectionTarget"/>
     </scan>
 
-</beans>
\ No newline at end of file
+</beans>
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlBeansTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlBeansTest.java
deleted file mode 100644
index 477e450b67d..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlBeansTest.java
+++ /dev/null
@@ -1,76 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.inject.Inject;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-routes.xml")
-@Ignore
-public class XmlBeansTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-beans.xml").toFile(),
-                        "imported-routes.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlConsumerTemplateTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlConsumerTemplateTest.java
deleted file mode 100644
index feb4144ebe7..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlConsumerTemplateTest.java
+++ /dev/null
@@ -1,87 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.ConsumerTemplate;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.is;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlConsumerTemplateTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Named
-    @Inject
-    private ConsumerTemplate consumer;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-consumer.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void verifyConsumerTemplate() {
-        assertThat("Consumer template Camel context is incorrect!",
-                consumer.getCamelContext().getName(),
-                is(equalTo("test")));
-
-        assertThat("Consumer template cache size is incorrect!",
-                consumer.getMaximumCacheSize(),
-                is(equalTo(100)));
-    }
-
-    @Test
-    public void sendMessageToInbound() {
-        inbound.sendBody("seda:foo", "message");
-
-        String body = consumer.receiveBody("seda:foo", TimeUnit.SECONDS.toMillis(1L), String.class);
-
-        assertThat("Body is incorrect!", body, is(equalTo("message")));
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlEndpointTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlEndpointTest.java
deleted file mode 100644
index 87033230dcc..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlEndpointTest.java
+++ /dev/null
@@ -1,109 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.BlockingQueue;
-import java.util.concurrent.LinkedBlockingQueue;
-import java.util.concurrent.TimeUnit;
-
-import javax.enterprise.inject.Produces;
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.Endpoint;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.seda.SedaEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.instanceOf;
-import static org.hamcrest.Matchers.is;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlEndpointTest {
-
-    @Inject
-    @Uri("seda:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Inject
-    @Named("bar")
-    private Endpoint endpoint;
-
-    @Produces
-    @Named("queue")
-    private static <T> BlockingQueue<T> queue() {
-        return new MyBlockingQueue<>();
-    }
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-endpoint.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    @Ignore("@ApplicationScoped bean proxy cannot be casted to endpoint implementation")
-    public void verifyXmlEndpoint() {
-        assertThat("Endpoint type is incorrect!", endpoint, is(instanceOf(SedaEndpoint.class)));
-        SedaEndpoint seda = (SedaEndpoint) endpoint;
-        assertThat("Endpoint queue is incorrect!",
-                seda.getQueue(), is(instanceOf(MyBlockingQueue.class)));
-        assertThat("Endpoint concurrent consumers count is incorrect!",
-                seda.getConcurrentConsumers(), is(equalTo(10)));
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
-
-class MyBlockingQueue<E> extends LinkedBlockingQueue<E> {
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlErrorHandlerPolicyTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlErrorHandlerPolicyTest.java
deleted file mode 100644
index 2ca59e11d2d..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlErrorHandlerPolicyTest.java
+++ /dev/null
@@ -1,137 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.enterprise.inject.Produces;
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.CamelException;
-import org.apache.camel.CamelExecutionException;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.cdi.rule.LogEventVerifier;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.ClassRule;
-import org.junit.Test;
-import org.junit.rules.TestRule;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.cdi.rule.LogEventMatcher.logEvent;
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.containsInRelativeOrder;
-import static org.hamcrest.Matchers.containsString;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.instanceOf;
-import static org.hamcrest.Matchers.is;
-import static org.hamcrest.Matchers.matchesPattern;
-import static org.junit.Assert.fail;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlErrorHandlerPolicyTest {
-
-    @ClassRule
-    public static TestRule verifier = new LogEventVerifier() {
-        @Override
-        protected void verify() {
-            assertThat("Log messages not found!", getEvents(),
-                    containsInRelativeOrder(
-                            logEvent()
-                                    .withLevel("INFO")
-                                    .withMessage(containsString("Camel CDI is starting Camel context [test]")),
-                            logEvent()
-                                    .withLevel("WARN")
-                                    .withMessage(matchesPattern(
-                                            "Failed delivery for \\(MessageId: .+\\). "
-                                                                + "On delivery attempt: 3 "
-                                                                + "caught: org.apache.camel.CamelException: failure message!")),
-                            logEvent()
-                                    .withLevel("ERROR")
-                                    .withMessage(matchesPattern(
-                                            "(?s)Failed delivery for \\(MessageId: .+\\). "
-                                                                + "Exhausted after delivery attempt: 4 "
-                                                                + "caught: org.apache.camel.CamelException: failure message!.*")),
-                            logEvent()
-                                    .withLevel("INFO")
-                                    .withMessage(containsString("Camel CDI is stopping Camel context [test]"))));
-        }
-    };
-
-    @Named
-    @Produces
-    private Exception failure = new CamelException("failure message!");
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-errorHandler-policy.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("Response to message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-
-    @Test
-    public void sendExceptionToInbound() {
-        try {
-            inbound.sendBody("exception");
-        } catch (Exception exception) {
-            assertThat("Exception is incorrect!",
-                    exception, is(instanceOf(CamelExecutionException.class)));
-            assertThat("Exception cause is incorrect!",
-                    exception.getCause(), is(instanceOf(CamelException.class)));
-            assertThat("Exception message is incorrect!",
-                    exception.getCause().getMessage(), is(equalTo("failure message!")));
-            return;
-        }
-        fail("No exception thrown!");
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlErrorHandlerTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlErrorHandlerTest.java
deleted file mode 100644
index e1555c70b41..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlErrorHandlerTest.java
+++ /dev/null
@@ -1,103 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.enterprise.inject.Produces;
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.Processor;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlErrorHandlerTest {
-
-    @Named
-    @Produces
-    private Processor processor = exchange -> exchange.getIn()
-            .setHeader("header",
-                    exchange.getProperty(Exchange.EXCEPTION_CAUGHT, Exception.class).getMessage());
-
-    @Named
-    @Produces
-    private Exception failure = new Exception("failure message!");
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:exception")
-    private MockEndpoint exception;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-errorHandler.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("Response to message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-
-    @Test
-    public void sendExceptionToInbound() throws InterruptedException {
-        exception.expectedMessageCount(1);
-        exception.expectedBodiesReceived("exception");
-        exception.expectedHeaderReceived("header", "failure message!");
-
-        inbound.sendBody("exception");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, exception);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlProducerTemplateTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlProducerTemplateTest.java
deleted file mode 100644
index f1911874781..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlProducerTemplateTest.java
+++ /dev/null
@@ -1,93 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.is;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlProducerTemplateTest {
-
-    @Named
-    @Inject
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-producer.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void verifyProducerTemplate() {
-        assertThat("Producer template Camel context is incorrect!",
-                inbound.getCamelContext().getName(),
-                is(equalTo("test")));
-
-        assertThat("Producer template cache size is incorrect!",
-                inbound.getMaximumCacheSize(),
-                is(equalTo(100)));
-
-        assertThat("Producer template default endpoint is incorrect!",
-                inbound.getDefaultEndpoint().getEndpointUri(),
-                is(equalTo("direct://inbound")));
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlPropertyPlaceholderTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlPropertyPlaceholderTest.java
deleted file mode 100644
index 25fa267d4d3..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlPropertyPlaceholderTest.java
+++ /dev/null
@@ -1,60 +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.cdi.test;
-
-import java.nio.file.Paths;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.is;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlPropertyPlaceholderTest {
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-properties.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void resolvePropertyFromLocation(CamelContext context) throws Exception {
-        assertThat("Property from classpath location does not resolve!",
-                context.resolvePropertyPlaceholders("{{header.message}}"),
-                is(equalTo("message from file")));
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRestContextTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRestContextTest.java
deleted file mode 100644
index 87008ec0cd9..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRestContextTest.java
+++ /dev/null
@@ -1,103 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.List;
-import java.util.concurrent.TimeUnit;
-
-import javax.enterprise.inject.Produces;
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.cdi.mock.DummyRestConsumerFactory;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.model.rest.RestDefinition;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.hasSize;
-import static org.hamcrest.Matchers.is;
-
-@RunWith(Arquillian.class)
-@ImportResource({
-        "imported-context-restContext.xml",
-        "imported-context-restContextRef.xml"
-})
-public class XmlRestContextTest {
-
-    @Produces
-    private static DummyRestConsumerFactory rest = new DummyRestConsumerFactory();
-
-    @Inject
-    @Uri("seda:get-inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Inject
-    @Named("rest")
-    private List<RestDefinition> rests;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-restContext.xml").toFile(),
-                        "imported-context-restContext.xml")
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-restContextRef.xml").toFile(),
-                        "imported-context-restContextRef.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void verifyRestContext() {
-        assertThat("Rest context is incorrect!", rests, hasSize(1));
-        RestDefinition rest = rests.get(0);
-        assertThat("Rest path is incorrect!", rest.getPath(), is(equalTo("/inbound")));
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("Response to request");
-
-        inbound.sendBody("request");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteConfigurationTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteConfigurationTest.java
deleted file mode 100644
index 7bbcb0dc290..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteConfigurationTest.java
+++ /dev/null
@@ -1,77 +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.cdi.test;
-
-import java.nio.file.Paths;
-
-import javax.inject.Inject;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.junit.Assert.fail;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlRouteConfigurationTest {
-
-    @Inject
-    private ProducerTemplate template;
-
-    @Inject
-    @Uri("mock:error")
-    private MockEndpoint mock;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routeConfiguration.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void testRoutesConfigurationOnException() throws Exception {
-        mock.expectedBodiesReceived("Bye World");
-
-        try {
-            template.sendBody("direct:start", "Hello World");
-            fail("Should throw exception");
-        } catch (Exception e) {
-            // expected
-        }
-        template.sendBody("direct:start2", "Bye World");
-
-        mock.assertIsSatisfied();
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteContextImportTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteContextImportTest.java
deleted file mode 100644
index 8b9cd1af522..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteContextImportTest.java
+++ /dev/null
@@ -1,97 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.List;
-import java.util.concurrent.TimeUnit;
-
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.model.RouteDefinition;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.hasSize;
-import static org.hamcrest.Matchers.is;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlRouteContextImportTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Inject
-    @Named("import")
-    private List<RouteDefinition> routes;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routeContextRef-import.xml").toFile(),
-                        "imported-context.xml")
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routeContext.xml").toFile(),
-                        "imported-route-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void verifyRouteContext() {
-        assertThat("Route context is incorrect!", routes, hasSize(1));
-        RouteDefinition route = routes.get(0);
-
-        assertThat("Route is incorrect!",
-                route.getInput().getEndpointUri(), is(equalTo("direct:inbound")));
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("Response to message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteContextResourceTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteContextResourceTest.java
deleted file mode 100644
index 687f2b53870..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteContextResourceTest.java
+++ /dev/null
@@ -1,80 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.inject.Inject;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-
-@RunWith(Arquillian.class)
-@ImportResource({
-        "imported-context.xml",
-        "imported-route-context.xml"
-})
-public class XmlRouteContextResourceTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routeContextRef.xml").toFile(),
-                        "imported-context.xml")
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routeContext.xml").toFile(),
-                        "imported-route-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("Response to message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteTemplateContextImportTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteTemplateContextImportTest.java
deleted file mode 100644
index f91ad55a1de..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRouteTemplateContextImportTest.java
+++ /dev/null
@@ -1,85 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.List;
-
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.model.RouteTemplateDefinition;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.hasSize;
-import static org.junit.Assert.assertEquals;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlRouteTemplateContextImportTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Inject
-    @Named("myCoolTemplates")
-    private List<RouteTemplateDefinition> templates;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routeContextTemplateRef-import.xml").toFile(),
-                        "imported-context.xml")
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routeTemplateContext.xml").toFile(),
-                        "imported-routetemplate-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void verifyRouteTemplateContext() {
-        assertThat("RouteTemplate context is incorrect!", templates, hasSize(1));
-        RouteTemplateDefinition template = templates.get(0);
-
-        assertEquals(2, template.getTemplateParameters().size());
-        assertEquals("direct:{{foo}}", template.getRoute().getInput().getEndpointUri());
-    }
-
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRoutesDefinitionTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRoutesDefinitionTest.java
deleted file mode 100644
index 5ee36997169..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlRoutesDefinitionTest.java
+++ /dev/null
@@ -1,74 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.inject.Inject;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-routes.xml")
-public class XmlRoutesDefinitionTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:outbound")
-    private MockEndpoint outbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-routes.xml").toFile(),
-                        "imported-routes.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlServiceCallConfigurationTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlServiceCallConfigurationTest.java
deleted file mode 100644
index 1843392a104..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlServiceCallConfigurationTest.java
+++ /dev/null
@@ -1,82 +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.cdi.test;
-
-import java.nio.file.Paths;
-
-import javax.inject.Inject;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.model.Model;
-import org.apache.camel.model.cloud.ServiceCallConfigurationDefinition;
-import org.apache.camel.model.cloud.StaticServiceCallServiceDiscoveryConfiguration;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlServiceCallConfigurationTest {
-
-    @Inject
-    private CamelContext context;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-service-call-configuration.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void testServiceDiscoveryConfiguration() {
-        ServiceCallConfigurationDefinition conf1 = context.getExtension(Model.class).getServiceCallConfiguration("conf1");
-        assertNotNull("No ServiceCallConfiguration (1)", conf1);
-        assertNotNull("No ServiceDiscoveryConfiguration (1)", conf1.getServiceDiscoveryConfiguration());
-
-        StaticServiceCallServiceDiscoveryConfiguration discovery1
-                = (StaticServiceCallServiceDiscoveryConfiguration) conf1.getServiceDiscoveryConfiguration();
-        assertEquals(1, discovery1.getServers().size());
-        assertEquals("localhost:9091", discovery1.getServers().get(0));
-
-        ServiceCallConfigurationDefinition conf2 = context.getExtension(Model.class).getServiceCallConfiguration("conf2");
-        assertNotNull("No ServiceCallConfiguration (2)", conf2);
-        assertNotNull("No ServiceDiscoveryConfiguration (2)", conf2.getServiceDiscoveryConfiguration());
-
-        StaticServiceCallServiceDiscoveryConfiguration discovery2
-                = (StaticServiceCallServiceDiscoveryConfiguration) conf2.getServiceDiscoveryConfiguration();
-        assertEquals(2, discovery2.getServers().size());
-        assertEquals("localhost:9092", discovery2.getServers().get(0));
-        assertEquals("localhost:9093,localhost:9094", discovery2.getServers().get(1));
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlTemplatedRoutesDefinitionTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlTemplatedRoutesDefinitionTest.java
deleted file mode 100644
index b8934fd54b2..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlTemplatedRoutesDefinitionTest.java
+++ /dev/null
@@ -1,74 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.TimeUnit;
-
-import javax.inject.Inject;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.apache.camel.component.mock.MockEndpoint.assertIsSatisfied;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-routes.xml")
-public class XmlTemplatedRoutesDefinitionTest {
-
-    @Inject
-    @Uri("direct:fooVal")
-    private ProducerTemplate inbound;
-
-    @Inject
-    @Uri("mock:barVal")
-    private MockEndpoint outbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-templated-routes.xml").toFile(),
-                        "imported-routes.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void sendMessageToInbound() throws InterruptedException {
-        outbound.expectedMessageCount(1);
-        outbound.expectedBodiesReceived("message");
-
-        inbound.sendBody("message");
-
-        assertIsSatisfied(2L, TimeUnit.SECONDS, outbound);
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlThreadPoolProfileTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlThreadPoolProfileTest.java
deleted file mode 100644
index 4fd2ac1a61e..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlThreadPoolProfileTest.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.cdi.test;
-
-import java.nio.file.Paths;
-
-import javax.inject.Inject;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.apache.camel.spi.ThreadPoolProfile;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.equalTo;
-import static org.hamcrest.Matchers.is;
-import static org.hamcrest.Matchers.matchesPattern;
-import static org.hamcrest.Matchers.notNullValue;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlThreadPoolProfileTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-threadPoolProfile.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void verifyThreadProfile(CamelContext context) {
-        ThreadPoolProfile profile = context.getExecutorServiceManager().getThreadPoolProfile("thread-pool-profile");
-        assertThat("Thread pool profile is null!", profile, is(notNullValue()));
-        assertThat("Thread pool profile is incorrect!", profile.getPoolSize(), is(equalTo(5)));
-    }
-
-    @Test
-    public void sendMessageToInbound() {
-        String body = inbound.requestBody((Object) "message", String.class);
-
-        assertThat("Body is incorrect!", body,
-                matchesPattern("^Processed \\[message] with \\[Camel \\(test\\) thread #\\d+ - Profile Threads]$"));
-    }
-}
diff --git a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlThreadPoolTest.java b/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlThreadPoolTest.java
deleted file mode 100644
index 2dc1c217c7d..00000000000
--- a/components/camel-cdi/src/test/java/org/apache/camel/cdi/test/XmlThreadPoolTest.java
+++ /dev/null
@@ -1,76 +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.cdi.test;
-
-import java.nio.file.Paths;
-import java.util.concurrent.ExecutorService;
-
-import javax.inject.Inject;
-import javax.inject.Named;
-
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.cdi.CdiCamelExtension;
-import org.apache.camel.cdi.ImportResource;
-import org.apache.camel.cdi.Uri;
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.EmptyAsset;
-import org.jboss.shrinkwrap.api.spec.JavaArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import static org.hamcrest.MatcherAssert.assertThat;
-import static org.hamcrest.Matchers.is;
-import static org.hamcrest.Matchers.matchesPattern;
-import static org.hamcrest.Matchers.notNullValue;
-
-@RunWith(Arquillian.class)
-@ImportResource("imported-context.xml")
-public class XmlThreadPoolTest {
-
-    @Inject
-    @Uri("direct:inbound")
-    private ProducerTemplate inbound;
-
-    @Deployment
-    public static Archive<?> deployment() {
-        return ShrinkWrap.create(JavaArchive.class)
-                // Camel CDI
-                .addPackage(CdiCamelExtension.class.getPackage())
-                // Test Camel XML
-                .addAsResource(
-                        Paths.get("src/test/resources/camel-context-threadPool.xml").toFile(),
-                        "imported-context.xml")
-                // Bean archive deployment descriptor
-                .addAsManifestResource(EmptyAsset.INSTANCE, "beans.xml");
-    }
-
-    @Test
-    public void verifyThreadPool(@Named("thread-pool") ExecutorService executor) {
-        assertThat("Thread pool is incorrect!", executor, is(notNullValue()));
-    }
-
-    @Test
-    public void sendMessageToInbound() {
-        String body = inbound.requestBody((Object) "message", String.class);
-
-        assertThat("Body is incorrect!", body,
-                matchesPattern("^Processed \\[message] with \\[Camel \\(test\\) thread #\\d+ - Thread Name]$"));
-    }
-}
diff --git a/components/camel-cdi/src/test/resources/camel-context-beans.xml b/components/camel-cdi/src/test/resources/camel-context-beans.xml
deleted file mode 100644
index ea12728130a..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-beans.xml
+++ /dev/null
@@ -1,36 +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:camel="http://camel.apache.org/schema/spring"
-       xsi:schemaLocation="http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <camel:endpoint id="inbound" uri="direct:inbound"/>
-    <camel:endpoint id="outbound" uri="mock:outbound"/>
-
-    <camel:camelContext>
-        <camel:route>
-            <camel:from uri="ref:inbound"/>
-            <camel:to uri="ref:outbound"/>
-        </camel:route>
-    </camel:camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-consumer.xml b/components/camel-cdi/src/test/resources/camel-context-consumer.xml
deleted file mode 100644
index fdcf1f7325c..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-consumer.xml
+++ /dev/null
@@ -1,32 +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.
-
--->
-<camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <consumerTemplate id="consumer" maximumCacheSize="100"/>
-
-    <route>
-        <from uri="direct:inbound"/>
-        <to uri="seda:outbound"/>
-    </route>
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-endpoint.xml b/components/camel-cdi/src/test/resources/camel-context-endpoint.xml
deleted file mode 100644
index c211c2accc0..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-endpoint.xml
+++ /dev/null
@@ -1,35 +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.
-
--->
-<camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <endpoint id="bar" uri="seda:inbound">
-        <property key="queue" value="#queue"/>
-        <property key="concurrentConsumers" value="10"/>
-    </endpoint>
-
-    <route>
-        <from uri="ref:bar"/>
-        <to uri="mock:outbound"/>
-    </route>
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-errorHandler-policy.xml b/components/camel-cdi/src/test/resources/camel-context-errorHandler-policy.xml
deleted file mode 100644
index 62cc38d90f6..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-errorHandler-policy.xml
+++ /dev/null
@@ -1,48 +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.
-
--->
-<camelContext id="test" errorHandlerRef="error-handler"
-              xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <errorHandler id="error-handler" redeliveryPolicyRef="policy"/>
-
-    <redeliveryPolicyProfile id="policy" maximumRedeliveries="3"
-                             redeliveryDelay="25"
-                             retryAttemptedLogLevel="WARN"/>
-
-    <route>
-        <from uri="direct:inbound"/>
-        <choice>
-            <when>
-                <simple>${body} contains 'exception'</simple>
-                <throwException ref="failure"/>
-            </when>
-            <otherwise>
-                <transform>
-                    <simple>Response to ${body}</simple>
-                </transform>
-                <to uri="mock:outbound"/>
-            </otherwise>
-        </choice>
-    </route>
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-errorHandler.xml b/components/camel-cdi/src/test/resources/camel-context-errorHandler.xml
deleted file mode 100644
index 69a76cb8d17..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-errorHandler.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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <errorHandler id="error-handler"
-                  type="DeadLetterChannel"
-                  deadLetterUri="mock:exception"
-                  onPrepareFailureRef="processor" xmlns="http://camel.apache.org/schema/spring"/>
-
-    <camelContext id="test" errorHandlerRef="error-handler"
-                  xmlns="http://camel.apache.org/schema/spring">
-
-        <route>
-            <from uri="direct:inbound"/>
-            <choice>
-                <when>
-                    <simple>${body} contains 'exception'</simple>
-                    <throwException ref="failure"/>
-                </when>
-                <otherwise>
-                    <transform>
-                        <simple>Response to ${body}</simple>
-                    </transform>
-                    <to uri="mock:outbound"/>
-                </otherwise>
-            </choice>
-        </route>
-
-    </camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-export.xml b/components/camel-cdi/src/test/resources/camel-context-export.xml
deleted file mode 100644
index 4c7618057c3..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-export.xml
+++ /dev/null
@@ -1,31 +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.
-
--->
-<camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <export id="service" uri="direct:service"
-            serviceRef="implementation"/>
-            <!-- Eager instantiation of bean whose type is an interface
-            does not work in OpenWebBeans -->
-            <!--serviceInterface="org.apache.camel.cdi.bean.Service"-->
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-multiples.xml b/components/camel-cdi/src/test/resources/camel-context-multiples.xml
deleted file mode 100644
index b9052a2941f..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-multiples.xml
+++ /dev/null
@@ -1,39 +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-3.0.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <camelContext id="first" xmlns="http://camel.apache.org/schema/spring">
-        <route id="first-route">
-            <from uri="direct:inbound"/>
-            <setHeader name="context">
-                <constant>first</constant>
-            </setHeader>
-            <to uri="mock:outbound"/>
-        </route>
-    </camelContext>
-
-    <camelContext id="second">
-
-    </camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-producer.xml b/components/camel-cdi/src/test/resources/camel-context-producer.xml
deleted file mode 100644
index aac1ac5aff0..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-producer.xml
+++ /dev/null
@@ -1,32 +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.
-
--->
-<camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <template id="inbound" defaultEndpoint="direct:inbound" maximumCacheSize="100"/>
-
-    <route>
-        <from uri="direct:inbound"/>
-        <to uri="mock:outbound"/>
-    </route>
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-properties.xml b/components/camel-cdi/src/test/resources/camel-context-properties.xml
deleted file mode 100644
index 5554037ff49..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-properties.xml
+++ /dev/null
@@ -1,27 +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.
-
--->
-<camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <propertyPlaceholder location="classpath:placeholder.properties"/>
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-proxy.xml b/components/camel-cdi/src/test/resources/camel-context-proxy.xml
deleted file mode 100644
index f1322e44334..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-proxy.xml
+++ /dev/null
@@ -1,36 +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.
-
--->
-<camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <proxy id="proxy"
-           serviceInterface="org.apache.camel.cdi.bean.Service"
-           serviceUrl="direct:service"/>
-
-    <route>
-        <from uri="direct:service"/>
-        <transform>
-            <simple>Service called with: [${body}]</simple>
-        </transform>
-    </route>
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-restContext.xml b/components/camel-cdi/src/test/resources/camel-context-restContext.xml
deleted file mode 100644
index 0b4375415cd..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-restContext.xml
+++ /dev/null
@@ -1,31 +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.
-
--->
-<restContext id="rest" xmlns="http://camel.apache.org/schema/spring"
-             xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-             xsi:schemaLocation="http://camel.apache.org/schema/spring
-             http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <rest path="/inbound">
-        <get>
-            <to uri="direct:inbound"/>
-        </get>
-    </rest>
-
-</restContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-restContextRef.xml b/components/camel-cdi/src/test/resources/camel-context-restContextRef.xml
deleted file mode 100644
index 02f58d0c7a1..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-restContextRef.xml
+++ /dev/null
@@ -1,35 +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.
-
--->
-<camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-              xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-              xsi:schemaLocation="http://camel.apache.org/schema/spring
-              http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <restContextRef ref="rest"/>
-
-    <route>
-        <from uri="direct:inbound"/>
-        <transform>
-            <simple>Response to ${body}</simple>
-        </transform>
-        <to uri="mock:outbound"/>
-    </route>
-
-</camelContext>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-routeConfiguration.xml b/components/camel-cdi/src/test/resources/camel-context-routeConfiguration.xml
deleted file mode 100644
index a77cae34c63..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-routeConfiguration.xml
+++ /dev/null
@@ -1,49 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <camelContext xmlns="http://camel.apache.org/schema/spring">
-
-        <routeConfiguration id="handleError">
-            <onException>
-                <exception>java.lang.Exception</exception>
-                <handled>
-                    <constant>true</constant>
-                </handled>
-                <to uri="mock:error"/>
-            </onException>
-        </routeConfiguration>
-
-        <route>
-            <from uri="direct:start"/>
-            <throwException exceptionType="java.lang.IllegalArgumentException" message="Foo"/>
-        </route>
-
-        <route routeConfigurationId="handleError">
-            <from uri="direct:start2"/>
-            <throwException exceptionType="java.lang.IllegalArgumentException" message="Foo2"/>
-        </route>
-
-    </camelContext>
-
-</beans>
diff --git a/components/camel-cdi/src/test/resources/camel-context-routeContext.xml b/components/camel-cdi/src/test/resources/camel-context-routeContext.xml
deleted file mode 100644
index 4d1d6845268..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-routeContext.xml
+++ /dev/null
@@ -1,32 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <routeContext id="import" xmlns="http://camel.apache.org/schema/spring">
-        <route>
-            <from uri="direct:inbound"/>
-            <to uri="direct:outbound"/>
-        </route>
-    </routeContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-routeContextRef-import.xml b/components/camel-cdi/src/test/resources/camel-context-routeContextRef-import.xml
deleted file mode 100644
index a4641897b70..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-routeContextRef-import.xml
+++ /dev/null
@@ -1,41 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <import resource="imported-route-context.xml" xmlns="http://camel.apache.org/schema/spring"/>
-
-    <camelContext id="test" xmlns="http://camel.apache.org/schema/spring">
-
-        <routeContextRef ref="import"/>
-
-        <route>
-            <from uri="direct:outbound"/>
-            <transform>
-                <simple>Response to ${body}</simple>
-            </transform>
-            <to uri="mock:outbound"/>
-        </route>
-
-    </camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-routeContextRef.xml b/components/camel-cdi/src/test/resources/camel-context-routeContextRef.xml
deleted file mode 100644
index c130cf8ea49..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-routeContextRef.xml
+++ /dev/null
@@ -1,42 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <!-- Test with Camel CDI resource import -->
-    <!--<import resource="imported-route-context.xml"/>-->
-
-    <camelContext id="test" xmlns="http://camel.apache.org/schema/spring">
-
-        <routeContextRef ref="import"/>
-
-        <route>
-            <from uri="direct:outbound"/>
-            <transform>
-                <simple>Response to ${body}</simple>
-            </transform>
-            <to uri="mock:outbound"/>
-        </route>
-
-    </camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-routeContextTemplateRef-import.xml b/components/camel-cdi/src/test/resources/camel-context-routeContextTemplateRef-import.xml
deleted file mode 100644
index d9308ae906d..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-routeContextTemplateRef-import.xml
+++ /dev/null
@@ -1,33 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <import resource="imported-routetemplate-context.xml" xmlns="http://camel.apache.org/schema/spring"/>
-
-    <camelContext id="test" xmlns="http://camel.apache.org/schema/spring">
-
-        <routeTemplateContextRef ref="myCoolTemplates"/>
-
-    </camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-routeTemplateContext.xml b/components/camel-cdi/src/test/resources/camel-context-routeTemplateContext.xml
deleted file mode 100644
index e2987e70990..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-routeTemplateContext.xml
+++ /dev/null
@@ -1,38 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <!-- this is an included XML file where we only the routeTemplateContext -->
-    <routeTemplateContext id="myCoolTemplates" xmlns="http://camel.apache.org/schema/spring">
-        <routeTemplate id="myTemplate">
-            <description>blah blah</description>
-            <templateParameter name="foo"/>
-            <templateParameter name="bar"/>
-            <route>
-                <from uri="direct:{{foo}}"/>
-                <to uri="mock:{{bar}}"/>
-            </route>
-        </routeTemplate>
-    </routeTemplateContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-routes.xml b/components/camel-cdi/src/test/resources/camel-context-routes.xml
deleted file mode 100644
index e018d5149dd..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-routes.xml
+++ /dev/null
@@ -1,30 +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.
-
--->
-<routes xmlns="http://camel.apache.org/schema/spring"
-        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-        xsi:schemaLocation="http://camel.apache.org/schema/spring
-        http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <route>
-        <from uri="direct:inbound"/>
-        <to uri="mock:outbound"/>
-    </route>
-
-</routes>
diff --git a/components/camel-cdi/src/test/resources/camel-context-service-call-configuration.xml b/components/camel-cdi/src/test/resources/camel-context-service-call-configuration.xml
deleted file mode 100644
index 52579e65d7a..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-service-call-configuration.xml
+++ /dev/null
@@ -1,54 +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.xsd
-        http://camel.apache.org/schema/spring
-        http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <camelContext id="test" xmlns="http://camel.apache.org/schema/spring">
-
-        <serviceCallConfiguration id="conf1">
-            <staticServiceDiscovery>
-                <servers>localhost:9091</servers>
-            </staticServiceDiscovery>
-        </serviceCallConfiguration>
-
-        <serviceCallConfiguration id="conf2">
-            <staticServiceDiscovery>
-                <servers>localhost:9092</servers>
-                <servers>localhost:9093,localhost:9094</servers>
-            </staticServiceDiscovery>
-        </serviceCallConfiguration>
-
-        <route id="test1">
-            <from uri="direct:start1"/>
-            <serviceCall name="test" configurationRef="conf1"/>
-        </route>
-        <route id="test2">
-            <from uri="direct:start2"/>
-            <serviceCall name="test" configurationRef="conf2"/>
-        </route>
-
-    </camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-templated-routes.xml b/components/camel-cdi/src/test/resources/camel-context-templated-routes.xml
deleted file mode 100644
index e3f2d09fe20..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-templated-routes.xml
+++ /dev/null
@@ -1,43 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <camelContext xmlns="http://camel.apache.org/schema/spring">
-
-        <routeTemplate id="myTemplate">
-            <description>blah blah</description>
-            <templateParameter name="foo"/>
-            <templateParameter name="bar"/>
-            <route>
-                <from uri="direct:{{foo}}"/>
-                <to uri="mock:{{bar}}"/>
-            </route>
-        </routeTemplate>
-        <templatedRoute routeTemplateRef="myTemplate" routeId="my-route">
-            <parameter name="foo" value="fooVal"/>
-            <parameter name="bar" value="barVal"/>
-        </templatedRoute>
-
-    </camelContext>
-
-</beans>
diff --git a/components/camel-cdi/src/test/resources/camel-context-threadPool.xml b/components/camel-cdi/src/test/resources/camel-context-threadPool.xml
deleted file mode 100644
index 8db5d3a83c6..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-threadPool.xml
+++ /dev/null
@@ -1,42 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <camelContext id="test" xmlns="http://camel.apache.org/schema/spring">
-        <threadPool id="thread-pool"
-                    poolSize="5"
-                    threadName="Thread Name"
-                    maxQueueSize="100"/>
-
-        <route>
-            <from uri="direct:inbound"/>
-            <log message="Received [${body}] from [${threadName}]"/>
-            <threads executorService="thread-pool"/>
-            <log message="Processing [${body}] with [${threadName}]"/>
-            <transform>
-                <simple>Processed [${body}] with [${threadName}]</simple>
-            </transform>
-        </route>
-    </camelContext>
-
-</beans>
\ No newline at end of file
diff --git a/components/camel-cdi/src/test/resources/camel-context-threadPoolProfile.xml b/components/camel-cdi/src/test/resources/camel-context-threadPoolProfile.xml
deleted file mode 100644
index c509001d3c8..00000000000
--- a/components/camel-cdi/src/test/resources/camel-context-threadPoolProfile.xml
+++ /dev/null
@@ -1,41 +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.xsd
-       http://camel.apache.org/schema/spring http://camel.apache.org/schema/spring/camel-spring.xsd">
-
-    <camelContext id="test" xmlns="http://camel.apache.org/schema/spring"
-                  threadNamePattern="Camel (#camelId#) thread ##counter# - Profile #name#">
-        <threadPoolProfile id="thread-pool-profile"
-                           poolSize="5"/>
-
-        <route>
-            <from uri="direct:inbound"/>
-            <log message="Received [${body}] from [${threadName}]"/>
-            <threads executorService="thread-pool-profile"/>
-            <log message="Processing [${body}] with [${threadName}]"/>
-            <transform>
-                <simple>Processed [${body}] with [${threadName}]</simple>
-            </transform>
-        </route>
-    </camelContext>
-
-</beans>
\ No newline at end of file