You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2021/03/06 15:55:37 UTC

[camel-spring-boot-examples] branch master updated: CAMEL-16011 Remove prefix spring-boot from all modules (#33)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new cbc3ad0  CAMEL-16011 Remove prefix spring-boot from all modules (#33)
cbc3ad0 is described below

commit cbc3ad06807497e075605aab586acf081e978ec9
Author: metters <me...@users.noreply.github.com>
AuthorDate: Sat Mar 6 16:55:32 2021 +0100

    CAMEL-16011 Remove prefix spring-boot from all modules (#33)
    
    In order to reproduce how I migrated/rename the modules:
    Execute `rename 's/^(spring-boot-)([a-z-]+)$/$2/' *` in the terminal.
    This does not rename two modules, for which I then executed:
    `rename 's/^(spring-boot-)(aws2-s3|resilience4j)$/$2/' *`
    
    After that I fixed all module names in the root pom.xml
    
    Co-authored-by: Matthias Streidel <ma...@senacor.com>
---
 {spring-boot-activemq => activemq}/pom.xml         |   0
 {spring-boot-activemq => activemq}/readme.adoc     |   0
 .../java/sample/camel/SampleAmqApplication.java    |   0
 .../java/sample/camel/SampleAutowiredAmqRoute.java |   0
 .../src/main/resources/application.properties      |   0
 .../sample/camel/SampleAmqApplicationTests.java    |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 .../src/main/java/sample/camel/Application.java    |   0
 .../src/main/java/sample/camel/MyRouteBuilder.java |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-amqp => amqp}/pom.xml                 |   0
 {spring-boot-amqp => amqp}/readme.adoc             |   0
 .../src/main/data/ReadMe.txt                       |   0
 .../src/main/java/sample/camel/AmqpConfig.java     |   0
 .../java/sample/camel/SampleAmqApplication.java    |   0
 .../sample/camel/SampleAutowiredAmqpRoute.java     |   0
 .../src/main/resources/application.properties      |   0
 .../sample/camel/SampleAmqApplicationTests.java    |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../src/main/java/sample/camel/CamelConfig.java    |   0
 .../src/main/java/sample/camel/CounterBean.java    |   0
 .../java/sample/camel/Service1Application.java     |   0
 .../src/main/java/sample/camel/Service1Route.java  |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-arangodb => arangodb}/README.adoc     |   0
 {spring-boot-arangodb => arangodb}/pom.xml         |   0
 .../example/springboot/arangodb/Application.java   |   0
 .../example/springboot/arangodb/CamelRoute.java    |   0
 .../example/springboot/arangodb/MyBeanService.java |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-aws2-s3 => aws2-s3}/README.adoc       |   0
 {spring-boot-aws2-s3 => aws2-s3}/pom.xml           |   0
 .../example/springboot/aws2s3/Application.java     |   0
 .../example/springboot/aws2s3/CamelRoute.java      |   0
 .../src/main/resources/application.properties      |   0
 .../src/main/resources/logback.xml                 |   0
 .../cluster-bootstrap/pom.xml                      |   0
 .../camel/examples/cluster/ClusterBootstrap.java   |   0
 .../cluster/ClusterBootstrapConfiguration.java     |   0
 .../src/main/resources/application.properties      |   0
 .../cluster-node/pom.xml                           |   0
 .../apache/camel/examples/cluster/ClusterNode.java |   0
 .../examples/cluster/ClusterNodeConfiguration.java |   0
 .../src/main/resources/application.properties      |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 {spring-boot-fhir-auth-tx => fhir-auth-tx}/pom.xml |   0
 .../readme.adoc                                    |   0
 .../src/main/data/patients.csv                     |   0
 .../main/java/sample/camel/MyCamelApplication.java |   0
 .../src/main/java/sample/camel/MyCamelRouter.java  |   0
 .../src/main/resources/application.properties      |   0
 .../java/sample/camel/MyCamelApplicationTest.java  |   0
 {spring-boot-fhir => fhir}/pom.xml                 |   0
 {spring-boot-fhir => fhir}/readme.adoc             |   0
 .../src/main/data/hl7v2.patient                    |   0
 .../main/java/sample/camel/MyCamelApplication.java |   0
 .../src/main/java/sample/camel/MyCamelRouter.java  |   0
 .../src/main/resources/application.properties      |   0
 .../java/sample/camel/MyCamelApplicationTest.java  |   0
 {spring-boot-geocoder => geocoder}/README.adoc     |   0
 {spring-boot-geocoder => geocoder}/pom.xml         |   0
 .../example/springboot/geocoder/Application.java   |   0
 .../springboot/geocoder/CamelGeocoderRoute.java    |   0
 .../src/main/resources/application.properties      |   0
 .../springboot/geocoder/ApplicationTest.java       |   0
 .../README.adoc                                    |   0
 .../hello-camel-grpc-client-kubernetes/pom.xml     |   0
 .../camel/example/springboot/grpc/Application.java |   0
 .../example/springboot/grpc/CamelGrpcRoute.java    |   0
 .../src/main/proto/hellocamel.proto                |   0
 .../src/main/resources/application.properties      |   0
 .../hello-camel-grpc-server-kubernetes/pom.xml     |   0
 .../camel/examples/grpc/HelloCamelServer.java      |   0
 .../src/main/proto/hellocamel.proto                |   0
 .../pom.xml                                        |   0
 {spring-boot-grpc => grpc}/README.adoc             |   0
 .../hello-camel-grpc-client/pom.xml                |   0
 .../camel/example/springboot/grpc/Application.java |   0
 .../example/springboot/grpc/CamelGrpcRoute.java    |   0
 .../src/main/proto/hellocamel.proto                |   0
 .../src/main/resources/application.properties      |   0
 .../hello-camel-grpc-server/pom.xml                |   0
 .../camel/examples/grpc/HelloCamelServer.java      |   0
 .../src/main/proto/hellocamel.proto                |   0
 {spring-boot-grpc => grpc}/pom.xml                 |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 .../src/main/java/sample/camel/Application.java    |   0
 .../main/java/sample/camel/MonkeyHealthCheck.java  |   0
 .../main/java/sample/camel/MyConfiguration.java    |   0
 .../src/main/java/sample/camel/MyRouteBuilder.java |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-hystrix => hystrix}/README.adoc       |   0
 {spring-boot-hystrix => hystrix}/client/pom.xml    |   0
 .../main/java/sample/camel/ClientApplication.java  |   0
 .../src/main/java/sample/camel/ClientRoute.java    |   0
 .../src/main/java/sample/camel/CounterBean.java    |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../client}/src/main/resources/META-INF/NOTICE.txt |   0
 .../client/src/main/resources/META-INF/beans.xml   |   0
 .../src/main/resources/application.properties      |   0
 .../client}/src/main/resources/log4j2.properties   |   0
 .../images/hystrix-web-console.png                 | Bin
 {spring-boot-hystrix => hystrix}/pom.xml           |   0
 {spring-boot-hystrix => hystrix}/service1/pom.xml  |   0
 .../java/sample/camel/Service1Application.java     |   0
 .../src/main/java/sample/camel/Service1Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-hystrix => hystrix}/service2/pom.xml  |   0
 .../java/sample/camel/Service2Application.java     |   0
 .../src/main/java/sample/camel/Service2Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../service2}/src/main/resources/log4j2.properties |   0
 {spring-boot-infinispan => infinispan}/README.adoc |   0
 {spring-boot-infinispan => infinispan}/pom.xml     |   0
 .../example/springboot/infinispan/Application.java |   0
 .../infinispan/CamelInfinispanRoute.java           |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-jira => jira}/README.adoc             |   0
 {spring-boot-jira => jira}/pom.xml                 |   0
 .../apache/camel/example/jira/AddIssueRoute.java   |   0
 .../org/apache/camel/example/jira/Application.java |   0
 .../apache/camel/example/jira/AttachFileRoute.java |   0
 .../camel/example/jira/NewCommentsRoute.java       |   0
 .../src/main/resources/application.properties      |   0
 .../src/main/resources/logback.xml                 |   0
 {spring-boot-kafka-avro => kafka-avro}/README.adoc |   0
 {spring-boot-kafka-avro => kafka-avro}/pom.xml     |   0
 .../camel/example/kafka/avro/Application.java      |   0
 .../camel/example/kafka/avro/AvroRouteBuilder.java |   0
 .../kafka/avro/CustomKafkaAvroDeserializer.java    |   0
 .../kafka/avro/CustomKafkaAvroSerializer.java      |   0
 .../avro/KafkaAvroMessageConsumerProcessor.java    |   0
 .../kafka/avro/KafkaAvroMessageProcessor.java      |   0
 .../example/kafka/avro/KafkaAvroProcessor.java     |   0
 .../src/main/resources/application.properties      |   0
 .../src/main/resources/avro/employee.avsc          |   0
 .../src/main/resources/log4j2.properties           |   0
 .../src/main/resources/register_schema.py          |   0
 .../src/main/resources/spring/camel-context.xml    |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../kafka/offsetRepository/KafkaProcessor.java     |   0
 .../kafka/offsetRepository/OffsetRepoApp.java      |   0
 .../src/main/resources/application.properties      |   0
 .../src/main/resources/log4j2.properties           |   0
 .../src/main/resources/offsetStateRepo.dat         |   0
 .../src/main/resources/spring/camel-context.xml    |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../camel/springboot/example/Application.java      |   0
 .../springboot/example/CustomLoadBalancer.java     |   0
 .../springboot/example/LoadBalancerEIPRouter.java  |   0
 .../camel/springboot/example/MyException.java      |   0
 .../src/main/resources/application.properties      |   0
 .../springboot/example/LoadBalancerEIPTest.java    |   0
 {spring-boot-master => master}/pom.xml             |   0
 {spring-boot-master => master}/readme.adoc         |   0
 .../apache/camel/examples/master/MasterNode.java   |   0
 .../examples/master/MasterNodeConfiguration.java   |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-metrics => metrics}/README.adoc       |   0
 {spring-boot-metrics => metrics}/pom.xml           |   0
 .../example/spring/boot/metrics/Application.java   |   0
 .../src/main/resources/application.properties      |   0
 .../README.adoc                                    |   0
 .../client/pom.xml                                 |   0
 .../main/java/sample/camel/ClientApplication.java  |   0
 .../src/main/java/sample/camel/ClientRoute.java    |   0
 .../src/main/java/sample/camel/CounterBean.java    |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../client}/src/main/resources/META-INF/NOTICE.txt |   0
 .../client}/src/main/resources/META-INF/beans.xml  |   0
 .../client}/src/main/resources/log4j2.properties   |   0
 .../loggingtracer/pom.xml                          |   0
 .../sample/opentracing/logging/LoggingTracer.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../src/main/resources/META-INF/beans.xml          |   0
 .../META-INF/services/io.opentracing.Tracer        |   0
 .../src/main/resources/log4j2.properties           |   0
 {spring-boot-opentracing => opentracing}/pom.xml   |   0
 .../service1/pom.xml                               |   0
 .../java/sample/camel/Service1Application.java     |   0
 .../src/main/java/sample/camel/Service1Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../src/main/resources/application.properties      |   0
 .../service2/pom.xml                               |   0
 .../java/sample/camel/Service2Application.java     |   0
 .../src/main/java/sample/camel/Service2Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../service2}/src/main/resources/log4j2.properties |   0
 {spring-boot-pojo => pojo}/README.adoc             |   0
 {spring-boot-pojo => pojo}/pom.xml                 |   0
 .../src/main/java/sample/camel/Application.java    |   0
 .../src/main/java/sample/camel/MagicNumber.java    |   0
 .../src/main/java/sample/camel/NumberPojo.java     |   0
 .../src/main/java/sample/camel/NumberRoute.java    |   0
 .../src/main/resources/application.properties      |   0
 pom.xml                                            |  92 ++++++++++-----------
 {spring-boot-rabbitmq => rabbitmq}/pom.xml         |   0
 {spring-boot-rabbitmq => rabbitmq}/readme.adoc     |   0
 .../java/sample/camel/SampleCamelApplication.java  |   0
 .../main/java/sample/camel/SampleCamelRouter.java  |   0
 .../src/main/resources/application.properties      |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 .../streams/BasicCamelToReactorExample.java        |   0
 .../streams/BasicCamelToReactorInOutExample.java   |   0
 .../streams/BasicReactorToCamelExample.java        |   0
 .../streams/BasicReactorToCamelInOutExample.java   |   0
 .../reactive/streams/ClientAPIRestExample.java     |   0
 .../reactive/streams/ClientAPIWorkflowExample.java |   0
 .../example/reactive/streams/RestExample.java      |   0
 .../streams/app/ReactiveStreamsSpringBootApp.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../src/main/resources/META-INF/spring.factories   |   0
 .../src/main/resources/application.yml             |   0
 .../README.adoc                                    |   0
 .../client/pom.xml                                 |   0
 .../main/java/sample/camel/ClientApplication.java  |   0
 .../src/main/java/sample/camel/ClientRoute.java    |   0
 .../src/main/java/sample/camel/CounterBean.java    |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../client}/src/main/resources/META-INF/NOTICE.txt |   0
 .../client}/src/main/resources/META-INF/beans.xml  |   0
 .../src/main/resources/application.properties      |   0
 .../client}/src/main/resources/log4j2.properties   |   0
 .../client2/pom.xml                                |   0
 .../main/java/sample/camel/Client2Application.java |   0
 .../src/main/java/sample/camel/Client2Route.java   |   0
 .../src/main/java/sample/camel/CounterBean.java    |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../client2}/src/main/resources/META-INF/beans.xml |   0
 .../src/main/resources/application.properties      |   0
 .../client2}/src/main/resources/log4j2.properties  |   0
 {spring-boot-resilience4j => resilience4j}/pom.xml |   0
 .../service1/pom.xml                               |   0
 .../java/sample/camel/Service1Application.java     |   0
 .../src/main/java/sample/camel/Service1Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../src/main/resources/application.properties      |   0
 .../service2/pom.xml                               |   0
 .../java/sample/camel/Service2Application.java     |   0
 .../src/main/java/sample/camel/Service2Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../service2/src/main/resources/log4j2.properties  |   0
 {spring-boot-rest-jpa => rest-jpa}/README.adoc     |   0
 {spring-boot-rest-jpa => rest-jpa}/pom.xml         |   0
 .../example/spring/boot/rest/jpa/Application.java  |   0
 .../camel/example/spring/boot/rest/jpa/Book.java   |   0
 .../spring/boot/rest/jpa/BookRepository.java       |   0
 .../example/spring/boot/rest/jpa/Database.java     |   0
 .../camel/example/spring/boot/rest/jpa/Order.java  |   0
 .../spring/boot/rest/jpa/OrderRepository.java      |   0
 .../example/spring/boot/rest/jpa/OrderService.java |   0
 .../src/main/resources/application-dev.yml         |   0
 .../src/main/resources/application.yml             |   0
 .../src/main/resources/data.sql                    |   0
 .../spring/boot/rest/jpa/ApplicationTest.java      |   0
 .../src/test/resources/application.yml             |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../camel/example/RestOpenApiApplication.java      |   0
 .../README.adoc                                    |   0
 {spring-boot-rest-openapi => rest-openapi}/pom.xml |   0
 .../camel/example/springboot/Application.java      |   0
 .../camel/example/springboot/CamelRouter.java      |   0
 .../org/apache/camel/example/springboot/User.java  |   0
 .../camel/example/springboot/UserService.java      |   0
 .../camel/example/springboot/UserServiceImpl.java  |   0
 .../src/main/resources/application.properties      |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 .../src/main/java/sample/camel/PetController.java  |   0
 .../main/java/sample/camel/RestApplication.java    |   0
 .../src/main/java/sample/camel/RestRoute.java      |   0
 .../src/main/resources/application.properties      |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../camel/example/RestSwaggerApplication.java      |   0
 .../README.adoc                                    |   0
 {spring-boot-rest-swagger => rest-swagger}/pom.xml |   0
 .../camel/example/springboot/Application.java      |   0
 .../camel/example/springboot/CamelRouter.java      |   0
 .../org/apache/camel/example/springboot/User.java  |   0
 .../camel/example/springboot/UserService.java      |   0
 .../camel/example/springboot/UserServiceImpl.java  |   0
 .../src/main/resources/application.properties      |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 .../main/java/sample/camel/MyCamelApplication.java |   0
 .../main/java/sample/camel/MyRouteTemplates.java   |   0
 .../main/java/sample/camel/MyTemplateBuilder.java  |   0
 .../src/main/resources/application.properties      |   0
 .../sample/camel/MyCamelApplicationJUnit5Test.java |   0
 .../README.adoc                                    |   0
 .../consumer/pom.xml                               |   0
 .../example/ServiceCallConsumerApplication.java    |   0
 .../ServiceCallConsumerAutoConfiguration.java      |   0
 .../src/main/resources/application.properties      |   0
 .../consumer/src/main/resources/logback.xml        |   0
 {spring-boot-servicecall => servicecall}/pom.xml   |   0
 .../services/pom.xml                               |   0
 .../services/src/main/bash/consul-run-linux.sh     |   0
 .../services/src/main/bash/consul-run-osx.sh       |   0
 .../apache/camel/example/ServiceApplication.java   |   0
 .../src/main/resources/application.properties      |   0
 .../src/main/resources/consul/services.json        |   0
 .../services/src/main/resources/logback.xml        |   0
 .../README.adoc                                    |   0
 {spring-boot-splitter-eip => splitter-eip}/pom.xml |   0
 .../spring/boot/AggregationStrategyPojo.java       |   0
 .../camel/example/spring/boot/Application.java     |   0
 .../example/spring/boot/MyMessageTransformer.java  |   0
 .../camel/example/spring/boot/SplitterRouter.java  |   0
 .../src/main/resources/application.properties      |   0
 .../src/test/java/CamelSplitterEIPTests.java       |   0
 {spring-boot-strimzi => strimzi}/.gitignore        |   0
 {spring-boot-strimzi => strimzi}/README.adoc       |   0
 {spring-boot-strimzi => strimzi}/pom.xml           |   0
 .../prepare-truststore.sh                          |   0
 {spring-boot-strimzi => strimzi}/route-diagram.png | Bin
 .../src/main/fabric8/deployment.yml                |   0
 .../apache/camel/example/strimzi/Application.java  |   0
 .../camel/example/strimzi/StrimziRouteBuilder.java |   0
 .../main/resources/application-local.properties    |   0
 .../src/main/resources/application.properties      |   0
 .../main/resources/kafka-ephemeral-kubernetes.yaml |   0
 .../main/resources/kafka-ephemeral-openshift.yaml  |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 .../src/main/java/sample/camel/Application.java    |   0
 .../main/java/sample/camel/ApplicationRoutes.java  |   0
 .../src/main/resources/application.properties      |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../org/apache/camel/example/mention/Contact.java  |   0
 .../mention/TwitterSalesforceApplication.java      |   0
 .../example/mention/TwitterSalesforceRoute.java    |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../src/main/resources/application.properties      |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../camel/CustomGeneratedConverterLoader.java      |   0
 .../services/org/apache/camel/TypeConverterLoader  |   0
 .../src/main/java/sample/camel/Application.java    |   0
 .../sample/camel/CustomGeneratedConverter.java     |   0
 .../java/sample/camel/CustomRuntimeConverter.java  |   0
 .../java/sample/camel/DataTypeConverterRouter.java |   0
 .../src/main/java/sample/camel/Person.java         |   0
 .../services/org/apache/camel/TypeConverter        |   0
 .../services/org/apache/camel/TypeConverterLoader  |   0
 .../src/main/resources/application.properties      |   0
 .../sample/camel/CustomConverterGeneratedTest.java |   0
 .../sample/camel/CustomConverterRuntimeTest.java   |   0
 .../pom.xml                                        |   0
 .../readme.adoc                                    |   0
 .../realm-export.json                              |   0
 .../camel/undertow/spring/boot/Application.java    |   0
 .../src/main/resources/application.properties      |   0
 .../README.adoc                                    |   0
 {spring-boot-unit-testing => unit-testing}/pom.xml |   0
 .../camel/example/spring/boot/Application.java     |   0
 .../boot/InterceptorSimulatedErrorException.java   |   0
 .../spring/boot/MockSimulatedErrorException.java   |   0
 .../camel/example/spring/boot/UnitTestsRouter.java |   0
 .../src/main/resources/application.properties      |   0
 .../src/test/java/CamelSpringBootUnitTests.java    |   0
 {spring-boot-validator => validator}/pom.xml       |   0
 {spring-boot-validator => validator}/readme.adoc   |   0
 .../main/java/sample/camel/GreetingValidator.java  |   0
 .../src/main/java/sample/camel/SampleBean.java     |   0
 .../java/sample/camel/SampleCamelApplication.java  |   0
 .../main/java/sample/camel/SampleCamelRouter.java  |   0
 .../src/main/resources/application.properties      |   0
 .../sample/camel/SampleCamelApplicationTest.java   |   0
 {spring-boot-webhook => webhook}/pom.xml           |   0
 {spring-boot-webhook => webhook}/readme.adoc       |   0
 .../apache/camel/example/webhook/Application.java  |   0
 .../src/main/resources/application.properties      |   0
 .../README.adoc                                    |   0
 .../pom.xml                                        |   0
 .../src/main/data/order1.json                      |   0
 .../src/main/data/order2.json                      |   0
 .../src/main/java/sample/camel/AmqpConfig.java     |   0
 .../src/main/java/sample/camel/OrderRoute.java     |   0
 .../main/java/sample/camel/WidgetGadgetApp.java    |   0
 .../main/java/sample/camel/WidgetGadgetRoute.java  |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-xml => xml}/pom.xml                   |   0
 {spring-boot-xml => xml}/readme.adoc               |   0
 .../src/main/java/sample/camel/SampleBean.java     |   0
 .../java/sample/camel/SampleCamelApplication.java  |   0
 .../src/main/resources/application.properties      |   0
 .../src/main/resources/my-camel.xml                |   0
 .../sample/camel/SampleCamelApplicationTest.java   |   0
 {spring-boot-zipkin => zipkin}/README.adoc         |   0
 {spring-boot-zipkin => zipkin}/client/pom.xml      |   0
 .../main/java/sample/camel/ClientApplication.java  |   0
 .../src/main/java/sample/camel/ClientRoute.java    |   0
 .../src/main/java/sample/camel/CounterBean.java    |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../client}/src/main/resources/META-INF/NOTICE.txt |   0
 .../client/src/main/resources/META-INF/beans.xml   |   0
 .../client}/src/main/resources/log4j2.properties   |   0
 .../images/zipkin-web-console-1.png                | Bin
 .../images/zipkin-web-console-2.png                | Bin
 {spring-boot-zipkin => zipkin}/pom.xml             |   0
 {spring-boot-zipkin => zipkin}/service1/pom.xml    |   0
 .../java/sample/camel/Service1Application.java     |   0
 .../src/main/java/sample/camel/Service1Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../src/main/resources/application.properties      |   0
 {spring-boot-zipkin => zipkin}/service2/pom.xml    |   0
 .../java/sample/camel/Service2Application.java     |   0
 .../src/main/java/sample/camel/Service2Route.java  |   0
 .../src/main/resources/META-INF/LICENSE.txt        |   0
 .../src/main/resources/META-INF/NOTICE.txt         |   0
 .../service2}/src/main/resources/log4j2.properties |   0
 434 files changed, 46 insertions(+), 46 deletions(-)

diff --git a/spring-boot-activemq/pom.xml b/activemq/pom.xml
similarity index 100%
rename from spring-boot-activemq/pom.xml
rename to activemq/pom.xml
diff --git a/spring-boot-activemq/readme.adoc b/activemq/readme.adoc
similarity index 100%
rename from spring-boot-activemq/readme.adoc
rename to activemq/readme.adoc
diff --git a/spring-boot-activemq/src/main/java/sample/camel/SampleAmqApplication.java b/activemq/src/main/java/sample/camel/SampleAmqApplication.java
similarity index 100%
rename from spring-boot-activemq/src/main/java/sample/camel/SampleAmqApplication.java
rename to activemq/src/main/java/sample/camel/SampleAmqApplication.java
diff --git a/spring-boot-activemq/src/main/java/sample/camel/SampleAutowiredAmqRoute.java b/activemq/src/main/java/sample/camel/SampleAutowiredAmqRoute.java
similarity index 100%
rename from spring-boot-activemq/src/main/java/sample/camel/SampleAutowiredAmqRoute.java
rename to activemq/src/main/java/sample/camel/SampleAutowiredAmqRoute.java
diff --git a/spring-boot-activemq/src/main/resources/application.properties b/activemq/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-activemq/src/main/resources/application.properties
rename to activemq/src/main/resources/application.properties
diff --git a/spring-boot-activemq/src/test/java/sample/camel/SampleAmqApplicationTests.java b/activemq/src/test/java/sample/camel/SampleAmqApplicationTests.java
similarity index 100%
rename from spring-boot-activemq/src/test/java/sample/camel/SampleAmqApplicationTests.java
rename to activemq/src/test/java/sample/camel/SampleAmqApplicationTests.java
diff --git a/spring-boot-actuator-http-metrics/pom.xml b/actuator-http-metrics/pom.xml
similarity index 100%
rename from spring-boot-actuator-http-metrics/pom.xml
rename to actuator-http-metrics/pom.xml
diff --git a/spring-boot-actuator-http-metrics/readme.adoc b/actuator-http-metrics/readme.adoc
similarity index 100%
rename from spring-boot-actuator-http-metrics/readme.adoc
rename to actuator-http-metrics/readme.adoc
diff --git a/spring-boot-actuator-http-metrics/src/main/java/sample/camel/Application.java b/actuator-http-metrics/src/main/java/sample/camel/Application.java
similarity index 100%
rename from spring-boot-actuator-http-metrics/src/main/java/sample/camel/Application.java
rename to actuator-http-metrics/src/main/java/sample/camel/Application.java
diff --git a/spring-boot-actuator-http-metrics/src/main/java/sample/camel/MyRouteBuilder.java b/actuator-http-metrics/src/main/java/sample/camel/MyRouteBuilder.java
similarity index 100%
rename from spring-boot-actuator-http-metrics/src/main/java/sample/camel/MyRouteBuilder.java
rename to actuator-http-metrics/src/main/java/sample/camel/MyRouteBuilder.java
diff --git a/spring-boot-actuator-http-metrics/src/main/resources/application.properties b/actuator-http-metrics/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-actuator-http-metrics/src/main/resources/application.properties
rename to actuator-http-metrics/src/main/resources/application.properties
diff --git a/spring-boot-amqp/pom.xml b/amqp/pom.xml
similarity index 100%
rename from spring-boot-amqp/pom.xml
rename to amqp/pom.xml
diff --git a/spring-boot-amqp/readme.adoc b/amqp/readme.adoc
similarity index 100%
rename from spring-boot-amqp/readme.adoc
rename to amqp/readme.adoc
diff --git a/spring-boot-amqp/src/main/data/ReadMe.txt b/amqp/src/main/data/ReadMe.txt
similarity index 100%
rename from spring-boot-amqp/src/main/data/ReadMe.txt
rename to amqp/src/main/data/ReadMe.txt
diff --git a/spring-boot-amqp/src/main/java/sample/camel/AmqpConfig.java b/amqp/src/main/java/sample/camel/AmqpConfig.java
similarity index 100%
rename from spring-boot-amqp/src/main/java/sample/camel/AmqpConfig.java
rename to amqp/src/main/java/sample/camel/AmqpConfig.java
diff --git a/spring-boot-amqp/src/main/java/sample/camel/SampleAmqApplication.java b/amqp/src/main/java/sample/camel/SampleAmqApplication.java
similarity index 100%
rename from spring-boot-amqp/src/main/java/sample/camel/SampleAmqApplication.java
rename to amqp/src/main/java/sample/camel/SampleAmqApplication.java
diff --git a/spring-boot-amqp/src/main/java/sample/camel/SampleAutowiredAmqpRoute.java b/amqp/src/main/java/sample/camel/SampleAutowiredAmqpRoute.java
similarity index 100%
rename from spring-boot-amqp/src/main/java/sample/camel/SampleAutowiredAmqpRoute.java
rename to amqp/src/main/java/sample/camel/SampleAutowiredAmqpRoute.java
diff --git a/spring-boot-amqp/src/main/resources/application.properties b/amqp/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-amqp/src/main/resources/application.properties
rename to amqp/src/main/resources/application.properties
diff --git a/spring-boot-amqp/src/test/java/sample/camel/SampleAmqApplicationTests.java b/amqp/src/test/java/sample/camel/SampleAmqApplicationTests.java
similarity index 100%
rename from spring-boot-amqp/src/test/java/sample/camel/SampleAmqApplicationTests.java
rename to amqp/src/test/java/sample/camel/SampleAmqApplicationTests.java
diff --git a/spring-boot-apm-opentracing/README.adoc b/apm-opentracing/README.adoc
similarity index 100%
rename from spring-boot-apm-opentracing/README.adoc
rename to apm-opentracing/README.adoc
diff --git a/spring-boot-apm-opentracing/pom.xml b/apm-opentracing/pom.xml
similarity index 100%
rename from spring-boot-apm-opentracing/pom.xml
rename to apm-opentracing/pom.xml
diff --git a/spring-boot-apm-opentracing/src/main/java/sample/camel/CamelConfig.java b/apm-opentracing/src/main/java/sample/camel/CamelConfig.java
similarity index 100%
rename from spring-boot-apm-opentracing/src/main/java/sample/camel/CamelConfig.java
rename to apm-opentracing/src/main/java/sample/camel/CamelConfig.java
diff --git a/spring-boot-apm-opentracing/src/main/java/sample/camel/CounterBean.java b/apm-opentracing/src/main/java/sample/camel/CounterBean.java
similarity index 100%
rename from spring-boot-apm-opentracing/src/main/java/sample/camel/CounterBean.java
rename to apm-opentracing/src/main/java/sample/camel/CounterBean.java
diff --git a/spring-boot-apm-opentracing/src/main/java/sample/camel/Service1Application.java b/apm-opentracing/src/main/java/sample/camel/Service1Application.java
similarity index 100%
rename from spring-boot-apm-opentracing/src/main/java/sample/camel/Service1Application.java
rename to apm-opentracing/src/main/java/sample/camel/Service1Application.java
diff --git a/spring-boot-apm-opentracing/src/main/java/sample/camel/Service1Route.java b/apm-opentracing/src/main/java/sample/camel/Service1Route.java
similarity index 100%
rename from spring-boot-apm-opentracing/src/main/java/sample/camel/Service1Route.java
rename to apm-opentracing/src/main/java/sample/camel/Service1Route.java
diff --git a/spring-boot-apm-opentracing/src/main/resources/application.properties b/apm-opentracing/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-apm-opentracing/src/main/resources/application.properties
rename to apm-opentracing/src/main/resources/application.properties
diff --git a/spring-boot-arangodb/README.adoc b/arangodb/README.adoc
similarity index 100%
rename from spring-boot-arangodb/README.adoc
rename to arangodb/README.adoc
diff --git a/spring-boot-arangodb/pom.xml b/arangodb/pom.xml
similarity index 100%
rename from spring-boot-arangodb/pom.xml
rename to arangodb/pom.xml
diff --git a/spring-boot-arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/Application.java b/arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/Application.java
similarity index 100%
rename from spring-boot-arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/Application.java
rename to arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/Application.java
diff --git a/spring-boot-arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/CamelRoute.java b/arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/CamelRoute.java
similarity index 100%
rename from spring-boot-arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/CamelRoute.java
rename to arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/CamelRoute.java
diff --git a/spring-boot-arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/MyBeanService.java b/arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/MyBeanService.java
similarity index 100%
rename from spring-boot-arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/MyBeanService.java
rename to arangodb/src/main/java/org/apache/camel/example/springboot/arangodb/MyBeanService.java
diff --git a/spring-boot-arangodb/src/main/resources/application.properties b/arangodb/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-arangodb/src/main/resources/application.properties
rename to arangodb/src/main/resources/application.properties
diff --git a/spring-boot-aws2-s3/README.adoc b/aws2-s3/README.adoc
similarity index 100%
rename from spring-boot-aws2-s3/README.adoc
rename to aws2-s3/README.adoc
diff --git a/spring-boot-aws2-s3/pom.xml b/aws2-s3/pom.xml
similarity index 100%
rename from spring-boot-aws2-s3/pom.xml
rename to aws2-s3/pom.xml
diff --git a/spring-boot-aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/Application.java b/aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/Application.java
similarity index 100%
rename from spring-boot-aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/Application.java
rename to aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/Application.java
diff --git a/spring-boot-aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/CamelRoute.java b/aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/CamelRoute.java
similarity index 100%
rename from spring-boot-aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/CamelRoute.java
rename to aws2-s3/src/main/java/org/apache/camel/example/springboot/aws2s3/CamelRoute.java
diff --git a/spring-boot-aws2-s3/src/main/resources/application.properties b/aws2-s3/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-aws2-s3/src/main/resources/application.properties
rename to aws2-s3/src/main/resources/application.properties
diff --git a/spring-boot-aws2-s3/src/main/resources/logback.xml b/aws2-s3/src/main/resources/logback.xml
similarity index 100%
rename from spring-boot-aws2-s3/src/main/resources/logback.xml
rename to aws2-s3/src/main/resources/logback.xml
diff --git a/spring-boot-clustered-route-controller/cluster-bootstrap/pom.xml b/clustered-route-controller/cluster-bootstrap/pom.xml
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-bootstrap/pom.xml
rename to clustered-route-controller/cluster-bootstrap/pom.xml
diff --git a/spring-boot-clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrap.java b/clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrap.java
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrap.java
rename to clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrap.java
diff --git a/spring-boot-clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrapConfiguration.java b/clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrapConfiguration.java
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrapConfiguration.java
rename to clustered-route-controller/cluster-bootstrap/src/main/java/org/apache/camel/examples/cluster/ClusterBootstrapConfiguration.java
diff --git a/spring-boot-clustered-route-controller/cluster-bootstrap/src/main/resources/application.properties b/clustered-route-controller/cluster-bootstrap/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-bootstrap/src/main/resources/application.properties
rename to clustered-route-controller/cluster-bootstrap/src/main/resources/application.properties
diff --git a/spring-boot-clustered-route-controller/cluster-node/pom.xml b/clustered-route-controller/cluster-node/pom.xml
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-node/pom.xml
rename to clustered-route-controller/cluster-node/pom.xml
diff --git a/spring-boot-clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNode.java b/clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNode.java
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNode.java
rename to clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNode.java
diff --git a/spring-boot-clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNodeConfiguration.java b/clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNodeConfiguration.java
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNodeConfiguration.java
rename to clustered-route-controller/cluster-node/src/main/java/org/apache/camel/examples/cluster/ClusterNodeConfiguration.java
diff --git a/spring-boot-clustered-route-controller/cluster-node/src/main/resources/application.properties b/clustered-route-controller/cluster-node/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-clustered-route-controller/cluster-node/src/main/resources/application.properties
rename to clustered-route-controller/cluster-node/src/main/resources/application.properties
diff --git a/spring-boot-clustered-route-controller/pom.xml b/clustered-route-controller/pom.xml
similarity index 100%
rename from spring-boot-clustered-route-controller/pom.xml
rename to clustered-route-controller/pom.xml
diff --git a/spring-boot-clustered-route-controller/readme.adoc b/clustered-route-controller/readme.adoc
similarity index 100%
rename from spring-boot-clustered-route-controller/readme.adoc
rename to clustered-route-controller/readme.adoc
diff --git a/spring-boot-fhir-auth-tx/pom.xml b/fhir-auth-tx/pom.xml
similarity index 100%
rename from spring-boot-fhir-auth-tx/pom.xml
rename to fhir-auth-tx/pom.xml
diff --git a/spring-boot-fhir-auth-tx/readme.adoc b/fhir-auth-tx/readme.adoc
similarity index 100%
rename from spring-boot-fhir-auth-tx/readme.adoc
rename to fhir-auth-tx/readme.adoc
diff --git a/spring-boot-fhir-auth-tx/src/main/data/patients.csv b/fhir-auth-tx/src/main/data/patients.csv
similarity index 100%
rename from spring-boot-fhir-auth-tx/src/main/data/patients.csv
rename to fhir-auth-tx/src/main/data/patients.csv
diff --git a/spring-boot-fhir-auth-tx/src/main/java/sample/camel/MyCamelApplication.java b/fhir-auth-tx/src/main/java/sample/camel/MyCamelApplication.java
similarity index 100%
rename from spring-boot-fhir-auth-tx/src/main/java/sample/camel/MyCamelApplication.java
rename to fhir-auth-tx/src/main/java/sample/camel/MyCamelApplication.java
diff --git a/spring-boot-fhir-auth-tx/src/main/java/sample/camel/MyCamelRouter.java b/fhir-auth-tx/src/main/java/sample/camel/MyCamelRouter.java
similarity index 100%
rename from spring-boot-fhir-auth-tx/src/main/java/sample/camel/MyCamelRouter.java
rename to fhir-auth-tx/src/main/java/sample/camel/MyCamelRouter.java
diff --git a/spring-boot-fhir-auth-tx/src/main/resources/application.properties b/fhir-auth-tx/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-fhir-auth-tx/src/main/resources/application.properties
rename to fhir-auth-tx/src/main/resources/application.properties
diff --git a/spring-boot-fhir-auth-tx/src/test/java/sample/camel/MyCamelApplicationTest.java b/fhir-auth-tx/src/test/java/sample/camel/MyCamelApplicationTest.java
similarity index 100%
rename from spring-boot-fhir-auth-tx/src/test/java/sample/camel/MyCamelApplicationTest.java
rename to fhir-auth-tx/src/test/java/sample/camel/MyCamelApplicationTest.java
diff --git a/spring-boot-fhir/pom.xml b/fhir/pom.xml
similarity index 100%
rename from spring-boot-fhir/pom.xml
rename to fhir/pom.xml
diff --git a/spring-boot-fhir/readme.adoc b/fhir/readme.adoc
similarity index 100%
rename from spring-boot-fhir/readme.adoc
rename to fhir/readme.adoc
diff --git a/spring-boot-fhir/src/main/data/hl7v2.patient b/fhir/src/main/data/hl7v2.patient
similarity index 100%
rename from spring-boot-fhir/src/main/data/hl7v2.patient
rename to fhir/src/main/data/hl7v2.patient
diff --git a/spring-boot-fhir/src/main/java/sample/camel/MyCamelApplication.java b/fhir/src/main/java/sample/camel/MyCamelApplication.java
similarity index 100%
rename from spring-boot-fhir/src/main/java/sample/camel/MyCamelApplication.java
rename to fhir/src/main/java/sample/camel/MyCamelApplication.java
diff --git a/spring-boot-fhir/src/main/java/sample/camel/MyCamelRouter.java b/fhir/src/main/java/sample/camel/MyCamelRouter.java
similarity index 100%
rename from spring-boot-fhir/src/main/java/sample/camel/MyCamelRouter.java
rename to fhir/src/main/java/sample/camel/MyCamelRouter.java
diff --git a/spring-boot-fhir/src/main/resources/application.properties b/fhir/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-fhir/src/main/resources/application.properties
rename to fhir/src/main/resources/application.properties
diff --git a/spring-boot-fhir/src/test/java/sample/camel/MyCamelApplicationTest.java b/fhir/src/test/java/sample/camel/MyCamelApplicationTest.java
similarity index 100%
rename from spring-boot-fhir/src/test/java/sample/camel/MyCamelApplicationTest.java
rename to fhir/src/test/java/sample/camel/MyCamelApplicationTest.java
diff --git a/spring-boot-geocoder/README.adoc b/geocoder/README.adoc
similarity index 100%
rename from spring-boot-geocoder/README.adoc
rename to geocoder/README.adoc
diff --git a/spring-boot-geocoder/pom.xml b/geocoder/pom.xml
similarity index 100%
rename from spring-boot-geocoder/pom.xml
rename to geocoder/pom.xml
diff --git a/spring-boot-geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/Application.java b/geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/Application.java
similarity index 100%
rename from spring-boot-geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/Application.java
rename to geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/Application.java
diff --git a/spring-boot-geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/CamelGeocoderRoute.java b/geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/CamelGeocoderRoute.java
similarity index 100%
rename from spring-boot-geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/CamelGeocoderRoute.java
rename to geocoder/src/main/java/org/apache/camel/example/springboot/geocoder/CamelGeocoderRoute.java
diff --git a/spring-boot-geocoder/src/main/resources/application.properties b/geocoder/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-geocoder/src/main/resources/application.properties
rename to geocoder/src/main/resources/application.properties
diff --git a/spring-boot-geocoder/src/test/java/org/apache/camel/example/springboot/geocoder/ApplicationTest.java b/geocoder/src/test/java/org/apache/camel/example/springboot/geocoder/ApplicationTest.java
similarity index 100%
rename from spring-boot-geocoder/src/test/java/org/apache/camel/example/springboot/geocoder/ApplicationTest.java
rename to geocoder/src/test/java/org/apache/camel/example/springboot/geocoder/ApplicationTest.java
diff --git a/spring-boot-grpc-kubernetes/README.adoc b/grpc-kubernetes/README.adoc
similarity index 100%
rename from spring-boot-grpc-kubernetes/README.adoc
rename to grpc-kubernetes/README.adoc
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/pom.xml b/grpc-kubernetes/hello-camel-grpc-client-kubernetes/pom.xml
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/pom.xml
rename to grpc-kubernetes/hello-camel-grpc-client-kubernetes/pom.xml
diff --git a/spring-boot-grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/Application.java b/grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/Application.java
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/Application.java
rename to grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/Application.java
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java b/grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java
rename to grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java
diff --git a/spring-boot-grpc/hello-camel-grpc-server/src/main/proto/hellocamel.proto b/grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/proto/hellocamel.proto
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-server/src/main/proto/hellocamel.proto
rename to grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/proto/hellocamel.proto
diff --git a/spring-boot-grpc/hello-camel-grpc-client/src/main/resources/application.properties b/grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-client/src/main/resources/application.properties
rename to grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/resources/application.properties
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-server-kubernetes/pom.xml b/grpc-kubernetes/hello-camel-grpc-server-kubernetes/pom.xml
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-server-kubernetes/pom.xml
rename to grpc-kubernetes/hello-camel-grpc-server-kubernetes/pom.xml
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java b/grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java
rename to grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java
diff --git a/spring-boot-grpc/hello-camel-grpc-client/src/main/proto/hellocamel.proto b/grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/proto/hellocamel.proto
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-client/src/main/proto/hellocamel.proto
rename to grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/proto/hellocamel.proto
diff --git a/spring-boot-grpc-kubernetes/pom.xml b/grpc-kubernetes/pom.xml
similarity index 100%
rename from spring-boot-grpc-kubernetes/pom.xml
rename to grpc-kubernetes/pom.xml
diff --git a/spring-boot-grpc/README.adoc b/grpc/README.adoc
similarity index 100%
rename from spring-boot-grpc/README.adoc
rename to grpc/README.adoc
diff --git a/spring-boot-grpc/hello-camel-grpc-client/pom.xml b/grpc/hello-camel-grpc-client/pom.xml
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-client/pom.xml
rename to grpc/hello-camel-grpc-client/pom.xml
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/Application.java b/grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/Application.java
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/java/org/apache/camel/example/springboot/grpc/Application.java
rename to grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/Application.java
diff --git a/spring-boot-grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java b/grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java
rename to grpc/hello-camel-grpc-client/src/main/java/org/apache/camel/example/springboot/grpc/CamelGrpcRoute.java
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/proto/hellocamel.proto b/grpc/hello-camel-grpc-client/src/main/proto/hellocamel.proto
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-server-kubernetes/src/main/proto/hellocamel.proto
rename to grpc/hello-camel-grpc-client/src/main/proto/hellocamel.proto
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/resources/application.properties b/grpc/hello-camel-grpc-client/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/resources/application.properties
rename to grpc/hello-camel-grpc-client/src/main/resources/application.properties
diff --git a/spring-boot-grpc/hello-camel-grpc-server/pom.xml b/grpc/hello-camel-grpc-server/pom.xml
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-server/pom.xml
rename to grpc/hello-camel-grpc-server/pom.xml
diff --git a/spring-boot-grpc/hello-camel-grpc-server/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java b/grpc/hello-camel-grpc-server/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java
similarity index 100%
rename from spring-boot-grpc/hello-camel-grpc-server/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java
rename to grpc/hello-camel-grpc-server/src/main/java/org/apache/camel/examples/grpc/HelloCamelServer.java
diff --git a/spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/proto/hellocamel.proto b/grpc/hello-camel-grpc-server/src/main/proto/hellocamel.proto
similarity index 100%
rename from spring-boot-grpc-kubernetes/hello-camel-grpc-client-kubernetes/src/main/proto/hellocamel.proto
rename to grpc/hello-camel-grpc-server/src/main/proto/hellocamel.proto
diff --git a/spring-boot-grpc/pom.xml b/grpc/pom.xml
similarity index 100%
rename from spring-boot-grpc/pom.xml
rename to grpc/pom.xml
diff --git a/spring-boot-health-checks/pom.xml b/health-checks/pom.xml
similarity index 100%
rename from spring-boot-health-checks/pom.xml
rename to health-checks/pom.xml
diff --git a/spring-boot-health-checks/readme.adoc b/health-checks/readme.adoc
similarity index 100%
rename from spring-boot-health-checks/readme.adoc
rename to health-checks/readme.adoc
diff --git a/spring-boot-health-checks/src/main/java/sample/camel/Application.java b/health-checks/src/main/java/sample/camel/Application.java
similarity index 100%
rename from spring-boot-health-checks/src/main/java/sample/camel/Application.java
rename to health-checks/src/main/java/sample/camel/Application.java
diff --git a/spring-boot-health-checks/src/main/java/sample/camel/MonkeyHealthCheck.java b/health-checks/src/main/java/sample/camel/MonkeyHealthCheck.java
similarity index 100%
rename from spring-boot-health-checks/src/main/java/sample/camel/MonkeyHealthCheck.java
rename to health-checks/src/main/java/sample/camel/MonkeyHealthCheck.java
diff --git a/spring-boot-health-checks/src/main/java/sample/camel/MyConfiguration.java b/health-checks/src/main/java/sample/camel/MyConfiguration.java
similarity index 100%
rename from spring-boot-health-checks/src/main/java/sample/camel/MyConfiguration.java
rename to health-checks/src/main/java/sample/camel/MyConfiguration.java
diff --git a/spring-boot-health-checks/src/main/java/sample/camel/MyRouteBuilder.java b/health-checks/src/main/java/sample/camel/MyRouteBuilder.java
similarity index 100%
rename from spring-boot-health-checks/src/main/java/sample/camel/MyRouteBuilder.java
rename to health-checks/src/main/java/sample/camel/MyRouteBuilder.java
diff --git a/spring-boot-health-checks/src/main/resources/application.properties b/health-checks/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-health-checks/src/main/resources/application.properties
rename to health-checks/src/main/resources/application.properties
diff --git a/spring-boot-hystrix/README.adoc b/hystrix/README.adoc
similarity index 100%
rename from spring-boot-hystrix/README.adoc
rename to hystrix/README.adoc
diff --git a/spring-boot-hystrix/client/pom.xml b/hystrix/client/pom.xml
similarity index 100%
rename from spring-boot-hystrix/client/pom.xml
rename to hystrix/client/pom.xml
diff --git a/spring-boot-hystrix/client/src/main/java/sample/camel/ClientApplication.java b/hystrix/client/src/main/java/sample/camel/ClientApplication.java
similarity index 100%
rename from spring-boot-hystrix/client/src/main/java/sample/camel/ClientApplication.java
rename to hystrix/client/src/main/java/sample/camel/ClientApplication.java
diff --git a/spring-boot-hystrix/client/src/main/java/sample/camel/ClientRoute.java b/hystrix/client/src/main/java/sample/camel/ClientRoute.java
similarity index 100%
rename from spring-boot-hystrix/client/src/main/java/sample/camel/ClientRoute.java
rename to hystrix/client/src/main/java/sample/camel/ClientRoute.java
diff --git a/spring-boot-resilience4j/client/src/main/java/sample/camel/CounterBean.java b/hystrix/client/src/main/java/sample/camel/CounterBean.java
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/java/sample/camel/CounterBean.java
rename to hystrix/client/src/main/java/sample/camel/CounterBean.java
diff --git a/spring-boot-zipkin/service2/src/main/resources/META-INF/LICENSE.txt b/hystrix/client/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-zipkin/service2/src/main/resources/META-INF/LICENSE.txt
rename to hystrix/client/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-zipkin/service2/src/main/resources/META-INF/NOTICE.txt b/hystrix/client/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-zipkin/service2/src/main/resources/META-INF/NOTICE.txt
rename to hystrix/client/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-zipkin/client/src/main/resources/META-INF/beans.xml b/hystrix/client/src/main/resources/META-INF/beans.xml
similarity index 100%
rename from spring-boot-zipkin/client/src/main/resources/META-INF/beans.xml
rename to hystrix/client/src/main/resources/META-INF/beans.xml
diff --git a/spring-boot-hystrix/client/src/main/resources/application.properties b/hystrix/client/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-hystrix/client/src/main/resources/application.properties
rename to hystrix/client/src/main/resources/application.properties
diff --git a/spring-boot-zipkin/service2/src/main/resources/log4j2.properties b/hystrix/client/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-zipkin/service2/src/main/resources/log4j2.properties
rename to hystrix/client/src/main/resources/log4j2.properties
diff --git a/spring-boot-hystrix/images/hystrix-web-console.png b/hystrix/images/hystrix-web-console.png
similarity index 100%
rename from spring-boot-hystrix/images/hystrix-web-console.png
rename to hystrix/images/hystrix-web-console.png
diff --git a/spring-boot-hystrix/pom.xml b/hystrix/pom.xml
similarity index 100%
rename from spring-boot-hystrix/pom.xml
rename to hystrix/pom.xml
diff --git a/spring-boot-hystrix/service1/pom.xml b/hystrix/service1/pom.xml
similarity index 100%
rename from spring-boot-hystrix/service1/pom.xml
rename to hystrix/service1/pom.xml
diff --git a/spring-boot-resilience4j/service1/src/main/java/sample/camel/Service1Application.java b/hystrix/service1/src/main/java/sample/camel/Service1Application.java
similarity index 100%
rename from spring-boot-resilience4j/service1/src/main/java/sample/camel/Service1Application.java
rename to hystrix/service1/src/main/java/sample/camel/Service1Application.java
diff --git a/spring-boot-resilience4j/service1/src/main/java/sample/camel/Service1Route.java b/hystrix/service1/src/main/java/sample/camel/Service1Route.java
similarity index 100%
rename from spring-boot-resilience4j/service1/src/main/java/sample/camel/Service1Route.java
rename to hystrix/service1/src/main/java/sample/camel/Service1Route.java
diff --git a/spring-boot-zipkin/service1/src/main/resources/META-INF/LICENSE.txt b/hystrix/service1/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-zipkin/service1/src/main/resources/META-INF/LICENSE.txt
rename to hystrix/service1/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-zipkin/service1/src/main/resources/META-INF/NOTICE.txt b/hystrix/service1/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-zipkin/service1/src/main/resources/META-INF/NOTICE.txt
rename to hystrix/service1/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-resilience4j/service1/src/main/resources/application.properties b/hystrix/service1/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-resilience4j/service1/src/main/resources/application.properties
rename to hystrix/service1/src/main/resources/application.properties
diff --git a/spring-boot-hystrix/service2/pom.xml b/hystrix/service2/pom.xml
similarity index 100%
rename from spring-boot-hystrix/service2/pom.xml
rename to hystrix/service2/pom.xml
diff --git a/spring-boot-hystrix/service2/src/main/java/sample/camel/Service2Application.java b/hystrix/service2/src/main/java/sample/camel/Service2Application.java
similarity index 100%
rename from spring-boot-hystrix/service2/src/main/java/sample/camel/Service2Application.java
rename to hystrix/service2/src/main/java/sample/camel/Service2Application.java
diff --git a/spring-boot-resilience4j/service2/src/main/java/sample/camel/Service2Route.java b/hystrix/service2/src/main/java/sample/camel/Service2Route.java
similarity index 100%
rename from spring-boot-resilience4j/service2/src/main/java/sample/camel/Service2Route.java
rename to hystrix/service2/src/main/java/sample/camel/Service2Route.java
diff --git a/spring-boot-zipkin/client/src/main/resources/META-INF/LICENSE.txt b/hystrix/service2/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-zipkin/client/src/main/resources/META-INF/LICENSE.txt
rename to hystrix/service2/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-zipkin/client/src/main/resources/META-INF/NOTICE.txt b/hystrix/service2/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-zipkin/client/src/main/resources/META-INF/NOTICE.txt
rename to hystrix/service2/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-zipkin/client/src/main/resources/log4j2.properties b/hystrix/service2/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-zipkin/client/src/main/resources/log4j2.properties
rename to hystrix/service2/src/main/resources/log4j2.properties
diff --git a/spring-boot-infinispan/README.adoc b/infinispan/README.adoc
similarity index 100%
rename from spring-boot-infinispan/README.adoc
rename to infinispan/README.adoc
diff --git a/spring-boot-infinispan/pom.xml b/infinispan/pom.xml
similarity index 100%
rename from spring-boot-infinispan/pom.xml
rename to infinispan/pom.xml
diff --git a/spring-boot-infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/Application.java b/infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/Application.java
similarity index 100%
rename from spring-boot-infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/Application.java
rename to infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/Application.java
diff --git a/spring-boot-infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/CamelInfinispanRoute.java b/infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/CamelInfinispanRoute.java
similarity index 100%
rename from spring-boot-infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/CamelInfinispanRoute.java
rename to infinispan/src/main/java/org/apache/camel/example/springboot/infinispan/CamelInfinispanRoute.java
diff --git a/spring-boot-infinispan/src/main/resources/application.properties b/infinispan/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-infinispan/src/main/resources/application.properties
rename to infinispan/src/main/resources/application.properties
diff --git a/spring-boot-jira/README.adoc b/jira/README.adoc
similarity index 100%
rename from spring-boot-jira/README.adoc
rename to jira/README.adoc
diff --git a/spring-boot-jira/pom.xml b/jira/pom.xml
similarity index 100%
rename from spring-boot-jira/pom.xml
rename to jira/pom.xml
diff --git a/spring-boot-jira/src/main/java/org/apache/camel/example/jira/AddIssueRoute.java b/jira/src/main/java/org/apache/camel/example/jira/AddIssueRoute.java
similarity index 100%
rename from spring-boot-jira/src/main/java/org/apache/camel/example/jira/AddIssueRoute.java
rename to jira/src/main/java/org/apache/camel/example/jira/AddIssueRoute.java
diff --git a/spring-boot-jira/src/main/java/org/apache/camel/example/jira/Application.java b/jira/src/main/java/org/apache/camel/example/jira/Application.java
similarity index 100%
rename from spring-boot-jira/src/main/java/org/apache/camel/example/jira/Application.java
rename to jira/src/main/java/org/apache/camel/example/jira/Application.java
diff --git a/spring-boot-jira/src/main/java/org/apache/camel/example/jira/AttachFileRoute.java b/jira/src/main/java/org/apache/camel/example/jira/AttachFileRoute.java
similarity index 100%
rename from spring-boot-jira/src/main/java/org/apache/camel/example/jira/AttachFileRoute.java
rename to jira/src/main/java/org/apache/camel/example/jira/AttachFileRoute.java
diff --git a/spring-boot-jira/src/main/java/org/apache/camel/example/jira/NewCommentsRoute.java b/jira/src/main/java/org/apache/camel/example/jira/NewCommentsRoute.java
similarity index 100%
rename from spring-boot-jira/src/main/java/org/apache/camel/example/jira/NewCommentsRoute.java
rename to jira/src/main/java/org/apache/camel/example/jira/NewCommentsRoute.java
diff --git a/spring-boot-jira/src/main/resources/application.properties b/jira/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-jira/src/main/resources/application.properties
rename to jira/src/main/resources/application.properties
diff --git a/spring-boot-jira/src/main/resources/logback.xml b/jira/src/main/resources/logback.xml
similarity index 100%
rename from spring-boot-jira/src/main/resources/logback.xml
rename to jira/src/main/resources/logback.xml
diff --git a/spring-boot-kafka-avro/README.adoc b/kafka-avro/README.adoc
similarity index 100%
rename from spring-boot-kafka-avro/README.adoc
rename to kafka-avro/README.adoc
diff --git a/spring-boot-kafka-avro/pom.xml b/kafka-avro/pom.xml
similarity index 100%
rename from spring-boot-kafka-avro/pom.xml
rename to kafka-avro/pom.xml
diff --git a/spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/Application.java b/kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/Application.java
similarity index 100%
rename from spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/Application.java
rename to kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/Application.java
diff --git a/spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/AvroRouteBuilder.java b/kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/AvroRouteBuilder.java
similarity index 100%
rename from spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/AvroRouteBuilder.java
rename to kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/AvroRouteBuilder.java
diff --git a/spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroDeserializer.java b/kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroDeserializer.java
similarity index 100%
rename from spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroDeserializer.java
rename to kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroDeserializer.java
diff --git a/spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroSerializer.java b/kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroSerializer.java
similarity index 100%
rename from spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroSerializer.java
rename to kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/CustomKafkaAvroSerializer.java
diff --git a/spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageConsumerProcessor.java b/kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageConsumerProcessor.java
similarity index 100%
rename from spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageConsumerProcessor.java
rename to kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageConsumerProcessor.java
diff --git a/spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageProcessor.java b/kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageProcessor.java
similarity index 100%
rename from spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageProcessor.java
rename to kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroMessageProcessor.java
diff --git a/spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroProcessor.java b/kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroProcessor.java
similarity index 100%
rename from spring-boot-kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroProcessor.java
rename to kafka-avro/src/main/java/org/apache/camel/example/kafka/avro/KafkaAvroProcessor.java
diff --git a/spring-boot-kafka-avro/src/main/resources/application.properties b/kafka-avro/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-kafka-avro/src/main/resources/application.properties
rename to kafka-avro/src/main/resources/application.properties
diff --git a/spring-boot-kafka-avro/src/main/resources/avro/employee.avsc b/kafka-avro/src/main/resources/avro/employee.avsc
similarity index 100%
rename from spring-boot-kafka-avro/src/main/resources/avro/employee.avsc
rename to kafka-avro/src/main/resources/avro/employee.avsc
diff --git a/spring-boot-kafka-offsetrepository/src/main/resources/log4j2.properties b/kafka-avro/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-kafka-offsetrepository/src/main/resources/log4j2.properties
rename to kafka-avro/src/main/resources/log4j2.properties
diff --git a/spring-boot-kafka-avro/src/main/resources/register_schema.py b/kafka-avro/src/main/resources/register_schema.py
similarity index 100%
rename from spring-boot-kafka-avro/src/main/resources/register_schema.py
rename to kafka-avro/src/main/resources/register_schema.py
diff --git a/spring-boot-kafka-avro/src/main/resources/spring/camel-context.xml b/kafka-avro/src/main/resources/spring/camel-context.xml
similarity index 100%
rename from spring-boot-kafka-avro/src/main/resources/spring/camel-context.xml
rename to kafka-avro/src/main/resources/spring/camel-context.xml
diff --git a/spring-boot-kafka-offsetrepository/README.adoc b/kafka-offsetrepository/README.adoc
similarity index 100%
rename from spring-boot-kafka-offsetrepository/README.adoc
rename to kafka-offsetrepository/README.adoc
diff --git a/spring-boot-kafka-offsetrepository/pom.xml b/kafka-offsetrepository/pom.xml
similarity index 100%
rename from spring-boot-kafka-offsetrepository/pom.xml
rename to kafka-offsetrepository/pom.xml
diff --git a/spring-boot-kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/KafkaProcessor.java b/kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/KafkaProcessor.java
similarity index 100%
rename from spring-boot-kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/KafkaProcessor.java
rename to kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/KafkaProcessor.java
diff --git a/spring-boot-kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/OffsetRepoApp.java b/kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/OffsetRepoApp.java
similarity index 100%
rename from spring-boot-kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/OffsetRepoApp.java
rename to kafka-offsetrepository/src/main/java/org/apache/camel/example/kafka/offsetRepository/OffsetRepoApp.java
diff --git a/spring-boot-kafka-offsetrepository/src/main/resources/application.properties b/kafka-offsetrepository/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-kafka-offsetrepository/src/main/resources/application.properties
rename to kafka-offsetrepository/src/main/resources/application.properties
diff --git a/spring-boot-kafka-avro/src/main/resources/log4j2.properties b/kafka-offsetrepository/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-kafka-avro/src/main/resources/log4j2.properties
rename to kafka-offsetrepository/src/main/resources/log4j2.properties
diff --git a/spring-boot-kafka-offsetrepository/src/main/resources/offsetStateRepo.dat b/kafka-offsetrepository/src/main/resources/offsetStateRepo.dat
similarity index 100%
rename from spring-boot-kafka-offsetrepository/src/main/resources/offsetStateRepo.dat
rename to kafka-offsetrepository/src/main/resources/offsetStateRepo.dat
diff --git a/spring-boot-kafka-offsetrepository/src/main/resources/spring/camel-context.xml b/kafka-offsetrepository/src/main/resources/spring/camel-context.xml
similarity index 100%
rename from spring-boot-kafka-offsetrepository/src/main/resources/spring/camel-context.xml
rename to kafka-offsetrepository/src/main/resources/spring/camel-context.xml
diff --git a/spring-boot-load-balancer-eip/README.adoc b/load-balancer-eip/README.adoc
similarity index 100%
rename from spring-boot-load-balancer-eip/README.adoc
rename to load-balancer-eip/README.adoc
diff --git a/spring-boot-load-balancer-eip/pom.xml b/load-balancer-eip/pom.xml
similarity index 100%
rename from spring-boot-load-balancer-eip/pom.xml
rename to load-balancer-eip/pom.xml
diff --git a/spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/Application.java b/load-balancer-eip/src/main/java/org/apache/camel/springboot/example/Application.java
similarity index 100%
rename from spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/Application.java
rename to load-balancer-eip/src/main/java/org/apache/camel/springboot/example/Application.java
diff --git a/spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/CustomLoadBalancer.java b/load-balancer-eip/src/main/java/org/apache/camel/springboot/example/CustomLoadBalancer.java
similarity index 100%
rename from spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/CustomLoadBalancer.java
rename to load-balancer-eip/src/main/java/org/apache/camel/springboot/example/CustomLoadBalancer.java
diff --git a/spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/LoadBalancerEIPRouter.java b/load-balancer-eip/src/main/java/org/apache/camel/springboot/example/LoadBalancerEIPRouter.java
similarity index 100%
rename from spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/LoadBalancerEIPRouter.java
rename to load-balancer-eip/src/main/java/org/apache/camel/springboot/example/LoadBalancerEIPRouter.java
diff --git a/spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/MyException.java b/load-balancer-eip/src/main/java/org/apache/camel/springboot/example/MyException.java
similarity index 100%
rename from spring-boot-load-balancer-eip/src/main/java/org/apache/camel/springboot/example/MyException.java
rename to load-balancer-eip/src/main/java/org/apache/camel/springboot/example/MyException.java
diff --git a/spring-boot-load-balancer-eip/src/main/resources/application.properties b/load-balancer-eip/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-load-balancer-eip/src/main/resources/application.properties
rename to load-balancer-eip/src/main/resources/application.properties
diff --git a/spring-boot-load-balancer-eip/src/test/java/org/apache/camel/springboot/example/LoadBalancerEIPTest.java b/load-balancer-eip/src/test/java/org/apache/camel/springboot/example/LoadBalancerEIPTest.java
similarity index 100%
rename from spring-boot-load-balancer-eip/src/test/java/org/apache/camel/springboot/example/LoadBalancerEIPTest.java
rename to load-balancer-eip/src/test/java/org/apache/camel/springboot/example/LoadBalancerEIPTest.java
diff --git a/spring-boot-master/pom.xml b/master/pom.xml
similarity index 100%
rename from spring-boot-master/pom.xml
rename to master/pom.xml
diff --git a/spring-boot-master/readme.adoc b/master/readme.adoc
similarity index 100%
rename from spring-boot-master/readme.adoc
rename to master/readme.adoc
diff --git a/spring-boot-master/src/main/java/org/apache/camel/examples/master/MasterNode.java b/master/src/main/java/org/apache/camel/examples/master/MasterNode.java
similarity index 100%
rename from spring-boot-master/src/main/java/org/apache/camel/examples/master/MasterNode.java
rename to master/src/main/java/org/apache/camel/examples/master/MasterNode.java
diff --git a/spring-boot-master/src/main/java/org/apache/camel/examples/master/MasterNodeConfiguration.java b/master/src/main/java/org/apache/camel/examples/master/MasterNodeConfiguration.java
similarity index 100%
rename from spring-boot-master/src/main/java/org/apache/camel/examples/master/MasterNodeConfiguration.java
rename to master/src/main/java/org/apache/camel/examples/master/MasterNodeConfiguration.java
diff --git a/spring-boot-master/src/main/resources/application.properties b/master/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-master/src/main/resources/application.properties
rename to master/src/main/resources/application.properties
diff --git a/spring-boot-metrics/README.adoc b/metrics/README.adoc
similarity index 100%
rename from spring-boot-metrics/README.adoc
rename to metrics/README.adoc
diff --git a/spring-boot-metrics/pom.xml b/metrics/pom.xml
similarity index 100%
rename from spring-boot-metrics/pom.xml
rename to metrics/pom.xml
diff --git a/spring-boot-metrics/src/main/java/org/apache/camel/example/spring/boot/metrics/Application.java b/metrics/src/main/java/org/apache/camel/example/spring/boot/metrics/Application.java
similarity index 100%
rename from spring-boot-metrics/src/main/java/org/apache/camel/example/spring/boot/metrics/Application.java
rename to metrics/src/main/java/org/apache/camel/example/spring/boot/metrics/Application.java
diff --git a/spring-boot-metrics/src/main/resources/application.properties b/metrics/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-metrics/src/main/resources/application.properties
rename to metrics/src/main/resources/application.properties
diff --git a/spring-boot-opentracing/README.adoc b/opentracing/README.adoc
similarity index 100%
rename from spring-boot-opentracing/README.adoc
rename to opentracing/README.adoc
diff --git a/spring-boot-opentracing/client/pom.xml b/opentracing/client/pom.xml
similarity index 100%
rename from spring-boot-opentracing/client/pom.xml
rename to opentracing/client/pom.xml
diff --git a/spring-boot-opentracing/client/src/main/java/sample/camel/ClientApplication.java b/opentracing/client/src/main/java/sample/camel/ClientApplication.java
similarity index 100%
rename from spring-boot-opentracing/client/src/main/java/sample/camel/ClientApplication.java
rename to opentracing/client/src/main/java/sample/camel/ClientApplication.java
diff --git a/spring-boot-zipkin/client/src/main/java/sample/camel/ClientRoute.java b/opentracing/client/src/main/java/sample/camel/ClientRoute.java
similarity index 100%
rename from spring-boot-zipkin/client/src/main/java/sample/camel/ClientRoute.java
rename to opentracing/client/src/main/java/sample/camel/ClientRoute.java
diff --git a/spring-boot-zipkin/client/src/main/java/sample/camel/CounterBean.java b/opentracing/client/src/main/java/sample/camel/CounterBean.java
similarity index 100%
rename from spring-boot-zipkin/client/src/main/java/sample/camel/CounterBean.java
rename to opentracing/client/src/main/java/sample/camel/CounterBean.java
diff --git a/spring-boot-twitter-salesforce/src/main/resources/META-INF/LICENSE.txt b/opentracing/client/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-twitter-salesforce/src/main/resources/META-INF/LICENSE.txt
rename to opentracing/client/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-twitter-salesforce/src/main/resources/META-INF/NOTICE.txt b/opentracing/client/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-twitter-salesforce/src/main/resources/META-INF/NOTICE.txt
rename to opentracing/client/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-resilience4j/client2/src/main/resources/META-INF/beans.xml b/opentracing/client/src/main/resources/META-INF/beans.xml
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/resources/META-INF/beans.xml
rename to opentracing/client/src/main/resources/META-INF/beans.xml
diff --git a/spring-boot-opentracing/service2/src/main/resources/log4j2.properties b/opentracing/client/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-opentracing/service2/src/main/resources/log4j2.properties
rename to opentracing/client/src/main/resources/log4j2.properties
diff --git a/spring-boot-opentracing/loggingtracer/pom.xml b/opentracing/loggingtracer/pom.xml
similarity index 100%
rename from spring-boot-opentracing/loggingtracer/pom.xml
rename to opentracing/loggingtracer/pom.xml
diff --git a/spring-boot-opentracing/loggingtracer/src/main/java/sample/opentracing/logging/LoggingTracer.java b/opentracing/loggingtracer/src/main/java/sample/opentracing/logging/LoggingTracer.java
similarity index 100%
rename from spring-boot-opentracing/loggingtracer/src/main/java/sample/opentracing/logging/LoggingTracer.java
rename to opentracing/loggingtracer/src/main/java/sample/opentracing/logging/LoggingTracer.java
diff --git a/spring-boot-resilience4j/service2/src/main/resources/META-INF/LICENSE.txt b/opentracing/loggingtracer/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-resilience4j/service2/src/main/resources/META-INF/LICENSE.txt
rename to opentracing/loggingtracer/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-resilience4j/service2/src/main/resources/META-INF/NOTICE.txt b/opentracing/loggingtracer/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-resilience4j/service2/src/main/resources/META-INF/NOTICE.txt
rename to opentracing/loggingtracer/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-resilience4j/client/src/main/resources/META-INF/beans.xml b/opentracing/loggingtracer/src/main/resources/META-INF/beans.xml
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/resources/META-INF/beans.xml
rename to opentracing/loggingtracer/src/main/resources/META-INF/beans.xml
diff --git a/spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/services/io.opentracing.Tracer b/opentracing/loggingtracer/src/main/resources/META-INF/services/io.opentracing.Tracer
similarity index 100%
rename from spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/services/io.opentracing.Tracer
rename to opentracing/loggingtracer/src/main/resources/META-INF/services/io.opentracing.Tracer
diff --git a/spring-boot-opentracing/loggingtracer/src/main/resources/log4j2.properties b/opentracing/loggingtracer/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-opentracing/loggingtracer/src/main/resources/log4j2.properties
rename to opentracing/loggingtracer/src/main/resources/log4j2.properties
diff --git a/spring-boot-opentracing/pom.xml b/opentracing/pom.xml
similarity index 100%
rename from spring-boot-opentracing/pom.xml
rename to opentracing/pom.xml
diff --git a/spring-boot-opentracing/service1/pom.xml b/opentracing/service1/pom.xml
similarity index 100%
rename from spring-boot-opentracing/service1/pom.xml
rename to opentracing/service1/pom.xml
diff --git a/spring-boot-opentracing/service1/src/main/java/sample/camel/Service1Application.java b/opentracing/service1/src/main/java/sample/camel/Service1Application.java
similarity index 100%
rename from spring-boot-opentracing/service1/src/main/java/sample/camel/Service1Application.java
rename to opentracing/service1/src/main/java/sample/camel/Service1Application.java
diff --git a/spring-boot-zipkin/service1/src/main/java/sample/camel/Service1Route.java b/opentracing/service1/src/main/java/sample/camel/Service1Route.java
similarity index 100%
rename from spring-boot-zipkin/service1/src/main/java/sample/camel/Service1Route.java
rename to opentracing/service1/src/main/java/sample/camel/Service1Route.java
diff --git a/spring-boot-resilience4j/service1/src/main/resources/META-INF/LICENSE.txt b/opentracing/service1/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-resilience4j/service1/src/main/resources/META-INF/LICENSE.txt
rename to opentracing/service1/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-resilience4j/service1/src/main/resources/META-INF/NOTICE.txt b/opentracing/service1/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-resilience4j/service1/src/main/resources/META-INF/NOTICE.txt
rename to opentracing/service1/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-opentracing/service1/src/main/resources/application.properties b/opentracing/service1/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-opentracing/service1/src/main/resources/application.properties
rename to opentracing/service1/src/main/resources/application.properties
diff --git a/spring-boot-opentracing/service2/pom.xml b/opentracing/service2/pom.xml
similarity index 100%
rename from spring-boot-opentracing/service2/pom.xml
rename to opentracing/service2/pom.xml
diff --git a/spring-boot-opentracing/service2/src/main/java/sample/camel/Service2Application.java b/opentracing/service2/src/main/java/sample/camel/Service2Application.java
similarity index 100%
rename from spring-boot-opentracing/service2/src/main/java/sample/camel/Service2Application.java
rename to opentracing/service2/src/main/java/sample/camel/Service2Application.java
diff --git a/spring-boot-opentracing/service2/src/main/java/sample/camel/Service2Route.java b/opentracing/service2/src/main/java/sample/camel/Service2Route.java
similarity index 100%
rename from spring-boot-opentracing/service2/src/main/java/sample/camel/Service2Route.java
rename to opentracing/service2/src/main/java/sample/camel/Service2Route.java
diff --git a/spring-boot-resilience4j/client2/src/main/resources/META-INF/LICENSE.txt b/opentracing/service2/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/resources/META-INF/LICENSE.txt
rename to opentracing/service2/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-resilience4j/client2/src/main/resources/META-INF/NOTICE.txt b/opentracing/service2/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/resources/META-INF/NOTICE.txt
rename to opentracing/service2/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-opentracing/client/src/main/resources/log4j2.properties b/opentracing/service2/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-opentracing/client/src/main/resources/log4j2.properties
rename to opentracing/service2/src/main/resources/log4j2.properties
diff --git a/spring-boot-pojo/README.adoc b/pojo/README.adoc
similarity index 100%
rename from spring-boot-pojo/README.adoc
rename to pojo/README.adoc
diff --git a/spring-boot-pojo/pom.xml b/pojo/pom.xml
similarity index 100%
rename from spring-boot-pojo/pom.xml
rename to pojo/pom.xml
diff --git a/spring-boot-supervising-route-controller/src/main/java/sample/camel/Application.java b/pojo/src/main/java/sample/camel/Application.java
similarity index 100%
rename from spring-boot-supervising-route-controller/src/main/java/sample/camel/Application.java
rename to pojo/src/main/java/sample/camel/Application.java
diff --git a/spring-boot-pojo/src/main/java/sample/camel/MagicNumber.java b/pojo/src/main/java/sample/camel/MagicNumber.java
similarity index 100%
rename from spring-boot-pojo/src/main/java/sample/camel/MagicNumber.java
rename to pojo/src/main/java/sample/camel/MagicNumber.java
diff --git a/spring-boot-pojo/src/main/java/sample/camel/NumberPojo.java b/pojo/src/main/java/sample/camel/NumberPojo.java
similarity index 100%
rename from spring-boot-pojo/src/main/java/sample/camel/NumberPojo.java
rename to pojo/src/main/java/sample/camel/NumberPojo.java
diff --git a/spring-boot-pojo/src/main/java/sample/camel/NumberRoute.java b/pojo/src/main/java/sample/camel/NumberRoute.java
similarity index 100%
rename from spring-boot-pojo/src/main/java/sample/camel/NumberRoute.java
rename to pojo/src/main/java/sample/camel/NumberRoute.java
diff --git a/spring-boot-pojo/src/main/resources/application.properties b/pojo/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-pojo/src/main/resources/application.properties
rename to pojo/src/main/resources/application.properties
diff --git a/pom.xml b/pom.xml
index c71f27c..279e507 100644
--- a/pom.xml
+++ b/pom.xml
@@ -36,52 +36,52 @@
 
 	<modules>
 		<module>spring-boot</module>
-		<module>spring-boot-activemq</module>
-		<module>spring-boot-actuator-http-metrics</module>
-		<module>spring-boot-amqp</module>
-		<module>spring-boot-apm-opentracing</module>
-		<module>spring-boot-arangodb</module>
-		<module>spring-boot-aws2-s3</module>
-		<module>spring-boot-clustered-route-controller</module>
-		<module>spring-boot-fhir</module>
-		<module>spring-boot-fhir-auth-tx</module>
-		<module>spring-boot-geocoder</module>
-		<module>spring-boot-grpc</module>
-		<module>spring-boot-grpc-kubernetes</module>
-		<module>spring-boot-health-checks</module>
-		<module>spring-boot-hystrix</module>
-		<module>spring-boot-infinispan</module>
-		<module>spring-boot-jira</module>
-		<module>spring-boot-kafka-avro</module>
-		<module>spring-boot-kafka-offsetrepository</module>
-		<module>spring-boot-load-balancer-eip</module>
-		<module>spring-boot-master</module>
-		<module>spring-boot-metrics</module>
-		<module>spring-boot-opentracing</module>
-		<module>spring-boot-pojo</module>
-		<module>spring-boot-rabbitmq</module>
-		<module>spring-boot-reactive-streams</module>
-		<module>spring-boot-resilience4j</module>
-		<module>spring-boot-rest-jpa</module>
-		<module>spring-boot-rest-producer</module>
-		<module>spring-boot-rest-swagger</module>
-		<module>spring-boot-rest-swagger-simple</module>
-		<module>spring-boot-rest-openapi</module>
-		<module>spring-boot-rest-openapi-simple</module>
-		<module>spring-boot-routetemplate</module>
-		<module>spring-boot-servicecall</module>
-		<module>spring-boot-supervising-route-controller</module>
-		<module>spring-boot-twitter-salesforce</module>
-		<module>spring-boot-type-converter</module>
-		<module>spring-boot-undertow-spring-security</module>
-		<module>spring-boot-validator</module>
-		<module>spring-boot-webhook</module>
-		<module>spring-boot-xml</module>
-		<module>spring-boot-zipkin</module>
-		<module>spring-boot-strimzi</module>
-		<module>spring-boot-splitter-eip</module>
-		<module>spring-boot-widget-gadget</module>
-		<module>spring-boot-unit-testing</module>
+		<module>activemq</module>
+		<module>actuator-http-metrics</module>
+		<module>amqp</module>
+		<module>apm-opentracing</module>
+		<module>arangodb</module>
+		<module>aws2-s3</module>
+		<module>clustered-route-controller</module>
+		<module>fhir</module>
+		<module>fhir-auth-tx</module>
+		<module>geocoder</module>
+		<module>grpc</module>
+		<module>grpc-kubernetes</module>
+		<module>health-checks</module>
+		<module>hystrix</module>
+		<module>infinispan</module>
+		<module>jira</module>
+		<module>kafka-avro</module>
+		<module>kafka-offsetrepository</module>
+		<module>load-balancer-eip</module>
+		<module>master</module>
+		<module>metrics</module>
+		<module>opentracing</module>
+		<module>pojo</module>
+		<module>rabbitmq</module>
+		<module>reactive-streams</module>
+		<module>resilience4j</module>
+		<module>rest-jpa</module>
+		<module>rest-producer</module>
+		<module>rest-swagger</module>
+		<module>rest-swagger-simple</module>
+		<module>rest-openapi</module>
+		<module>rest-openapi-simple</module>
+		<module>routetemplate</module>
+		<module>servicecall</module>
+		<module>supervising-route-controller</module>
+		<module>twitter-salesforce</module>
+		<module>type-converter</module>
+		<module>undertow-spring-security</module>
+		<module>validator</module>
+		<module>webhook</module>
+		<module>xml</module>
+		<module>zipkin</module>
+		<module>strimzi</module>
+		<module>splitter-eip</module>
+		<module>widget-gadget</module>
+		<module>unit-testing</module>
 	</modules>
 
 	<properties>
diff --git a/spring-boot-rabbitmq/pom.xml b/rabbitmq/pom.xml
similarity index 100%
rename from spring-boot-rabbitmq/pom.xml
rename to rabbitmq/pom.xml
diff --git a/spring-boot-rabbitmq/readme.adoc b/rabbitmq/readme.adoc
similarity index 100%
rename from spring-boot-rabbitmq/readme.adoc
rename to rabbitmq/readme.adoc
diff --git a/spring-boot-rabbitmq/src/main/java/sample/camel/SampleCamelApplication.java b/rabbitmq/src/main/java/sample/camel/SampleCamelApplication.java
similarity index 100%
rename from spring-boot-rabbitmq/src/main/java/sample/camel/SampleCamelApplication.java
rename to rabbitmq/src/main/java/sample/camel/SampleCamelApplication.java
diff --git a/spring-boot-rabbitmq/src/main/java/sample/camel/SampleCamelRouter.java b/rabbitmq/src/main/java/sample/camel/SampleCamelRouter.java
similarity index 100%
rename from spring-boot-rabbitmq/src/main/java/sample/camel/SampleCamelRouter.java
rename to rabbitmq/src/main/java/sample/camel/SampleCamelRouter.java
diff --git a/spring-boot-rabbitmq/src/main/resources/application.properties b/rabbitmq/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-rabbitmq/src/main/resources/application.properties
rename to rabbitmq/src/main/resources/application.properties
diff --git a/spring-boot-reactive-streams/pom.xml b/reactive-streams/pom.xml
similarity index 100%
rename from spring-boot-reactive-streams/pom.xml
rename to reactive-streams/pom.xml
diff --git a/spring-boot-reactive-streams/readme.adoc b/reactive-streams/readme.adoc
similarity index 100%
rename from spring-boot-reactive-streams/readme.adoc
rename to reactive-streams/readme.adoc
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorExample.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorExample.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorExample.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorExample.java
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorInOutExample.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorInOutExample.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorInOutExample.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicCamelToReactorInOutExample.java
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelExample.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelExample.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelExample.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelExample.java
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelInOutExample.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelInOutExample.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelInOutExample.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/BasicReactorToCamelInOutExample.java
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIRestExample.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIRestExample.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIRestExample.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIRestExample.java
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIWorkflowExample.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIWorkflowExample.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIWorkflowExample.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/ClientAPIWorkflowExample.java
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/RestExample.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/RestExample.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/RestExample.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/RestExample.java
diff --git a/spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/app/ReactiveStreamsSpringBootApp.java b/reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/app/ReactiveStreamsSpringBootApp.java
similarity index 100%
rename from spring-boot-reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/app/ReactiveStreamsSpringBootApp.java
rename to reactive-streams/src/main/java/org/apache/camel/example/reactive/streams/app/ReactiveStreamsSpringBootApp.java
diff --git a/spring-boot-resilience4j/client/src/main/resources/META-INF/LICENSE.txt b/reactive-streams/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/resources/META-INF/LICENSE.txt
rename to reactive-streams/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-resilience4j/client/src/main/resources/META-INF/NOTICE.txt b/reactive-streams/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/resources/META-INF/NOTICE.txt
rename to reactive-streams/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-reactive-streams/src/main/resources/META-INF/spring.factories b/reactive-streams/src/main/resources/META-INF/spring.factories
similarity index 100%
rename from spring-boot-reactive-streams/src/main/resources/META-INF/spring.factories
rename to reactive-streams/src/main/resources/META-INF/spring.factories
diff --git a/spring-boot-reactive-streams/src/main/resources/application.yml b/reactive-streams/src/main/resources/application.yml
similarity index 100%
rename from spring-boot-reactive-streams/src/main/resources/application.yml
rename to reactive-streams/src/main/resources/application.yml
diff --git a/spring-boot-resilience4j/README.adoc b/resilience4j/README.adoc
similarity index 100%
rename from spring-boot-resilience4j/README.adoc
rename to resilience4j/README.adoc
diff --git a/spring-boot-resilience4j/client/pom.xml b/resilience4j/client/pom.xml
similarity index 100%
rename from spring-boot-resilience4j/client/pom.xml
rename to resilience4j/client/pom.xml
diff --git a/spring-boot-resilience4j/client/src/main/java/sample/camel/ClientApplication.java b/resilience4j/client/src/main/java/sample/camel/ClientApplication.java
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/java/sample/camel/ClientApplication.java
rename to resilience4j/client/src/main/java/sample/camel/ClientApplication.java
diff --git a/spring-boot-resilience4j/client/src/main/java/sample/camel/ClientRoute.java b/resilience4j/client/src/main/java/sample/camel/ClientRoute.java
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/java/sample/camel/ClientRoute.java
rename to resilience4j/client/src/main/java/sample/camel/ClientRoute.java
diff --git a/spring-boot-hystrix/client/src/main/java/sample/camel/CounterBean.java b/resilience4j/client/src/main/java/sample/camel/CounterBean.java
similarity index 100%
rename from spring-boot-hystrix/client/src/main/java/sample/camel/CounterBean.java
rename to resilience4j/client/src/main/java/sample/camel/CounterBean.java
diff --git a/spring-boot-reactive-streams/src/main/resources/META-INF/LICENSE.txt b/resilience4j/client/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-reactive-streams/src/main/resources/META-INF/LICENSE.txt
rename to resilience4j/client/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-reactive-streams/src/main/resources/META-INF/NOTICE.txt b/resilience4j/client/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-reactive-streams/src/main/resources/META-INF/NOTICE.txt
rename to resilience4j/client/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/beans.xml b/resilience4j/client/src/main/resources/META-INF/beans.xml
similarity index 100%
rename from spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/beans.xml
rename to resilience4j/client/src/main/resources/META-INF/beans.xml
diff --git a/spring-boot-resilience4j/client/src/main/resources/application.properties b/resilience4j/client/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/resources/application.properties
rename to resilience4j/client/src/main/resources/application.properties
diff --git a/spring-boot-resilience4j/client2/src/main/resources/log4j2.properties b/resilience4j/client/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/resources/log4j2.properties
rename to resilience4j/client/src/main/resources/log4j2.properties
diff --git a/spring-boot-resilience4j/client2/pom.xml b/resilience4j/client2/pom.xml
similarity index 100%
rename from spring-boot-resilience4j/client2/pom.xml
rename to resilience4j/client2/pom.xml
diff --git a/spring-boot-resilience4j/client2/src/main/java/sample/camel/Client2Application.java b/resilience4j/client2/src/main/java/sample/camel/Client2Application.java
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/java/sample/camel/Client2Application.java
rename to resilience4j/client2/src/main/java/sample/camel/Client2Application.java
diff --git a/spring-boot-resilience4j/client2/src/main/java/sample/camel/Client2Route.java b/resilience4j/client2/src/main/java/sample/camel/Client2Route.java
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/java/sample/camel/Client2Route.java
rename to resilience4j/client2/src/main/java/sample/camel/Client2Route.java
diff --git a/spring-boot-resilience4j/client2/src/main/java/sample/camel/CounterBean.java b/resilience4j/client2/src/main/java/sample/camel/CounterBean.java
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/java/sample/camel/CounterBean.java
rename to resilience4j/client2/src/main/java/sample/camel/CounterBean.java
diff --git a/spring-boot-opentracing/service2/src/main/resources/META-INF/LICENSE.txt b/resilience4j/client2/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-opentracing/service2/src/main/resources/META-INF/LICENSE.txt
rename to resilience4j/client2/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-opentracing/service2/src/main/resources/META-INF/NOTICE.txt b/resilience4j/client2/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-opentracing/service2/src/main/resources/META-INF/NOTICE.txt
rename to resilience4j/client2/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-opentracing/client/src/main/resources/META-INF/beans.xml b/resilience4j/client2/src/main/resources/META-INF/beans.xml
similarity index 100%
rename from spring-boot-opentracing/client/src/main/resources/META-INF/beans.xml
rename to resilience4j/client2/src/main/resources/META-INF/beans.xml
diff --git a/spring-boot-resilience4j/client2/src/main/resources/application.properties b/resilience4j/client2/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-resilience4j/client2/src/main/resources/application.properties
rename to resilience4j/client2/src/main/resources/application.properties
diff --git a/spring-boot-resilience4j/client/src/main/resources/log4j2.properties b/resilience4j/client2/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-resilience4j/client/src/main/resources/log4j2.properties
rename to resilience4j/client2/src/main/resources/log4j2.properties
diff --git a/spring-boot-resilience4j/pom.xml b/resilience4j/pom.xml
similarity index 100%
rename from spring-boot-resilience4j/pom.xml
rename to resilience4j/pom.xml
diff --git a/spring-boot-resilience4j/service1/pom.xml b/resilience4j/service1/pom.xml
similarity index 100%
rename from spring-boot-resilience4j/service1/pom.xml
rename to resilience4j/service1/pom.xml
diff --git a/spring-boot-hystrix/service1/src/main/java/sample/camel/Service1Application.java b/resilience4j/service1/src/main/java/sample/camel/Service1Application.java
similarity index 100%
rename from spring-boot-hystrix/service1/src/main/java/sample/camel/Service1Application.java
rename to resilience4j/service1/src/main/java/sample/camel/Service1Application.java
diff --git a/spring-boot-hystrix/service1/src/main/java/sample/camel/Service1Route.java b/resilience4j/service1/src/main/java/sample/camel/Service1Route.java
similarity index 100%
rename from spring-boot-hystrix/service1/src/main/java/sample/camel/Service1Route.java
rename to resilience4j/service1/src/main/java/sample/camel/Service1Route.java
diff --git a/spring-boot-opentracing/service1/src/main/resources/META-INF/LICENSE.txt b/resilience4j/service1/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-opentracing/service1/src/main/resources/META-INF/LICENSE.txt
rename to resilience4j/service1/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-opentracing/service1/src/main/resources/META-INF/NOTICE.txt b/resilience4j/service1/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-opentracing/service1/src/main/resources/META-INF/NOTICE.txt
rename to resilience4j/service1/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-hystrix/service1/src/main/resources/application.properties b/resilience4j/service1/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-hystrix/service1/src/main/resources/application.properties
rename to resilience4j/service1/src/main/resources/application.properties
diff --git a/spring-boot-resilience4j/service2/pom.xml b/resilience4j/service2/pom.xml
similarity index 100%
rename from spring-boot-resilience4j/service2/pom.xml
rename to resilience4j/service2/pom.xml
diff --git a/spring-boot-resilience4j/service2/src/main/java/sample/camel/Service2Application.java b/resilience4j/service2/src/main/java/sample/camel/Service2Application.java
similarity index 100%
rename from spring-boot-resilience4j/service2/src/main/java/sample/camel/Service2Application.java
rename to resilience4j/service2/src/main/java/sample/camel/Service2Application.java
diff --git a/spring-boot-hystrix/service2/src/main/java/sample/camel/Service2Route.java b/resilience4j/service2/src/main/java/sample/camel/Service2Route.java
similarity index 100%
rename from spring-boot-hystrix/service2/src/main/java/sample/camel/Service2Route.java
rename to resilience4j/service2/src/main/java/sample/camel/Service2Route.java
diff --git a/spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/LICENSE.txt b/resilience4j/service2/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/LICENSE.txt
rename to resilience4j/service2/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/NOTICE.txt b/resilience4j/service2/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-opentracing/loggingtracer/src/main/resources/META-INF/NOTICE.txt
rename to resilience4j/service2/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-resilience4j/service2/src/main/resources/log4j2.properties b/resilience4j/service2/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-resilience4j/service2/src/main/resources/log4j2.properties
rename to resilience4j/service2/src/main/resources/log4j2.properties
diff --git a/spring-boot-rest-jpa/README.adoc b/rest-jpa/README.adoc
similarity index 100%
rename from spring-boot-rest-jpa/README.adoc
rename to rest-jpa/README.adoc
diff --git a/spring-boot-rest-jpa/pom.xml b/rest-jpa/pom.xml
similarity index 100%
rename from spring-boot-rest-jpa/pom.xml
rename to rest-jpa/pom.xml
diff --git a/spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Application.java b/rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Application.java
similarity index 100%
rename from spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Application.java
rename to rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Application.java
diff --git a/spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Book.java b/rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Book.java
similarity index 100%
rename from spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Book.java
rename to rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Book.java
diff --git a/spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/BookRepository.java b/rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/BookRepository.java
similarity index 100%
rename from spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/BookRepository.java
rename to rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/BookRepository.java
diff --git a/spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Database.java b/rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Database.java
similarity index 100%
rename from spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Database.java
rename to rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Database.java
diff --git a/spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Order.java b/rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Order.java
similarity index 100%
rename from spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Order.java
rename to rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/Order.java
diff --git a/spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderRepository.java b/rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderRepository.java
similarity index 100%
rename from spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderRepository.java
rename to rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderRepository.java
diff --git a/spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderService.java b/rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderService.java
similarity index 100%
rename from spring-boot-rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderService.java
rename to rest-jpa/src/main/java/org/apache/camel/example/spring/boot/rest/jpa/OrderService.java
diff --git a/spring-boot-rest-jpa/src/main/resources/application-dev.yml b/rest-jpa/src/main/resources/application-dev.yml
similarity index 100%
rename from spring-boot-rest-jpa/src/main/resources/application-dev.yml
rename to rest-jpa/src/main/resources/application-dev.yml
diff --git a/spring-boot-rest-jpa/src/main/resources/application.yml b/rest-jpa/src/main/resources/application.yml
similarity index 100%
rename from spring-boot-rest-jpa/src/main/resources/application.yml
rename to rest-jpa/src/main/resources/application.yml
diff --git a/spring-boot-rest-jpa/src/main/resources/data.sql b/rest-jpa/src/main/resources/data.sql
similarity index 100%
rename from spring-boot-rest-jpa/src/main/resources/data.sql
rename to rest-jpa/src/main/resources/data.sql
diff --git a/spring-boot-rest-jpa/src/test/java/org/apache/camel/example/spring/boot/rest/jpa/ApplicationTest.java b/rest-jpa/src/test/java/org/apache/camel/example/spring/boot/rest/jpa/ApplicationTest.java
similarity index 100%
rename from spring-boot-rest-jpa/src/test/java/org/apache/camel/example/spring/boot/rest/jpa/ApplicationTest.java
rename to rest-jpa/src/test/java/org/apache/camel/example/spring/boot/rest/jpa/ApplicationTest.java
diff --git a/spring-boot-rest-jpa/src/test/resources/application.yml b/rest-jpa/src/test/resources/application.yml
similarity index 100%
rename from spring-boot-rest-jpa/src/test/resources/application.yml
rename to rest-jpa/src/test/resources/application.yml
diff --git a/spring-boot-rest-openapi-simple/README.adoc b/rest-openapi-simple/README.adoc
similarity index 100%
rename from spring-boot-rest-openapi-simple/README.adoc
rename to rest-openapi-simple/README.adoc
diff --git a/spring-boot-rest-openapi-simple/pom.xml b/rest-openapi-simple/pom.xml
similarity index 100%
rename from spring-boot-rest-openapi-simple/pom.xml
rename to rest-openapi-simple/pom.xml
diff --git a/spring-boot-rest-openapi-simple/src/main/java/org/apache/camel/example/RestOpenApiApplication.java b/rest-openapi-simple/src/main/java/org/apache/camel/example/RestOpenApiApplication.java
similarity index 100%
rename from spring-boot-rest-openapi-simple/src/main/java/org/apache/camel/example/RestOpenApiApplication.java
rename to rest-openapi-simple/src/main/java/org/apache/camel/example/RestOpenApiApplication.java
diff --git a/spring-boot-rest-openapi/README.adoc b/rest-openapi/README.adoc
similarity index 100%
rename from spring-boot-rest-openapi/README.adoc
rename to rest-openapi/README.adoc
diff --git a/spring-boot-rest-openapi/pom.xml b/rest-openapi/pom.xml
similarity index 100%
rename from spring-boot-rest-openapi/pom.xml
rename to rest-openapi/pom.xml
diff --git a/spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/Application.java b/rest-openapi/src/main/java/org/apache/camel/example/springboot/Application.java
similarity index 100%
rename from spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/Application.java
rename to rest-openapi/src/main/java/org/apache/camel/example/springboot/Application.java
diff --git a/spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/CamelRouter.java b/rest-openapi/src/main/java/org/apache/camel/example/springboot/CamelRouter.java
similarity index 100%
rename from spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/CamelRouter.java
rename to rest-openapi/src/main/java/org/apache/camel/example/springboot/CamelRouter.java
diff --git a/spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/User.java b/rest-openapi/src/main/java/org/apache/camel/example/springboot/User.java
similarity index 100%
rename from spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/User.java
rename to rest-openapi/src/main/java/org/apache/camel/example/springboot/User.java
diff --git a/spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/UserService.java b/rest-openapi/src/main/java/org/apache/camel/example/springboot/UserService.java
similarity index 100%
rename from spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/UserService.java
rename to rest-openapi/src/main/java/org/apache/camel/example/springboot/UserService.java
diff --git a/spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java b/rest-openapi/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java
similarity index 100%
rename from spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java
rename to rest-openapi/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java
diff --git a/spring-boot-rest-swagger/src/main/resources/application.properties b/rest-openapi/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-rest-swagger/src/main/resources/application.properties
rename to rest-openapi/src/main/resources/application.properties
diff --git a/spring-boot-rest-producer/pom.xml b/rest-producer/pom.xml
similarity index 100%
rename from spring-boot-rest-producer/pom.xml
rename to rest-producer/pom.xml
diff --git a/spring-boot-rest-producer/readme.adoc b/rest-producer/readme.adoc
similarity index 100%
rename from spring-boot-rest-producer/readme.adoc
rename to rest-producer/readme.adoc
diff --git a/spring-boot-rest-producer/src/main/java/sample/camel/PetController.java b/rest-producer/src/main/java/sample/camel/PetController.java
similarity index 100%
rename from spring-boot-rest-producer/src/main/java/sample/camel/PetController.java
rename to rest-producer/src/main/java/sample/camel/PetController.java
diff --git a/spring-boot-rest-producer/src/main/java/sample/camel/RestApplication.java b/rest-producer/src/main/java/sample/camel/RestApplication.java
similarity index 100%
rename from spring-boot-rest-producer/src/main/java/sample/camel/RestApplication.java
rename to rest-producer/src/main/java/sample/camel/RestApplication.java
diff --git a/spring-boot-rest-producer/src/main/java/sample/camel/RestRoute.java b/rest-producer/src/main/java/sample/camel/RestRoute.java
similarity index 100%
rename from spring-boot-rest-producer/src/main/java/sample/camel/RestRoute.java
rename to rest-producer/src/main/java/sample/camel/RestRoute.java
diff --git a/spring-boot-rest-producer/src/main/resources/application.properties b/rest-producer/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-rest-producer/src/main/resources/application.properties
rename to rest-producer/src/main/resources/application.properties
diff --git a/spring-boot-rest-swagger-simple/README.adoc b/rest-swagger-simple/README.adoc
similarity index 100%
rename from spring-boot-rest-swagger-simple/README.adoc
rename to rest-swagger-simple/README.adoc
diff --git a/spring-boot-rest-swagger-simple/pom.xml b/rest-swagger-simple/pom.xml
similarity index 100%
rename from spring-boot-rest-swagger-simple/pom.xml
rename to rest-swagger-simple/pom.xml
diff --git a/spring-boot-rest-swagger-simple/src/main/java/org/apache/camel/example/RestSwaggerApplication.java b/rest-swagger-simple/src/main/java/org/apache/camel/example/RestSwaggerApplication.java
similarity index 100%
rename from spring-boot-rest-swagger-simple/src/main/java/org/apache/camel/example/RestSwaggerApplication.java
rename to rest-swagger-simple/src/main/java/org/apache/camel/example/RestSwaggerApplication.java
diff --git a/spring-boot-rest-swagger/README.adoc b/rest-swagger/README.adoc
similarity index 100%
rename from spring-boot-rest-swagger/README.adoc
rename to rest-swagger/README.adoc
diff --git a/spring-boot-rest-swagger/pom.xml b/rest-swagger/pom.xml
similarity index 100%
rename from spring-boot-rest-swagger/pom.xml
rename to rest-swagger/pom.xml
diff --git a/spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/Application.java b/rest-swagger/src/main/java/org/apache/camel/example/springboot/Application.java
similarity index 100%
rename from spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/Application.java
rename to rest-swagger/src/main/java/org/apache/camel/example/springboot/Application.java
diff --git a/spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/CamelRouter.java b/rest-swagger/src/main/java/org/apache/camel/example/springboot/CamelRouter.java
similarity index 100%
rename from spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/CamelRouter.java
rename to rest-swagger/src/main/java/org/apache/camel/example/springboot/CamelRouter.java
diff --git a/spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/User.java b/rest-swagger/src/main/java/org/apache/camel/example/springboot/User.java
similarity index 100%
rename from spring-boot-rest-swagger/src/main/java/org/apache/camel/example/springboot/User.java
rename to rest-swagger/src/main/java/org/apache/camel/example/springboot/User.java
diff --git a/spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/UserService.java b/rest-swagger/src/main/java/org/apache/camel/example/springboot/UserService.java
similarity index 100%
rename from spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/UserService.java
rename to rest-swagger/src/main/java/org/apache/camel/example/springboot/UserService.java
diff --git a/spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java b/rest-swagger/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java
similarity index 100%
rename from spring-boot-rest-openapi/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java
rename to rest-swagger/src/main/java/org/apache/camel/example/springboot/UserServiceImpl.java
diff --git a/spring-boot-rest-openapi/src/main/resources/application.properties b/rest-swagger/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-rest-openapi/src/main/resources/application.properties
rename to rest-swagger/src/main/resources/application.properties
diff --git a/spring-boot-routetemplate/pom.xml b/routetemplate/pom.xml
similarity index 100%
rename from spring-boot-routetemplate/pom.xml
rename to routetemplate/pom.xml
diff --git a/spring-boot-routetemplate/readme.adoc b/routetemplate/readme.adoc
similarity index 100%
rename from spring-boot-routetemplate/readme.adoc
rename to routetemplate/readme.adoc
diff --git a/spring-boot-routetemplate/src/main/java/sample/camel/MyCamelApplication.java b/routetemplate/src/main/java/sample/camel/MyCamelApplication.java
similarity index 100%
rename from spring-boot-routetemplate/src/main/java/sample/camel/MyCamelApplication.java
rename to routetemplate/src/main/java/sample/camel/MyCamelApplication.java
diff --git a/spring-boot-routetemplate/src/main/java/sample/camel/MyRouteTemplates.java b/routetemplate/src/main/java/sample/camel/MyRouteTemplates.java
similarity index 100%
rename from spring-boot-routetemplate/src/main/java/sample/camel/MyRouteTemplates.java
rename to routetemplate/src/main/java/sample/camel/MyRouteTemplates.java
diff --git a/spring-boot-routetemplate/src/main/java/sample/camel/MyTemplateBuilder.java b/routetemplate/src/main/java/sample/camel/MyTemplateBuilder.java
similarity index 100%
rename from spring-boot-routetemplate/src/main/java/sample/camel/MyTemplateBuilder.java
rename to routetemplate/src/main/java/sample/camel/MyTemplateBuilder.java
diff --git a/spring-boot-routetemplate/src/main/resources/application.properties b/routetemplate/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-routetemplate/src/main/resources/application.properties
rename to routetemplate/src/main/resources/application.properties
diff --git a/spring-boot-routetemplate/src/test/java/sample/camel/MyCamelApplicationJUnit5Test.java b/routetemplate/src/test/java/sample/camel/MyCamelApplicationJUnit5Test.java
similarity index 100%
rename from spring-boot-routetemplate/src/test/java/sample/camel/MyCamelApplicationJUnit5Test.java
rename to routetemplate/src/test/java/sample/camel/MyCamelApplicationJUnit5Test.java
diff --git a/spring-boot-servicecall/README.adoc b/servicecall/README.adoc
similarity index 100%
rename from spring-boot-servicecall/README.adoc
rename to servicecall/README.adoc
diff --git a/spring-boot-servicecall/consumer/pom.xml b/servicecall/consumer/pom.xml
similarity index 100%
rename from spring-boot-servicecall/consumer/pom.xml
rename to servicecall/consumer/pom.xml
diff --git a/spring-boot-servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerApplication.java b/servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerApplication.java
similarity index 100%
rename from spring-boot-servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerApplication.java
rename to servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerApplication.java
diff --git a/spring-boot-servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerAutoConfiguration.java b/servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerAutoConfiguration.java
similarity index 100%
rename from spring-boot-servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerAutoConfiguration.java
rename to servicecall/consumer/src/main/java/org/apache/camel/example/ServiceCallConsumerAutoConfiguration.java
diff --git a/spring-boot-servicecall/consumer/src/main/resources/application.properties b/servicecall/consumer/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-servicecall/consumer/src/main/resources/application.properties
rename to servicecall/consumer/src/main/resources/application.properties
diff --git a/spring-boot-servicecall/consumer/src/main/resources/logback.xml b/servicecall/consumer/src/main/resources/logback.xml
similarity index 100%
rename from spring-boot-servicecall/consumer/src/main/resources/logback.xml
rename to servicecall/consumer/src/main/resources/logback.xml
diff --git a/spring-boot-servicecall/pom.xml b/servicecall/pom.xml
similarity index 100%
rename from spring-boot-servicecall/pom.xml
rename to servicecall/pom.xml
diff --git a/spring-boot-servicecall/services/pom.xml b/servicecall/services/pom.xml
similarity index 100%
rename from spring-boot-servicecall/services/pom.xml
rename to servicecall/services/pom.xml
diff --git a/spring-boot-servicecall/services/src/main/bash/consul-run-linux.sh b/servicecall/services/src/main/bash/consul-run-linux.sh
similarity index 100%
rename from spring-boot-servicecall/services/src/main/bash/consul-run-linux.sh
rename to servicecall/services/src/main/bash/consul-run-linux.sh
diff --git a/spring-boot-servicecall/services/src/main/bash/consul-run-osx.sh b/servicecall/services/src/main/bash/consul-run-osx.sh
similarity index 100%
rename from spring-boot-servicecall/services/src/main/bash/consul-run-osx.sh
rename to servicecall/services/src/main/bash/consul-run-osx.sh
diff --git a/spring-boot-servicecall/services/src/main/java/org/apache/camel/example/ServiceApplication.java b/servicecall/services/src/main/java/org/apache/camel/example/ServiceApplication.java
similarity index 100%
rename from spring-boot-servicecall/services/src/main/java/org/apache/camel/example/ServiceApplication.java
rename to servicecall/services/src/main/java/org/apache/camel/example/ServiceApplication.java
diff --git a/spring-boot-servicecall/services/src/main/resources/application.properties b/servicecall/services/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-servicecall/services/src/main/resources/application.properties
rename to servicecall/services/src/main/resources/application.properties
diff --git a/spring-boot-servicecall/services/src/main/resources/consul/services.json b/servicecall/services/src/main/resources/consul/services.json
similarity index 100%
rename from spring-boot-servicecall/services/src/main/resources/consul/services.json
rename to servicecall/services/src/main/resources/consul/services.json
diff --git a/spring-boot-servicecall/services/src/main/resources/logback.xml b/servicecall/services/src/main/resources/logback.xml
similarity index 100%
rename from spring-boot-servicecall/services/src/main/resources/logback.xml
rename to servicecall/services/src/main/resources/logback.xml
diff --git a/spring-boot-splitter-eip/README.adoc b/splitter-eip/README.adoc
similarity index 100%
rename from spring-boot-splitter-eip/README.adoc
rename to splitter-eip/README.adoc
diff --git a/spring-boot-splitter-eip/pom.xml b/splitter-eip/pom.xml
similarity index 100%
rename from spring-boot-splitter-eip/pom.xml
rename to splitter-eip/pom.xml
diff --git a/spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/AggregationStrategyPojo.java b/splitter-eip/src/main/java/org/apache/camel/example/spring/boot/AggregationStrategyPojo.java
similarity index 100%
rename from spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/AggregationStrategyPojo.java
rename to splitter-eip/src/main/java/org/apache/camel/example/spring/boot/AggregationStrategyPojo.java
diff --git a/spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/Application.java b/splitter-eip/src/main/java/org/apache/camel/example/spring/boot/Application.java
similarity index 100%
rename from spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/Application.java
rename to splitter-eip/src/main/java/org/apache/camel/example/spring/boot/Application.java
diff --git a/spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/MyMessageTransformer.java b/splitter-eip/src/main/java/org/apache/camel/example/spring/boot/MyMessageTransformer.java
similarity index 100%
rename from spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/MyMessageTransformer.java
rename to splitter-eip/src/main/java/org/apache/camel/example/spring/boot/MyMessageTransformer.java
diff --git a/spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/SplitterRouter.java b/splitter-eip/src/main/java/org/apache/camel/example/spring/boot/SplitterRouter.java
similarity index 100%
rename from spring-boot-splitter-eip/src/main/java/org/apache/camel/example/spring/boot/SplitterRouter.java
rename to splitter-eip/src/main/java/org/apache/camel/example/spring/boot/SplitterRouter.java
diff --git a/spring-boot-splitter-eip/src/main/resources/application.properties b/splitter-eip/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-splitter-eip/src/main/resources/application.properties
rename to splitter-eip/src/main/resources/application.properties
diff --git a/spring-boot-splitter-eip/src/test/java/CamelSplitterEIPTests.java b/splitter-eip/src/test/java/CamelSplitterEIPTests.java
similarity index 100%
rename from spring-boot-splitter-eip/src/test/java/CamelSplitterEIPTests.java
rename to splitter-eip/src/test/java/CamelSplitterEIPTests.java
diff --git a/spring-boot-strimzi/.gitignore b/strimzi/.gitignore
similarity index 100%
rename from spring-boot-strimzi/.gitignore
rename to strimzi/.gitignore
diff --git a/spring-boot-strimzi/README.adoc b/strimzi/README.adoc
similarity index 100%
rename from spring-boot-strimzi/README.adoc
rename to strimzi/README.adoc
diff --git a/spring-boot-strimzi/pom.xml b/strimzi/pom.xml
similarity index 100%
rename from spring-boot-strimzi/pom.xml
rename to strimzi/pom.xml
diff --git a/spring-boot-strimzi/prepare-truststore.sh b/strimzi/prepare-truststore.sh
similarity index 100%
rename from spring-boot-strimzi/prepare-truststore.sh
rename to strimzi/prepare-truststore.sh
diff --git a/spring-boot-strimzi/route-diagram.png b/strimzi/route-diagram.png
similarity index 100%
rename from spring-boot-strimzi/route-diagram.png
rename to strimzi/route-diagram.png
diff --git a/spring-boot-strimzi/src/main/fabric8/deployment.yml b/strimzi/src/main/fabric8/deployment.yml
similarity index 100%
rename from spring-boot-strimzi/src/main/fabric8/deployment.yml
rename to strimzi/src/main/fabric8/deployment.yml
diff --git a/spring-boot-strimzi/src/main/java/org/apache/camel/example/strimzi/Application.java b/strimzi/src/main/java/org/apache/camel/example/strimzi/Application.java
similarity index 100%
rename from spring-boot-strimzi/src/main/java/org/apache/camel/example/strimzi/Application.java
rename to strimzi/src/main/java/org/apache/camel/example/strimzi/Application.java
diff --git a/spring-boot-strimzi/src/main/java/org/apache/camel/example/strimzi/StrimziRouteBuilder.java b/strimzi/src/main/java/org/apache/camel/example/strimzi/StrimziRouteBuilder.java
similarity index 100%
rename from spring-boot-strimzi/src/main/java/org/apache/camel/example/strimzi/StrimziRouteBuilder.java
rename to strimzi/src/main/java/org/apache/camel/example/strimzi/StrimziRouteBuilder.java
diff --git a/spring-boot-strimzi/src/main/resources/application-local.properties b/strimzi/src/main/resources/application-local.properties
similarity index 100%
rename from spring-boot-strimzi/src/main/resources/application-local.properties
rename to strimzi/src/main/resources/application-local.properties
diff --git a/spring-boot-strimzi/src/main/resources/application.properties b/strimzi/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-strimzi/src/main/resources/application.properties
rename to strimzi/src/main/resources/application.properties
diff --git a/spring-boot-strimzi/src/main/resources/kafka-ephemeral-kubernetes.yaml b/strimzi/src/main/resources/kafka-ephemeral-kubernetes.yaml
similarity index 100%
rename from spring-boot-strimzi/src/main/resources/kafka-ephemeral-kubernetes.yaml
rename to strimzi/src/main/resources/kafka-ephemeral-kubernetes.yaml
diff --git a/spring-boot-strimzi/src/main/resources/kafka-ephemeral-openshift.yaml b/strimzi/src/main/resources/kafka-ephemeral-openshift.yaml
similarity index 100%
rename from spring-boot-strimzi/src/main/resources/kafka-ephemeral-openshift.yaml
rename to strimzi/src/main/resources/kafka-ephemeral-openshift.yaml
diff --git a/spring-boot-supervising-route-controller/pom.xml b/supervising-route-controller/pom.xml
similarity index 100%
rename from spring-boot-supervising-route-controller/pom.xml
rename to supervising-route-controller/pom.xml
diff --git a/spring-boot-supervising-route-controller/readme.adoc b/supervising-route-controller/readme.adoc
similarity index 100%
rename from spring-boot-supervising-route-controller/readme.adoc
rename to supervising-route-controller/readme.adoc
diff --git a/spring-boot-pojo/src/main/java/sample/camel/Application.java b/supervising-route-controller/src/main/java/sample/camel/Application.java
similarity index 100%
rename from spring-boot-pojo/src/main/java/sample/camel/Application.java
rename to supervising-route-controller/src/main/java/sample/camel/Application.java
diff --git a/spring-boot-supervising-route-controller/src/main/java/sample/camel/ApplicationRoutes.java b/supervising-route-controller/src/main/java/sample/camel/ApplicationRoutes.java
similarity index 100%
rename from spring-boot-supervising-route-controller/src/main/java/sample/camel/ApplicationRoutes.java
rename to supervising-route-controller/src/main/java/sample/camel/ApplicationRoutes.java
diff --git a/spring-boot-supervising-route-controller/src/main/resources/application.properties b/supervising-route-controller/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-supervising-route-controller/src/main/resources/application.properties
rename to supervising-route-controller/src/main/resources/application.properties
diff --git a/spring-boot-twitter-salesforce/README.adoc b/twitter-salesforce/README.adoc
similarity index 100%
rename from spring-boot-twitter-salesforce/README.adoc
rename to twitter-salesforce/README.adoc
diff --git a/spring-boot-twitter-salesforce/pom.xml b/twitter-salesforce/pom.xml
similarity index 100%
rename from spring-boot-twitter-salesforce/pom.xml
rename to twitter-salesforce/pom.xml
diff --git a/spring-boot-twitter-salesforce/src/main/java/org/apache/camel/example/mention/Contact.java b/twitter-salesforce/src/main/java/org/apache/camel/example/mention/Contact.java
similarity index 100%
rename from spring-boot-twitter-salesforce/src/main/java/org/apache/camel/example/mention/Contact.java
rename to twitter-salesforce/src/main/java/org/apache/camel/example/mention/Contact.java
diff --git a/spring-boot-twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceApplication.java b/twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceApplication.java
similarity index 100%
rename from spring-boot-twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceApplication.java
rename to twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceApplication.java
diff --git a/spring-boot-twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceRoute.java b/twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceRoute.java
similarity index 100%
rename from spring-boot-twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceRoute.java
rename to twitter-salesforce/src/main/java/org/apache/camel/example/mention/TwitterSalesforceRoute.java
diff --git a/spring-boot-opentracing/client/src/main/resources/META-INF/LICENSE.txt b/twitter-salesforce/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-opentracing/client/src/main/resources/META-INF/LICENSE.txt
rename to twitter-salesforce/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-opentracing/client/src/main/resources/META-INF/NOTICE.txt b/twitter-salesforce/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-opentracing/client/src/main/resources/META-INF/NOTICE.txt
rename to twitter-salesforce/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-twitter-salesforce/src/main/resources/application.properties b/twitter-salesforce/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-twitter-salesforce/src/main/resources/application.properties
rename to twitter-salesforce/src/main/resources/application.properties
diff --git a/spring-boot-type-converter/README.adoc b/type-converter/README.adoc
similarity index 100%
rename from spring-boot-type-converter/README.adoc
rename to type-converter/README.adoc
diff --git a/spring-boot-type-converter/pom.xml b/type-converter/pom.xml
similarity index 100%
rename from spring-boot-type-converter/pom.xml
rename to type-converter/pom.xml
diff --git a/spring-boot-type-converter/src/generated/java/sample/camel/CustomGeneratedConverterLoader.java b/type-converter/src/generated/java/sample/camel/CustomGeneratedConverterLoader.java
similarity index 100%
rename from spring-boot-type-converter/src/generated/java/sample/camel/CustomGeneratedConverterLoader.java
rename to type-converter/src/generated/java/sample/camel/CustomGeneratedConverterLoader.java
diff --git a/spring-boot-type-converter/src/generated/resources/META-INF/services/org/apache/camel/TypeConverterLoader b/type-converter/src/generated/resources/META-INF/services/org/apache/camel/TypeConverterLoader
similarity index 100%
rename from spring-boot-type-converter/src/generated/resources/META-INF/services/org/apache/camel/TypeConverterLoader
rename to type-converter/src/generated/resources/META-INF/services/org/apache/camel/TypeConverterLoader
diff --git a/spring-boot-type-converter/src/main/java/sample/camel/Application.java b/type-converter/src/main/java/sample/camel/Application.java
similarity index 100%
rename from spring-boot-type-converter/src/main/java/sample/camel/Application.java
rename to type-converter/src/main/java/sample/camel/Application.java
diff --git a/spring-boot-type-converter/src/main/java/sample/camel/CustomGeneratedConverter.java b/type-converter/src/main/java/sample/camel/CustomGeneratedConverter.java
similarity index 100%
rename from spring-boot-type-converter/src/main/java/sample/camel/CustomGeneratedConverter.java
rename to type-converter/src/main/java/sample/camel/CustomGeneratedConverter.java
diff --git a/spring-boot-type-converter/src/main/java/sample/camel/CustomRuntimeConverter.java b/type-converter/src/main/java/sample/camel/CustomRuntimeConverter.java
similarity index 100%
rename from spring-boot-type-converter/src/main/java/sample/camel/CustomRuntimeConverter.java
rename to type-converter/src/main/java/sample/camel/CustomRuntimeConverter.java
diff --git a/spring-boot-type-converter/src/main/java/sample/camel/DataTypeConverterRouter.java b/type-converter/src/main/java/sample/camel/DataTypeConverterRouter.java
similarity index 100%
rename from spring-boot-type-converter/src/main/java/sample/camel/DataTypeConverterRouter.java
rename to type-converter/src/main/java/sample/camel/DataTypeConverterRouter.java
diff --git a/spring-boot-type-converter/src/main/java/sample/camel/Person.java b/type-converter/src/main/java/sample/camel/Person.java
similarity index 100%
rename from spring-boot-type-converter/src/main/java/sample/camel/Person.java
rename to type-converter/src/main/java/sample/camel/Person.java
diff --git a/spring-boot-type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverter b/type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverter
similarity index 100%
rename from spring-boot-type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverter
rename to type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverter
diff --git a/spring-boot-type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverterLoader b/type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverterLoader
similarity index 100%
rename from spring-boot-type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverterLoader
rename to type-converter/src/main/resources/META-INF/services/org/apache/camel/TypeConverterLoader
diff --git a/spring-boot-type-converter/src/main/resources/application.properties b/type-converter/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-type-converter/src/main/resources/application.properties
rename to type-converter/src/main/resources/application.properties
diff --git a/spring-boot-type-converter/src/test/java/sample/camel/CustomConverterGeneratedTest.java b/type-converter/src/test/java/sample/camel/CustomConverterGeneratedTest.java
similarity index 100%
rename from spring-boot-type-converter/src/test/java/sample/camel/CustomConverterGeneratedTest.java
rename to type-converter/src/test/java/sample/camel/CustomConverterGeneratedTest.java
diff --git a/spring-boot-type-converter/src/test/java/sample/camel/CustomConverterRuntimeTest.java b/type-converter/src/test/java/sample/camel/CustomConverterRuntimeTest.java
similarity index 100%
rename from spring-boot-type-converter/src/test/java/sample/camel/CustomConverterRuntimeTest.java
rename to type-converter/src/test/java/sample/camel/CustomConverterRuntimeTest.java
diff --git a/spring-boot-undertow-spring-security/pom.xml b/undertow-spring-security/pom.xml
similarity index 100%
rename from spring-boot-undertow-spring-security/pom.xml
rename to undertow-spring-security/pom.xml
diff --git a/spring-boot-undertow-spring-security/readme.adoc b/undertow-spring-security/readme.adoc
similarity index 100%
rename from spring-boot-undertow-spring-security/readme.adoc
rename to undertow-spring-security/readme.adoc
diff --git a/spring-boot-undertow-spring-security/realm-export.json b/undertow-spring-security/realm-export.json
similarity index 100%
rename from spring-boot-undertow-spring-security/realm-export.json
rename to undertow-spring-security/realm-export.json
diff --git a/spring-boot-undertow-spring-security/src/main/java/org/apache/camel/undertow/spring/boot/Application.java b/undertow-spring-security/src/main/java/org/apache/camel/undertow/spring/boot/Application.java
similarity index 100%
rename from spring-boot-undertow-spring-security/src/main/java/org/apache/camel/undertow/spring/boot/Application.java
rename to undertow-spring-security/src/main/java/org/apache/camel/undertow/spring/boot/Application.java
diff --git a/spring-boot-undertow-spring-security/src/main/resources/application.properties b/undertow-spring-security/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-undertow-spring-security/src/main/resources/application.properties
rename to undertow-spring-security/src/main/resources/application.properties
diff --git a/spring-boot-unit-testing/README.adoc b/unit-testing/README.adoc
similarity index 100%
rename from spring-boot-unit-testing/README.adoc
rename to unit-testing/README.adoc
diff --git a/spring-boot-unit-testing/pom.xml b/unit-testing/pom.xml
similarity index 100%
rename from spring-boot-unit-testing/pom.xml
rename to unit-testing/pom.xml
diff --git a/spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/Application.java b/unit-testing/src/main/java/org/apache/camel/example/spring/boot/Application.java
similarity index 100%
rename from spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/Application.java
rename to unit-testing/src/main/java/org/apache/camel/example/spring/boot/Application.java
diff --git a/spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/InterceptorSimulatedErrorException.java b/unit-testing/src/main/java/org/apache/camel/example/spring/boot/InterceptorSimulatedErrorException.java
similarity index 100%
rename from spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/InterceptorSimulatedErrorException.java
rename to unit-testing/src/main/java/org/apache/camel/example/spring/boot/InterceptorSimulatedErrorException.java
diff --git a/spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/MockSimulatedErrorException.java b/unit-testing/src/main/java/org/apache/camel/example/spring/boot/MockSimulatedErrorException.java
similarity index 100%
rename from spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/MockSimulatedErrorException.java
rename to unit-testing/src/main/java/org/apache/camel/example/spring/boot/MockSimulatedErrorException.java
diff --git a/spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/UnitTestsRouter.java b/unit-testing/src/main/java/org/apache/camel/example/spring/boot/UnitTestsRouter.java
similarity index 100%
rename from spring-boot-unit-testing/src/main/java/org/apache/camel/example/spring/boot/UnitTestsRouter.java
rename to unit-testing/src/main/java/org/apache/camel/example/spring/boot/UnitTestsRouter.java
diff --git a/spring-boot-unit-testing/src/main/resources/application.properties b/unit-testing/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-unit-testing/src/main/resources/application.properties
rename to unit-testing/src/main/resources/application.properties
diff --git a/spring-boot-unit-testing/src/test/java/CamelSpringBootUnitTests.java b/unit-testing/src/test/java/CamelSpringBootUnitTests.java
similarity index 100%
rename from spring-boot-unit-testing/src/test/java/CamelSpringBootUnitTests.java
rename to unit-testing/src/test/java/CamelSpringBootUnitTests.java
diff --git a/spring-boot-validator/pom.xml b/validator/pom.xml
similarity index 100%
rename from spring-boot-validator/pom.xml
rename to validator/pom.xml
diff --git a/spring-boot-validator/readme.adoc b/validator/readme.adoc
similarity index 100%
rename from spring-boot-validator/readme.adoc
rename to validator/readme.adoc
diff --git a/spring-boot-validator/src/main/java/sample/camel/GreetingValidator.java b/validator/src/main/java/sample/camel/GreetingValidator.java
similarity index 100%
rename from spring-boot-validator/src/main/java/sample/camel/GreetingValidator.java
rename to validator/src/main/java/sample/camel/GreetingValidator.java
diff --git a/spring-boot-xml/src/main/java/sample/camel/SampleBean.java b/validator/src/main/java/sample/camel/SampleBean.java
similarity index 100%
rename from spring-boot-xml/src/main/java/sample/camel/SampleBean.java
rename to validator/src/main/java/sample/camel/SampleBean.java
diff --git a/spring-boot-validator/src/main/java/sample/camel/SampleCamelApplication.java b/validator/src/main/java/sample/camel/SampleCamelApplication.java
similarity index 100%
rename from spring-boot-validator/src/main/java/sample/camel/SampleCamelApplication.java
rename to validator/src/main/java/sample/camel/SampleCamelApplication.java
diff --git a/spring-boot-validator/src/main/java/sample/camel/SampleCamelRouter.java b/validator/src/main/java/sample/camel/SampleCamelRouter.java
similarity index 100%
rename from spring-boot-validator/src/main/java/sample/camel/SampleCamelRouter.java
rename to validator/src/main/java/sample/camel/SampleCamelRouter.java
diff --git a/spring-boot-validator/src/main/resources/application.properties b/validator/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-validator/src/main/resources/application.properties
rename to validator/src/main/resources/application.properties
diff --git a/spring-boot-xml/src/test/java/sample/camel/SampleCamelApplicationTest.java b/validator/src/test/java/sample/camel/SampleCamelApplicationTest.java
similarity index 100%
rename from spring-boot-xml/src/test/java/sample/camel/SampleCamelApplicationTest.java
rename to validator/src/test/java/sample/camel/SampleCamelApplicationTest.java
diff --git a/spring-boot-webhook/pom.xml b/webhook/pom.xml
similarity index 100%
rename from spring-boot-webhook/pom.xml
rename to webhook/pom.xml
diff --git a/spring-boot-webhook/readme.adoc b/webhook/readme.adoc
similarity index 100%
rename from spring-boot-webhook/readme.adoc
rename to webhook/readme.adoc
diff --git a/spring-boot-webhook/src/main/java/org/apache/camel/example/webhook/Application.java b/webhook/src/main/java/org/apache/camel/example/webhook/Application.java
similarity index 100%
rename from spring-boot-webhook/src/main/java/org/apache/camel/example/webhook/Application.java
rename to webhook/src/main/java/org/apache/camel/example/webhook/Application.java
diff --git a/spring-boot-webhook/src/main/resources/application.properties b/webhook/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-webhook/src/main/resources/application.properties
rename to webhook/src/main/resources/application.properties
diff --git a/spring-boot-widget-gadget/README.adoc b/widget-gadget/README.adoc
similarity index 100%
rename from spring-boot-widget-gadget/README.adoc
rename to widget-gadget/README.adoc
diff --git a/spring-boot-widget-gadget/pom.xml b/widget-gadget/pom.xml
similarity index 100%
rename from spring-boot-widget-gadget/pom.xml
rename to widget-gadget/pom.xml
diff --git a/spring-boot-widget-gadget/src/main/data/order1.json b/widget-gadget/src/main/data/order1.json
similarity index 100%
rename from spring-boot-widget-gadget/src/main/data/order1.json
rename to widget-gadget/src/main/data/order1.json
diff --git a/spring-boot-widget-gadget/src/main/data/order2.json b/widget-gadget/src/main/data/order2.json
similarity index 100%
rename from spring-boot-widget-gadget/src/main/data/order2.json
rename to widget-gadget/src/main/data/order2.json
diff --git a/spring-boot-widget-gadget/src/main/java/sample/camel/AmqpConfig.java b/widget-gadget/src/main/java/sample/camel/AmqpConfig.java
similarity index 100%
rename from spring-boot-widget-gadget/src/main/java/sample/camel/AmqpConfig.java
rename to widget-gadget/src/main/java/sample/camel/AmqpConfig.java
diff --git a/spring-boot-widget-gadget/src/main/java/sample/camel/OrderRoute.java b/widget-gadget/src/main/java/sample/camel/OrderRoute.java
similarity index 100%
rename from spring-boot-widget-gadget/src/main/java/sample/camel/OrderRoute.java
rename to widget-gadget/src/main/java/sample/camel/OrderRoute.java
diff --git a/spring-boot-widget-gadget/src/main/java/sample/camel/WidgetGadgetApp.java b/widget-gadget/src/main/java/sample/camel/WidgetGadgetApp.java
similarity index 100%
rename from spring-boot-widget-gadget/src/main/java/sample/camel/WidgetGadgetApp.java
rename to widget-gadget/src/main/java/sample/camel/WidgetGadgetApp.java
diff --git a/spring-boot-widget-gadget/src/main/java/sample/camel/WidgetGadgetRoute.java b/widget-gadget/src/main/java/sample/camel/WidgetGadgetRoute.java
similarity index 100%
rename from spring-boot-widget-gadget/src/main/java/sample/camel/WidgetGadgetRoute.java
rename to widget-gadget/src/main/java/sample/camel/WidgetGadgetRoute.java
diff --git a/spring-boot-widget-gadget/src/main/resources/application.properties b/widget-gadget/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-widget-gadget/src/main/resources/application.properties
rename to widget-gadget/src/main/resources/application.properties
diff --git a/spring-boot-xml/pom.xml b/xml/pom.xml
similarity index 100%
rename from spring-boot-xml/pom.xml
rename to xml/pom.xml
diff --git a/spring-boot-xml/readme.adoc b/xml/readme.adoc
similarity index 100%
rename from spring-boot-xml/readme.adoc
rename to xml/readme.adoc
diff --git a/spring-boot-validator/src/main/java/sample/camel/SampleBean.java b/xml/src/main/java/sample/camel/SampleBean.java
similarity index 100%
rename from spring-boot-validator/src/main/java/sample/camel/SampleBean.java
rename to xml/src/main/java/sample/camel/SampleBean.java
diff --git a/spring-boot-xml/src/main/java/sample/camel/SampleCamelApplication.java b/xml/src/main/java/sample/camel/SampleCamelApplication.java
similarity index 100%
rename from spring-boot-xml/src/main/java/sample/camel/SampleCamelApplication.java
rename to xml/src/main/java/sample/camel/SampleCamelApplication.java
diff --git a/spring-boot-xml/src/main/resources/application.properties b/xml/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-xml/src/main/resources/application.properties
rename to xml/src/main/resources/application.properties
diff --git a/spring-boot-xml/src/main/resources/my-camel.xml b/xml/src/main/resources/my-camel.xml
similarity index 100%
rename from spring-boot-xml/src/main/resources/my-camel.xml
rename to xml/src/main/resources/my-camel.xml
diff --git a/spring-boot-validator/src/test/java/sample/camel/SampleCamelApplicationTest.java b/xml/src/test/java/sample/camel/SampleCamelApplicationTest.java
similarity index 100%
rename from spring-boot-validator/src/test/java/sample/camel/SampleCamelApplicationTest.java
rename to xml/src/test/java/sample/camel/SampleCamelApplicationTest.java
diff --git a/spring-boot-zipkin/README.adoc b/zipkin/README.adoc
similarity index 100%
rename from spring-boot-zipkin/README.adoc
rename to zipkin/README.adoc
diff --git a/spring-boot-zipkin/client/pom.xml b/zipkin/client/pom.xml
similarity index 100%
rename from spring-boot-zipkin/client/pom.xml
rename to zipkin/client/pom.xml
diff --git a/spring-boot-zipkin/client/src/main/java/sample/camel/ClientApplication.java b/zipkin/client/src/main/java/sample/camel/ClientApplication.java
similarity index 100%
rename from spring-boot-zipkin/client/src/main/java/sample/camel/ClientApplication.java
rename to zipkin/client/src/main/java/sample/camel/ClientApplication.java
diff --git a/spring-boot-opentracing/client/src/main/java/sample/camel/ClientRoute.java b/zipkin/client/src/main/java/sample/camel/ClientRoute.java
similarity index 100%
rename from spring-boot-opentracing/client/src/main/java/sample/camel/ClientRoute.java
rename to zipkin/client/src/main/java/sample/camel/ClientRoute.java
diff --git a/spring-boot-opentracing/client/src/main/java/sample/camel/CounterBean.java b/zipkin/client/src/main/java/sample/camel/CounterBean.java
similarity index 100%
rename from spring-boot-opentracing/client/src/main/java/sample/camel/CounterBean.java
rename to zipkin/client/src/main/java/sample/camel/CounterBean.java
diff --git a/spring-boot-hystrix/service2/src/main/resources/META-INF/LICENSE.txt b/zipkin/client/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-hystrix/service2/src/main/resources/META-INF/LICENSE.txt
rename to zipkin/client/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-hystrix/service2/src/main/resources/META-INF/NOTICE.txt b/zipkin/client/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-hystrix/service2/src/main/resources/META-INF/NOTICE.txt
rename to zipkin/client/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-hystrix/client/src/main/resources/META-INF/beans.xml b/zipkin/client/src/main/resources/META-INF/beans.xml
similarity index 100%
rename from spring-boot-hystrix/client/src/main/resources/META-INF/beans.xml
rename to zipkin/client/src/main/resources/META-INF/beans.xml
diff --git a/spring-boot-hystrix/service2/src/main/resources/log4j2.properties b/zipkin/client/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-hystrix/service2/src/main/resources/log4j2.properties
rename to zipkin/client/src/main/resources/log4j2.properties
diff --git a/spring-boot-zipkin/images/zipkin-web-console-1.png b/zipkin/images/zipkin-web-console-1.png
similarity index 100%
rename from spring-boot-zipkin/images/zipkin-web-console-1.png
rename to zipkin/images/zipkin-web-console-1.png
diff --git a/spring-boot-zipkin/images/zipkin-web-console-2.png b/zipkin/images/zipkin-web-console-2.png
similarity index 100%
rename from spring-boot-zipkin/images/zipkin-web-console-2.png
rename to zipkin/images/zipkin-web-console-2.png
diff --git a/spring-boot-zipkin/pom.xml b/zipkin/pom.xml
similarity index 100%
rename from spring-boot-zipkin/pom.xml
rename to zipkin/pom.xml
diff --git a/spring-boot-zipkin/service1/pom.xml b/zipkin/service1/pom.xml
similarity index 100%
rename from spring-boot-zipkin/service1/pom.xml
rename to zipkin/service1/pom.xml
diff --git a/spring-boot-zipkin/service1/src/main/java/sample/camel/Service1Application.java b/zipkin/service1/src/main/java/sample/camel/Service1Application.java
similarity index 100%
rename from spring-boot-zipkin/service1/src/main/java/sample/camel/Service1Application.java
rename to zipkin/service1/src/main/java/sample/camel/Service1Application.java
diff --git a/spring-boot-opentracing/service1/src/main/java/sample/camel/Service1Route.java b/zipkin/service1/src/main/java/sample/camel/Service1Route.java
similarity index 100%
rename from spring-boot-opentracing/service1/src/main/java/sample/camel/Service1Route.java
rename to zipkin/service1/src/main/java/sample/camel/Service1Route.java
diff --git a/spring-boot-hystrix/service1/src/main/resources/META-INF/LICENSE.txt b/zipkin/service1/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-hystrix/service1/src/main/resources/META-INF/LICENSE.txt
rename to zipkin/service1/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-hystrix/service1/src/main/resources/META-INF/NOTICE.txt b/zipkin/service1/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-hystrix/service1/src/main/resources/META-INF/NOTICE.txt
rename to zipkin/service1/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-zipkin/service1/src/main/resources/application.properties b/zipkin/service1/src/main/resources/application.properties
similarity index 100%
rename from spring-boot-zipkin/service1/src/main/resources/application.properties
rename to zipkin/service1/src/main/resources/application.properties
diff --git a/spring-boot-zipkin/service2/pom.xml b/zipkin/service2/pom.xml
similarity index 100%
rename from spring-boot-zipkin/service2/pom.xml
rename to zipkin/service2/pom.xml
diff --git a/spring-boot-zipkin/service2/src/main/java/sample/camel/Service2Application.java b/zipkin/service2/src/main/java/sample/camel/Service2Application.java
similarity index 100%
rename from spring-boot-zipkin/service2/src/main/java/sample/camel/Service2Application.java
rename to zipkin/service2/src/main/java/sample/camel/Service2Application.java
diff --git a/spring-boot-zipkin/service2/src/main/java/sample/camel/Service2Route.java b/zipkin/service2/src/main/java/sample/camel/Service2Route.java
similarity index 100%
rename from spring-boot-zipkin/service2/src/main/java/sample/camel/Service2Route.java
rename to zipkin/service2/src/main/java/sample/camel/Service2Route.java
diff --git a/spring-boot-hystrix/client/src/main/resources/META-INF/LICENSE.txt b/zipkin/service2/src/main/resources/META-INF/LICENSE.txt
similarity index 100%
rename from spring-boot-hystrix/client/src/main/resources/META-INF/LICENSE.txt
rename to zipkin/service2/src/main/resources/META-INF/LICENSE.txt
diff --git a/spring-boot-hystrix/client/src/main/resources/META-INF/NOTICE.txt b/zipkin/service2/src/main/resources/META-INF/NOTICE.txt
similarity index 100%
rename from spring-boot-hystrix/client/src/main/resources/META-INF/NOTICE.txt
rename to zipkin/service2/src/main/resources/META-INF/NOTICE.txt
diff --git a/spring-boot-hystrix/client/src/main/resources/log4j2.properties b/zipkin/service2/src/main/resources/log4j2.properties
similarity index 100%
rename from spring-boot-hystrix/client/src/main/resources/log4j2.properties
rename to zipkin/service2/src/main/resources/log4j2.properties