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

[camel-quarkus] branch camel-main updated (8704a16 -> 8f456bc)

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

github-bot pushed a change to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git.


 discard 8704a16  Temporarilly manually update google-auth-library-credentials until gRPC is upgraded to 1.45.x
 discard a22c3cf  Temporarilly disable Aws2KinesisTest.kinesis due to #3638
 discard 42bd5b2  3579 Improve quartz test coverage
 discard 03020bc  Fix #3592 add some ReflectiveClassBuildItem for camel-kafka (#3594)
 discard fe173e0  Work around Tika version incompatibilities between Quarkus Tika & Camel Tika #3599
 discard e3415aa  Temporary hacks to handle version misalignment of smallrye-health and smallrye-faulttolerance in Quarkus & Camel
 discard 012b764  Test for Debezium mysql - passing additionalProperties results in wrong properties beeing passed #3488
 discard dbf9ea7  Upgrade Camel to 3.16.0
     add c226c97  Updated CHANGELOG.md
     new 12a983d  Upgrade Camel to 3.16.0
     new 3699da4  Test for Debezium mysql - passing additionalProperties results in wrong properties beeing passed #3488
     new 7178534  Temporary hacks to handle version misalignment of smallrye-health and smallrye-faulttolerance in Quarkus & Camel
     new 3555acf  Work around Tika version incompatibilities between Quarkus Tika & Camel Tika #3599
     new 88cf86d  Fix #3592 add some ReflectiveClassBuildItem for camel-kafka (#3594)
     new 7df5826  3579 Improve quartz test coverage
     new e129839  Temporarilly disable Aws2KinesisTest.kinesis due to #3638
     new 8f456bc  Temporarilly manually update google-auth-library-credentials until gRPC is upgraded to 1.45.x

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (8704a16)
            \
             N -- N -- N   refs/heads/camel-main (8f456bc)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

The 8 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 CHANGELOG.md | 6 ++++++
 1 file changed, 6 insertions(+)

[camel-quarkus] 05/08: Fix #3592 add some ReflectiveClassBuildItem for camel-kafka (#3594)

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit 88cf86ddc43a4bc6bf3e44aa69ea4e7c69cbadb3
Author: Amos Feng <zh...@gmail.com>
AuthorDate: Fri Mar 11 17:06:30 2022 +0800

    Fix #3592 add some ReflectiveClassBuildItem for camel-kafka (#3594)
---
 .../component/kafka/deployment/KafkaProcessor.java | 26 ++++++++++
 .../quarkus/test/support/kafka/InjectKafka.java    | 27 ++++++++++
 .../test/support/kafka/KafkaTestResource.java      |  7 +++
 integration-tests/kafka/pom.xml                    |  4 ++
 .../kafka/it/CamelKafkaHealthCheckIT.java          | 23 +++++++++
 .../kafka/it/CamelKafkaHealthCheckTest.java        | 59 ++++++++++++++++++++++
 .../kafka/it/KafkaHealthCheckProfile.java          | 29 +++++++++++
 7 files changed, 175 insertions(+)

diff --git a/extensions/kafka/deployment/src/main/java/org/apache/camel/quarkus/component/kafka/deployment/KafkaProcessor.java b/extensions/kafka/deployment/src/main/java/org/apache/camel/quarkus/component/kafka/deployment/KafkaProcessor.java
index 90e2945..270a7a1 100644
--- a/extensions/kafka/deployment/src/main/java/org/apache/camel/quarkus/component/kafka/deployment/KafkaProcessor.java
+++ b/extensions/kafka/deployment/src/main/java/org/apache/camel/quarkus/component/kafka/deployment/KafkaProcessor.java
@@ -16,7 +16,9 @@
  */
 package org.apache.camel.quarkus.component.kafka.deployment;
 
+import java.util.Collection;
 import java.util.Optional;
+import java.util.stream.Stream;
 
 import io.quarkus.arc.deployment.AdditionalBeanBuildItem;
 import io.quarkus.deployment.Capabilities;
@@ -24,19 +26,28 @@ import io.quarkus.deployment.Capability;
 import io.quarkus.deployment.IsNormal;
 import io.quarkus.deployment.annotations.BuildProducer;
 import io.quarkus.deployment.annotations.BuildStep;
+import io.quarkus.deployment.builditem.CombinedIndexBuildItem;
 import io.quarkus.deployment.builditem.DevServicesLauncherConfigResultBuildItem;
 import io.quarkus.deployment.builditem.FeatureBuildItem;
 import io.quarkus.deployment.builditem.RunTimeConfigurationDefaultBuildItem;
+import io.quarkus.deployment.builditem.nativeimage.ReflectiveClassBuildItem;
 import io.quarkus.deployment.dev.devservices.GlobalDevServicesConfig;
 import io.quarkus.kafka.client.deployment.KafkaBuildTimeConfig;
 import org.apache.camel.quarkus.component.kafka.KafkaClientFactoryProducer;
 import org.eclipse.microprofile.config.Config;
 import org.eclipse.microprofile.config.ConfigProvider;
+import org.jboss.jandex.ClassInfo;
+import org.jboss.jandex.DotName;
+import org.jboss.jandex.IndexView;
 
 class KafkaProcessor {
     private static final String FEATURE = "camel-kafka";
     private static final String CAMEL_KAFKA_BROKERS = "camel.component.kafka.brokers";
     private static final String KAFKA_BOOTSTRAP_SERVERS = "kafka.bootstrap.servers";
+    private static final DotName[] KAFKA_CLIENTS_TYPES = {
+            DotName.createSimple("org.apache.kafka.clients.producer.Producer"),
+            DotName.createSimple("org.apache.kafka.clients.consumer.Consumer")
+    };
 
     @BuildStep
     FeatureBuildItem feature() {
@@ -68,4 +79,19 @@ class KafkaProcessor {
             }
         }
     }
+
+    @BuildStep
+    public void reflectiveClasses(CombinedIndexBuildItem combinedIndex,
+            BuildProducer<ReflectiveClassBuildItem> reflectiveClass) {
+        IndexView index = combinedIndex.getIndex();
+
+        Stream.of(KAFKA_CLIENTS_TYPES)
+                .map(index::getAllKnownImplementors)
+                .flatMap(Collection::stream)
+                .map(ClassInfo::toString)
+                .forEach(name -> reflectiveClass.produce(new ReflectiveClassBuildItem(false, true, name)));
+
+        reflectiveClass
+                .produce(new ReflectiveClassBuildItem(false, true, "org.apache.kafka.clients.producer.internals.Sender"));
+    }
 }
diff --git a/integration-tests-support/kafka/src/main/java/org/apache/camel/quarkus/test/support/kafka/InjectKafka.java b/integration-tests-support/kafka/src/main/java/org/apache/camel/quarkus/test/support/kafka/InjectKafka.java
new file mode 100644
index 0000000..02dca6a
--- /dev/null
+++ b/integration-tests-support/kafka/src/main/java/org/apache/camel/quarkus/test/support/kafka/InjectKafka.java
@@ -0,0 +1,27 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.quarkus.test.support.kafka;
+
+import java.lang.annotation.ElementType;
+import java.lang.annotation.Retention;
+import java.lang.annotation.RetentionPolicy;
+import java.lang.annotation.Target;
+
+@Target({ ElementType.ANNOTATION_TYPE, ElementType.METHOD, ElementType.FIELD })
+@Retention(RetentionPolicy.RUNTIME)
+public @interface InjectKafka {
+}
diff --git a/integration-tests-support/kafka/src/main/java/org/apache/camel/quarkus/test/support/kafka/KafkaTestResource.java b/integration-tests-support/kafka/src/main/java/org/apache/camel/quarkus/test/support/kafka/KafkaTestResource.java
index dce93d4..9c81c69 100644
--- a/integration-tests-support/kafka/src/main/java/org/apache/camel/quarkus/test/support/kafka/KafkaTestResource.java
+++ b/integration-tests-support/kafka/src/main/java/org/apache/camel/quarkus/test/support/kafka/KafkaTestResource.java
@@ -63,4 +63,11 @@ public class KafkaTestResource implements QuarkusTestResourceLifecycleManager {
             }
         }
     }
+
+    @Override
+    public void inject(TestInjector testInjector) {
+        testInjector.injectIntoFields(container,
+                new TestInjector.AnnotatedAndMatchesType(InjectKafka.class, KafkaContainer.class));
+    }
+
 }
diff --git a/integration-tests/kafka/pom.xml b/integration-tests/kafka/pom.xml
index e9e3e24..d298715 100644
--- a/integration-tests/kafka/pom.xml
+++ b/integration-tests/kafka/pom.xml
@@ -57,6 +57,10 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
+            <artifactId>camel-quarkus-microprofile-health</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-integration-tests-support-kafka</artifactId>
         </dependency>
         <dependency>
diff --git a/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaHealthCheckIT.java b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaHealthCheckIT.java
new file mode 100644
index 0000000..2961643
--- /dev/null
+++ b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaHealthCheckIT.java
@@ -0,0 +1,23 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.quarkus.component.kafka.it;
+
+import io.quarkus.test.junit.NativeImageTest;
+
+@NativeImageTest
+public class CamelKafkaHealthCheckIT extends CamelKafkaHealthCheckTest {
+}
diff --git a/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaHealthCheckTest.java b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaHealthCheckTest.java
new file mode 100644
index 0000000..27bd629
--- /dev/null
+++ b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaHealthCheckTest.java
@@ -0,0 +1,59 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.quarkus.component.kafka.it;
+
+import io.quarkus.test.common.QuarkusTestResource;
+import io.quarkus.test.junit.QuarkusTest;
+import io.quarkus.test.junit.TestProfile;
+import io.restassured.RestAssured;
+import io.restassured.http.ContentType;
+import org.apache.camel.quarkus.test.support.kafka.InjectKafka;
+import org.apache.camel.quarkus.test.support.kafka.KafkaTestResource;
+import org.junit.jupiter.api.Test;
+import org.testcontainers.containers.KafkaContainer;
+
+import static org.hamcrest.Matchers.containsString;
+import static org.hamcrest.Matchers.is;
+import static org.hamcrest.Matchers.notNullValue;
+
+@QuarkusTest
+@QuarkusTestResource(KafkaTestResource.class)
+@TestProfile(KafkaHealthCheckProfile.class)
+public class CamelKafkaHealthCheckTest {
+
+    @InjectKafka
+    KafkaContainer container;
+
+    @Test
+    void testHealthCheck() {
+        RestAssured.when().get("/q/health").then()
+                .contentType(ContentType.JSON)
+                .header("Content-Type", containsString("charset=UTF-8"))
+                .body("status", is("UP"));
+
+        // stop the kafka container to test health-check DOWN
+        container.stop();
+
+        RestAssured.when().get("/q/health").then()
+                .contentType(ContentType.JSON)
+                .header("Content-Type", containsString("charset=UTF-8"))
+                .body("status", is("DOWN"),
+                        "checks.find { it.name == 'camel-kafka' }.status", is("DOWN"),
+                        "checks.find { it.name == 'camel-kafka' }.data.topic", notNullValue(),
+                        "checks.find { it.name == 'camel-kafka' }.data.'client.id'", notNullValue());
+    }
+}
diff --git a/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/KafkaHealthCheckProfile.java b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/KafkaHealthCheckProfile.java
new file mode 100644
index 0000000..620c5dc
--- /dev/null
+++ b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/KafkaHealthCheckProfile.java
@@ -0,0 +1,29 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.quarkus.component.kafka.it;
+
+import java.util.Map;
+
+import io.quarkus.test.junit.QuarkusTestProfile;
+
+public class KafkaHealthCheckProfile implements QuarkusTestProfile {
+    @Override
+    public Map<String, String> getConfigOverrides() {
+        // force shutdown
+        return Map.of("camel.main.shutdownTimeout", "10");
+    }
+}

[camel-quarkus] 03/08: Temporary hacks to handle version misalignment of smallrye-health and smallrye-faulttolerance in Quarkus & Camel

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit 7178534ca3c28ea5623d4e916df35cfe08b67975
Author: James Netherton <ja...@gmail.com>
AuthorDate: Fri Feb 11 10:08:03 2022 +0000

    Temporary hacks to handle version misalignment of smallrye-health and smallrye-faulttolerance in Quarkus & Camel
---
 .../MicroprofileFaultToleranceProcessor.java       |   9 +
 .../microprofile-fault-tolerance/runtime/pom.xml   |   2 +
 .../FaultToleranceConfiguration.java               | 120 +++++
 .../faulttolerance/FaultToleranceConstants.java}   |  21 +-
 .../faulttolerance/FaultToleranceProcessor.java    | 536 +++++++++++++++++++++
 .../FaultToleranceProcessorFactory.java}           |  28 +-
 .../faulttolerance/FaultToleranceReifier.java      | 193 ++++++++
 .../apache/camel/model/CircuitBreakerDefinition    |  18 +
 .../runtime/CamelMicroProfileHealthRecorder.java   |   3 +-
 ...amelQuarkusMicroProfileHealthCheckRegistry.java |  62 +++
 10 files changed, 958 insertions(+), 34 deletions(-)

diff --git a/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java b/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java
index 05673b1..6e8c382 100644
--- a/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java
+++ b/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java
@@ -16,9 +16,13 @@
  */
 package org.apache.camel.quarkus.component.microprofile.fault.tolerance.deployment;
 
+import java.nio.file.Paths;
+
 import io.quarkus.deployment.annotations.BuildStep;
 import io.quarkus.deployment.builditem.FeatureBuildItem;
 import io.quarkus.deployment.builditem.nativeimage.NativeImageResourceBuildItem;
+import org.apache.camel.component.microprofile.faulttolerance.FaultToleranceProcessorFactory;
+import org.apache.camel.quarkus.core.deployment.spi.CamelServiceBuildItem;
 
 class MicroprofileFaultToleranceProcessor {
 
@@ -35,4 +39,9 @@ class MicroprofileFaultToleranceProcessor {
                 "META-INF/services/org/apache/camel/model/CircuitBreakerDefinition");
     }
 
+    @BuildStep
+    CamelServiceBuildItem camelCronServicePattern() {
+        return new CamelServiceBuildItem(Paths.get("META-INF/services/org/apache/camel/model/CircuitBreakerDefinition"),
+                FaultToleranceProcessorFactory.class.getName());
+    }
 }
diff --git a/extensions/microprofile-fault-tolerance/runtime/pom.xml b/extensions/microprofile-fault-tolerance/runtime/pom.xml
index 3401f07..22e3962 100644
--- a/extensions/microprofile-fault-tolerance/runtime/pom.xml
+++ b/extensions/microprofile-fault-tolerance/runtime/pom.xml
@@ -56,10 +56,12 @@
             <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-core</artifactId>
         </dependency>
+        <!-- Not compatible with Quarkus 2.7.x
         <dependency>
             <groupId>org.apache.camel</groupId>
             <artifactId>camel-microprofile-fault-tolerance</artifactId>
         </dependency>
+        -->
     </dependencies>
 
     <build>
diff --git a/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceConfiguration.java b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceConfiguration.java
new file mode 100644
index 0000000..7cb3d4d
--- /dev/null
+++ b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceConfiguration.java
@@ -0,0 +1,120 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.component.microprofile.faulttolerance;
+
+public class FaultToleranceConfiguration {
+
+    private long delay;
+    private int successThreshold;
+    private int requestVolumeThreshold;
+    private float failureRatio;
+    private boolean timeoutEnabled;
+    private long timeoutDuration;
+    private int timeoutPoolSize;
+    private String timeoutExecutorServiceRef;
+    private boolean bulkheadEnabled;
+    private int bulkheadMaxConcurrentCalls;
+    private int bulkheadWaitingTaskQueue;
+
+    public long getDelay() {
+        return delay;
+    }
+
+    public void setDelay(long delay) {
+        this.delay = delay;
+    }
+
+    public int getSuccessThreshold() {
+        return successThreshold;
+    }
+
+    public void setSuccessThreshold(int successThreshold) {
+        this.successThreshold = successThreshold;
+    }
+
+    public int getRequestVolumeThreshold() {
+        return requestVolumeThreshold;
+    }
+
+    public void setRequestVolumeThreshold(int requestVolumeThreshold) {
+        this.requestVolumeThreshold = requestVolumeThreshold;
+    }
+
+    public float getFailureRatio() {
+        return failureRatio;
+    }
+
+    public void setFailureRatio(float failureRatio) {
+        this.failureRatio = failureRatio;
+    }
+
+    public boolean isTimeoutEnabled() {
+        return timeoutEnabled;
+    }
+
+    public void setTimeoutEnabled(boolean timeoutEnabled) {
+        this.timeoutEnabled = timeoutEnabled;
+    }
+
+    public long getTimeoutDuration() {
+        return timeoutDuration;
+    }
+
+    public void setTimeoutDuration(long timeoutDuration) {
+        this.timeoutDuration = timeoutDuration;
+    }
+
+    public int getTimeoutPoolSize() {
+        return timeoutPoolSize;
+    }
+
+    public void setTimeoutPoolSize(int timeoutPoolSize) {
+        this.timeoutPoolSize = timeoutPoolSize;
+    }
+
+    public String getTimeoutExecutorServiceRef() {
+        return timeoutExecutorServiceRef;
+    }
+
+    public void setTimeoutExecutorServiceRef(String timeoutExecutorServiceRef) {
+        this.timeoutExecutorServiceRef = timeoutExecutorServiceRef;
+    }
+
+    public boolean isBulkheadEnabled() {
+        return bulkheadEnabled;
+    }
+
+    public void setBulkheadEnabled(boolean bulkheadEnabled) {
+        this.bulkheadEnabled = bulkheadEnabled;
+    }
+
+    public int getBulkheadMaxConcurrentCalls() {
+        return bulkheadMaxConcurrentCalls;
+    }
+
+    public void setBulkheadMaxConcurrentCalls(int bulkheadMaxConcurrentCalls) {
+        this.bulkheadMaxConcurrentCalls = bulkheadMaxConcurrentCalls;
+    }
+
+    public int getBulkheadWaitingTaskQueue() {
+        return bulkheadWaitingTaskQueue;
+    }
+
+    public void setBulkheadWaitingTaskQueue(int bulkheadWaitingTaskQueue) {
+        this.bulkheadWaitingTaskQueue = bulkheadWaitingTaskQueue;
+    }
+}
diff --git a/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceConstants.java
similarity index 53%
copy from extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java
copy to extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceConstants.java
index 05673b1..3bb0027 100644
--- a/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java
+++ b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceConstants.java
@@ -14,25 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.quarkus.component.microprofile.fault.tolerance.deployment;
+package org.apache.camel.component.microprofile.faulttolerance;
 
-import io.quarkus.deployment.annotations.BuildStep;
-import io.quarkus.deployment.builditem.FeatureBuildItem;
-import io.quarkus.deployment.builditem.nativeimage.NativeImageResourceBuildItem;
+public interface FaultToleranceConstants {
 
-class MicroprofileFaultToleranceProcessor {
-
-    private static final String FEATURE = "camel-microprofile-fault-tolerance";
-
-    @BuildStep
-    FeatureBuildItem feature() {
-        return new FeatureBuildItem(FEATURE);
-    }
-
-    @BuildStep
-    NativeImageResourceBuildItem initResources() {
-        return new NativeImageResourceBuildItem(
-                "META-INF/services/org/apache/camel/model/CircuitBreakerDefinition");
-    }
+    String DEFAULT_FAULT_TOLERANCE_CONFIGURATION_ID = "fault-tolerance-configuration";
 
 }
diff --git a/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceProcessor.java b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceProcessor.java
new file mode 100644
index 0000000..2195b89
--- /dev/null
+++ b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceProcessor.java
@@ -0,0 +1,536 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.component.microprofile.faulttolerance;
+
+import java.util.ArrayList;
+import java.util.List;
+import java.util.concurrent.Callable;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.ScheduledExecutorService;
+
+import io.smallrye.faulttolerance.core.FaultToleranceStrategy;
+import io.smallrye.faulttolerance.core.InvocationContext;
+import io.smallrye.faulttolerance.core.bulkhead.FutureThreadPoolBulkhead;
+import io.smallrye.faulttolerance.core.circuit.breaker.CircuitBreaker;
+import io.smallrye.faulttolerance.core.fallback.Fallback;
+import io.smallrye.faulttolerance.core.stopwatch.SystemStopwatch;
+import io.smallrye.faulttolerance.core.timeout.ScheduledExecutorTimeoutWatcher;
+import io.smallrye.faulttolerance.core.timeout.Timeout;
+import io.smallrye.faulttolerance.core.timeout.TimeoutWatcher;
+import io.smallrye.faulttolerance.core.util.SetOfThrowables;
+import org.apache.camel.AsyncCallback;
+import org.apache.camel.CamelContext;
+import org.apache.camel.CamelContextAware;
+import org.apache.camel.Exchange;
+import org.apache.camel.ExchangePropertyKey;
+import org.apache.camel.ExtendedCamelContext;
+import org.apache.camel.ExtendedExchange;
+import org.apache.camel.Navigate;
+import org.apache.camel.Processor;
+import org.apache.camel.Route;
+import org.apache.camel.RuntimeExchangeException;
+import org.apache.camel.api.management.ManagedAttribute;
+import org.apache.camel.api.management.ManagedResource;
+import org.apache.camel.processor.PooledExchangeTask;
+import org.apache.camel.processor.PooledExchangeTaskFactory;
+import org.apache.camel.processor.PooledTaskFactory;
+import org.apache.camel.processor.PrototypeTaskFactory;
+import org.apache.camel.spi.IdAware;
+import org.apache.camel.spi.ProcessorExchangeFactory;
+import org.apache.camel.spi.RouteIdAware;
+import org.apache.camel.spi.UnitOfWork;
+import org.apache.camel.support.AsyncProcessorSupport;
+import org.apache.camel.support.ExchangeHelper;
+import org.apache.camel.support.UnitOfWorkHelper;
+import org.apache.camel.support.service.ServiceHelper;
+import org.apache.camel.util.ObjectHelper;
+import org.eclipse.microprofile.faulttolerance.exceptions.CircuitBreakerOpenException;
+import org.eclipse.microprofile.faulttolerance.exceptions.TimeoutException;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import static io.smallrye.faulttolerance.core.Invocation.invocation;
+
+/**
+ * Implementation of Circuit Breaker EIP using microprofile fault tolerance.
+ */
+@ManagedResource(description = "Managed FaultTolerance Processor")
+public class FaultToleranceProcessor extends AsyncProcessorSupport
+        implements CamelContextAware, Navigate<Processor>, org.apache.camel.Traceable, IdAware, RouteIdAware {
+
+    private static final Logger LOG = LoggerFactory.getLogger(FaultToleranceProcessor.class);
+
+    private volatile CircuitBreaker circuitBreaker;
+    private CamelContext camelContext;
+    private String id;
+    private String routeId;
+    private final FaultToleranceConfiguration config;
+    private final Processor processor;
+    private final Processor fallbackProcessor;
+    private ScheduledExecutorService scheduledExecutorService;
+    private boolean shutdownScheduledExecutorService;
+    private ExecutorService executorService;
+    private boolean shutdownExecutorService;
+    private ProcessorExchangeFactory processorExchangeFactory;
+    private PooledExchangeTaskFactory taskFactory;
+    private PooledExchangeTaskFactory fallbackTaskFactory;
+
+    public FaultToleranceProcessor(FaultToleranceConfiguration config, Processor processor,
+            Processor fallbackProcessor) {
+        this.config = config;
+        this.processor = processor;
+        this.fallbackProcessor = fallbackProcessor;
+    }
+
+    @Override
+    public CamelContext getCamelContext() {
+        return camelContext;
+    }
+
+    @Override
+    public void setCamelContext(CamelContext camelContext) {
+        this.camelContext = camelContext;
+    }
+
+    @Override
+    public String getId() {
+        return id;
+    }
+
+    @Override
+    public void setId(String id) {
+        this.id = id;
+    }
+
+    @Override
+    public String getRouteId() {
+        return routeId;
+    }
+
+    @Override
+    public void setRouteId(String routeId) {
+        this.routeId = routeId;
+    }
+
+    public CircuitBreaker getCircuitBreaker() {
+        return circuitBreaker;
+    }
+
+    public void setCircuitBreaker(CircuitBreaker circuitBreaker) {
+        this.circuitBreaker = circuitBreaker;
+    }
+
+    public boolean isShutdownExecutorService() {
+        return shutdownExecutorService;
+    }
+
+    public void setShutdownExecutorService(boolean shutdownExecutorService) {
+        this.shutdownExecutorService = shutdownExecutorService;
+    }
+
+    public ExecutorService getExecutorService() {
+        return executorService;
+    }
+
+    public void setExecutorService(ExecutorService executorService) {
+        this.executorService = executorService;
+    }
+
+    @Override
+    public String getTraceLabel() {
+        return "faultTolerance";
+    }
+
+    @ManagedAttribute(description = "Returns the current delay in milliseconds.")
+    public long getDelay() {
+        return config.getDelay();
+    }
+
+    @ManagedAttribute(description = "Returns the current failure rate in percentage.")
+    public float getFailureRate() {
+        return config.getFailureRatio();
+    }
+
+    @ManagedAttribute(description = "Returns the current request volume threshold.")
+    public int getRequestVolumeThreshold() {
+        return config.getRequestVolumeThreshold();
+    }
+
+    @ManagedAttribute(description = "Returns the current success threshold.")
+    public int getSuccessThreshold() {
+        return config.getSuccessThreshold();
+    }
+
+    @ManagedAttribute(description = "Is timeout enabled")
+    public boolean isTimeoutEnabled() {
+        return config.isTimeoutEnabled();
+    }
+
+    @ManagedAttribute(description = "The timeout wait duration")
+    public long getTimeoutDuration() {
+        return config.getTimeoutDuration();
+    }
+
+    @ManagedAttribute(description = "The timeout pool size for the thread pool")
+    public int getTimeoutPoolSize() {
+        return config.getTimeoutPoolSize();
+    }
+
+    @ManagedAttribute(description = "Is bulkhead enabled")
+    public boolean isBulkheadEnabled() {
+        return config.isBulkheadEnabled();
+    }
+
+    @ManagedAttribute(description = "The max amount of concurrent calls the bulkhead will support.")
+    public int getBulkheadMaxConcurrentCalls() {
+        return config.getBulkheadMaxConcurrentCalls();
+    }
+
+    @ManagedAttribute(description = "The task queue size for holding waiting tasks to be processed by the bulkhead")
+    public int getBulkheadWaitingTaskQueue() {
+        return config.getBulkheadWaitingTaskQueue();
+    }
+
+    @Override
+    public List<Processor> next() {
+        if (!hasNext()) {
+            return null;
+        }
+        List<Processor> answer = new ArrayList<>();
+        answer.add(processor);
+        if (fallbackProcessor != null) {
+            answer.add(fallbackProcessor);
+        }
+        return answer;
+    }
+
+    @Override
+    public boolean hasNext() {
+        return true;
+    }
+
+    @Override
+    @SuppressWarnings("unchecked")
+    public boolean process(Exchange exchange, AsyncCallback callback) {
+        // run this as if we run inside try .. catch so there is no regular
+        // Camel error handler
+        exchange.setProperty(ExchangePropertyKey.TRY_ROUTE_BLOCK, true);
+
+        CircuitBreakerFallbackTask fallbackTask = null;
+        CircuitBreakerTask task = (CircuitBreakerTask) taskFactory.acquire(exchange, callback);
+
+        // circuit breaker
+        FaultToleranceStrategy target = circuitBreaker;
+
+        // 1. bulkhead
+        if (config.isBulkheadEnabled()) {
+            target = new FutureThreadPoolBulkhead(
+                    target, "bulkhead", config.getBulkheadMaxConcurrentCalls(),
+                    config.getBulkheadWaitingTaskQueue());
+        }
+        // 2. timeout
+        if (config.isTimeoutEnabled()) {
+            TimeoutWatcher watcher = new ScheduledExecutorTimeoutWatcher(scheduledExecutorService);
+            target = new Timeout(target, "timeout", config.getTimeoutDuration(), watcher);
+        }
+        // 3. fallback
+        if (fallbackProcessor != null) {
+            fallbackTask = (CircuitBreakerFallbackTask) fallbackTaskFactory.acquire(exchange, callback);
+            final CircuitBreakerFallbackTask fFallbackTask = fallbackTask;
+            target = new Fallback(target, "fallback", fallbackContext -> {
+                exchange.setException(fallbackContext.failure);
+                return fFallbackTask.call();
+            }, SetOfThrowables.ALL, SetOfThrowables.EMPTY);
+        }
+
+        try {
+            target.apply(new InvocationContext(task));
+        } catch (CircuitBreakerOpenException e) {
+            // the circuit breaker triggered a call rejected
+            exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SUCCESSFUL_EXECUTION, false);
+            exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_FROM_FALLBACK, false);
+            exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SHORT_CIRCUITED, true);
+            exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_REJECTED, true);
+        } catch (Exception e) {
+            // some other kind of exception
+            exchange.setException(e);
+        } finally {
+            taskFactory.release(task);
+            if (fallbackTask != null) {
+                fallbackTaskFactory.release(fallbackTask);
+            }
+        }
+
+        exchange.removeProperty(ExchangePropertyKey.TRY_ROUTE_BLOCK);
+        callback.done(true);
+        return true;
+    }
+
+    @Override
+    protected void doBuild() throws Exception {
+        ObjectHelper.notNull(camelContext, "CamelContext", this);
+
+        boolean pooled = camelContext.adapt(ExtendedCamelContext.class).getExchangeFactory().isPooled();
+        if (pooled) {
+            int capacity = camelContext.adapt(ExtendedCamelContext.class).getExchangeFactory().getCapacity();
+            taskFactory = new PooledTaskFactory(getId()) {
+                @Override
+                public PooledExchangeTask create(Exchange exchange, AsyncCallback callback) {
+                    return new CircuitBreakerTask();
+                }
+            };
+            taskFactory.setCapacity(capacity);
+            fallbackTaskFactory = new PooledTaskFactory(getId()) {
+                @Override
+                public PooledExchangeTask create(Exchange exchange, AsyncCallback callback) {
+                    return new CircuitBreakerFallbackTask();
+                }
+            };
+            fallbackTaskFactory.setCapacity(capacity);
+        } else {
+            taskFactory = new PrototypeTaskFactory() {
+                @Override
+                public PooledExchangeTask create(Exchange exchange, AsyncCallback callback) {
+                    return new CircuitBreakerTask();
+                }
+            };
+            fallbackTaskFactory = new PrototypeTaskFactory() {
+                @Override
+                public PooledExchangeTask create(Exchange exchange, AsyncCallback callback) {
+                    return new CircuitBreakerFallbackTask();
+                }
+            };
+        }
+
+        // create a per processor exchange factory
+        this.processorExchangeFactory = getCamelContext().adapt(ExtendedCamelContext.class)
+                .getProcessorExchangeFactory().newProcessorExchangeFactory(this);
+        this.processorExchangeFactory.setRouteId(getRouteId());
+        this.processorExchangeFactory.setId(getId());
+
+        ServiceHelper.buildService(processorExchangeFactory, taskFactory, fallbackTaskFactory, processor);
+    }
+
+    @Override
+    @SuppressWarnings("unchecked")
+    protected void doInit() throws Exception {
+        ObjectHelper.notNull(camelContext, "CamelContext", this);
+        if (circuitBreaker == null) {
+            circuitBreaker = new CircuitBreaker(
+                    invocation(), id, SetOfThrowables.ALL,
+                    SetOfThrowables.EMPTY, config.getDelay(), config.getRequestVolumeThreshold(), config.getFailureRatio(),
+                    config.getSuccessThreshold(), new SystemStopwatch());
+        }
+
+        ServiceHelper.initService(processorExchangeFactory, taskFactory, fallbackTaskFactory, processor);
+    }
+
+    @Override
+    protected void doStart() throws Exception {
+        if (config.isTimeoutEnabled() && scheduledExecutorService == null) {
+            scheduledExecutorService = getCamelContext().getExecutorServiceManager().newScheduledThreadPool(this,
+                    "CircuitBreakerTimeout", config.getTimeoutPoolSize());
+            shutdownScheduledExecutorService = true;
+        }
+        if (config.isBulkheadEnabled() && executorService == null) {
+            executorService = getCamelContext().getExecutorServiceManager().newThreadPool(this, "CircuitBreakerBulkhead",
+                    config.getBulkheadMaxConcurrentCalls(), config.getBulkheadMaxConcurrentCalls());
+            shutdownExecutorService = true;
+        }
+
+        ServiceHelper.startService(processorExchangeFactory, taskFactory, fallbackTaskFactory, processor);
+    }
+
+    @Override
+    protected void doStop() throws Exception {
+        if (shutdownScheduledExecutorService && scheduledExecutorService != null) {
+            getCamelContext().getExecutorServiceManager().shutdownNow(scheduledExecutorService);
+            scheduledExecutorService = null;
+        }
+        if (shutdownExecutorService && executorService != null) {
+            getCamelContext().getExecutorServiceManager().shutdownNow(executorService);
+            executorService = null;
+        }
+
+        ServiceHelper.stopService(processorExchangeFactory, taskFactory, fallbackTaskFactory, processor);
+    }
+
+    @Override
+    protected void doShutdown() throws Exception {
+        ServiceHelper.stopAndShutdownServices(processorExchangeFactory, taskFactory, fallbackTaskFactory, processor);
+    }
+
+    private final class CircuitBreakerTask implements PooledExchangeTask, Callable<Exchange> {
+
+        private Exchange exchange;
+
+        @Override
+        public void prepare(Exchange exchange, AsyncCallback callback) {
+            this.exchange = exchange;
+            // callback not in use
+        }
+
+        @Override
+        public void reset() {
+            this.exchange = null;
+        }
+
+        @Override
+        public void run() {
+            // not in use
+        }
+
+        @Override
+        public Exchange call() throws Exception {
+            Exchange copy = null;
+            UnitOfWork uow = null;
+            Throwable cause;
+
+            // turn of interruption to allow fault tolerance to process the exchange under its handling
+            exchange.adapt(ExtendedExchange.class).setInterruptable(false);
+
+            try {
+                LOG.debug("Running processor: {} with exchange: {}", processor, exchange);
+
+                // prepare a copy of exchange so downstream processors don't
+                // cause side-effects if they mutate the exchange
+                // in case timeout processing and continue with the fallback etc
+                copy = processorExchangeFactory.createCorrelatedCopy(exchange, false);
+                if (copy.getUnitOfWork() != null) {
+                    uow = copy.getUnitOfWork();
+                } else {
+                    // prepare uow on copy
+                    uow = copy.getContext().adapt(ExtendedCamelContext.class).getUnitOfWorkFactory().createUnitOfWork(copy);
+                    copy.adapt(ExtendedExchange.class).setUnitOfWork(uow);
+                    // the copy must be starting from the route where its copied from
+                    Route route = ExchangeHelper.getRoute(exchange);
+                    if (route != null) {
+                        uow.pushRoute(route);
+                    }
+                }
+
+                // process the processor until its fully done
+                processor.process(copy);
+
+                // handle the processing result
+                if (copy.getException() != null) {
+                    exchange.setException(copy.getException());
+                } else {
+                    // copy the result as its regarded as success
+                    ExchangeHelper.copyResults(exchange, copy);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SUCCESSFUL_EXECUTION, true);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_FROM_FALLBACK, false);
+                }
+            } catch (Exception e) {
+                exchange.setException(e);
+            } finally {
+                // must done uow
+                UnitOfWorkHelper.doneUow(uow, copy);
+                // remember any thrown exception
+                cause = exchange.getException();
+            }
+
+            // and release exchange back in pool
+            processorExchangeFactory.release(exchange);
+
+            if (cause != null) {
+                // throw exception so resilient4j know it was a failure
+                throw RuntimeExchangeException.wrapRuntimeException(cause);
+            }
+            return exchange;
+        }
+    }
+
+    private final class CircuitBreakerFallbackTask implements PooledExchangeTask, Callable<Exchange> {
+
+        private Exchange exchange;
+
+        @Override
+        public void prepare(Exchange exchange, AsyncCallback callback) {
+            this.exchange = exchange;
+            // callback not in use
+        }
+
+        @Override
+        public void reset() {
+            this.exchange = null;
+        }
+
+        @Override
+        public void run() {
+            // not in use
+        }
+
+        @Override
+        public Exchange call() throws Exception {
+            Throwable throwable = exchange.getException();
+            if (fallbackProcessor == null) {
+                if (throwable instanceof TimeoutException) {
+                    // the circuit breaker triggered a timeout (and there is no
+                    // fallback) so lets mark the exchange as failed
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SUCCESSFUL_EXECUTION, false);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_FROM_FALLBACK, false);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SHORT_CIRCUITED, false);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_TIMED_OUT, true);
+                    exchange.setException(throwable);
+                    return exchange;
+                } else if (throwable instanceof CircuitBreakerOpenException) {
+                    // the circuit breaker triggered a call rejected
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SUCCESSFUL_EXECUTION, false);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_FROM_FALLBACK, false);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SHORT_CIRCUITED, true);
+                    exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_REJECTED, true);
+                    return exchange;
+                } else {
+                    // throw exception so fault tolerance know it was a failure
+                    throw RuntimeExchangeException.wrapRuntimeException(throwable);
+                }
+            }
+
+            // fallback route is handling the exception so its short-circuited
+            exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SUCCESSFUL_EXECUTION, false);
+            exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_FROM_FALLBACK, true);
+            exchange.setProperty(ExchangePropertyKey.CIRCUIT_BREAKER_RESPONSE_SHORT_CIRCUITED, true);
+
+            // store the last to endpoint as the failure endpoint
+            if (exchange.getProperty(ExchangePropertyKey.FAILURE_ENDPOINT) == null) {
+                exchange.setProperty(ExchangePropertyKey.FAILURE_ENDPOINT,
+                        exchange.getProperty(ExchangePropertyKey.TO_ENDPOINT));
+            }
+            // give the rest of the pipeline another chance
+            exchange.setProperty(ExchangePropertyKey.EXCEPTION_HANDLED, true);
+            exchange.setProperty(ExchangePropertyKey.EXCEPTION_CAUGHT, exchange.getException());
+            exchange.setRouteStop(false);
+            exchange.setException(null);
+            // and we should not be regarded as exhausted as we are in a try ..
+            // catch block
+            exchange.adapt(ExtendedExchange.class).setRedeliveryExhausted(false);
+            // run the fallback processor
+            try {
+                LOG.debug("Running fallback: {} with exchange: {}", fallbackProcessor, exchange);
+                // process the fallback until its fully done
+                fallbackProcessor.process(exchange);
+                LOG.debug("Running fallback: {} with exchange: {} done", fallbackProcessor, exchange);
+            } catch (Exception e) {
+                exchange.setException(e);
+            }
+
+            return exchange;
+        }
+    }
+
+}
diff --git a/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceProcessorFactory.java
similarity index 52%
copy from extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java
copy to extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceProcessorFactory.java
index 05673b1..2b70ca9 100644
--- a/extensions/microprofile-fault-tolerance/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/fault/tolerance/deployment/MicroprofileFaultToleranceProcessor.java
+++ b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceProcessorFactory.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.camel.quarkus.component.microprofile.fault.tolerance.deployment;
+package org.apache.camel.component.microprofile.faulttolerance;
 
-import io.quarkus.deployment.annotations.BuildStep;
-import io.quarkus.deployment.builditem.FeatureBuildItem;
-import io.quarkus.deployment.builditem.nativeimage.NativeImageResourceBuildItem;
+import org.apache.camel.Processor;
+import org.apache.camel.Route;
+import org.apache.camel.model.CircuitBreakerDefinition;
+import org.apache.camel.support.TypedProcessorFactory;
 
-class MicroprofileFaultToleranceProcessor {
-
-    private static final String FEATURE = "camel-microprofile-fault-tolerance";
+/**
+ * To integrate camel-microprofile-faulttolerance with the Camel routes using the Circuit Breaker EIP.
+ */
+public class FaultToleranceProcessorFactory extends TypedProcessorFactory<CircuitBreakerDefinition> {
 
-    @BuildStep
-    FeatureBuildItem feature() {
-        return new FeatureBuildItem(FEATURE);
+    public FaultToleranceProcessorFactory() {
+        super(CircuitBreakerDefinition.class);
     }
 
-    @BuildStep
-    NativeImageResourceBuildItem initResources() {
-        return new NativeImageResourceBuildItem(
-                "META-INF/services/org/apache/camel/model/CircuitBreakerDefinition");
+    @Override
+    public Processor doCreateProcessor(Route route, CircuitBreakerDefinition definition) throws Exception {
+        return new FaultToleranceReifier(route, definition).createProcessor();
     }
 
 }
diff --git a/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceReifier.java b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceReifier.java
new file mode 100644
index 0000000..2664734
--- /dev/null
+++ b/extensions/microprofile-fault-tolerance/runtime/src/main/java/org/apache/camel/component/microprofile/faulttolerance/FaultToleranceReifier.java
@@ -0,0 +1,193 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.component.microprofile.faulttolerance;
+
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Optional;
+import java.util.concurrent.ExecutorService;
+
+import io.smallrye.faulttolerance.core.circuit.breaker.CircuitBreaker;
+import org.apache.camel.ExtendedCamelContext;
+import org.apache.camel.Processor;
+import org.apache.camel.Route;
+import org.apache.camel.model.CircuitBreakerDefinition;
+import org.apache.camel.model.FaultToleranceConfigurationCommon;
+import org.apache.camel.model.FaultToleranceConfigurationDefinition;
+import org.apache.camel.model.Model;
+import org.apache.camel.reifier.ProcessorReifier;
+import org.apache.camel.spi.BeanIntrospection;
+import org.apache.camel.spi.ExtendedPropertyConfigurerGetter;
+import org.apache.camel.spi.PropertyConfigurer;
+import org.apache.camel.support.PropertyBindingSupport;
+import org.apache.camel.util.function.Suppliers;
+
+public class FaultToleranceReifier extends ProcessorReifier<CircuitBreakerDefinition> {
+
+    public FaultToleranceReifier(Route route, CircuitBreakerDefinition definition) {
+        super(route, definition);
+    }
+
+    @Override
+    public Processor createProcessor() throws Exception {
+        // create the regular and fallback processors
+        Processor processor = createChildProcessor(true);
+        Processor fallback = null;
+        if (definition.getOnFallback() != null) {
+            fallback = createProcessor(definition.getOnFallback());
+        }
+        boolean fallbackViaNetwork = definition.getOnFallback() != null
+                && parseBoolean(definition.getOnFallback().getFallbackViaNetwork(), false);
+        if (fallbackViaNetwork) {
+            throw new UnsupportedOperationException("camel-microprofile-fault-tolerance does not support onFallbackViaNetwork");
+        }
+        final FaultToleranceConfigurationCommon config = buildFaultToleranceConfiguration();
+
+        FaultToleranceConfiguration configuration = new FaultToleranceConfiguration();
+        configureCircuitBreaker(config, configuration);
+        configureTimeLimiter(config, configuration);
+        configureBulkhead(config, configuration);
+
+        FaultToleranceProcessor answer = new FaultToleranceProcessor(configuration, processor, fallback);
+        // using any existing circuit breakers?
+        if (config.getCircuitBreaker() != null) {
+            CircuitBreaker cb = mandatoryLookup(parseString(config.getCircuitBreaker()), CircuitBreaker.class);
+            answer.setCircuitBreaker(cb);
+        }
+        configureBulkheadExecutorService(answer, config);
+        return answer;
+    }
+
+    private void configureCircuitBreaker(FaultToleranceConfigurationCommon config, FaultToleranceConfiguration target) {
+        target.setDelay(parseDuration(config.getDelay(), 5000));
+        target.setSuccessThreshold(parseInt(config.getSuccessThreshold(), 1));
+        target.setRequestVolumeThreshold(parseInt(config.getRequestVolumeThreshold(), 20));
+        if (config.getFailureRatio() != null) {
+            float num = parseFloat(config.getFailureRatio(), 50);
+            if (num < 1 || num > 100) {
+                throw new IllegalArgumentException("FailureRatio must be between 1 and 100, was: " + num);
+            }
+            float percent = num / 100;
+            target.setFailureRatio(percent);
+        } else {
+            target.setFailureRatio(0.5f);
+        }
+    }
+
+    private void configureTimeLimiter(FaultToleranceConfigurationCommon config, FaultToleranceConfiguration target) {
+        if (!parseBoolean(config.getTimeoutEnabled(), false)) {
+            target.setTimeoutEnabled(false);
+        } else {
+            target.setTimeoutEnabled(true);
+        }
+
+        target.setTimeoutDuration(parseDuration(config.getTimeoutDuration(), 1000));
+        target.setTimeoutPoolSize(parseInt(config.getTimeoutPoolSize(), 10));
+    }
+
+    private void configureBulkhead(FaultToleranceConfigurationCommon config, FaultToleranceConfiguration target) {
+        if (!parseBoolean(config.getBulkheadEnabled(), false)) {
+            return;
+        }
+
+        target.setBulkheadMaxConcurrentCalls(parseInt(config.getBulkheadMaxConcurrentCalls(), 10));
+        target.setBulkheadWaitingTaskQueue(parseInt(config.getBulkheadWaitingTaskQueue(), 10));
+    }
+
+    private void configureBulkheadExecutorService(FaultToleranceProcessor processor, FaultToleranceConfigurationCommon config) {
+        if (!parseBoolean(config.getBulkheadEnabled(), false)) {
+            return;
+        }
+
+        if (config.getBulkheadExecutorService() != null) {
+            String ref = config.getBulkheadExecutorService();
+            boolean shutdownThreadPool = false;
+            ExecutorService executorService = lookupByNameAndType(ref, ExecutorService.class);
+            if (executorService == null) {
+                executorService = lookupExecutorServiceRef("CircuitBreaker", definition, ref);
+                shutdownThreadPool = true;
+            }
+            processor.setExecutorService(executorService);
+            processor.setShutdownExecutorService(shutdownThreadPool);
+        }
+    }
+
+    // *******************************
+    // Helpers
+    // *******************************
+
+    FaultToleranceConfigurationDefinition buildFaultToleranceConfiguration() throws Exception {
+        Map<String, Object> properties = new HashMap<>();
+
+        final PropertyConfigurer configurer = camelContext.adapt(ExtendedCamelContext.class)
+                .getConfigurerResolver()
+                .resolvePropertyConfigurer(FaultToleranceConfigurationDefinition.class.getName(), camelContext);
+
+        // Extract properties from default configuration, the one configured on
+        // camel context takes the precedence over those in the registry
+        loadProperties(properties, Suppliers.firstNotNull(
+                () -> camelContext.getExtension(Model.class).getFaultToleranceConfiguration(null),
+                () -> lookupByNameAndType(FaultToleranceConstants.DEFAULT_FAULT_TOLERANCE_CONFIGURATION_ID,
+                        FaultToleranceConfigurationDefinition.class)),
+                configurer);
+
+        // Extract properties from referenced configuration, the one configured
+        // on camel context takes the precedence over those in the registry
+        if (definition.getConfiguration() != null) {
+            final String ref = parseString(definition.getConfiguration());
+
+            loadProperties(properties, Suppliers.firstNotNull(
+                    () -> camelContext.getExtension(Model.class).getFaultToleranceConfiguration(ref),
+                    () -> mandatoryLookup(ref, FaultToleranceConfigurationDefinition.class)),
+                    configurer);
+        }
+
+        // Extract properties from local configuration
+        loadProperties(properties, Optional.ofNullable(definition.getFaultToleranceConfiguration()), configurer);
+
+        // Apply properties to a new configuration
+        FaultToleranceConfigurationDefinition config = new FaultToleranceConfigurationDefinition();
+        PropertyBindingSupport.build()
+                .withCamelContext(camelContext)
+                .withConfigurer(configurer)
+                .withProperties(properties)
+                .withTarget(config)
+                .bind();
+
+        return config;
+    }
+
+    private void loadProperties(Map<String, Object> properties, Optional<?> optional, PropertyConfigurer configurer) {
+        BeanIntrospection beanIntrospection = camelContext.adapt(ExtendedCamelContext.class).getBeanIntrospection();
+        optional.ifPresent(bean -> {
+            if (configurer instanceof ExtendedPropertyConfigurerGetter) {
+                ExtendedPropertyConfigurerGetter getter = (ExtendedPropertyConfigurerGetter) configurer;
+                Map<String, Object> types = getter.getAllOptions(bean);
+                types.forEach((k, t) -> {
+                    Object value = getter.getOptionValue(bean, k, true);
+                    if (value != null) {
+                        properties.put(k, value);
+                    }
+                });
+            } else {
+                // no configurer found so use bean introspection (reflection)
+                beanIntrospection.getProperties(bean, properties, null, false);
+            }
+        });
+    }
+
+}
diff --git a/extensions/microprofile-fault-tolerance/runtime/src/main/resources/META-INF/services/org/apache/camel/model/CircuitBreakerDefinition b/extensions/microprofile-fault-tolerance/runtime/src/main/resources/META-INF/services/org/apache/camel/model/CircuitBreakerDefinition
new file mode 100644
index 0000000..c43d558
--- /dev/null
+++ b/extensions/microprofile-fault-tolerance/runtime/src/main/resources/META-INF/services/org/apache/camel/model/CircuitBreakerDefinition
@@ -0,0 +1,18 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+# http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+#
+
+class=org.apache.camel.component.microprofile.faulttolerance.FaultToleranceProcessorFactory
diff --git a/extensions/microprofile-health/runtime/src/main/java/org/apache/camel/quarkus/component/microprofile/health/runtime/CamelMicroProfileHealthRecorder.java b/extensions/microprofile-health/runtime/src/main/java/org/apache/camel/quarkus/component/microprofile/health/runtime/CamelMicroProfileHealthRecorder.java
index e33777b..907c133 100644
--- a/extensions/microprofile-health/runtime/src/main/java/org/apache/camel/quarkus/component/microprofile/health/runtime/CamelMicroProfileHealthRecorder.java
+++ b/extensions/microprofile-health/runtime/src/main/java/org/apache/camel/quarkus/component/microprofile/health/runtime/CamelMicroProfileHealthRecorder.java
@@ -20,7 +20,6 @@ import io.quarkus.runtime.RuntimeValue;
 import io.quarkus.runtime.annotations.Recorder;
 import org.apache.camel.CamelContext;
 import org.apache.camel.health.HealthCheckRegistry;
-import org.apache.camel.microprofile.health.CamelMicroProfileHealthCheckRegistry;
 import org.apache.camel.spi.CamelContextCustomizer;
 
 @Recorder
@@ -31,7 +30,7 @@ public class CamelMicroProfileHealthRecorder {
         return new RuntimeValue<>(new CamelContextCustomizer() {
             @Override
             public void configure(CamelContext camelContext) {
-                HealthCheckRegistry registry = new CamelMicroProfileHealthCheckRegistry(camelContext);
+                HealthCheckRegistry registry = new CamelQuarkusMicroProfileHealthCheckRegistry(camelContext);
                 registry.setId("camel-microprofile-health");
                 registry.setEnabled(true);
 
diff --git a/extensions/microprofile-health/runtime/src/main/java/org/apache/camel/quarkus/component/microprofile/health/runtime/CamelQuarkusMicroProfileHealthCheckRegistry.java b/extensions/microprofile-health/runtime/src/main/java/org/apache/camel/quarkus/component/microprofile/health/runtime/CamelQuarkusMicroProfileHealthCheckRegistry.java
new file mode 100644
index 0000000..8f51f80
--- /dev/null
+++ b/extensions/microprofile-health/runtime/src/main/java/org/apache/camel/quarkus/component/microprofile/health/runtime/CamelQuarkusMicroProfileHealthCheckRegistry.java
@@ -0,0 +1,62 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.quarkus.component.microprofile.health.runtime;
+
+import java.lang.annotation.Annotation;
+import java.util.Set;
+
+import javax.enterprise.inject.spi.Bean;
+import javax.enterprise.inject.spi.BeanManager;
+import javax.enterprise.inject.spi.CDI;
+
+import io.smallrye.health.api.HealthRegistry;
+import io.smallrye.health.registry.LivenessHealthRegistry;
+import io.smallrye.health.registry.ReadinessHealthRegistry;
+import org.apache.camel.CamelContext;
+import org.apache.camel.microprofile.health.CamelMicroProfileHealthCheckRegistry;
+import org.eclipse.microprofile.health.Liveness;
+import org.eclipse.microprofile.health.Readiness;
+
+public class CamelQuarkusMicroProfileHealthCheckRegistry extends CamelMicroProfileHealthCheckRegistry {
+
+    CamelQuarkusMicroProfileHealthCheckRegistry(CamelContext camelContext) {
+        super(camelContext);
+    }
+
+    @Override
+    protected HealthRegistry getLivenessRegistry() {
+        return getHealthRegistryBean(LivenessHealthRegistry.class, Liveness.Literal.INSTANCE);
+    }
+
+    @Override
+    protected HealthRegistry getReadinessRegistry() {
+        return getHealthRegistryBean(ReadinessHealthRegistry.class, Readiness.Literal.INSTANCE);
+    }
+
+    private static HealthRegistry getHealthRegistryBean(Class<? extends HealthRegistry> type, Annotation qualifier) {
+        BeanManager beanManager = CDI.current().getBeanManager();
+        Set<Bean<?>> beans = beanManager.getBeans(type, qualifier);
+        if (beans.isEmpty()) {
+            throw new IllegalStateException(
+                    "Beans for type " + type.getName() + " with qualifier " + qualifier + " could not be found.");
+        }
+
+        Bean<?> bean = beanManager.resolve(beans);
+        Object reference = beanManager.getReference(bean, type, beanManager.createCreationalContext(bean));
+        return type.cast(reference);
+    }
+}

[camel-quarkus] 06/08: 3579 Improve quartz test coverage

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit 7df5826485e363d50842f4f036f4ac00dadf9e50
Author: JiriOndrusek <on...@gmail.com>
AuthorDate: Tue Mar 8 09:44:20 2022 +0100

    3579 Improve quartz test coverage
---
 .../ROOT/pages/reference/extensions/quartz.adoc    |  58 ++++++
 extensions/quartz/deployment/pom.xml               |  10 +
 .../quartz/deployment/QuartzProcessor.java         |  58 +++++-
 extensions/quartz/runtime/pom.xml                  |  14 ++
 .../quartz/runtime/src/main/doc/limitations.adoc   |   4 +
 extensions/quartz/runtime/src/main/doc/usage.adoc  |  46 +++++
 .../CamelQuarkusQuartzConnectionProvider.java      |  66 +++++++
 integration-tests/quartz/pom.xml                   |  30 +++
 .../component/quartz/it/QuartzResource.java        |  74 ++++++++
 .../quarkus/component/quartz/it/QuartzRoutes.java  |  28 ++-
 .../src/main/resources/application.properties      |  47 +++++
 .../db/migration/V1.0.1__QuarkusQuartz.sql         | 207 +++++++++++++++++++++
 .../src/main/resources/quartz-node-A.properties    |  62 ++++++
 .../src/main/resources/quartz-node-B.properties    |  63 +++++++
 .../src/main/resources/quartz-node-C.properties    |  67 +++++++
 .../quartz/src/main/resources/quartz.properties    |  26 +++
 .../quarkus/component/quartz/it/QuartzTest.java    |  76 ++++++++
 pom.xml                                            |   1 +
 poms/bom/pom.xml                                   |   5 +
 19 files changed, 940 insertions(+), 2 deletions(-)

diff --git a/docs/modules/ROOT/pages/reference/extensions/quartz.adoc b/docs/modules/ROOT/pages/reference/extensions/quartz.adoc
index 99c7cdf..196d77f 100644
--- a/docs/modules/ROOT/pages/reference/extensions/quartz.adoc
+++ b/docs/modules/ROOT/pages/reference/extensions/quartz.adoc
@@ -38,3 +38,61 @@ Or add the coordinates to your existing project:
 ----
 
 Check the xref:user-guide/index.adoc[User guide] for more information about writing Camel Quarkus applications.
+
+== Usage
+
+=== Clustering
+
+There are two options how to run Quartz in clustered mode:
+
+==== Quarkus based
+
+This is the preferred option. Follow the https://quarkus.io/guides/quartz[scheduling periodic tasks quartz guide].
+
+- Define database configuration in `application.properties`.
+- Use for example `flyway` to create database tables required for `Quartz`.
+
+===== Quartz based with an Agroal datasource
+
+Follow the http://www.quartz-scheduler.org/documentation/quartz-1.8.6/configuration/ConfigJDBCJobStoreClustering.html#configure-clustering-with-jdbc-jobstore[Configure Clustering with JDBC-JobStore Guide] with different DS configuration:
+
+- Use `quartz.properties` to configure `JobStore`.
+- Define datasource via quarkus (see the https://quarkus.io/guides/datasource[Quarkus datasource documentation)] and use `CamelQuarkusQuartzConnectionProvider` as `ConnectionProvider` in `quartz.properties`:
+
+```
+...
+org.quartz.jobStore.dataSource = myDS
+
+# datasource configuration
+org.quartz.dataSource.myDS.connectionProvider.class = org.apache.camel.quarkus.component.quartz.CamelQuarkusQuartzConnectionProvider
+org.quartz.dataSource.myDSB.dataSourceName = ds_name_if_not_set_default_ds_will_be_used
+```
+
+
+- You can use for example `flyway` to create database tables required for `Quartz`.
+
+===== Quartz based
+
+You can follow the http://www.quartz-scheduler.org/documentation/quartz-1.8.6/configuration/ConfigJDBCJobStoreClustering.html#configure-clustering-with-jdbc-jobstore[Configure Clustering with JDBC-JobStore Guide] without any modification:
+
+```
+...
+org.quartz.jobStore.dataSource = myDS
+
+# datasource configuration
+org.quartz.dataSource.myDS.driver = org.postgresql.Driver
+
+# datasource configuration
+org.quartz.dataSource.myDS.URL=jdbc:postgresql://localhost:5432/default
+org.quartz.dataSource.myDS.user = quarkus
+org.quartz.dataSource.myDS.password = quarkus
+```
+
+
+== Camel Quarkus limitations
+
+=== JDBC Job Store
+
+Quartz's property `org.quartz.jobStore.useProperties` is set to `true` and can not be modified. The value is forced by the Quarkus Quartz extension.
+See the Quartz documentation for more information about `org.quartz.jobStore.useProperties`.
+
diff --git a/extensions/quartz/deployment/pom.xml b/extensions/quartz/deployment/pom.xml
index 6c9eb0d..2420c69 100644
--- a/extensions/quartz/deployment/pom.xml
+++ b/extensions/quartz/deployment/pom.xml
@@ -33,6 +33,12 @@
         <dependency>
             <groupId>io.quarkus</groupId>
             <artifactId>quarkus-quartz-deployment</artifactId>
+            <exclusions>
+                <exclusion>
+                    <artifactId>mchange-commons-java</artifactId>
+                    <groupId>com.mchange</groupId>
+                </exclusion>
+            </exclusions>
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
@@ -42,6 +48,10 @@
             <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-quartz</artifactId>
         </dependency>
+        <dependency>
+            <groupId>io.quarkus</groupId>
+            <artifactId>quarkus-agroal-deployment</artifactId>
+        </dependency>
     </dependencies>
 
     <build>
diff --git a/extensions/quartz/deployment/src/main/java/org/apache/camel/quarkus/component/quartz/deployment/QuartzProcessor.java b/extensions/quartz/deployment/src/main/java/org/apache/camel/quarkus/component/quartz/deployment/QuartzProcessor.java
index 0174322..86d9262 100644
--- a/extensions/quartz/deployment/src/main/java/org/apache/camel/quarkus/component/quartz/deployment/QuartzProcessor.java
+++ b/extensions/quartz/deployment/src/main/java/org/apache/camel/quarkus/component/quartz/deployment/QuartzProcessor.java
@@ -16,10 +16,19 @@
  */
 package org.apache.camel.quarkus.component.quartz.deployment;
 
+import io.quarkus.bootstrap.model.ApplicationModel;
+import io.quarkus.deployment.annotations.BuildProducer;
 import io.quarkus.deployment.annotations.BuildStep;
+import io.quarkus.deployment.builditem.CombinedIndexBuildItem;
 import io.quarkus.deployment.builditem.FeatureBuildItem;
+import io.quarkus.deployment.builditem.IndexDependencyBuildItem;
 import io.quarkus.deployment.builditem.nativeimage.NativeImageResourceBuildItem;
+import io.quarkus.deployment.builditem.nativeimage.NativeImageSystemPropertyBuildItem;
 import io.quarkus.deployment.builditem.nativeimage.ReflectiveClassBuildItem;
+import io.quarkus.deployment.pkg.builditem.CurateOutcomeBuildItem;
+import org.jboss.jandex.DotName;
+import org.jboss.jandex.IndexView;
+import org.quartz.impl.jdbcjobstore.StdJDBCDelegate;
 
 class QuartzProcessor {
 
@@ -27,8 +36,17 @@ class QuartzProcessor {
     private static final String[] QUARTZ_JOB_CLASSES = new String[] {
             "org.apache.camel.component.quartz.CamelJob",
             "org.apache.camel.component.quartz.StatefulCamelJob",
-            "org.apache.camel.pollconsumer.quartz.QuartzScheduledPollConsumerJob"
+            "org.apache.camel.pollconsumer.quartz.QuartzScheduledPollConsumerJob",
+            "org.quartz.utils.C3p0PoolingConnectionProvider"
     };
+    private static final String[] QUARTZ_JOB_CLASSES_WITH_METHODS = new String[] {
+            "org.quartz.impl.jdbcjobstore.JobStoreTX",
+            "org.quartz.impl.jdbcjobstore.JobStoreSupport",
+            "org.quartz.impl.triggers.SimpleTriggerImpl",
+            "org.quartz.impl.triggers.AbstractTrigger",
+            "org.apache.camel.quarkus.component.quartz.CamelQuarkusQuartzConnectionProvider"
+    };
+    private static final DotName SQL_JDBC_DELEGATE = DotName.createSimple(StdJDBCDelegate.class.getName());
 
     @BuildStep
     FeatureBuildItem feature() {
@@ -44,4 +62,42 @@ class QuartzProcessor {
     ReflectiveClassBuildItem registerForReflection() {
         return new ReflectiveClassBuildItem(false, false, QUARTZ_JOB_CLASSES);
     }
+
+    @BuildStep
+    ReflectiveClassBuildItem registerForReflectionWithMethods() {
+        return new ReflectiveClassBuildItem(true, false, QUARTZ_JOB_CLASSES_WITH_METHODS);
+    }
+
+    @BuildStep
+    void registerForReflection(BuildProducer<ReflectiveClassBuildItem> reflectiveClasses,
+            CombinedIndexBuildItem combinedIndex, CurateOutcomeBuildItem curateOutcome) {
+        IndexView index = combinedIndex.getIndex();
+
+        ApplicationModel applicationModel = curateOutcome.getApplicationModel();
+        boolean oracleBlobIsPresent = applicationModel.getDependencies().stream()
+                .anyMatch(d -> d.getGroupId().equals("com.oracle.database.jdbc"));
+
+        final String[] delegatesImpl = index
+                .getAllKnownSubclasses(SQL_JDBC_DELEGATE)
+                .stream()
+                .map(c -> c.name().toString())
+                .filter(n -> oracleBlobIsPresent || !n.contains("oracle"))
+                .toArray(String[]::new);
+
+        reflectiveClasses.produce(new ReflectiveClassBuildItem(false, true, delegatesImpl));
+
+    }
+
+    @BuildStep
+    void indexSaxonHe(BuildProducer<IndexDependencyBuildItem> deps) {
+        deps.produce(new IndexDependencyBuildItem("org.quartz-scheduler", "quartz"));
+    }
+
+    @BuildStep
+    NativeImageSystemPropertyBuildItem disableJMX() {
+
+        return new NativeImageSystemPropertyBuildItem("com.mchange.v2.c3p0.management.ManagementCoordinator",
+                "com.mchange.v2.c3p0.management.NullManagementCoordinator");
+    }
+
 }
diff --git a/extensions/quartz/runtime/pom.xml b/extensions/quartz/runtime/pom.xml
index 08ed812..7365236 100644
--- a/extensions/quartz/runtime/pom.xml
+++ b/extensions/quartz/runtime/pom.xml
@@ -50,6 +50,12 @@
         <dependency>
             <groupId>io.quarkus</groupId>
             <artifactId>quarkus-quartz</artifactId>
+            <exclusions>
+                <exclusion>
+                    <artifactId>mchange-commons-java</artifactId>
+                    <groupId>com.mchange</groupId>
+                </exclusion>
+            </exclusions>
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
@@ -59,6 +65,14 @@
             <groupId>org.apache.camel</groupId>
             <artifactId>camel-quartz</artifactId>
         </dependency>
+        <dependency>
+            <groupId>com.mchange</groupId>
+            <artifactId>c3p0</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>io.quarkus</groupId>
+            <artifactId>quarkus-agroal</artifactId>
+        </dependency>
     </dependencies>
 
     <build>
diff --git a/extensions/quartz/runtime/src/main/doc/limitations.adoc b/extensions/quartz/runtime/src/main/doc/limitations.adoc
new file mode 100644
index 0000000..dbff30b
--- /dev/null
+++ b/extensions/quartz/runtime/src/main/doc/limitations.adoc
@@ -0,0 +1,4 @@
+=== JDBC Job Store
+
+Quartz's property `org.quartz.jobStore.useProperties` is set to `true` and can not be modified. The value is forced by the Quarkus Quartz extension.
+See the Quartz documentation for more information about `org.quartz.jobStore.useProperties`.
\ No newline at end of file
diff --git a/extensions/quartz/runtime/src/main/doc/usage.adoc b/extensions/quartz/runtime/src/main/doc/usage.adoc
new file mode 100644
index 0000000..0d34bbf
--- /dev/null
+++ b/extensions/quartz/runtime/src/main/doc/usage.adoc
@@ -0,0 +1,46 @@
+=== Clustering
+
+There are two options how to run Quartz in clustered mode:
+
+==== Quarkus based
+
+This is the preferred option. Follow the https://quarkus.io/guides/quartz[scheduling periodic tasks quartz guide].
+
+- Define database configuration in `application.properties`.
+- Use for example `flyway` to create database tables required for `Quartz`.
+
+===== Quartz based with an Agroal datasource
+
+Follow the http://www.quartz-scheduler.org/documentation/quartz-1.8.6/configuration/ConfigJDBCJobStoreClustering.html#configure-clustering-with-jdbc-jobstore[Configure Clustering with JDBC-JobStore Guide] with different DS configuration:
+
+- Use `quartz.properties` to configure `JobStore`.
+- Define datasource via quarkus (see the https://quarkus.io/guides/datasource[Quarkus datasource documentation)] and use `CamelQuarkusQuartzConnectionProvider` as `ConnectionProvider` in `quartz.properties`:
+
+```
+...
+org.quartz.jobStore.dataSource = myDS
+
+# datasource configuration
+org.quartz.dataSource.myDS.connectionProvider.class = org.apache.camel.quarkus.component.quartz.CamelQuarkusQuartzConnectionProvider
+org.quartz.dataSource.myDSB.dataSourceName = ds_name_if_not_set_default_ds_will_be_used
+```
+
+
+- You can use for example `flyway` to create database tables required for `Quartz`.
+
+===== Quartz based
+
+You can follow the http://www.quartz-scheduler.org/documentation/quartz-1.8.6/configuration/ConfigJDBCJobStoreClustering.html#configure-clustering-with-jdbc-jobstore[Configure Clustering with JDBC-JobStore Guide] without any modification:
+
+```
+...
+org.quartz.jobStore.dataSource = myDS
+
+# datasource configuration
+org.quartz.dataSource.myDS.driver = org.postgresql.Driver
+
+# datasource configuration
+org.quartz.dataSource.myDS.URL=jdbc:postgresql://localhost:5432/default
+org.quartz.dataSource.myDS.user = quarkus
+org.quartz.dataSource.myDS.password = quarkus
+```
\ No newline at end of file
diff --git a/extensions/quartz/runtime/src/main/java/org/apache/camel/quarkus/component/quartz/CamelQuarkusQuartzConnectionProvider.java b/extensions/quartz/runtime/src/main/java/org/apache/camel/quarkus/component/quartz/CamelQuarkusQuartzConnectionProvider.java
new file mode 100644
index 0000000..cea123e
--- /dev/null
+++ b/extensions/quartz/runtime/src/main/java/org/apache/camel/quarkus/component/quartz/CamelQuarkusQuartzConnectionProvider.java
@@ -0,0 +1,66 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.quarkus.component.quartz;
+
+import java.sql.Connection;
+import java.sql.SQLException;
+
+import io.agroal.api.AgroalDataSource;
+import io.quarkus.agroal.DataSource.DataSourceLiteral;
+import io.quarkus.arc.Arc;
+import io.quarkus.arc.ArcContainer;
+import io.quarkus.arc.InstanceHandle;
+import org.quartz.utils.ConnectionProvider;
+
+public class CamelQuarkusQuartzConnectionProvider implements ConnectionProvider {
+    private AgroalDataSource dataSource;
+    private String dataSourceName;
+
+    @Override
+    public Connection getConnection() throws SQLException {
+        return dataSource.getConnection();
+    }
+
+    @Override
+    public void shutdown() {
+        // Do nothing as the connection will be closed inside the Agroal extension
+    }
+
+    @Override
+    public void initialize() {
+        final ArcContainer container = Arc.container();
+        final InstanceHandle<AgroalDataSource> instanceHandle;
+        final boolean useDefaultDataSource = dataSourceName == null || "".equals(dataSourceName.trim());
+        if (useDefaultDataSource) {
+            instanceHandle = container.instance(AgroalDataSource.class);
+        } else {
+            instanceHandle = container.instance(AgroalDataSource.class, new DataSourceLiteral(dataSourceName));
+        }
+        if (instanceHandle.isAvailable()) {
+            this.dataSource = instanceHandle.get();
+        } else {
+            String message = String.format(
+                    "JDBC Store configured but '%s' datasource is missing. You can configure your datasource by following the guide available at: https://quarkus.io/guides/datasource",
+                    useDefaultDataSource ? "default" : dataSourceName);
+            throw new IllegalStateException(message);
+        }
+    }
+
+    public void setDataSourceName(String dataSourceName) {
+        this.dataSourceName = dataSourceName;
+    }
+}
diff --git a/integration-tests/quartz/pom.xml b/integration-tests/quartz/pom.xml
index 8370af4..c705f47 100644
--- a/integration-tests/quartz/pom.xml
+++ b/integration-tests/quartz/pom.xml
@@ -47,6 +47,26 @@
             <groupId>io.quarkus</groupId>
             <artifactId>quarkus-resteasy</artifactId>
         </dependency>
+        <dependency>
+            <groupId>io.quarkus</groupId>
+            <artifactId>quarkus-resteasy-jackson</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>io.quarkus</groupId>
+            <artifactId>quarkus-jdbc-postgresql</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>io.quarkus</groupId>
+            <artifactId>quarkus-jdbc-h2</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>io.quarkus</groupId>
+            <artifactId>quarkus-agroal</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>io.quarkus</groupId>
+            <artifactId>quarkus-flyway</artifactId>
+        </dependency>
 
         <!-- test dependencies -->
         <dependency>
@@ -59,6 +79,16 @@
             <artifactId>rest-assured</artifactId>
             <scope>test</scope>
         </dependency>
+        <dependency>
+            <groupId>org.awaitility</groupId>
+            <artifactId>awaitility</artifactId>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.camel.quarkus</groupId>
+            <artifactId>camel-quarkus-integration-test-support</artifactId>
+            <scope>test</scope>
+        </dependency>
     </dependencies>
 
 
diff --git a/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzResource.java b/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzResource.java
index 1abac2f..f0e6c19 100644
--- a/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzResource.java
+++ b/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzResource.java
@@ -16,21 +16,74 @@
  */
 package org.apache.camel.quarkus.component.quartz.it;
 
+import java.util.Map;
+import java.util.stream.Collectors;
+
 import javax.inject.Inject;
+import javax.inject.Named;
+import javax.inject.Singleton;
 import javax.ws.rs.GET;
 import javax.ws.rs.Path;
 import javax.ws.rs.Produces;
 import javax.ws.rs.QueryParam;
 import javax.ws.rs.core.MediaType;
 
+import org.apache.camel.CamelContext;
 import org.apache.camel.ConsumerTemplate;
+import org.apache.camel.Exchange;
+import org.apache.camel.component.quartz.QuartzComponent;
+import org.apache.camel.util.CollectionHelper;
+import org.quartz.CronTrigger;
 
 @Path("/quartz")
 public class QuartzResource {
 
     @Inject
+    CamelContext camelContext;
+
+    @Inject
     ConsumerTemplate consumerTemplate;
 
+    @javax.enterprise.inject.Produces
+    @Singleton
+    @Named("quartzFromProperties")
+    public QuartzComponent createQuartzFromProperties() {
+        return new QuartzComponent();
+    }
+
+    @javax.enterprise.inject.Produces
+    @Singleton
+    @Named("quartzNodeA")
+    public QuartzComponent createQuartzNodeA() {
+        return new QuartzComponent();
+    }
+
+    @javax.enterprise.inject.Produces
+    @Singleton
+    @Named("quartzNodeB")
+    public QuartzComponent createQuartzNodeB() {
+        return new QuartzComponent();
+    }
+
+    @javax.enterprise.inject.Produces
+    @Singleton
+    @Named("quartzNodeC")
+    public QuartzComponent createQuartzNodeC() {
+        return new QuartzComponent();
+    }
+
+    @Path("/getNameAndResult")
+    @GET
+    @Produces(MediaType.APPLICATION_JSON)
+    public Map<String, String> getSchedulerNameAndResult(@QueryParam("componentName") String componentName,
+            @QueryParam("fromEndpoint") String fromEndpoint) throws Exception {
+
+        QuartzComponent comp = camelContext.getComponent(componentName, QuartzComponent.class);
+
+        return CollectionHelper.mapOf("name", comp.getScheduler().getSchedulerName().replaceFirst(camelContext.getName(), ""),
+                "result", consumerTemplate.receiveBody("seda:" + fromEndpoint + "-result", 5000, String.class));
+    }
+
     @Path("/get")
     @GET
     @Produces(MediaType.TEXT_PLAIN)
@@ -38,4 +91,25 @@ public class QuartzResource {
         return consumerTemplate.receiveBody("seda:" + fromEndpoint + "-result", 5000, String.class);
     }
 
+    @Path("/getHeaders")
+    @GET
+    @Produces(MediaType.APPLICATION_JSON)
+    public Map<String, String> getHeaders(@QueryParam("fromEndpoint") String fromEndpoint) throws Exception {
+        Exchange exchange = consumerTemplate.receive("seda:" + fromEndpoint + "-result", 5000);
+
+        return exchange.getMessage().getHeaders().entrySet().stream().filter(e -> e.getValue() instanceof String)
+                .collect(Collectors.toMap(Map.Entry::getKey, e -> e.getValue().toString()));
+    }
+
+    @Path("/getMisfire")
+    @GET
+    @Produces(MediaType.APPLICATION_JSON)
+    public Map<String, String> getMisfire(@QueryParam("fromEndpoint") String fromEndpoint) throws Exception {
+        Exchange exchange = consumerTemplate.receive("seda:" + fromEndpoint + "-result", 5000);
+
+        System.out.println(exchange.getMessage().getHeaders().keySet().stream().collect(Collectors.joining(",")));
+        return CollectionHelper.mapOf("timezone",
+                exchange.getMessage().getHeader("trigger", CronTrigger.class).getTimeZone().getID(),
+                "misfire", exchange.getMessage().getHeader("trigger", CronTrigger.class).getMisfireInstruction() + "");
+    }
 }
diff --git a/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzRoutes.java b/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzRoutes.java
index d836ee5..2b1a427 100644
--- a/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzRoutes.java
+++ b/integration-tests/quartz/src/main/java/org/apache/camel/quarkus/component/quartz/it/QuartzRoutes.java
@@ -22,12 +22,38 @@ public class QuartzRoutes extends RouteBuilder {
 
     @Override
     public void configure() throws Exception {
-        from("quartz:0/1 * * * * ?")
+
+        from("quartz:quartz/1 * * * * ?")
                 .setBody(constant("Hello Camel Quarkus quartz"))
                 .to("seda:quartz-result");
 
         from("cron:tab?schedule=0/1 * * * * ?")
                 .setBody(constant("Hello Camel Quarkus cron"))
                 .to("seda:cron-result");
+
+        from("quartzFromProperties:properties/* 1 * * * ")
+                .setBody(constant("Hello Camel Quarkus Quartz Properties"))
+                .to("seda:quartz-properties-result");
+
+        // cron trigger
+        from("quartz://cronTrigger?cron=0/1+*+*+*+*+?&trigger.timeZone=Europe/Stockholm")
+                .setBody(constant("Hello Camel Quarkus Quartz From Cron Trigger"))
+                .to("seda:quartz-cron-trigger-result");
+
+        from("quartz://misfire?cron=0/1+*+*+*+*+?&trigger.timeZone=Europe/Stockholm&trigger.misfireInstruction=2")
+                .to("seda:quartz-cron-misfire-result");
+
+        from("quartzNodeA:nodeA/1 * * * * ")
+                .setBody(constant("Hello Camel Quarkus Quartz NodeA"))
+                .to("seda:quartz-nodeA-result");
+
+        from("quartzNodeB:nodeB/1 * * * * ")
+                .setBody(constant("Hello Camel Quarkus Quartz NodeB"))
+                .to("seda:quartz-nodeB-result");
+
+        from("quartzNodeC:nodeC/1 * * * * ")
+                .setBody(constant("Hello Camel Quarkus Quartz NodeC"))
+                .to("seda:quartz-nodeC-result");
+
     }
 }
diff --git a/integration-tests/quartz/src/main/resources/application.properties b/integration-tests/quartz/src/main/resources/application.properties
new file mode 100644
index 0000000..0805de0
--- /dev/null
+++ b/integration-tests/quartz/src/main/resources/application.properties
@@ -0,0 +1,47 @@
+## ---------------------------------------------------------------------------
+## Licensed to the Apache Software Foundation (ASF) under one or more
+## contributor license agreements.  See the NOTICE file distributed with
+## this work for additional information regarding copyright ownership.
+## The ASF licenses this file to You under the Apache License, Version 2.0
+## (the "License"); you may not use this file except in compliance with
+## the License.  You may obtain a copy of the License at
+##
+##      http://www.apache.org/licenses/LICENSE-2.0
+##
+## Unless required by applicable law or agreed to in writing, software
+## distributed under the License is distributed on an "AS IS" BASIS,
+## WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+## See the License for the specific language governing permissions and
+## limitations under the License.
+## ---------------------------------------------------------------------------
+
+camel.component.quartzNodeA.propertiesFile=quartz-node-A.properties
+camel.component.quartzNodeB.propertiesFile=quartz-node-B.properties
+camel.component.quartzFromProperties.propertiesFile=quartz.properties
+
+quarkus.native.resources.includes = quartz*.properties
+
+quarkus.datasource.devservices.enabled = true
+
+#postgresql db
+quarkus.datasource.db-kind=postgresql
+# flyway to create Quartz tables
+quarkus.flyway.connect-retries=10
+quarkus.flyway.table=flyway_quarkus_history
+quarkus.flyway.migrate-at-start=true
+quarkus.flyway.baseline-on-migrate=true
+quarkus.flyway.baseline-version=1.0
+quarkus.flyway.baseline-description=Quartz
+
+# h2 db
+quarkus.datasource.h2ds.db-kind=h2
+# flyway to create Quartz tables
+quarkus.flyway.h2ds.connect-retries=10
+quarkus.flyway.h2ds.table=flyway_quarkus_history
+quarkus.flyway.h2ds.migrate-at-start=true
+quarkus.flyway.h2ds.baseline-on-migrate=true
+quarkus.flyway.h2ds.baseline-version=1.0
+quarkus.flyway.h2ds.baseline-description=Quartz
+
+#fixed port is required to use quarz.properties for DS configuration
+quarkus.datasource.devservices.port = 5432
\ No newline at end of file
diff --git a/integration-tests/quartz/src/main/resources/db/migration/V1.0.1__QuarkusQuartz.sql b/integration-tests/quartz/src/main/resources/db/migration/V1.0.1__QuarkusQuartz.sql
new file mode 100644
index 0000000..e62f739
--- /dev/null
+++ b/integration-tests/quartz/src/main/resources/db/migration/V1.0.1__QuarkusQuartz.sql
@@ -0,0 +1,207 @@
+--
+-- Licensed to the Apache Software Foundation (ASF) under one or more
+-- contributor license agreements.  See the NOTICE file distributed with
+-- this work for additional information regarding copyright ownership.
+-- The ASF licenses this file to You under the Apache License, Version 2.0
+-- (the "License"); you may not use this file except in compliance with
+-- the License.  You may obtain a copy of the License at
+--
+--      http://www.apache.org/licenses/LICENSE-2.0
+--
+-- Unless required by applicable law or agreed to in writing, software
+-- distributed under the License is distributed on an "AS IS" BASIS,
+-- WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+-- See the License for the specific language governing permissions and
+-- limitations under the License.
+--
+
+CREATE TABLE QRTZ_JOB_DETAILS
+(
+    SCHED_NAME        VARCHAR(120) NOT NULL,
+    JOB_NAME          VARCHAR(200) NOT NULL,
+    JOB_GROUP         VARCHAR(200) NOT NULL,
+    DESCRIPTION       VARCHAR(250) NULL,
+    JOB_CLASS_NAME    VARCHAR(250) NOT NULL,
+    IS_DURABLE        BOOL         NOT NULL,
+    IS_NONCONCURRENT  BOOL         NOT NULL,
+    IS_UPDATE_DATA    BOOL         NOT NULL,
+    REQUESTS_RECOVERY BOOL         NOT NULL,
+    JOB_DATA          BYTEA        NULL,
+    PRIMARY KEY (SCHED_NAME, JOB_NAME, JOB_GROUP)
+);
+
+CREATE TABLE QRTZ_TRIGGERS
+(
+    SCHED_NAME     VARCHAR(120) NOT NULL,
+    TRIGGER_NAME   VARCHAR(200) NOT NULL,
+    TRIGGER_GROUP  VARCHAR(200) NOT NULL,
+    JOB_NAME       VARCHAR(200) NOT NULL,
+    JOB_GROUP      VARCHAR(200) NOT NULL,
+    DESCRIPTION    VARCHAR(250) NULL,
+    NEXT_FIRE_TIME BIGINT       NULL,
+    PREV_FIRE_TIME BIGINT       NULL,
+    PRIORITY       INTEGER      NULL,
+    TRIGGER_STATE  VARCHAR(16)  NOT NULL,
+    TRIGGER_TYPE   VARCHAR(8)   NOT NULL,
+    START_TIME     BIGINT       NOT NULL,
+    END_TIME       BIGINT       NULL,
+    CALENDAR_NAME  VARCHAR(200) NULL,
+    MISFIRE_INSTR  SMALLINT     NULL,
+    JOB_DATA       BYTEA        NULL,
+    PRIMARY KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP),
+    FOREIGN KEY (SCHED_NAME, JOB_NAME, JOB_GROUP)
+        REFERENCES QRTZ_JOB_DETAILS (SCHED_NAME, JOB_NAME, JOB_GROUP)
+);
+
+CREATE TABLE QRTZ_SIMPLE_TRIGGERS
+(
+    SCHED_NAME      VARCHAR(120) NOT NULL,
+    TRIGGER_NAME    VARCHAR(200) NOT NULL,
+    TRIGGER_GROUP   VARCHAR(200) NOT NULL,
+    REPEAT_COUNT    BIGINT       NOT NULL,
+    REPEAT_INTERVAL BIGINT       NOT NULL,
+    TIMES_TRIGGERED BIGINT       NOT NULL,
+    PRIMARY KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP),
+    FOREIGN KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+        REFERENCES QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+);
+
+CREATE TABLE QRTZ_CRON_TRIGGERS
+(
+    SCHED_NAME      VARCHAR(120) NOT NULL,
+    TRIGGER_NAME    VARCHAR(200) NOT NULL,
+    TRIGGER_GROUP   VARCHAR(200) NOT NULL,
+    CRON_EXPRESSION VARCHAR(120) NOT NULL,
+    TIME_ZONE_ID    VARCHAR(80),
+    PRIMARY KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP),
+    FOREIGN KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+        REFERENCES QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+);
+
+CREATE TABLE QRTZ_SIMPROP_TRIGGERS
+(
+    SCHED_NAME    VARCHAR(120)   NOT NULL,
+    TRIGGER_NAME  VARCHAR(200)   NOT NULL,
+    TRIGGER_GROUP VARCHAR(200)   NOT NULL,
+    STR_PROP_1    VARCHAR(512)   NULL,
+    STR_PROP_2    VARCHAR(512)   NULL,
+    STR_PROP_3    VARCHAR(512)   NULL,
+    INT_PROP_1    INT            NULL,
+    INT_PROP_2    INT            NULL,
+    LONG_PROP_1   BIGINT         NULL,
+    LONG_PROP_2   BIGINT         NULL,
+    DEC_PROP_1    NUMERIC(13, 4) NULL,
+    DEC_PROP_2    NUMERIC(13, 4) NULL,
+    BOOL_PROP_1   BOOL           NULL,
+    BOOL_PROP_2   BOOL           NULL,
+    PRIMARY KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP),
+    FOREIGN KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+        REFERENCES QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+);
+
+CREATE TABLE QRTZ_BLOB_TRIGGERS
+(
+    SCHED_NAME    VARCHAR(120) NOT NULL,
+    TRIGGER_NAME  VARCHAR(200) NOT NULL,
+    TRIGGER_GROUP VARCHAR(200) NOT NULL,
+    BLOB_DATA     BYTEA        NULL,
+    PRIMARY KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP),
+    FOREIGN KEY (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+        REFERENCES QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP)
+);
+
+CREATE TABLE QRTZ_CALENDARS
+(
+    SCHED_NAME    VARCHAR(120) NOT NULL,
+    CALENDAR_NAME VARCHAR(200) NOT NULL,
+    CALENDAR      BYTEA        NOT NULL,
+    PRIMARY KEY (SCHED_NAME, CALENDAR_NAME)
+);
+
+
+CREATE TABLE QRTZ_PAUSED_TRIGGER_GRPS
+(
+    SCHED_NAME    VARCHAR(120) NOT NULL,
+    TRIGGER_GROUP VARCHAR(200) NOT NULL,
+    PRIMARY KEY (SCHED_NAME, TRIGGER_GROUP)
+);
+
+CREATE TABLE QRTZ_FIRED_TRIGGERS
+(
+    SCHED_NAME        VARCHAR(120) NOT NULL,
+    ENTRY_ID          VARCHAR(95)  NOT NULL,
+    TRIGGER_NAME      VARCHAR(200) NOT NULL,
+    TRIGGER_GROUP     VARCHAR(200) NOT NULL,
+    INSTANCE_NAME     VARCHAR(200) NOT NULL,
+    FIRED_TIME        BIGINT       NOT NULL,
+    SCHED_TIME        BIGINT       NOT NULL,
+    PRIORITY          INTEGER      NOT NULL,
+    STATE             VARCHAR(16)  NOT NULL,
+    JOB_NAME          VARCHAR(200) NULL,
+    JOB_GROUP         VARCHAR(200) NULL,
+    IS_NONCONCURRENT  BOOL         NULL,
+    REQUESTS_RECOVERY BOOL         NULL,
+    PRIMARY KEY (SCHED_NAME, ENTRY_ID)
+);
+
+CREATE TABLE QRTZ_SCHEDULER_STATE
+(
+    SCHED_NAME        VARCHAR(120) NOT NULL,
+    INSTANCE_NAME     VARCHAR(200) NOT NULL,
+    LAST_CHECKIN_TIME BIGINT       NOT NULL,
+    CHECKIN_INTERVAL  BIGINT       NOT NULL,
+    PRIMARY KEY (SCHED_NAME, INSTANCE_NAME)
+);
+
+CREATE TABLE QRTZ_LOCKS
+(
+    SCHED_NAME VARCHAR(120) NOT NULL,
+    LOCK_NAME  VARCHAR(40)  NOT NULL,
+    PRIMARY KEY (SCHED_NAME, LOCK_NAME)
+);
+
+CREATE INDEX IDX_QRTZ_J_REQ_RECOVERY
+    ON QRTZ_JOB_DETAILS (SCHED_NAME, REQUESTS_RECOVERY);
+CREATE INDEX IDX_QRTZ_J_GRP
+    ON QRTZ_JOB_DETAILS (SCHED_NAME, JOB_GROUP);
+
+CREATE INDEX IDX_QRTZ_T_J
+    ON QRTZ_TRIGGERS (SCHED_NAME, JOB_NAME, JOB_GROUP);
+CREATE INDEX IDX_QRTZ_T_JG
+    ON QRTZ_TRIGGERS (SCHED_NAME, JOB_GROUP);
+CREATE INDEX IDX_QRTZ_T_C
+    ON QRTZ_TRIGGERS (SCHED_NAME, CALENDAR_NAME);
+CREATE INDEX IDX_QRTZ_T_G
+    ON QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_GROUP);
+CREATE INDEX IDX_QRTZ_T_STATE
+    ON QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_STATE);
+CREATE INDEX IDX_QRTZ_T_N_STATE
+    ON QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP, TRIGGER_STATE);
+CREATE INDEX IDX_QRTZ_T_N_G_STATE
+    ON QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_GROUP, TRIGGER_STATE);
+CREATE INDEX IDX_QRTZ_T_NEXT_FIRE_TIME
+    ON QRTZ_TRIGGERS (SCHED_NAME, NEXT_FIRE_TIME);
+CREATE INDEX IDX_QRTZ_T_NFT_ST
+    ON QRTZ_TRIGGERS (SCHED_NAME, TRIGGER_STATE, NEXT_FIRE_TIME);
+CREATE INDEX IDX_QRTZ_T_NFT_MISFIRE
+    ON QRTZ_TRIGGERS (SCHED_NAME, MISFIRE_INSTR, NEXT_FIRE_TIME);
+CREATE INDEX IDX_QRTZ_T_NFT_ST_MISFIRE
+    ON QRTZ_TRIGGERS (SCHED_NAME, MISFIRE_INSTR, NEXT_FIRE_TIME, TRIGGER_STATE);
+CREATE INDEX IDX_QRTZ_T_NFT_ST_MISFIRE_GRP
+    ON QRTZ_TRIGGERS (SCHED_NAME, MISFIRE_INSTR, NEXT_FIRE_TIME, TRIGGER_GROUP, TRIGGER_STATE);
+
+CREATE INDEX IDX_QRTZ_FT_TRIG_INST_NAME
+    ON QRTZ_FIRED_TRIGGERS (SCHED_NAME, INSTANCE_NAME);
+CREATE INDEX IDX_QRTZ_FT_INST_JOB_REQ_RCVRY
+    ON QRTZ_FIRED_TRIGGERS (SCHED_NAME, INSTANCE_NAME, REQUESTS_RECOVERY);
+CREATE INDEX IDX_QRTZ_FT_J_G
+    ON QRTZ_FIRED_TRIGGERS (SCHED_NAME, JOB_NAME, JOB_GROUP);
+CREATE INDEX IDX_QRTZ_FT_JG
+    ON QRTZ_FIRED_TRIGGERS (SCHED_NAME, JOB_GROUP);
+CREATE INDEX IDX_QRTZ_FT_T_G
+    ON QRTZ_FIRED_TRIGGERS (SCHED_NAME, TRIGGER_NAME, TRIGGER_GROUP);
+CREATE INDEX IDX_QRTZ_FT_TG
+    ON QRTZ_FIRED_TRIGGERS (SCHED_NAME, TRIGGER_GROUP);
+
+
+COMMIT;
\ No newline at end of file
diff --git a/integration-tests/quartz/src/main/resources/quartz-node-A.properties b/integration-tests/quartz/src/main/resources/quartz-node-A.properties
new file mode 100644
index 0000000..3c54402
--- /dev/null
+++ b/integration-tests/quartz/src/main/resources/quartz-node-A.properties
@@ -0,0 +1,62 @@
+## ---------------------------------------------------------------------------
+## Licensed to the Apache Software Foundation (ASF) under one or more
+## contributor license agreements.  See the NOTICE file distributed with
+## this work for additional information regarding copyright ownership.
+## The ASF licenses this file to You under the Apache License, Version 2.0
+## (the "License"); you may not use this file except in compliance with
+## the License.  You may obtain a copy of the License at
+##
+##      http://www.apache.org/licenses/LICENSE-2.0
+##
+## Unless required by applicable law or agreed to in writing, software
+## distributed under the License is distributed on an "AS IS" BASIS,
+## WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+## See the License for the specific language governing permissions and
+## limitations under the License.
+## ---------------------------------------------------------------------------
+
+#============================================================================
+# Configure Main Scheduler Properties
+#============================================================================
+
+org.quartz.jdbc.initialize-schema=always
+org.quartz.scheduler.instanceName = NodeA
+org.quartz.scheduler.instanceId = AUTO
+
+#============================================================================
+# Configure ThreadPool
+#============================================================================
+
+org.quartz.threadPool.class = org.quartz.simpl.SimpleThreadPool
+org.quartz.threadPool.threadCount = 25
+org.quartz.threadPool.threadPriority = 5
+
+#============================================================================
+# Configure JobStore
+#============================================================================
+
+org.quartz.jobStore.misfireThreshold = 60000
+
+org.quartz.jobStore.class=org.quartz.impl.jdbcjobstore.JobStoreTX
+org.quartz.jobStore.driverDelegateClass=org.quartz.impl.jdbcjobstore.PostgreSQLDelegate
+org.quartz.jobStore.useProperties = true
+org.quartz.jobStore.dataSource = myDSA
+org.quartz.jobStore.tablePrefix = QRTZ_
+
+org.quartz.jobStore.isClustered = true
+org.quartz.jobStore.clusterCheckinInterval = 500
+
+
+#============================================================================
+# Configure Datasources
+#============================================================================
+
+# datasource configuration
+org.quartz.dataSource.myDSA.connectionProvider.class = org.apache.camel.quarkus.component.quartz.CamelQuarkusQuartzConnectionProvider
+
+#
+#============================================================================
+# Disable JMX
+#============================================================================
+
+#com.mchange.v2.c3p0.management.ManagementCoordinator = com.mchange.v2.c3p0.management.NullManagementCoordinator
\ No newline at end of file
diff --git a/integration-tests/quartz/src/main/resources/quartz-node-B.properties b/integration-tests/quartz/src/main/resources/quartz-node-B.properties
new file mode 100644
index 0000000..210acdd
--- /dev/null
+++ b/integration-tests/quartz/src/main/resources/quartz-node-B.properties
@@ -0,0 +1,63 @@
+## ---------------------------------------------------------------------------
+## Licensed to the Apache Software Foundation (ASF) under one or more
+## contributor license agreements.  See the NOTICE file distributed with
+## this work for additional information regarding copyright ownership.
+## The ASF licenses this file to You under the Apache License, Version 2.0
+## (the "License"); you may not use this file except in compliance with
+## the License.  You may obtain a copy of the License at
+##
+##      http://www.apache.org/licenses/LICENSE-2.0
+##
+## Unless required by applicable law or agreed to in writing, software
+## distributed under the License is distributed on an "AS IS" BASIS,
+## WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+## See the License for the specific language governing permissions and
+## limitations under the License.
+## ---------------------------------------------------------------------------
+
+#============================================================================
+# Configure Main Scheduler Properties
+#============================================================================
+
+org.quartz.jdbc.initialize-schema=always
+org.quartz.scheduler.instanceName = NodeB
+org.quartz.scheduler.instanceId = AUTO
+
+#============================================================================
+# Configure ThreadPool
+#============================================================================
+
+org.quartz.threadPool.class = org.quartz.simpl.SimpleThreadPool
+org.quartz.threadPool.threadCount = 25
+org.quartz.threadPool.threadPriority = 5
+
+#============================================================================
+# Configure JobStore
+#============================================================================
+
+org.quartz.jobStore.misfireThreshold = 60000
+
+org.quartz.jobStore.class=org.quartz.impl.jdbcjobstore.JobStoreTX
+org.quartz.jobStore.driverDelegateClass=org.quartz.impl.jdbcjobstore.PostgreSQLDelegate
+org.quartz.jobStore.useProperties = true
+org.quartz.jobStore.dataSource = myDSB
+org.quartz.jobStore.tablePrefix = QRTZ_
+
+org.quartz.jobStore.isClustered = true
+org.quartz.jobStore.clusterCheckinInterval = 500
+
+
+#============================================================================
+# Configure Datasources
+#============================================================================
+
+# datasource configuration
+org.quartz.dataSource.myDSB.connectionProvider.class = org.apache.camel.quarkus.component.quartz.CamelQuarkusQuartzConnectionProvider
+org.quartz.dataSource.myDSB.dataSourceName = h2ds
+
+#
+#============================================================================
+# Disable JMX
+#============================================================================
+
+#com.mchange.v2.c3p0.management.ManagementCoordinator = com.mchange.v2.c3p0.management.NullManagementCoordinator
\ No newline at end of file
diff --git a/integration-tests/quartz/src/main/resources/quartz-node-C.properties b/integration-tests/quartz/src/main/resources/quartz-node-C.properties
new file mode 100644
index 0000000..11c2432
--- /dev/null
+++ b/integration-tests/quartz/src/main/resources/quartz-node-C.properties
@@ -0,0 +1,67 @@
+## ---------------------------------------------------------------------------
+## Licensed to the Apache Software Foundation (ASF) under one or more
+## contributor license agreements.  See the NOTICE file distributed with
+## this work for additional information regarding copyright ownership.
+## The ASF licenses this file to You under the Apache License, Version 2.0
+## (the "License"); you may not use this file except in compliance with
+## the License.  You may obtain a copy of the License at
+##
+##      http://www.apache.org/licenses/LICENSE-2.0
+##
+## Unless required by applicable law or agreed to in writing, software
+## distributed under the License is distributed on an "AS IS" BASIS,
+## WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+## See the License for the specific language governing permissions and
+## limitations under the License.
+## ---------------------------------------------------------------------------
+
+#============================================================================
+# Configure Main Scheduler Properties
+#============================================================================
+
+org.quartz.jdbc.initialize-schema=always
+org.quartz.scheduler.instanceName = NodeB
+org.quartz.scheduler.instanceId = AUTO
+
+#============================================================================
+# Configure ThreadPool
+#============================================================================
+
+org.quartz.threadPool.class = org.quartz.simpl.SimpleThreadPool
+org.quartz.threadPool.threadCount = 25
+org.quartz.threadPool.threadPriority = 5
+
+#============================================================================
+# Configure JobStore
+#============================================================================
+
+org.quartz.jobStore.misfireThreshold = 60000
+
+org.quartz.jobStore.class=org.quartz.impl.jdbcjobstore.JobStoreTX
+org.quartz.jobStore.driverDelegateClass=org.quartz.impl.jdbcjobstore.PostgreSQLDelegate
+org.quartz.jobStore.useProperties = true
+org.quartz.jobStore.dataSource = myDSC
+org.quartz.jobStore.tablePrefix = QRTZ_
+
+org.quartz.jobStore.isClustered = true
+org.quartz.jobStore.clusterCheckinInterval = 500
+
+
+#============================================================================
+# Configure Datasources
+#============================================================================
+
+# datasource configuration
+org.quartz.dataSource.myDSC.driver = org.postgresql.Driver
+
+# datasource configuration
+org.quartz.dataSource.myDSC.URL=jdbc:postgresql://localhost:5432/default
+org.quartz.dataSource.myDSC.user = quarkus
+org.quartz.dataSource.myDSC.password = quarkus
+
+#
+#============================================================================
+# Disable JMX
+#============================================================================
+
+#com.mchange.v2.c3p0.management.ManagementCoordinator = com.mchange.v2.c3p0.management.NullManagementCoordinator
\ No newline at end of file
diff --git a/integration-tests/quartz/src/main/resources/quartz.properties b/integration-tests/quartz/src/main/resources/quartz.properties
new file mode 100644
index 0000000..caf7989
--- /dev/null
+++ b/integration-tests/quartz/src/main/resources/quartz.properties
@@ -0,0 +1,26 @@
+## ---------------------------------------------------------------------------
+## Licensed to the Apache Software Foundation (ASF) under one or more
+## contributor license agreements.  See the NOTICE file distributed with
+## this work for additional information regarding copyright ownership.
+## The ASF licenses this file to You under the Apache License, Version 2.0
+## (the "License"); you may not use this file except in compliance with
+## the License.  You may obtain a copy of the License at
+##
+##      http://www.apache.org/licenses/LICENSE-2.0
+##
+## Unless required by applicable law or agreed to in writing, software
+## distributed under the License is distributed on an "AS IS" BASIS,
+## WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+## See the License for the specific language governing permissions and
+## limitations under the License.
+## ---------------------------------------------------------------------------
+
+org.quartz.scheduler.instanceName = MyScheduler
+org.quartz.scheduler.instanceId = 2
+org.quartz.scheduler.rmi.export = false
+org.quartz.scheduler.rmi.proxy = false
+
+org.quartz.threadPool.class = org.quartz.simpl.SimpleThreadPool
+org.quartz.threadPool.threadCount = 3
+
+org.quartz.jobStore.class = org.quartz.simpl.RAMJobStore
diff --git a/integration-tests/quartz/src/test/java/org/apache/camel/quarkus/component/quartz/it/QuartzTest.java b/integration-tests/quartz/src/test/java/org/apache/camel/quarkus/component/quartz/it/QuartzTest.java
index f37bb6f..c55252d 100644
--- a/integration-tests/quartz/src/test/java/org/apache/camel/quarkus/component/quartz/it/QuartzTest.java
+++ b/integration-tests/quartz/src/test/java/org/apache/camel/quarkus/component/quartz/it/QuartzTest.java
@@ -18,6 +18,7 @@ package org.apache.camel.quarkus.component.quartz.it;
 
 import io.quarkus.test.junit.QuarkusTest;
 import io.restassured.RestAssured;
+import org.junit.jupiter.api.Test;
 import org.junit.jupiter.params.ParameterizedTest;
 import org.junit.jupiter.params.provider.ValueSource;
 
@@ -36,4 +37,79 @@ class QuartzTest {
                 .statusCode(200)
                 .body(is("Hello Camel Quarkus " + component));
     }
+
+    @Test
+    public void testProperties() {
+        RestAssured.given()
+                .queryParam("fromEndpoint", "quartz-properties")
+                .queryParam("componentName", "quartzFromProperties")
+                .get("/quartz/getNameAndResult")
+                .then()
+                .statusCode(200)
+                .body("name", is("MyScheduler-"),
+                        "result", is("Hello Camel Quarkus Quartz Properties"));
+    }
+
+    @Test
+    public void testCronTrigger() {
+        RestAssured.given()
+                .queryParam("fromEndpoint", "quartz-cron-trigger")
+                .get("/quartz/get")
+                .then()
+                .statusCode(200)
+                .body(is("Hello Camel Quarkus Quartz From Cron Trigger"));
+
+    }
+
+    @Test
+    public void testHeaders() {
+        RestAssured.given()
+                .queryParam("fromEndpoint", "quartz")
+                .get("/quartz/getHeaders")
+                .then()
+                .statusCode(200)
+                .body("triggerName", is("1 * * * * "));
+    }
+
+    @Test
+    public void testMisfire() {
+        RestAssured.given()
+                .queryParam("fromEndpoint", "quartz-cron-misfire")
+                .get("/quartz/getMisfire")
+                .then()
+                .statusCode(200)
+                .body("timezone", is("Europe/Stockholm"),
+                        "misfire", is("2"));
+    }
+
+    @Test
+    public void testClustered() throws InterruptedException {
+        RestAssured.given()
+                .queryParam("fromEndpoint", "quartz-nodeA")
+                .get("/quartz/get")
+                .then()
+                .statusCode(200)
+                .body(is("Hello Camel Quarkus Quartz NodeA"));
+    }
+
+    @Test
+    public void testClusteredWithNamedDS() throws InterruptedException {
+        RestAssured.given()
+                .queryParam("fromEndpoint", "quartz-nodeB")
+                .get("/quartz/get")
+                .then()
+                .statusCode(200)
+                .body(is("Hello Camel Quarkus Quartz NodeB"));
+    }
+
+    @Test
+    public void testClusteredWithoutDS() throws InterruptedException {
+        //NodeB uses h2 db, which is not initialized therefore no message will be received
+        RestAssured.given()
+                .queryParam("fromEndpoint", "quartz-nodeC")
+                .get("/quartz/get")
+                .then()
+                .statusCode(200)
+                .body(is("Hello Camel Quarkus Quartz NodeC"));
+    }
 }
diff --git a/pom.xml b/pom.xml
index 82afbdb..ca7873c 100644
--- a/pom.xml
+++ b/pom.xml
@@ -72,6 +72,7 @@
         <azure-core.version>1.21.0</azure-core.version><!-- @sync com.azure:azure-sdk-bom:${azure-sdk-bom.version} dep:com.azure:azure-core -->
         <azure-core-test.version>1.7.3</azure-core-test.version>
         <bouncycastle.version>1.70</bouncycastle.version><!-- @sync io.quarkus:quarkus-bom:${quarkus.version} dep:org.bouncycastle:bcprov-jdk15on -->
+        <c3p0.version>${c3p0-version}</c3p0.version>
         <commons-beanutils.version>${commons-beanutils-version}</commons-beanutils.version>
         <commons-cli.version>1.4</commons-cli.version><!-- keep in sync with Quarkus, via quarkus-bootstrap-core -->
         <commons-collections.version>3.2.2</commons-collections.version><!-- used by hbase, should be pretty stable as commons-collections are not developed actively anymore -->
diff --git a/poms/bom/pom.xml b/poms/bom/pom.xml
index eead88e..dca66b4 100644
--- a/poms/bom/pom.xml
+++ b/poms/bom/pom.xml
@@ -6243,6 +6243,11 @@
                 <version>${zxing.version}</version>
             </dependency>
             <dependency>
+                <groupId>com.mchange</groupId>
+                <artifactId>c3p0</artifactId>
+                <version>${c3p0.version}</version>
+            </dependency>
+            <dependency>
                 <groupId>com.orbitz.consul</groupId>
                 <artifactId>consul-client</artifactId>
                 <version>${consul-client.version}</version>

[camel-quarkus] 02/08: Test for Debezium mysql - passing additionalProperties results in wrong properties beeing passed #3488

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit 3699da4a644c1edeade0070d76a249f29e863677
Author: JiriOndrusek <on...@gmail.com>
AuthorDate: Mon Feb 21 15:51:05 2022 +0100

    Test for Debezium mysql - passing additionalProperties results in wrong properties beeing passed #3488
---
 .../common/it/AbstractDebeziumResource.java        | 29 +++++++++++++++++++++-
 .../common/it/postgres/DebeziumPostgresTest.java   | 15 +++++++++++
 2 files changed, 43 insertions(+), 1 deletion(-)

diff --git a/integration-tests/debezium/src/main/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumResource.java b/integration-tests/debezium/src/main/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumResource.java
index ff49301..0e74a9b 100644
--- a/integration-tests/debezium/src/main/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumResource.java
+++ b/integration-tests/debezium/src/main/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumResource.java
@@ -16,11 +16,20 @@
  */
 package org.apache.camel.quarkus.component.debezium.common.it;
 
+import java.util.Map;
+import java.util.stream.Collectors;
+
 import javax.inject.Inject;
+import javax.ws.rs.GET;
+import javax.ws.rs.Path;
+import javax.ws.rs.Produces;
+import javax.ws.rs.core.MediaType;
 
+import org.apache.camel.CamelContext;
 import org.apache.camel.ConsumerTemplate;
 import org.apache.camel.Exchange;
 import org.apache.camel.component.debezium.DebeziumConstants;
+import org.apache.camel.component.debezium.DebeziumEndpoint;
 import org.eclipse.microprofile.config.Config;
 import org.eclipse.microprofile.config.inject.ConfigProperty;
 
@@ -41,10 +50,23 @@ public abstract class AbstractDebeziumResource {
     @Inject
     Config config;
 
+    @Inject
+    CamelContext camelContext;
+
     public AbstractDebeziumResource(Type type) {
         this.type = type;
     }
 
+    @Path("/getAdditionalProperties")
+    @GET
+    @Produces(MediaType.APPLICATION_JSON)
+    public Map<String, String> getAdditionalProperties() {
+        DebeziumEndpoint endpoint = (DebeziumEndpoint) camelContext.getEndpoint(getEndpointUrl()
+                + "&additionalProperties.database.connectionTimeZone=CET");
+        return endpoint.getConfiguration().getAdditionalProperties().entrySet().stream()
+                .collect(Collectors.toMap(Map.Entry::getKey, e -> (String) e.getValue()));
+    }
+
     String getEndpoinUrl(String hostname, String port, String username, String password, String databaseServerName,
             String offsetStorageFileName) {
         return type.getComponent() + ":localhost?"
@@ -90,6 +112,11 @@ public abstract class AbstractDebeziumResource {
     }
 
     private Exchange receiveAsExchange() {
+        String endpoint = getEndpointUrl();
+        return consumerTemplate.receive(endpoint, TIMEOUT);
+    }
+
+    protected String getEndpointUrl() {
         String endpoint = getEndpoinUrl(
                 config.getValue(type.getPropertyHostname(), String.class),
                 config.getValue(type.getPropertyPort(), String.class),
@@ -97,6 +124,6 @@ public abstract class AbstractDebeziumResource {
                 config.getValue(type.getPropertyPassword(), String.class),
                 "qa",
                 config.getValue(type.getPropertyOffsetFileName(), String.class));
-        return consumerTemplate.receive(endpoint, TIMEOUT);
+        return endpoint;
     }
 }
diff --git a/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/postgres/DebeziumPostgresTest.java b/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/postgres/DebeziumPostgresTest.java
index c610735..4a7148a 100644
--- a/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/postgres/DebeziumPostgresTest.java
+++ b/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/postgres/DebeziumPostgresTest.java
@@ -22,6 +22,7 @@ import java.sql.SQLException;
 
 import io.quarkus.test.common.QuarkusTestResource;
 import io.quarkus.test.junit.QuarkusTest;
+import io.restassured.RestAssured;
 import org.apache.camel.quarkus.component.debezium.common.it.AbstractDebeziumTest;
 import org.apache.camel.quarkus.component.debezium.common.it.Type;
 import org.eclipse.microprofile.config.Config;
@@ -30,8 +31,12 @@ import org.jboss.logging.Logger;
 import org.junit.jupiter.api.AfterAll;
 import org.junit.jupiter.api.BeforeAll;
 import org.junit.jupiter.api.MethodOrderer;
+import org.junit.jupiter.api.Order;
+import org.junit.jupiter.api.Test;
 import org.junit.jupiter.api.TestMethodOrder;
 
+import static org.hamcrest.Matchers.is;
+
 @QuarkusTest
 @QuarkusTestResource(DebeziumPostgresTestResource.class)
 @TestMethodOrder(MethodOrderer.OrderAnnotation.class)
@@ -51,6 +56,16 @@ class DebeziumPostgresTest extends AbstractDebeziumTest {
         connection = DriverManager.getConnection(jdbcUrl);
     }
 
+    @Test
+    @Order(4)
+    public void testAdditionalProperty() {
+        //https://github.com/apache/camel-quarkus/issues/3488
+        RestAssured.get(Type.postgres.getComponent() + "/getAdditionalProperties")
+                .then()
+                .statusCode(200)
+                .body("'database.connectionTimeZone'", is("CET"));
+    }
+
     @AfterAll
     public static void cleanUp() throws SQLException {
         if (connection != null) {

[camel-quarkus] 07/08: Temporarilly disable Aws2KinesisTest.kinesis due to #3638

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit e12983982ddcd9e58baf051bcd48fbc994d1b487
Author: James Netherton <ja...@gmail.com>
AuthorDate: Fri Mar 18 12:22:02 2022 +0000

    Temporarilly disable Aws2KinesisTest.kinesis due to #3638
---
 .../apache/camel/quarkus/component/aws2/kinesis/it/Aws2KinesisTest.java | 2 ++
 1 file changed, 2 insertions(+)

diff --git a/integration-test-groups/aws2/aws2-kinesis/src/test/java/org/apache/camel/quarkus/component/aws2/kinesis/it/Aws2KinesisTest.java b/integration-test-groups/aws2/aws2-kinesis/src/test/java/org/apache/camel/quarkus/component/aws2/kinesis/it/Aws2KinesisTest.java
index cfc8a43..e35ca1c 100644
--- a/integration-test-groups/aws2/aws2-kinesis/src/test/java/org/apache/camel/quarkus/component/aws2/kinesis/it/Aws2KinesisTest.java
+++ b/integration-test-groups/aws2/aws2-kinesis/src/test/java/org/apache/camel/quarkus/component/aws2/kinesis/it/Aws2KinesisTest.java
@@ -32,6 +32,7 @@ import org.eclipse.microprofile.config.Config;
 import org.eclipse.microprofile.config.ConfigProvider;
 import org.hamcrest.Matchers;
 import org.jboss.logging.Logger;
+import org.junit.jupiter.api.Disabled;
 import org.junit.jupiter.api.Test;
 import org.testcontainers.containers.localstack.LocalStackContainer.Service;
 import software.amazon.awssdk.core.ResponseInputStream;
@@ -51,6 +52,7 @@ class Aws2KinesisTest {
     @Aws2Client(Service.S3)
     S3Client client;
 
+    @Disabled("https://github.com/apache/camel-quarkus/issues/3638")
     @Test
     public void kinesis() {
         final String msg = "kinesis-" + java.util.UUID.randomUUID().toString().replace("-", "");

[camel-quarkus] 01/08: Upgrade Camel to 3.16.0

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit 12a983de6d658bafbfdca77e31e794b3518f4e66
Author: James Netherton <ja...@gmail.com>
AuthorDate: Wed Feb 9 11:13:37 2022 +0000

    Upgrade Camel to 3.16.0
---
 docs/antora.yml                                    |  6 +-
 .../examples/components/elasticsearch-rest.yml     |  2 +-
 docs/modules/ROOT/examples/dataformats/ical.yml    |  2 +-
 .../ROOT/examples/dataformats/jacksonXml.yml       |  2 +-
 docs/modules/ROOT/pages/migration-guide/2.8.0.adoc |  2 +-
 .../reference/extensions/elasticsearch-rest.adoc   |  6 +-
 .../ROOT/pages/reference/extensions/fhir.adoc      |  2 +-
 .../ROOT/pages/reference/extensions/ical.adoc      |  4 +-
 .../pages/reference/extensions/jacksonxml.adoc     |  4 +-
 .../ROOT/pages/reference/extensions/yaml-dsl.adoc  |  6 --
 .../pages/user-guide/defining-camel-routes.adoc    |  6 +-
 .../main/resources/META-INF/quarkus-extension.yaml |  1 +
 .../camel/quarkus/component/fhir/FhirConfig.java   |  2 +-
 .../camel/quarkus/component/fhir/FhirFlags.java    |  2 +-
 .../main/resources/META-INF/quarkus-extension.yaml |  2 +-
 .../main/resources/META-INF/quarkus-extension.yaml |  2 +-
 .../deployment/MicroProfileHealthProcessor.java    |  5 --
 .../MicroProfileHealthCamelChecksDisabledTest.java |  6 +-
 extensions/openapi-java/deployment/pom.xml         |  5 ++
 .../openapi/java/deployment/RESTOpenAPITest.java   |  4 +-
 .../openapi/java/deployment/RestRoutes.java        |  7 +-
 .../src/test/resources/application.properties      |  2 +-
 .../resources/routes/{my-route.xml => rests.xml}   |  4 +-
 .../resources/routes/{my-route.xml => routes.xml}  | 16 ++--
 .../src/main/resources/application.properties      |  2 +-
 .../component/stream/it/StreamResource.java        |  2 +-
 .../quarkus/component/stream/it/StreamTest.java    |  2 +-
 integration-tests/google-storage/pom.xml           |  5 ++
 .../storage/it/GoogleStorageTestResource.java      | 13 +--
 .../quarkus/component/kafka/CamelKafkaRoutes.java  |  2 +-
 .../src/main/resources/rests/my-rests.xml          |  8 +-
 .../src/main/resources/routes/my-routes.xml        |  7 ++
 .../src/main/resources/rests/my-rests.xml          |  8 +-
 .../src/main/resources/routes/my-routes.xml        |  7 ++
 .../camel/quarkus/main/CoreMainXmlJaxbTest.java    |  2 +-
 .../src/main/resources/routes/my-rests.yaml        |  6 +-
 .../it/health/CustomHealthCheckRepository.java     | 17 ----
 .../microprofile/it/health/FailingHealthCheck.java |  2 +-
 .../it/health/FailureThresholdHealthCheck.java     | 51 ------------
 .../it/health/MicroProfileHealthResource.java      | 17 +---
 .../src/main/resources/application.properties      |  7 +-
 .../it/health/MicroProfileHealthTest.java          | 67 ----------------
 .../component/openapijava/it/OpenApiRoutes.java    | 44 ++++------
 .../openapijava/it/common/OpenApiTest.java         |  4 +-
 integration-tests/platform-http/pom.xml            | 17 ++++
 .../platform/http/it/PlatformHttpRouteBuilder.java | 18 ++---
 .../component/http/server/it/PlatformHttpTest.java |  4 +-
 integration-tests/rest/pom.xml                     | 17 ++++
 .../quarkus/component/rest/it/RestRoutes.java      | 93 +++++++++++-----------
 integration-tests/servlet/pom.xml                  | 21 ++++-
 .../quarkus/component/servlet/CamelRoute.java      | 19 +++--
 pom.xml                                            |  8 +-
 52 files changed, 233 insertions(+), 337 deletions(-)

diff --git a/docs/antora.yml b/docs/antora.yml
index e4edba8..ea53a51 100644
--- a/docs/antora.yml
+++ b/docs/antora.yml
@@ -29,11 +29,11 @@ asciidoc:
 
     min-maven-version: 3.8.1 # replace ${min-maven-version}
     target-maven-version: 3.8.4 # replace ${target-maven-version}
-    camel-version: 3.15.0 # replace ${camel.version}
-    camel-docs-version: 3.15.x # replace ${camel.docs.components.version}
+    camel-version: 3.16.0-SNAPSHOT # replace ${camel.version}
+    camel-docs-version: 3.16.x # replace ${camel.docs.components.version}
     quarkus-version: 2.7.5.Final # replace ${quarkus.version}
     graalvm-version: 21.3.1 # replace ${graalvm.version}
     graalvm-docs-version: 21.3
     # attributes used in xrefs to other Antora components
-    cq-camel-components: 3.15.x@components # replace ${camel.docs.components.xref}
+    cq-camel-components: 3.16.x@components # replace ${camel.docs.components.xref}
     quarkus-examples-version: latest
diff --git a/docs/modules/ROOT/examples/components/elasticsearch-rest.yml b/docs/modules/ROOT/examples/components/elasticsearch-rest.yml
index 9532a39..e00e4ff 100644
--- a/docs/modules/ROOT/examples/components/elasticsearch-rest.yml
+++ b/docs/modules/ROOT/examples/components/elasticsearch-rest.yml
@@ -4,7 +4,7 @@ cqArtifactId: camel-quarkus-elasticsearch-rest
 cqArtifactIdBase: elasticsearch-rest
 cqNativeSupported: true
 cqStatus: Stable
-cqDeprecated: false
+cqDeprecated: true
 cqJvmSince: 1.0.0
 cqNativeSince: 1.0.0
 cqCamelPartName: elasticsearch-rest
diff --git a/docs/modules/ROOT/examples/dataformats/ical.yml b/docs/modules/ROOT/examples/dataformats/ical.yml
index 7948fe2..0c483ec 100644
--- a/docs/modules/ROOT/examples/dataformats/ical.yml
+++ b/docs/modules/ROOT/examples/dataformats/ical.yml
@@ -9,5 +9,5 @@ cqJvmSince: 1.0.0
 cqNativeSince: 1.0.0
 cqCamelPartName: ical
 cqCamelPartTitle: iCal
-cqCamelPartDescription: Marshal and unmarshal iCal (.ics) documents to/from model objects provided by the iCal4j library.
+cqCamelPartDescription: Marshal and unmarshal iCal (.ics) documents to/from model objects.
 cqExtensionPageTitle: iCal
diff --git a/docs/modules/ROOT/examples/dataformats/jacksonXml.yml b/docs/modules/ROOT/examples/dataformats/jacksonXml.yml
index b1fe57a..e29c70e 100644
--- a/docs/modules/ROOT/examples/dataformats/jacksonXml.yml
+++ b/docs/modules/ROOT/examples/dataformats/jacksonXml.yml
@@ -9,5 +9,5 @@ cqJvmSince: 1.0.0
 cqNativeSince: 1.0.0
 cqCamelPartName: jacksonXml
 cqCamelPartTitle: Jackson XML
-cqCamelPartDescription: Unmarshal a XML payloads to POJOs and back using XMLMapper extension of Jackson.
+cqCamelPartDescription: Unmarshal an XML payloads to POJOs and back using XMLMapper extension of Jackson.
 cqExtensionPageTitle: JacksonXML
diff --git a/docs/modules/ROOT/pages/migration-guide/2.8.0.adoc b/docs/modules/ROOT/pages/migration-guide/2.8.0.adoc
index 20a7f0c..bce307d 100644
--- a/docs/modules/ROOT/pages/migration-guide/2.8.0.adoc
+++ b/docs/modules/ROOT/pages/migration-guide/2.8.0.adoc
@@ -6,7 +6,7 @@ The following guide outlines how to adapt your code to changes that were made in
 
 In previous releases, the FHIR extension default was to enable support for all FHIR versions.
 
-This has now changed. Only the FHIR versions that the Camel FHIR component and DataFormat use by default are enabled (R4 & DSTU3).  
+This has now changed. Only the FHIR version that the Camel FHIR component and DataFormat use by default are enabled (R4).
 
 To enable or disable support for the various FHIR versions, you can add some configuration properties to `application.properties`. For example.
 
diff --git a/docs/modules/ROOT/pages/reference/extensions/elasticsearch-rest.adoc b/docs/modules/ROOT/pages/reference/extensions/elasticsearch-rest.adoc
index 6a26f46..412c4dc 100644
--- a/docs/modules/ROOT/pages/reference/extensions/elasticsearch-rest.adoc
+++ b/docs/modules/ROOT/pages/reference/extensions/elasticsearch-rest.adoc
@@ -6,14 +6,14 @@
 :cq-artifact-id: camel-quarkus-elasticsearch-rest
 :cq-native-supported: true
 :cq-status: Stable
-:cq-status-deprecation: Stable
+:cq-status-deprecation: Stable Deprecated
 :cq-description: Send requests to ElasticSearch via REST API
-:cq-deprecated: false
+:cq-deprecated: true
 :cq-jvm-since: 1.0.0
 :cq-native-since: 1.0.0
 
 [.badges]
-[.badge-key]##JVM since##[.badge-supported]##1.0.0## [.badge-key]##Native since##[.badge-supported]##1.0.0##
+[.badge-key]##JVM since##[.badge-supported]##1.0.0## [.badge-key]##Native since##[.badge-supported]##1.0.0## [.badge-key]##⚠️##[.badge-unsupported]##Deprecated##
 
 Send requests to ElasticSearch via REST API
 
diff --git a/docs/modules/ROOT/pages/reference/extensions/fhir.adoc b/docs/modules/ROOT/pages/reference/extensions/fhir.adoc
index fbd613d..3dbe816 100644
--- a/docs/modules/ROOT/pages/reference/extensions/fhir.adoc
+++ b/docs/modules/ROOT/pages/reference/extensions/fhir.adoc
@@ -80,7 +80,7 @@ Enable FHIR DSTU2_1 Specs in native mode.
 
 Enable FHIR DSTU3 Specs in native mode.
 | `boolean`
-| `true`
+| `false`
 
 |icon:lock[title=Fixed at build time] [[quarkus.camel.fhir.enable-r4]]`link:#quarkus.camel.fhir.enable-r4[quarkus.camel.fhir.enable-r4]`
 
diff --git a/docs/modules/ROOT/pages/reference/extensions/ical.adoc b/docs/modules/ROOT/pages/reference/extensions/ical.adoc
index cf8b0b3..2b686a5 100644
--- a/docs/modules/ROOT/pages/reference/extensions/ical.adoc
+++ b/docs/modules/ROOT/pages/reference/extensions/ical.adoc
@@ -7,7 +7,7 @@
 :cq-native-supported: true
 :cq-status: Stable
 :cq-status-deprecation: Stable
-:cq-description: Marshal and unmarshal iCal (.ics) documents to/from model objects provided by the iCal4j library.
+:cq-description: Marshal and unmarshal iCal (.ics) documents to/from model objects.
 :cq-deprecated: false
 :cq-jvm-since: 1.0.0
 :cq-native-since: 1.0.0
@@ -15,7 +15,7 @@
 [.badges]
 [.badge-key]##JVM since##[.badge-supported]##1.0.0## [.badge-key]##Native since##[.badge-supported]##1.0.0##
 
-Marshal and unmarshal iCal (.ics) documents to/from model objects provided by the iCal4j library.
+Marshal and unmarshal iCal (.ics) documents to/from model objects.
 
 == What's inside
 
diff --git a/docs/modules/ROOT/pages/reference/extensions/jacksonxml.adoc b/docs/modules/ROOT/pages/reference/extensions/jacksonxml.adoc
index 89f5df0..407a22d 100644
--- a/docs/modules/ROOT/pages/reference/extensions/jacksonxml.adoc
+++ b/docs/modules/ROOT/pages/reference/extensions/jacksonxml.adoc
@@ -7,7 +7,7 @@
 :cq-native-supported: true
 :cq-status: Stable
 :cq-status-deprecation: Stable
-:cq-description: Unmarshal a XML payloads to POJOs and back using XMLMapper extension of Jackson.
+:cq-description: Unmarshal an XML payloads to POJOs and back using XMLMapper extension of Jackson.
 :cq-deprecated: false
 :cq-jvm-since: 1.0.0
 :cq-native-since: 1.0.0
@@ -15,7 +15,7 @@
 [.badges]
 [.badge-key]##JVM since##[.badge-supported]##1.0.0## [.badge-key]##Native since##[.badge-supported]##1.0.0##
 
-Unmarshal a XML payloads to POJOs and back using XMLMapper extension of Jackson.
+Unmarshal an XML payloads to POJOs and back using XMLMapper extension of Jackson.
 
 == What's inside
 
diff --git a/docs/modules/ROOT/pages/reference/extensions/yaml-dsl.adoc b/docs/modules/ROOT/pages/reference/extensions/yaml-dsl.adoc
index bdde5d3..26484a9 100644
--- a/docs/modules/ROOT/pages/reference/extensions/yaml-dsl.adoc
+++ b/docs/modules/ROOT/pages/reference/extensions/yaml-dsl.adoc
@@ -16,12 +16,6 @@
 
 An YAML stack for parsing YAML route definitions
 
-== What's inside
-
-* xref:{cq-camel-components}:others:yaml-dsl.adoc[YAML DSL]
-
-Please refer to the above link for usage and configuration details.
-
 == Maven coordinates
 
 https://code.quarkus.io/?extension-search=camel-quarkus-yaml-dsl[Create a new project with this extension on code.quarkus.io, window="_blank"]
diff --git a/docs/modules/ROOT/pages/user-guide/defining-camel-routes.adoc b/docs/modules/ROOT/pages/user-guide/defining-camel-routes.adoc
index 9ae1eaa..fc5b912 100644
--- a/docs/modules/ROOT/pages/user-guide/defining-camel-routes.adoc
+++ b/docs/modules/ROOT/pages/user-guide/defining-camel-routes.adoc
@@ -96,10 +96,8 @@ The route XML should be in the simplified version like:
 ----
 <rests xmlns="http://camel.apache.org/schema/spring">
     <rest id="greeting" path="/greeting">
-        <get uri="/hello">
-            <setBody>
-                <constant>Hello World!</constant>
-            </setBody>
+        <get path="/hello">
+            <to uri="direct:greet"/>
         </get>
     </rest>
 </rests>
diff --git a/extensions/elasticsearch-rest/runtime/src/main/resources/META-INF/quarkus-extension.yaml b/extensions/elasticsearch-rest/runtime/src/main/resources/META-INF/quarkus-extension.yaml
index a27a504..f0b2b27 100644
--- a/extensions/elasticsearch-rest/runtime/src/main/resources/META-INF/quarkus-extension.yaml
+++ b/extensions/elasticsearch-rest/runtime/src/main/resources/META-INF/quarkus-extension.yaml
@@ -29,3 +29,4 @@ metadata:
   - "integration"
   status:
   - "stable"
+  - "deprecated"
\ No newline at end of file
diff --git a/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirConfig.java b/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirConfig.java
index b6aedc0..da85282 100644
--- a/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirConfig.java
+++ b/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirConfig.java
@@ -44,7 +44,7 @@ public final class FhirConfig {
     /**
      * Enable FHIR DSTU3 Specs in native mode.
      */
-    @ConfigItem(name = "enable-dstu3", defaultValue = "true")
+    @ConfigItem(name = "enable-dstu3", defaultValue = "false")
     public boolean enableDstu3;
 
     /**
diff --git a/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirFlags.java b/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirFlags.java
index 8f75a99..6437e8e 100644
--- a/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirFlags.java
+++ b/extensions/fhir/runtime/src/main/java/org/apache/camel/quarkus/component/fhir/FhirFlags.java
@@ -52,7 +52,7 @@ public final class FhirFlags {
         @Override
         public boolean getAsBoolean() {
             return ConfigProvider.getConfig().getOptionalValue("quarkus.camel.fhir.enable-dstu3", Boolean.class)
-                    .orElse(Boolean.TRUE);
+                    .orElse(Boolean.FALSE);
         }
     }
 
diff --git a/extensions/ical/runtime/src/main/resources/META-INF/quarkus-extension.yaml b/extensions/ical/runtime/src/main/resources/META-INF/quarkus-extension.yaml
index ba17ff6..62e12b7 100644
--- a/extensions/ical/runtime/src/main/resources/META-INF/quarkus-extension.yaml
+++ b/extensions/ical/runtime/src/main/resources/META-INF/quarkus-extension.yaml
@@ -22,7 +22,7 @@
 #
 ---
 name: "Camel iCal"
-description: "Marshal and unmarshal iCal (.ics) documents to/from model objects provided by the iCal4j library"
+description: "Marshal and unmarshal iCal (.ics) documents to/from model objects"
 metadata:
   guide: "https://camel.apache.org/camel-quarkus/latest/reference/extensions/ical.html"
   categories:
diff --git a/extensions/jacksonxml/runtime/src/main/resources/META-INF/quarkus-extension.yaml b/extensions/jacksonxml/runtime/src/main/resources/META-INF/quarkus-extension.yaml
index 597f13c..d2a4094 100644
--- a/extensions/jacksonxml/runtime/src/main/resources/META-INF/quarkus-extension.yaml
+++ b/extensions/jacksonxml/runtime/src/main/resources/META-INF/quarkus-extension.yaml
@@ -22,7 +22,7 @@
 #
 ---
 name: "Camel JacksonXML"
-description: "Unmarshal a XML payloads to POJOs and back using XMLMapper extension of Jackson"
+description: "Unmarshal an XML payloads to POJOs and back using XMLMapper extension of Jackson"
 metadata:
   guide: "https://camel.apache.org/camel-quarkus/latest/reference/extensions/jacksonxml.html"
   categories:
diff --git a/extensions/microprofile-health/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthProcessor.java b/extensions/microprofile-health/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthProcessor.java
index 6ea3406..e5a3b9e 100644
--- a/extensions/microprofile-health/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthProcessor.java
+++ b/extensions/microprofile-health/deployment/src/main/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthProcessor.java
@@ -32,7 +32,6 @@ import org.apache.camel.health.HealthCheck;
 import org.apache.camel.health.HealthCheckRegistry;
 import org.apache.camel.health.HealthCheckRepository;
 import org.apache.camel.impl.health.ConsumersHealthCheckRepository;
-import org.apache.camel.impl.health.ContextHealthCheck;
 import org.apache.camel.impl.health.HealthCheckRegistryRepository;
 import org.apache.camel.impl.health.RoutesHealthCheckRepository;
 import org.apache.camel.quarkus.component.microprofile.health.runtime.CamelMicroProfileHealthConfig;
@@ -118,10 +117,6 @@ class MicroProfileHealthProcessor {
                 return false;
             }
 
-            if (className.equals(ContextHealthCheck.class.getName())) {
-                return config.getOptionalValue("camel.health.contextEnabled", boolean.class).orElse(true);
-            }
-
             if (className.equals(RoutesHealthCheckRepository.class.getName())) {
                 return config.getOptionalValue("camel.health.routesEnabled", boolean.class).orElse(true);
             }
diff --git a/extensions/microprofile-health/deployment/src/test/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthCamelChecksDisabledTest.java b/extensions/microprofile-health/deployment/src/test/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthCamelChecksDisabledTest.java
index 16e194a5..3e8b6df 100644
--- a/extensions/microprofile-health/deployment/src/test/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthCamelChecksDisabledTest.java
+++ b/extensions/microprofile-health/deployment/src/test/java/org/apache/camel/quarkus/component/microprofile/health/deployment/MicroProfileHealthCamelChecksDisabledTest.java
@@ -37,6 +37,7 @@ import org.jboss.shrinkwrap.api.spec.JavaArchive;
 import org.junit.jupiter.api.Test;
 import org.junit.jupiter.api.extension.RegisterExtension;
 
+import static org.junit.jupiter.api.Assertions.assertNotNull;
 import static org.junit.jupiter.api.Assertions.assertNull;
 import static org.junit.jupiter.api.Assertions.assertTrue;
 
@@ -54,7 +55,6 @@ public class MicroProfileHealthCamelChecksDisabledTest {
         Writer writer = new StringWriter();
 
         Properties props = new Properties();
-        props.put("camel.health.contextEnabled", "false");
         props.put("camel.health.routesEnabled", "false");
         props.put("camel.health.consumersEnabled", "false");
         props.put("camel.health.registryEnabled", "false");
@@ -69,9 +69,9 @@ public class MicroProfileHealthCamelChecksDisabledTest {
     }
 
     @Test
-    public void contextHealthCheckNull() {
+    public void contextHealthCheckNotNull() {
         ContextHealthCheck contextHealthCheck = context.getRegistry().lookupByNameAndType("context", ContextHealthCheck.class);
-        assertNull(contextHealthCheck);
+        assertNotNull(contextHealthCheck);
     }
 
     @Test
diff --git a/extensions/openapi-java/deployment/pom.xml b/extensions/openapi-java/deployment/pom.xml
index 3ab740b..053ed8f 100644
--- a/extensions/openapi-java/deployment/pom.xml
+++ b/extensions/openapi-java/deployment/pom.xml
@@ -49,6 +49,11 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
+            <artifactId>camel-quarkus-direct</artifactId>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-rest</artifactId>
             <scope>test</scope>
         </dependency>
diff --git a/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RESTOpenAPITest.java b/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RESTOpenAPITest.java
index 7e75be4..0ee6b74 100644
--- a/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RESTOpenAPITest.java
+++ b/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RESTOpenAPITest.java
@@ -17,7 +17,6 @@
 
 package org.apache.camel.quarkus.component.openapi.java.deployment;
 
-import java.io.File;
 import java.util.Arrays;
 
 import io.quarkus.bootstrap.model.AppArtifact;
@@ -41,7 +40,8 @@ public class RESTOpenAPITest {
             .withConfigurationResource("application.properties")
             .setArchiveProducer(() -> ShrinkWrap.create(JavaArchive.class)
                     .addClasses(RestRoutes.class, QuarkusResource.class)
-                    .addAsResource(new File("src/test/resources/routes/my-route.xml"), "routes/my-route.xml"));
+                    .addAsResource("routes/rests.xml", "routes/rests.xml")
+                    .addAsResource("routes/routes.xml", "routes/routes.xml"));
 
     @BeforeAll
     static void setUp() {
diff --git a/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RestRoutes.java b/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RestRoutes.java
index a2b1e91..358df70 100644
--- a/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RestRoutes.java
+++ b/extensions/openapi-java/deployment/src/test/java/org/apache/camel/quarkus/component/openapi/java/deployment/RestRoutes.java
@@ -29,8 +29,9 @@ public class RestRoutes extends RouteBuilder {
                 .description("get test")
                 .id("get")
                 .produces("text/plain")
-                .route()
-                .setBody(constant("GET: /rest"))
-                .endRest();
+                .to("direct:output");
+
+        from("direct:output")
+                .setBody().constant("GET: /rest");
     }
 }
diff --git a/extensions/openapi-java/deployment/src/test/resources/application.properties b/extensions/openapi-java/deployment/src/test/resources/application.properties
index 685ea3f..a5d206d 100644
--- a/extensions/openapi-java/deployment/src/test/resources/application.properties
+++ b/extensions/openapi-java/deployment/src/test/resources/application.properties
@@ -23,4 +23,4 @@ quarkus.camel.openapi.expose.enabled=true
 # Camel - REST
 #
 camel.rest.context-path=/camel
-camel.main.routes-include-pattern=routes/my-route.xml
+camel.main.routes-include-pattern=routes/routes.xml,routes/rests.xml
diff --git a/extensions/openapi-java/deployment/src/test/resources/routes/my-route.xml b/extensions/openapi-java/deployment/src/test/resources/routes/rests.xml
similarity index 86%
copy from extensions/openapi-java/deployment/src/test/resources/routes/my-route.xml
copy to extensions/openapi-java/deployment/src/test/resources/routes/rests.xml
index f809a04..8c2e3c1 100644
--- a/extensions/openapi-java/deployment/src/test/resources/routes/my-route.xml
+++ b/extensions/openapi-java/deployment/src/test/resources/routes/rests.xml
@@ -16,10 +16,10 @@
     limitations under the License.
 
 -->
-<rests xmlns="http://camel.apache.org/schema/spring">
+<rests>
     <rest id="camel_xml_rest" path="/xml">
         <get>
-            <route><transform><constant>Camel XML Rest</constant></transform></route>
+            <to uri="direct:outputXML" />
         </get>
     </rest>
 </rests>
diff --git a/extensions/openapi-java/deployment/src/test/resources/routes/my-route.xml b/extensions/openapi-java/deployment/src/test/resources/routes/routes.xml
similarity index 77%
rename from extensions/openapi-java/deployment/src/test/resources/routes/my-route.xml
rename to extensions/openapi-java/deployment/src/test/resources/routes/routes.xml
index f809a04..53cf194 100644
--- a/extensions/openapi-java/deployment/src/test/resources/routes/my-route.xml
+++ b/extensions/openapi-java/deployment/src/test/resources/routes/routes.xml
@@ -16,10 +16,12 @@
     limitations under the License.
 
 -->
-<rests xmlns="http://camel.apache.org/schema/spring">
-    <rest id="camel_xml_rest" path="/xml">
-        <get>
-            <route><transform><constant>Camel XML Rest</constant></transform></route>
-        </get>
-    </rest>
-</rests>
+
+<routes xmlns="http://camel.apache.org/schema/spring">
+    <route>
+        <from uri="direct:outputXML"/>
+        <setBody>
+            <constant>Camel XML Rest</constant>
+        </setBody>
+    </route>
+</routes>
diff --git a/integration-test-groups/foundation/core-fault-tolerance/src/main/resources/application.properties b/integration-test-groups/foundation/core-fault-tolerance/src/main/resources/application.properties
index 82f317f..48c4c9b 100644
--- a/integration-test-groups/foundation/core-fault-tolerance/src/main/resources/application.properties
+++ b/integration-test-groups/foundation/core-fault-tolerance/src/main/resources/application.properties
@@ -17,7 +17,7 @@
 
 #
 # Camel
-camel.faulttolerance.circuitBreakerRef = customCircuitBreaker
+camel.faulttolerance.circuitBreaker = customCircuitBreaker
 camel.faulttolerance.delay = 15
 camel.faulttolerance.successThreshold = 4
 camel.faulttolerance.requestVolumeThreshold = 60
diff --git a/integration-test-groups/foundation/stream/src/main/java/org/apache/camel/quarkus/component/stream/it/StreamResource.java b/integration-test-groups/foundation/stream/src/main/java/org/apache/camel/quarkus/component/stream/it/StreamResource.java
index 24f6ea0..462bccc 100644
--- a/integration-test-groups/foundation/stream/src/main/java/org/apache/camel/quarkus/component/stream/it/StreamResource.java
+++ b/integration-test-groups/foundation/stream/src/main/java/org/apache/camel/quarkus/component/stream/it/StreamResource.java
@@ -42,7 +42,7 @@ public class StreamResource {
     public String greetingStream(String message) throws Exception {
         try (ByteArrayOutputStream stream = new ByteArrayOutputStream()) {
             producerTemplate.sendBodyAndHeader("stream:header", message.getBytes(), "stream", stream);
-            return "Hello " + stream.toString();
+            return "Hello " + stream;
         }
     }
 }
diff --git a/integration-test-groups/foundation/stream/src/test/java/org/apache/camel/quarkus/component/stream/it/StreamTest.java b/integration-test-groups/foundation/stream/src/test/java/org/apache/camel/quarkus/component/stream/it/StreamTest.java
index 374c3c7..b8b1ab9 100644
--- a/integration-test-groups/foundation/stream/src/test/java/org/apache/camel/quarkus/component/stream/it/StreamTest.java
+++ b/integration-test-groups/foundation/stream/src/test/java/org/apache/camel/quarkus/component/stream/it/StreamTest.java
@@ -33,6 +33,6 @@ class StreamTest {
                 .body("Camel Quarkus Stream")
                 .post("/stream/post")
                 .then().statusCode(200)
-                .body(is("Hello Camel Quarkus Stream"));
+                .body(is("Hello Camel Quarkus Stream" + System.lineSeparator()));
     }
 }
diff --git a/integration-tests/google-storage/pom.xml b/integration-tests/google-storage/pom.xml
index 383f1d0..7048f87 100644
--- a/integration-tests/google-storage/pom.xml
+++ b/integration-tests/google-storage/pom.xml
@@ -68,6 +68,11 @@
             <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-integration-test-support-mock-backend</artifactId>
         </dependency>
+        <dependency>
+            <groupId>org.apache.camel.quarkus</groupId>
+            <artifactId>camel-quarkus-integration-test-support</artifactId>
+            <scope>test</scope>
+        </dependency>
     </dependencies>
 
     <profiles>
diff --git a/integration-tests/google-storage/src/test/java/org/apache/camel/quarkus/component/google/storage/it/GoogleStorageTestResource.java b/integration-tests/google-storage/src/test/java/org/apache/camel/quarkus/component/google/storage/it/GoogleStorageTestResource.java
index 92c6cf5..234da5c 100644
--- a/integration-tests/google-storage/src/test/java/org/apache/camel/quarkus/component/google/storage/it/GoogleStorageTestResource.java
+++ b/integration-tests/google-storage/src/test/java/org/apache/camel/quarkus/component/google/storage/it/GoogleStorageTestResource.java
@@ -20,11 +20,13 @@ import java.util.HashMap;
 import java.util.Map;
 
 import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
+import org.apache.camel.quarkus.test.AvailablePortFinder;
+import org.testcontainers.containers.FixedHostPortGenericContainer;
 import org.testcontainers.containers.GenericContainer;
 
 public class GoogleStorageTestResource implements QuarkusTestResourceLifecycleManager {
 
-    public static final int PORT = 4443;
+    public static final int PORT = AvailablePortFinder.getNextAvailable();
     public static final String CONTAINER_NAME = "fsouza/fake-gcs-server";
 
     private GenericContainer<?> container;
@@ -35,14 +37,13 @@ public class GoogleStorageTestResource implements QuarkusTestResourceLifecycleMa
         Map<String, String> properties = new HashMap<>();
 
         if (GoogleStorageHelper.usingMockBackend()) {
-
-            container = new GenericContainer<>(CONTAINER_NAME)
-                    .withExposedPorts(PORT)
+            container = new FixedHostPortGenericContainer<>(CONTAINER_NAME)
+                    .withFixedExposedPort(PORT, PORT)
                     .withCreateContainerCmdModifier(
-                            it -> it.withEntrypoint("/bin/fake-gcs-server", "-scheme", "http"));
+                            it -> it.withEntrypoint("/bin/fake-gcs-server", "-scheme", "http", "-port", String.valueOf(PORT)));
             container.start();
 
-            properties.put(GoogleStorageResource.PARAM_PORT, container.getMappedPort(PORT).toString());
+            properties.put(GoogleStorageResource.PARAM_PORT, String.valueOf(PORT));
         }
 
         return properties;
diff --git a/integration-tests/kafka/src/main/java/org/apache/camel/quarkus/component/kafka/CamelKafkaRoutes.java b/integration-tests/kafka/src/main/java/org/apache/camel/quarkus/component/kafka/CamelKafkaRoutes.java
index e460fbc..381d825 100644
--- a/integration-tests/kafka/src/main/java/org/apache/camel/quarkus/component/kafka/CamelKafkaRoutes.java
+++ b/integration-tests/kafka/src/main/java/org/apache/camel/quarkus/component/kafka/CamelKafkaRoutes.java
@@ -61,7 +61,7 @@ public class CamelKafkaRoutes extends RouteBuilder {
 
         from("direct:idempotent")
                 .idempotentConsumer(header("id"))
-                .messageIdRepositoryRef("kafkaIdempotentRepository")
+                .idempotentRepository("kafkaIdempotentRepository")
                 .to("mock:idempotent-results")
                 .end();
 
diff --git a/integration-tests/main-xml-io/src/main/resources/rests/my-rests.xml b/integration-tests/main-xml-io/src/main/resources/rests/my-rests.xml
index fcbd834..24f641f 100644
--- a/integration-tests/main-xml-io/src/main/resources/rests/my-rests.xml
+++ b/integration-tests/main-xml-io/src/main/resources/rests/my-rests.xml
@@ -19,12 +19,8 @@
 -->
 <rests xmlns="http://camel.apache.org/schema/spring">
     <rest id="greet" path="/greeting">
-        <get uri="/hello">
-            <route id="rest-route">
-                <setBody>
-                    <constant>Hello World!</constant>
-                </setBody>
-            </route>
+        <get path="/hello">
+            <to uri="direct:greet"/>
         </get>
     </rest>
 </rests>
diff --git a/integration-tests/main-xml-io/src/main/resources/routes/my-routes.xml b/integration-tests/main-xml-io/src/main/resources/routes/my-routes.xml
index 48feb17..c367467 100644
--- a/integration-tests/main-xml-io/src/main/resources/routes/my-routes.xml
+++ b/integration-tests/main-xml-io/src/main/resources/routes/my-routes.xml
@@ -24,6 +24,13 @@
             http://camel.apache.org/schema/spring
             http://camel.apache.org/schema/spring/camel-spring.xsd">
 
+    <route id="rest-route">
+        <from uri="direct:greet"/>
+        <setBody>
+            <constant>Hello World!</constant>
+        </setBody>
+    </route>
+
     <route id="my-xml-route">
         <from uri="timer:from-xml?period=3000"/>
         <setBody>
diff --git a/integration-tests/main-xml-jaxb/src/main/resources/rests/my-rests.xml b/integration-tests/main-xml-jaxb/src/main/resources/rests/my-rests.xml
index fcbd834..24f641f 100644
--- a/integration-tests/main-xml-jaxb/src/main/resources/rests/my-rests.xml
+++ b/integration-tests/main-xml-jaxb/src/main/resources/rests/my-rests.xml
@@ -19,12 +19,8 @@
 -->
 <rests xmlns="http://camel.apache.org/schema/spring">
     <rest id="greet" path="/greeting">
-        <get uri="/hello">
-            <route id="rest-route">
-                <setBody>
-                    <constant>Hello World!</constant>
-                </setBody>
-            </route>
+        <get path="/hello">
+            <to uri="direct:greet"/>
         </get>
     </rest>
 </rests>
diff --git a/integration-tests/main-xml-jaxb/src/main/resources/routes/my-routes.xml b/integration-tests/main-xml-jaxb/src/main/resources/routes/my-routes.xml
index e491c29..c3763c0 100644
--- a/integration-tests/main-xml-jaxb/src/main/resources/routes/my-routes.xml
+++ b/integration-tests/main-xml-jaxb/src/main/resources/routes/my-routes.xml
@@ -23,6 +23,13 @@
             http://camel.apache.org/schema/spring
             http://camel.apache.org/schema/spring/camel-spring.xsd">
 
+    <route id="rest-route">
+        <from uri="direct:greet"/>
+        <setBody>
+            <constant>Hello World!</constant>
+        </setBody>
+    </route>
+
     <route id="my-xml-route">
         <from uri="timer:from-xml?period=3000"/>
         <setBody>
diff --git a/integration-tests/main-xml-jaxb/src/test/java/org/apache/camel/quarkus/main/CoreMainXmlJaxbTest.java b/integration-tests/main-xml-jaxb/src/test/java/org/apache/camel/quarkus/main/CoreMainXmlJaxbTest.java
index 6fbbfdc..89170e5 100644
--- a/integration-tests/main-xml-jaxb/src/test/java/org/apache/camel/quarkus/main/CoreMainXmlJaxbTest.java
+++ b/integration-tests/main-xml-jaxb/src/test/java/org/apache/camel/quarkus/main/CoreMainXmlJaxbTest.java
@@ -80,7 +80,7 @@ public class CoreMainXmlJaxbTest {
 
     private boolean logContainsDumpedRoutes(String log) {
         return log.contains("<route customId=\"true\" id=\"my-xml-route\">") &&
-                log.contains("<route customId=\"true\" id=\"rest-route\" rest=\"true\">") &&
+                log.contains("<route customId=\"true\" id=\"rest-route\">") &&
                 log.contains("<rest customId=\"true\" id=\"greet\" path=\"/greeting\">") &&
                 log.contains("<routeTemplate customId=\"true\" id=\"myTemplate\">");
     }
diff --git a/integration-tests/main-yaml/src/main/resources/routes/my-rests.yaml b/integration-tests/main-yaml/src/main/resources/routes/my-rests.yaml
index fd1f1b6..b248831 100644
--- a/integration-tests/main-yaml/src/main/resources/routes/my-rests.yaml
+++ b/integration-tests/main-yaml/src/main/resources/routes/my-rests.yaml
@@ -16,10 +16,10 @@
 #
 
 - rest:
-    path: "/greeting"
-    verb:
-      - method: "get"
+    get:
+      - path: "/greeting"
         to: "direct:rest"
+
 - route:
     id: "rest-route"
     from:
diff --git a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/CustomHealthCheckRepository.java b/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/CustomHealthCheckRepository.java
index c54665d..2d31330 100644
--- a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/CustomHealthCheckRepository.java
+++ b/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/CustomHealthCheckRepository.java
@@ -16,12 +16,10 @@
  */
 package org.apache.camel.quarkus.component.microprofile.it.health;
 
-import java.util.Collections;
 import java.util.Map;
 import java.util.stream.Stream;
 
 import org.apache.camel.health.HealthCheck;
-import org.apache.camel.health.HealthCheckConfiguration;
 import org.apache.camel.health.HealthCheckRepository;
 import org.apache.camel.health.HealthCheckResultBuilder;
 import org.apache.camel.impl.health.AbstractHealthCheck;
@@ -44,21 +42,6 @@ public class CustomHealthCheckRepository implements HealthCheckRepository {
     }
 
     @Override
-    public void setConfigurations(Map<String, HealthCheckConfiguration> configurations) {
-        // Noop
-    }
-
-    @Override
-    public Map<String, HealthCheckConfiguration> getConfigurations() {
-        return Collections.emptyMap();
-    }
-
-    @Override
-    public void addConfiguration(String id, HealthCheckConfiguration configuration) {
-        // Noop
-    }
-
-    @Override
     public Stream<HealthCheck> stream() {
         return Stream.of(check);
     }
diff --git a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/FailingHealthCheck.java b/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/FailingHealthCheck.java
index 2d56d54..b278052 100644
--- a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/FailingHealthCheck.java
+++ b/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/FailingHealthCheck.java
@@ -25,7 +25,7 @@ public class FailingHealthCheck extends AbstractHealthCheck {
 
     public FailingHealthCheck() {
         super("failing-check");
-        getConfiguration().setEnabled(false);
+        setEnabled(false);
     }
 
     @Override
diff --git a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/FailureThresholdHealthCheck.java b/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/FailureThresholdHealthCheck.java
deleted file mode 100644
index 6fbcb6e..0000000
--- a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/FailureThresholdHealthCheck.java
+++ /dev/null
@@ -1,51 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.camel.quarkus.component.microprofile.it.health;
-
-import java.util.Map;
-
-import org.apache.camel.health.HealthCheckResultBuilder;
-import org.apache.camel.impl.health.AbstractHealthCheck;
-
-public final class FailureThresholdHealthCheck extends AbstractHealthCheck {
-
-    private boolean returnStatusUp = false;
-
-    public FailureThresholdHealthCheck() {
-        super("failure-threshold", "failure-threshold");
-        getConfiguration().setEnabled(false);
-        getConfiguration().setFailureThreshold(2);
-        getConfiguration().setInterval(500);
-    }
-
-    @Override
-    protected void doCall(HealthCheckResultBuilder builder, Map<String, Object> options) {
-        if (isReturnStatusUp()) {
-            builder.up();
-        } else {
-            builder.down();
-        }
-    }
-
-    public void setReturnStatusUp(boolean returnStatusUp) {
-        this.returnStatusUp = returnStatusUp;
-    }
-
-    public boolean isReturnStatusUp() {
-        return returnStatusUp;
-    }
-}
diff --git a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthResource.java b/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthResource.java
index f5392e6..1e2e297 100644
--- a/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthResource.java
+++ b/integration-tests/microprofile/src/main/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthResource.java
@@ -24,7 +24,6 @@ import javax.ws.rs.PathParam;
 import javax.ws.rs.QueryParam;
 
 import org.apache.camel.CamelContext;
-import org.apache.camel.health.HealthCheck;
 import org.apache.camel.health.HealthCheckRegistry;
 
 @Path("/microprofile-health")
@@ -52,7 +51,7 @@ public class MicroProfileHealthResource {
             @QueryParam("healthCheckEnabled") boolean isHealthCheckEnabled) {
         HealthCheckRegistry registry = camelContext.getExtension(HealthCheckRegistry.class);
         registry.getCheck(healthCheckId).ifPresent(healthCheck -> {
-            healthCheck.getConfiguration().setEnabled(isHealthCheckEnabled);
+            healthCheck.setEnabled(isHealthCheckEnabled);
             if (isHealthCheckEnabled) {
                 registry.register(healthCheck);
             } else {
@@ -60,18 +59,4 @@ public class MicroProfileHealthResource {
             }
         });
     }
-
-    @Path("/{healthCheckId}/return/status")
-    @POST
-    public void modifyHealthCheckStatus(
-            @PathParam("healthCheckId") String healthCheckId,
-            @QueryParam("returnStatusUp") boolean isReturnStatusUp) {
-        HealthCheck healthCheck = camelContext
-                .getExtension(HealthCheckRegistry.class)
-                .getCheck(healthCheckId)
-                .get();
-
-        FailureThresholdHealthCheck failureThresholdHealthCheck = (FailureThresholdHealthCheck) healthCheck;
-        failureThresholdHealthCheck.setReturnStatusUp(isReturnStatusUp);
-    }
 }
diff --git a/integration-tests/microprofile/src/main/resources/application.properties b/integration-tests/microprofile/src/main/resources/application.properties
index 4537e97..9b94638 100644
--- a/integration-tests/microprofile/src/main/resources/application.properties
+++ b/integration-tests/microprofile/src/main/resources/application.properties
@@ -26,9 +26,4 @@ quarkus.camel.metrics.enable-message-history = true
 camel.context.name = quarkus-camel-example
 
 # Prevent unwanted routes appearing in the health check output
-camel.health.config[disabledHealthRoute].parent=routes
-camel.health.config[disabledHealthRoute].enabled=false
-
-camel.health.config[checkIntervalThreshold].parent = routes
-camel.health.config[checkIntervalThreshold].interval = 100
-camel.health.config[checkIntervalThreshold].failure-threshold = 2
+camel.health.exclude-pattern = disabledHealthRoute
diff --git a/integration-tests/microprofile/src/test/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthTest.java b/integration-tests/microprofile/src/test/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthTest.java
index db79af1..4c24962 100644
--- a/integration-tests/microprofile/src/test/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthTest.java
+++ b/integration-tests/microprofile/src/test/java/org/apache/camel/quarkus/component/microprofile/it/health/MicroProfileHealthTest.java
@@ -16,15 +16,10 @@
  */
 package org.apache.camel.quarkus.component.microprofile.it.health;
 
-import java.util.List;
-import java.util.concurrent.TimeUnit;
-
 import io.quarkus.test.junit.QuarkusTest;
 import io.restassured.RestAssured;
 import io.restassured.http.ContentType;
-import io.restassured.path.json.JsonPath;
 import org.apache.camel.ServiceStatus;
-import org.awaitility.Awaitility;
 import org.junit.jupiter.api.Test;
 
 import static org.hamcrest.Matchers.contains;
@@ -165,66 +160,4 @@ class MicroProfileHealthTest {
                     .statusCode(204);
         }
     }
-
-    @Test
-    public void testFailureThreshold() {
-        try {
-            RestAssured.given()
-                    .queryParam("healthCheckEnabled", "true")
-                    .post("/microprofile-health/failure-threshold")
-                    .then()
-                    .statusCode(204);
-
-            // Configured failure threshold and interval should allow the initial health state be UP
-            RestAssured.when().get("/q/health").then()
-                    .contentType(ContentType.JSON)
-                    .header("Content-Type", containsString("charset=UTF-8"))
-                    .body("status", is("UP"),
-                            "checks.findAll { it.name == 'failure-threshold' }.status.unique()", contains("UP"));
-
-            // Poll the health endpoint until the threshold / interval is exceeded and the health state transitions to DOWN
-            Awaitility.await().atMost(10, TimeUnit.SECONDS).pollDelay(50, TimeUnit.MILLISECONDS).until(() -> {
-                JsonPath result = RestAssured.when().get("/q/health").then()
-                        .contentType(ContentType.JSON)
-                        .header("Content-Type", containsString("charset=UTF-8"))
-                        .extract()
-                        .jsonPath();
-
-                String status = result.getString("status");
-                List<String> routeStatus = result.getList("checks.findAll { it.name == 'failure-threshold' }.status.unique()");
-                return status.equals("DOWN") && routeStatus.contains("DOWN");
-            });
-
-            RestAssured.given()
-                    .queryParam("returnStatusUp", true)
-                    .post("/microprofile-health/failure-threshold/return/status")
-                    .then()
-                    .statusCode(204);
-
-            // Try again with a poll delay > the failure interval and wait for the health state to transition to UP
-            Awaitility.await().atMost(10, TimeUnit.SECONDS).pollDelay(50, TimeUnit.MILLISECONDS).until(() -> {
-                JsonPath result = RestAssured.when().get("/q/health").then()
-                        .contentType(ContentType.JSON)
-                        .header("Content-Type", containsString("charset=UTF-8"))
-                        .extract()
-                        .jsonPath();
-
-                String status = result.getString("status");
-                List<String> routeStatus = result.getList("checks.findAll { it.name == 'failure-threshold' }.status.unique()");
-                return status.equals("UP") && routeStatus.contains("UP");
-            });
-        } finally {
-            RestAssured.given()
-                    .queryParam("returnStatusUp", false)
-                    .post("/microprofile-health/failure-threshold/return/status")
-                    .then()
-                    .statusCode(204);
-
-            RestAssured.given()
-                    .queryParam("healthCheckEnabled", "false")
-                    .post("/microprofile-health/failure-threshold")
-                    .then()
-                    .statusCode(204);
-        }
-    }
 }
diff --git a/integration-tests/openapi-java/src/main/java/org/apache/camel/quarkus/component/openapijava/it/OpenApiRoutes.java b/integration-tests/openapi-java/src/main/java/org/apache/camel/quarkus/component/openapijava/it/OpenApiRoutes.java
index 884bf4c..6176af9 100644
--- a/integration-tests/openapi-java/src/main/java/org/apache/camel/quarkus/component/openapijava/it/OpenApiRoutes.java
+++ b/integration-tests/openapi-java/src/main/java/org/apache/camel/quarkus/component/openapijava/it/OpenApiRoutes.java
@@ -64,10 +64,7 @@ public class OpenApiRoutes extends RouteBuilder {
                 .description("Gets a list of fruits")
                 .id("list")
                 .produces(MediaType.APPLICATION_JSON)
-                .route()
-                .setBody().constant(getFruits())
-                .marshal().json()
-                .endRest()
+                .to("direct:fruits")
 
                 .get("/operation/spec")
                 .param()
@@ -102,20 +99,14 @@ public class OpenApiRoutes extends RouteBuilder {
                 .code("error")
                 .message("Response Error")
                 .endResponseMessage()
-                .route()
-                .setBody().constant("GET: /operation/spec")
-                .endRest()
+                .to("direct:echoMethodPath")
 
                 .get("/security/scopes")
                 .security("OAuth2", "scope1,scope2,scope3")
-                .route()
-                .setBody().constant("GET: /security/scopes")
-                .endRest()
+                .to("direct:echoMethodPath")
 
                 .get("/security/api/key")
-                .route()
-                .setBody().constant("GET: /security/api/key/header")
-                .endRest()
+                .to("direct:echoMethodPath")
                 .securityDefinitions()
                 .apiKey("X-API-Key", "The API key")
                 .withHeader("X-API-KEY")
@@ -123,17 +114,13 @@ public class OpenApiRoutes extends RouteBuilder {
                 .end()
 
                 .get("/security/basic/auth")
-                .route()
-                .setBody().constant("/security/basic/auth")
-                .endRest()
+                .to("direct:echoMethodPath")
                 .securityDefinitions()
                 .basicAuth("basicAuth", "Basic Authentication")
                 .end()
 
                 .get("/security/oauth2")
-                .route()
-                .setBody().constant("/security/oauth2")
-                .endRest()
+                .to("direct:echoMethodPath")
                 .securityDefinitions()
                 .oauth2("oauth2", "OAuth2 Authentication")
                 .flow("implicit")
@@ -147,29 +134,30 @@ public class OpenApiRoutes extends RouteBuilder {
         if (openApiVersion.equals("3.0.0")) {
             rest()
                     .get("/security/bearer/token")
-                    .route()
-                    .setBody().constant("/security/bearer/token")
-                    .endRest()
+                    .to("direct:echoMethodPath")
                     .securityDefinitions()
                     .bearerToken("bearerAuth", "Bearer Token Authentication")
                     .end()
 
                     .get("/security/mutual/tls")
-                    .route()
-                    .setBody().constant("/security/mutual/tls")
-                    .endRest()
+                    .to("direct:echoMethodPath")
                     .securityDefinitions()
                     .mutualTLS("mutualTLS")
                     .end()
 
                     .get("/security/openid")
-                    .route()
-                    .setBody().constant("/security/openid")
-                    .endRest()
+                    .to("direct:echoMethodPath")
                     .securityDefinitions()
                     .openIdConnect("openId", "https://secure.apache.org/fake/openid-configuration")
                     .end();
         }
+
+        from("direct:fruits")
+                .setBody().constant(getFruits())
+                .marshal().json();
+
+        from("direct:echoMethodPath")
+                .setBody().simple("${header.CamelHttpMethod}: ${header.CamelHttpPath}");
     }
 
     private Set<Fruit> getFruits() {
diff --git a/integration-tests/openapi-java/src/test/java/org/apache/camel/quarkus/component/openapijava/it/common/OpenApiTest.java b/integration-tests/openapi-java/src/test/java/org/apache/camel/quarkus/component/openapijava/it/common/OpenApiTest.java
index 4f97265..352851e 100644
--- a/integration-tests/openapi-java/src/test/java/org/apache/camel/quarkus/component/openapijava/it/common/OpenApiTest.java
+++ b/integration-tests/openapi-java/src/test/java/org/apache/camel/quarkus/component/openapijava/it/common/OpenApiTest.java
@@ -200,9 +200,7 @@ public abstract class OpenApiTest {
                 .then()
                 .contentType(ContentType.JSON)
                 .statusCode(200)
-                .body(
-                        containsString("x-camelContextId"),
-                        containsString("x-routeId"));
+                .body(containsString("x-camelContextId"));
     }
 
     @Test
diff --git a/integration-tests/platform-http/pom.xml b/integration-tests/platform-http/pom.xml
index 172b01a..ea7a162 100644
--- a/integration-tests/platform-http/pom.xml
+++ b/integration-tests/platform-http/pom.xml
@@ -33,6 +33,10 @@
     <dependencies>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
+            <artifactId>camel-quarkus-direct</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-platform-http</artifactId>
         </dependency>
         <dependency>
@@ -110,6 +114,19 @@
                 <!-- The following dependencies guarantee that this module is built after them. You can update them by running `mvn process-resources -Pformat -N` from the source tree root directory -->
                 <dependency>
                     <groupId>org.apache.camel.quarkus</groupId>
+                    <artifactId>camel-quarkus-direct-deployment</artifactId>
+                    <version>${project.version}</version>
+                    <type>pom</type>
+                    <scope>test</scope>
+                    <exclusions>
+                        <exclusion>
+                            <groupId>*</groupId>
+                            <artifactId>*</artifactId>
+                        </exclusion>
+                    </exclusions>
+                </dependency>
+                <dependency>
+                    <groupId>org.apache.camel.quarkus</groupId>
                     <artifactId>camel-quarkus-log-deployment</artifactId>
                     <version>${project.version}</version>
                     <type>pom</type>
diff --git a/integration-tests/platform-http/src/main/java/org/apache/camel/quarkus/component/platform/http/it/PlatformHttpRouteBuilder.java b/integration-tests/platform-http/src/main/java/org/apache/camel/quarkus/component/platform/http/it/PlatformHttpRouteBuilder.java
index 0b315d1..2003c6e 100644
--- a/integration-tests/platform-http/src/main/java/org/apache/camel/quarkus/component/platform/http/it/PlatformHttpRouteBuilder.java
+++ b/integration-tests/platform-http/src/main/java/org/apache/camel/quarkus/component/platform/http/it/PlatformHttpRouteBuilder.java
@@ -48,14 +48,16 @@ public class PlatformHttpRouteBuilder extends RouteBuilder {
 
         rest()
                 .get("/platform-http/rest-get")
-                .route()
-                .setBody(constant("GET: /rest-get"))
-                .endRest()
+                .to("direct:echoMethodPath")
                 .post("/platform-http/rest-post")
                 .consumes("text/plain").produces("text/plain")
-                .route()
-                .setBody(constant("POST: /rest-post"))
-                .endRest();
+                .to("direct:echoMethodPath");
+
+        from("direct:echoMethodPath")
+                .setBody().simple("${header.CamelHttpMethod}: ${header.CamelHttpPath}");
+
+        from("direct:greet")
+                .setBody().simple("Hello ${header.name}");
 
         from("platform-http:/registry/inspect")
                 .process(e -> {
@@ -149,9 +151,7 @@ public class PlatformHttpRouteBuilder extends RouteBuilder {
         rest()
                 .get("/platform-http/hello-by-name/{name}")
                 .produces("text/plain")
-                .route()
-                .setBody(e -> "Hello " + e.getIn().getHeader("name", String.class))
-                .endRest();
+                .to("direct:greet");
 
         // Webhook tests
         from("platform-http:/platform-http/webhookpath")
diff --git a/integration-tests/platform-http/src/test/java/org/apache/camel/quarkus/component/http/server/it/PlatformHttpTest.java b/integration-tests/platform-http/src/test/java/org/apache/camel/quarkus/component/http/server/it/PlatformHttpTest.java
index 6a782c7..84d442b 100644
--- a/integration-tests/platform-http/src/test/java/org/apache/camel/quarkus/component/http/server/it/PlatformHttpTest.java
+++ b/integration-tests/platform-http/src/test/java/org/apache/camel/quarkus/component/http/server/it/PlatformHttpTest.java
@@ -69,11 +69,11 @@ class PlatformHttpTest {
     @Test
     public void rest() throws Throwable {
         RestAssured.get("/my-context/platform-http/rest-get")
-                .then().body(equalTo("GET: /rest-get"));
+                .then().body(equalTo("GET: /my-context/platform-http/rest-get"));
         RestAssured.given()
                 .contentType("text/plain")
                 .post("/my-context/platform-http/rest-post")
-                .then().body(equalTo("POST: /rest-post"));
+                .then().body(equalTo("POST: /my-context/platform-http/rest-post"));
     }
 
     @Test
diff --git a/integration-tests/rest/pom.xml b/integration-tests/rest/pom.xml
index dc80da2..dec26a0 100644
--- a/integration-tests/rest/pom.xml
+++ b/integration-tests/rest/pom.xml
@@ -37,6 +37,10 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
+            <artifactId>camel-quarkus-direct</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-http</artifactId>
         </dependency>
         <dependency>
@@ -126,6 +130,19 @@
                 </dependency>
                 <dependency>
                     <groupId>org.apache.camel.quarkus</groupId>
+                    <artifactId>camel-quarkus-direct-deployment</artifactId>
+                    <version>${project.version}</version>
+                    <type>pom</type>
+                    <scope>test</scope>
+                    <exclusions>
+                        <exclusion>
+                            <groupId>*</groupId>
+                            <artifactId>*</artifactId>
+                        </exclusion>
+                    </exclusions>
+                </dependency>
+                <dependency>
+                    <groupId>org.apache.camel.quarkus</groupId>
                     <artifactId>camel-quarkus-http-deployment</artifactId>
                     <version>${project.version}</version>
                     <type>pom</type>
diff --git a/integration-tests/rest/src/main/java/org/apache/camel/quarkus/component/rest/it/RestRoutes.java b/integration-tests/rest/src/main/java/org/apache/camel/quarkus/component/rest/it/RestRoutes.java
index 5342994..de4f92f 100644
--- a/integration-tests/rest/src/main/java/org/apache/camel/quarkus/component/rest/it/RestRoutes.java
+++ b/integration-tests/rest/src/main/java/org/apache/camel/quarkus/component/rest/it/RestRoutes.java
@@ -43,41 +43,29 @@ public class RestRoutes extends RouteBuilder {
         rest("/rest")
                 .delete()
                 .produces("text/plain")
-                .route()
-                .setBody(constant("DELETE: /rest"))
-                .endRest()
+                .to("direct:echoMethodPath")
 
                 .get()
                 .produces("text/plain")
-                .route()
-                .setBody(constant("GET: /rest"))
-                .endRest()
+                .to("direct:echoMethodPath")
 
                 .head()
-                .route()
-                .setHeader(Exchange.CONTENT_TYPE).constant("text/plain")
-                .endRest()
+                .to("direct:contentTypeText")
 
                 .patch()
                 .consumes("text/plain")
                 .produces("text/plain")
-                .route()
-                .setBody(simple("${body}: /rest"))
-                .endRest()
+                .to("direct:echoBodyPath")
 
                 .post()
                 .consumes("text/plain")
                 .produces("text/plain")
-                .route()
-                .setBody(simple("${body}: /rest"))
-                .endRest()
+                .to("direct:echoBodyPath")
 
                 .put()
                 .consumes("text/plain")
                 .produces("text/plain")
-                .route()
-                .setBody(simple("${body}: /rest"))
-                .endRest()
+                .to("direct:echoBodyPath")
 
                 .post("/validation")
                 .clientRequestValidation(true)
@@ -85,55 +73,67 @@ public class RestRoutes extends RouteBuilder {
                 .param().name("messageMiddle").type(RestParamType.body).required(true).endParam()
                 .param().name("messageEnd").type(RestParamType.header).required(true).endParam()
                 .param().name("unused").type(RestParamType.formData).required(false).endParam()
-                .route()
-                .setBody(simple("${header.messageStart} ${body} ${header.messageEnd}"))
-                .endRest()
+                .to("direct:greetWithBody")
 
                 .get("/template/{messageStart}/{messageEnd}")
-                .route()
-                .setBody(simple("${header.messageStart} ${header.messageEnd}"))
-                .endRest()
+                .to("direct:greet")
 
                 .post("/pojo/binding/json")
                 .bindingMode(RestBindingMode.json)
                 .type(Person.class)
                 .produces(MediaType.TEXT_PLAIN)
-                .route()
-                .setBody(simple("Name: ${body.firstName} ${body.lastName}, Age: ${body.age}"))
-                .setHeader(Exchange.CONTENT_TYPE, constant("text/plain"))
-                .endRest()
+                .to("direct:personString")
 
                 .get("/binding/json/producer")
-                .route()
-                .setBody(constant(PERSON_JSON))
-                .endRest()
+                .to("direct:personJson")
 
                 .post("/pojo/binding/xml")
                 .bindingMode(RestBindingMode.xml)
                 .type(Person.class)
                 .produces(MediaType.TEXT_PLAIN)
-                .route()
-                .setBody(simple("Name: ${body.firstName} ${body.lastName}, Age: ${body.age}"))
-                .setHeader(Exchange.CONTENT_TYPE, constant("text/plain"))
-                .endRest()
+                .to("direct:personString")
 
                 .get("/binding/xml/producer")
-                .route()
-                .setBody(constant(PERSON_XML))
-                .endRest()
+                .to("direct:personXml")
 
                 .post("/log")
-                .route()
-                .log("Hello ${body}")
-                .endRest()
+                .to("direct:hello")
 
                 .verb("head", "/custom/verb")
-                .route()
-                .setHeader(Exchange.CONTENT_TYPE, constant("text/plain"))
-                .endRest()
+                .to("direct:contentTypeText")
 
                 .post("/multipart/upload")
-                .route()
+                .to("direct:processAttachments");
+
+        from("direct:echoMethodPath")
+                .setBody().simple("${header.CamelHttpMethod}: ${header.CamelHttpPath}");
+
+        from("direct:echoBodyPath")
+                .setBody().simple("${body}: ${header.CamelHttpPath}");
+
+        from("direct:greetWithBody")
+                .setBody(simple("${header.messageStart} ${body} ${header.messageEnd}"));
+
+        from("direct:greet")
+                .setBody(simple("${header.messageStart} ${header.messageEnd}"));
+
+        from("direct:hello")
+                .log("Hello ${body}");
+
+        from("direct:personString")
+                .setHeader(Exchange.CONTENT_TYPE, constant("text/plain"))
+                .setBody().simple("Name: ${body.firstName} ${body.lastName}, Age: ${body.age}");
+
+        from("direct:personJson")
+                .setBody().constant(PERSON_JSON);
+
+        from("direct:personXml")
+                .setBody().constant(PERSON_XML);
+
+        from("direct:contentTypeText")
+                .setHeader(Exchange.CONTENT_TYPE).constant("text/plain");
+
+        from("direct:processAttachments")
                 .process(exchange -> {
                     AttachmentMessage attachmentMessage = exchange.getMessage(AttachmentMessage.class);
                     Map<String, DataHandler> attachments = attachmentMessage.getAttachments();
@@ -143,7 +143,6 @@ public class RestRoutes extends RouteBuilder {
                     } else {
                         exchange.getMessage().setBody("0");
                     }
-                })
-                .endRest();
+                });
     }
 }
diff --git a/integration-tests/servlet/pom.xml b/integration-tests/servlet/pom.xml
index 45737b4..36d8e71 100644
--- a/integration-tests/servlet/pom.xml
+++ b/integration-tests/servlet/pom.xml
@@ -33,7 +33,11 @@
     <dependencies>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-servlet</artifactId>
+            <artifactId>camel-quarkus-core-cloud</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.camel.quarkus</groupId>
+            <artifactId>camel-quarkus-direct</artifactId>
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
@@ -41,7 +45,7 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-core-cloud</artifactId>
+            <artifactId>camel-quarkus-servlet</artifactId>
         </dependency>
 
         <!-- test dependencies -->
@@ -110,6 +114,19 @@
                 </dependency>
                 <dependency>
                     <groupId>org.apache.camel.quarkus</groupId>
+                    <artifactId>camel-quarkus-direct-deployment</artifactId>
+                    <version>${project.version}</version>
+                    <type>pom</type>
+                    <scope>test</scope>
+                    <exclusions>
+                        <exclusion>
+                            <groupId>*</groupId>
+                            <artifactId>*</artifactId>
+                        </exclusion>
+                    </exclusions>
+                </dependency>
+                <dependency>
+                    <groupId>org.apache.camel.quarkus</groupId>
                     <artifactId>camel-quarkus-rest-deployment</artifactId>
                     <version>${project.version}</version>
                     <type>pom</type>
diff --git a/integration-tests/servlet/src/main/java/org/apache/camel/quarkus/component/servlet/CamelRoute.java b/integration-tests/servlet/src/main/java/org/apache/camel/quarkus/component/servlet/CamelRoute.java
index 0730289..933e426 100644
--- a/integration-tests/servlet/src/main/java/org/apache/camel/quarkus/component/servlet/CamelRoute.java
+++ b/integration-tests/servlet/src/main/java/org/apache/camel/quarkus/component/servlet/CamelRoute.java
@@ -18,6 +18,8 @@ package org.apache.camel.quarkus.component.servlet;
 
 import javax.enterprise.context.ApplicationScoped;
 
+import org.apache.camel.Exchange;
+import org.apache.camel.Processor;
 import org.apache.camel.builder.RouteBuilder;
 
 @ApplicationScoped
@@ -33,13 +35,10 @@ public class CamelRoute extends RouteBuilder {
 
         rest()
                 .get("/rest-get")
-                .route()
-                .setBody(constant("GET: /rest-get"))
-                .endRest()
+                .to("direct:echoMethodPath")
+
                 .post("/rest-post")
-                .route()
-                .setBody(constant("POST: /rest-post"))
-                .endRest();
+                .to("direct:echoMethodPath");
 
         from("servlet://hello?matchOnUriPrefix=true")
                 .setBody(constant("GET: /hello"));
@@ -50,6 +49,14 @@ public class CamelRoute extends RouteBuilder {
         from("servlet://favorite?servletName=my-favorite-servlet")
                 .setBody(constant("GET: /favorite"));
 
+        from("direct:echoMethodPath")
+                .process(new Processor() {
+                    @Override
+                    public void process(Exchange exchange) throws Exception {
+                        exchange.toString();
+                    }
+                })
+                .setBody().simple("${header.CamelHttpMethod}: ${header.CamelServletContextPath}");
     }
 
 }
diff --git a/pom.xml b/pom.xml
index 4bf3b9f..82afbdb 100644
--- a/pom.xml
+++ b/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel</groupId>
         <artifactId>camel-dependencies</artifactId>
-        <version>3.15.0</version>
+        <version>3.16.0-SNAPSHOT</version>
     </parent>
 
     <groupId>org.apache.camel.quarkus</groupId>
@@ -39,8 +39,8 @@
     <properties>
 
         <!-- Primary dependencies - maintained manually -->
-        <camel.major.minor>3.15</camel.major.minor> <!-- run after each change: cd docs && mvnd validate -->
-        <camel.version>${camel.major.minor}.0</camel.version>
+        <camel.major.minor>3.16</camel.major.minor> <!-- run after each change: cd docs && mvnd validate -->
+        <camel.version>${camel.major.minor}.0-SNAPSHOT</camel.version>
         <camel.docs.components.version>${camel.major.minor}.x</camel.docs.components.version><!-- the version in Camel's docs/components/antora.yml -->
         <camel.docs.components.xref>${camel.docs.components.version}@components</camel.docs.components.xref><!-- the version in Camel's docs/components/antora.yml -->
         <camel.docs.branch>camel-${camel.major.minor}.x</camel.docs.branch><!-- The stable camel branch on which our Antora docs depends -->
@@ -133,7 +133,7 @@
         <xalan.version>${xalan-version}</xalan.version>
         <xchange.version>${xchange-version}</xchange.version>
         <xerces.version>${xerces-version}</xerces.version>
-        <xmlgraphics-commons.version>2.6</xmlgraphics-commons.version><!-- @sync org.apache.xmlgraphics:fop-parent:${fop-version} prop:xmlgraphics.commons.version -->
+        <xmlgraphics-commons.version>2.7</xmlgraphics-commons.version><!-- @sync org.apache.xmlgraphics:fop-parent:${fop-version} prop:xmlgraphics.commons.version -->
         <xstream.version>${xstream-version}</xstream.version>
         <web3j.version>${web3j-version}</web3j.version>
         <web3j.quorum.version>${web3j-quorum-version}</web3j.quorum.version>

[camel-quarkus] 04/08: Work around Tika version incompatibilities between Quarkus Tika & Camel Tika #3599

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit 3555acffbf9c8f1b60066bdd0fdeffe2f17e420d
Author: James Netherton <ja...@gmail.com>
AuthorDate: Tue Mar 8 10:50:20 2022 +0000

    Work around Tika version incompatibilities between Quarkus Tika & Camel Tika #3599
---
 extensions/tika/runtime/pom.xml                    | 11 ++--
 .../camel/quarkus/component/tika/TikaRecorder.java | 33 +++++++++-
 .../tika/graalvm/TikaProducerSubstitutions.java    | 77 ++++++++++++++++++++++
 3 files changed, 115 insertions(+), 6 deletions(-)

diff --git a/extensions/tika/runtime/pom.xml b/extensions/tika/runtime/pom.xml
index 3470945..74ae8a2 100644
--- a/extensions/tika/runtime/pom.xml
+++ b/extensions/tika/runtime/pom.xml
@@ -58,11 +58,7 @@
             <exclusions>
                 <exclusion>
                     <groupId>org.apache.tika</groupId>
-                    <artifactId>tika-core</artifactId>
-                </exclusion>
-                <exclusion>
-                    <groupId>org.apache.tika</groupId>
-                    <artifactId>tika-parsers</artifactId>
+                    <artifactId>*</artifactId>
                 </exclusion>
             </exclusions>
         </dependency>
@@ -74,6 +70,11 @@
             <groupId>io.quarkiverse.tika</groupId>
             <artifactId>quarkus-tika</artifactId>
         </dependency>
+        <dependency>
+            <groupId>org.graalvm.nativeimage</groupId>
+            <artifactId>svm</artifactId>
+            <scope>provided</scope>
+        </dependency>
     </dependencies>
 
     <build>
diff --git a/extensions/tika/runtime/src/main/java/org/apache/camel/quarkus/component/tika/TikaRecorder.java b/extensions/tika/runtime/src/main/java/org/apache/camel/quarkus/component/tika/TikaRecorder.java
index 6d6760b..c5ea87f 100644
--- a/extensions/tika/runtime/src/main/java/org/apache/camel/quarkus/component/tika/TikaRecorder.java
+++ b/extensions/tika/runtime/src/main/java/org/apache/camel/quarkus/component/tika/TikaRecorder.java
@@ -18,9 +18,14 @@ package org.apache.camel.quarkus.component.tika;
 
 import java.io.IOException;
 import java.io.InputStream;
+import java.io.OutputStream;
+import java.io.OutputStreamWriter;
+import java.io.UnsupportedEncodingException;
 import java.util.Collections;
 import java.util.Set;
 
+import javax.xml.transform.TransformerConfigurationException;
+
 import org.xml.sax.ContentHandler;
 import org.xml.sax.SAXException;
 
@@ -36,12 +41,14 @@ import org.apache.camel.Producer;
 import org.apache.camel.component.tika.TikaComponent;
 import org.apache.camel.component.tika.TikaConfiguration;
 import org.apache.camel.component.tika.TikaEndpoint;
+import org.apache.camel.component.tika.TikaParseOutputFormat;
 import org.apache.camel.component.tika.TikaProducer;
 import org.apache.tika.exception.TikaException;
 import org.apache.tika.metadata.Metadata;
 import org.apache.tika.mime.MediaType;
 import org.apache.tika.parser.ParseContext;
 import org.apache.tika.parser.Parser;
+import org.apache.tika.parser.html.BoilerpipeContentHandler;
 
 @Recorder
 public class TikaRecorder {
@@ -78,7 +85,7 @@ public class TikaRecorder {
         @Override
         public Producer createProducer() throws Exception {
             TikaParser tikaParser = tikaParserProducer.tikaParser();
-            return new TikaProducer(this, new Parser() {
+            return new QuarkusTikaProducer(this, new Parser() {
                 @Override
                 public Set<MediaType> getSupportedTypes(ParseContext parseContext) {
                     return Collections.emptySet();
@@ -99,4 +106,28 @@ public class TikaRecorder {
         }
     }
 
+    // TODO: Remove this when Camel Tika & Quarkus Tika versions are aligned
+    // https://github.com/apache/camel-quarkus/issues/3599
+    static class QuarkusTikaProducer extends TikaProducer {
+
+        public QuarkusTikaProducer(TikaEndpoint endpoint) {
+            super(endpoint);
+        }
+
+        public QuarkusTikaProducer(TikaEndpoint endpoint, Parser parser) {
+            super(endpoint, parser);
+        }
+
+        @Override
+        protected ContentHandler getContentHandler(TikaConfiguration configuration, OutputStream outputStream)
+                throws TransformerConfigurationException, UnsupportedEncodingException {
+            TikaParseOutputFormat outputFormat = configuration.getTikaParseOutputFormat();
+            if (outputFormat.equals(TikaParseOutputFormat.textMain)) {
+                return new BoilerpipeContentHandler(
+                        new OutputStreamWriter(outputStream, configuration.getTikaParseOutputEncoding()));
+            }
+            return super.getContentHandler(configuration, outputStream);
+        }
+    }
+
 }
diff --git a/extensions/tika/runtime/src/main/java/org/apache/camel/quarkus/component/tika/graalvm/TikaProducerSubstitutions.java b/extensions/tika/runtime/src/main/java/org/apache/camel/quarkus/component/tika/graalvm/TikaProducerSubstitutions.java
new file mode 100644
index 0000000..343edae
--- /dev/null
+++ b/extensions/tika/runtime/src/main/java/org/apache/camel/quarkus/component/tika/graalvm/TikaProducerSubstitutions.java
@@ -0,0 +1,77 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.quarkus.component.tika.graalvm;
+
+import java.io.OutputStream;
+import java.io.OutputStreamWriter;
+import java.io.UnsupportedEncodingException;
+
+import javax.xml.transform.TransformerConfigurationException;
+import javax.xml.transform.sax.TransformerHandler;
+
+import org.xml.sax.ContentHandler;
+
+import com.oracle.svm.core.annotate.Alias;
+import com.oracle.svm.core.annotate.Substitute;
+import com.oracle.svm.core.annotate.TargetClass;
+import org.apache.camel.component.tika.TikaConfiguration;
+import org.apache.camel.component.tika.TikaParseOutputFormat;
+import org.apache.camel.component.tika.TikaProducer;
+import org.apache.tika.sax.BodyContentHandler;
+import org.apache.tika.sax.ExpandedTitleContentHandler;
+
+// TODO: Remove this when Camel Tika & Quarkus Tika versions are aligned
+// https://github.com/apache/camel-quarkus/issues/3599
+@TargetClass(TikaProducer.class)
+public final class TikaProducerSubstitutions {
+
+    @Alias
+    private String encoding;
+
+    // Removes problematic textMain switch case since it's covered in the custom TikaProducer in TikaRecorder
+    @Substitute
+    private ContentHandler getContentHandler(TikaConfiguration configuration, OutputStream outputStream)
+            throws TransformerConfigurationException, UnsupportedEncodingException {
+
+        ContentHandler result = null;
+
+        TikaParseOutputFormat outputFormat = configuration.getTikaParseOutputFormat();
+        switch (outputFormat) {
+        case xml:
+            result = getTransformerHandler(outputStream, "xml", true);
+            break;
+        case text:
+            result = new BodyContentHandler(new OutputStreamWriter(outputStream, this.encoding));
+            break;
+        case html:
+            result = new ExpandedTitleContentHandler(getTransformerHandler(outputStream, "html", true));
+            break;
+        default:
+            throw new IllegalArgumentException(
+                    String.format("Unknown format %s", configuration.getTikaParseOutputFormat()));
+        }
+        return result;
+    }
+
+    @Alias
+    private TransformerHandler getTransformerHandler(
+            OutputStream output, String method,
+            boolean prettyPrint)
+            throws TransformerConfigurationException, UnsupportedEncodingException {
+        return null;
+    }
+}

[camel-quarkus] 08/08: Temporarilly manually update google-auth-library-credentials until gRPC is upgraded to 1.45.x

Posted by gi...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a commit to branch camel-main
in repository https://gitbox.apache.org/repos/asf/camel-quarkus.git

commit 8f456bc904ad080334a5c029b2f18f88d513f424
Author: James Netherton <ja...@gmail.com>
AuthorDate: Fri Mar 18 13:09:23 2022 +0000

    Temporarilly manually update google-auth-library-credentials until gRPC is upgraded to 1.45.x
---
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/pom.xml b/pom.xml
index ca7873c..475a2c0 100644
--- a/pom.xml
+++ b/pom.xml
@@ -88,7 +88,7 @@
         <fommil.netlib.core.version>1.1.2</fommil.netlib.core.version><!-- Mess in Weka transitive deps -->
         <github-api.version>1.111</github-api.version><!-- Used in a Groovy script bellow -->
         <google-native-image-support.version>0.8.0</google-native-image-support.version>
-        <google-auth-library-credentials.version>0.22.2</google-auth-library-credentials.version><!-- @sync io.grpc:grpc-auth:${grpc.version} dep:com.google.auth:google-auth-library-credentials -->
+        <google-auth-library-credentials.version>1.5.3</google-auth-library-credentials.version>
         <graalvm.version>21.3.1</graalvm.version><!-- @sync io.quarkus:quarkus-bom:${quarkus.version} dep:org.graalvm.nativeimage:svm -->
         <grpc.version>1.43.2</grpc.version><!-- @sync io.quarkus:quarkus-bom:${quarkus.version} dep:io.grpc:grpc-core -->
         <guice-servlet.version>4.0</guice-servlet.version><!-- Spark -->