You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ja...@apache.org on 2021/04/19 14:44:19 UTC

[camel-quarkus] 01/02: Remove camel-quarkus-integration-testcontainers-support

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

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

commit 9b25ac02c227fa65eb6418e9847c3484972e6985
Author: James Netherton <ja...@gmail.com>
AuthorDate: Mon Apr 19 09:35:27 2021 +0100

    Remove camel-quarkus-integration-testcontainers-support
---
 extensions-jvm/couchbase/integration-test/pom.xml  |  5 --
 .../couchbase/it/CouchbaseTestResource.java        |  4 +-
 extensions-jvm/redis/integration-test/pom.xml      |  6 +--
 .../component/redis/it/RedisTestResource.java      |  4 +-
 integration-tests-support/aws2/pom.xml             |  2 +-
 .../test/support/aws2/Aws2TestResource.java        |  4 +-
 integration-tests-support/azure/pom.xml            |  6 +--
 integration-tests-support/pom.xml                  |  1 -
 .../testcontainers-support/pom.xml                 | 54 ----------------------
 .../ContainerResourceLifecycleManager.java         | 22 ---------
 .../quarkus/testcontainers/ContainerSupport.java   | 28 -----------
 .../src/main/resources/testcontainers.properties   | 18 --------
 integration-tests/activemq/pom.xml                 |  4 +-
 integration-tests/amqp/pom.xml                     |  4 +-
 integration-tests/arangodb/pom.xml                 |  4 +-
 .../arangodb/it/ArangodbTestResource.java          |  4 +-
 integration-tests/cassandraql/pom.xml              |  5 --
 .../cassandraql/it/CassandraqlTestResource.java    |  4 +-
 integration-tests/consul/pom.xml                   |  4 +-
 .../component/consul/it/ConsulTestResource.java    |  4 +-
 integration-tests/couchdb/pom.xml                  |  6 +--
 .../component/couchdb/it/CouchdbTestResource.java  |  4 +-
 integration-tests/debezium/pom.xml                 |  5 --
 .../common/it/AbstractDebeziumTestResource.java    |  4 +-
 integration-tests/elasticsearch-rest/pom.xml       |  4 +-
 integration-tests/fhir/pom.xml                     |  7 ++-
 .../component/fhir/it/FhirTestResource.java        |  4 +-
 integration-tests/google-pubsub/pom.xml            |  4 +-
 integration-tests/infinispan/pom.xml               | 11 ++---
 .../infinispan/InfinispanServerTestResource.java   | 11 +++--
 integration-tests/influxdb/pom.xml                 |  6 +--
 .../influxdb/it/InfluxdbTestResource.java          |  8 ++--
 integration-tests/ipfs/pom.xml                     |  4 +-
 integration-tests/jsch/pom.xml                     |  4 +-
 integration-tests/jta/pom.xml                      |  4 +-
 integration-tests/kafka-sasl/pom.xml               |  3 +-
 integration-tests/kafka/pom.xml                    |  3 +-
 .../component/kafka/it/CamelKafkaTestResource.java |  4 +-
 integration-tests/kudu/pom.xml                     |  6 +--
 .../component/kudu/it/KuduTestResource.java        |  4 +-
 integration-tests/lra/pom.xml                      |  7 ++-
 integration-tests/messaging/pom.xml                |  4 +-
 integration-tests/minio/pom.xml                    |  8 ++--
 .../component/minio/it/MinioTestResource.java      |  4 +-
 integration-tests/mongodb/pom.xml                  |  6 +--
 .../component/mongodb/it/MongoDbTestResource.java  |  4 +-
 integration-tests/nats/pom.xml                     |  8 ++--
 .../component/nats/it/NatsTestResource.java        |  4 +-
 integration-tests/nsq/pom.xml                      |  4 +-
 .../quarkus/component/nsq/it/NsqTestResource.java  |  4 +-
 integration-tests/paho-mqtt5/pom.xml               |  4 +-
 integration-tests/pg-replication-slot/pom.xml      |  4 +-
 .../slot/it/PgReplicationSlotTestResource.java     |  4 +-
 integration-tests/pgevent/pom.xml                  | 14 +++---
 .../component/pgevent/it/PgEventTestResource.java  | 13 +-----
 integration-tests/rabbitmq/pom.xml                 |  4 +-
 integration-tests/solr/pom.xml                     |  5 --
 .../component/solr/it/SolrTestResource.java        |  4 +-
 integration-tests/spring-rabbitmq/pom.xml          |  6 +--
 integration-tests/ssh/pom.xml                      |  4 +-
 integration-tests/vertx-kafka/pom.xml              |  5 --
 .../vertx/kafka/it/VertxKafkaTestResource.java     |  4 +-
 poms/bom-test/pom.xml                              |  5 --
 63 files changed, 127 insertions(+), 295 deletions(-)

diff --git a/extensions-jvm/couchbase/integration-test/pom.xml b/extensions-jvm/couchbase/integration-test/pom.xml
index 67caa34..504b398 100644
--- a/extensions-jvm/couchbase/integration-test/pom.xml
+++ b/extensions-jvm/couchbase/integration-test/pom.xml
@@ -52,11 +52,6 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
             <groupId>org.testcontainers</groupId>
             <artifactId>couchbase</artifactId>
             <scope>test</scope>
diff --git a/extensions-jvm/couchbase/integration-test/src/test/java/org/apache/camel/quarkus/component/couchbase/it/CouchbaseTestResource.java b/extensions-jvm/couchbase/integration-test/src/test/java/org/apache/camel/quarkus/component/couchbase/it/CouchbaseTestResource.java
index bd3177d..6afe63a 100644
--- a/extensions-jvm/couchbase/integration-test/src/test/java/org/apache/camel/quarkus/component/couchbase/it/CouchbaseTestResource.java
+++ b/extensions-jvm/couchbase/integration-test/src/test/java/org/apache/camel/quarkus/component/couchbase/it/CouchbaseTestResource.java
@@ -26,12 +26,12 @@ import com.couchbase.client.java.manager.bucket.BucketType;
 import com.couchbase.client.java.manager.view.DesignDocument;
 import com.couchbase.client.java.manager.view.View;
 import com.couchbase.client.java.view.DesignDocumentNamespace;
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.testcontainers.couchbase.CouchbaseContainer;
 import org.testcontainers.utility.DockerImageName;
 
-public class CouchbaseTestResource implements ContainerResourceLifecycleManager {
+public class CouchbaseTestResource implements QuarkusTestResourceLifecycleManager {
     private final static DockerImageName COUCHBASE_IMAGE = DockerImageName.parse("couchbase/server:6.5.1");
     public static final int KV_PORT = 11210;
     public static final int MANAGEMENT_PORT = 8091;
diff --git a/extensions-jvm/redis/integration-test/pom.xml b/extensions-jvm/redis/integration-test/pom.xml
index c713414..6b33138 100644
--- a/extensions-jvm/redis/integration-test/pom.xml
+++ b/extensions-jvm/redis/integration-test/pom.xml
@@ -80,11 +80,9 @@
             <artifactId>awaitility</artifactId>
             <scope>test</scope>
         </dependency>
-
-        <!-- test dependencies - camel-quarkus -->
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/extensions-jvm/redis/integration-test/src/test/java/org/apache/camel/quarkus/component/redis/it/RedisTestResource.java b/extensions-jvm/redis/integration-test/src/test/java/org/apache/camel/quarkus/component/redis/it/RedisTestResource.java
index d08f7d5..9081d37 100644
--- a/extensions-jvm/redis/integration-test/src/test/java/org/apache/camel/quarkus/component/redis/it/RedisTestResource.java
+++ b/extensions-jvm/redis/integration-test/src/test/java/org/apache/camel/quarkus/component/redis/it/RedisTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.redis.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -27,7 +27,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class RedisTestResource implements ContainerResourceLifecycleManager {
+public class RedisTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOG = LoggerFactory.getLogger(RedisTestResource.class);
     private static final int REDIS_PORT = 6379;
     private static final String REDIS_IMAGE = "redis:6.0.9";
diff --git a/integration-tests-support/aws2/pom.xml b/integration-tests-support/aws2/pom.xml
index 31fbbe3..64277ed 100644
--- a/integration-tests-support/aws2/pom.xml
+++ b/integration-tests-support/aws2/pom.xml
@@ -44,7 +44,7 @@
     <dependencies>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <artifactId>camel-quarkus-integration-test-support</artifactId>
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
diff --git a/integration-tests-support/aws2/src/main/java/org/apache/camel/quarkus/test/support/aws2/Aws2TestResource.java b/integration-tests-support/aws2/src/main/java/org/apache/camel/quarkus/test/support/aws2/Aws2TestResource.java
index 803bfbc..ab44ac5 100644
--- a/integration-tests-support/aws2/src/main/java/org/apache/camel/quarkus/test/support/aws2/Aws2TestResource.java
+++ b/integration-tests-support/aws2/src/main/java/org/apache/camel/quarkus/test/support/aws2/Aws2TestResource.java
@@ -24,15 +24,15 @@ import java.util.Optional;
 import java.util.ServiceLoader;
 import java.util.stream.Stream;
 
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.quarkus.test.mock.backend.MockBackendUtils;
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
 import org.jboss.logging.Logger;
 import org.testcontainers.containers.localstack.LocalStackContainer;
 import org.testcontainers.containers.localstack.LocalStackContainer.Service;
 import org.testcontainers.utility.DockerImageName;
 import software.amazon.awssdk.core.SdkClient;
 
-public final class Aws2TestResource implements ContainerResourceLifecycleManager {
+public final class Aws2TestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOG = Logger.getLogger(Aws2TestResource.class);
 
     private Aws2TestEnvContext envContext;
diff --git a/integration-tests-support/azure/pom.xml b/integration-tests-support/azure/pom.xml
index ab5469d..1109627 100644
--- a/integration-tests-support/azure/pom.xml
+++ b/integration-tests-support/azure/pom.xml
@@ -48,11 +48,11 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <artifactId>camel-quarkus-integration-test-support-mock-backend</artifactId>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-test-support-mock-backend</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
         </dependency>
     </dependencies>
 </project>
diff --git a/integration-tests-support/pom.xml b/integration-tests-support/pom.xml
index da128f3..0e49022 100644
--- a/integration-tests-support/pom.xml
+++ b/integration-tests-support/pom.xml
@@ -45,7 +45,6 @@
         <module>custom-main-listener</module>
         <module>process-executor-support</module>
         <module>test-support</module>
-        <module>testcontainers-support</module>
         <module>mock-backend</module>
         <module>wiremock</module>
     </modules>
diff --git a/integration-tests-support/testcontainers-support/pom.xml b/integration-tests-support/testcontainers-support/pom.xml
deleted file mode 100644
index b492b27..0000000
--- a/integration-tests-support/testcontainers-support/pom.xml
+++ /dev/null
@@ -1,54 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-         http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
-
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
-    <parent>
-        <groupId>org.apache.camel.quarkus</groupId>
-        <artifactId>camel-quarkus-integration-tests-support</artifactId>
-        <version>1.9.0-SNAPSHOT</version>
-        <relativePath>../pom.xml</relativePath>
-    </parent>
-    <modelVersion>4.0.0</modelVersion>
-
-    <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-    <name>Camel Quarkus :: Integration Tests :: Tescontainers :: Support</name>
-
-    <dependencyManagement>
-        <dependencies>
-            <dependency>
-                <groupId>org.apache.camel.quarkus</groupId>
-                <artifactId>camel-quarkus-bom-test</artifactId>
-                <version>${project.version}</version>
-                <type>pom</type>
-                <scope>import</scope>
-            </dependency>
-        </dependencies>
-    </dependencyManagement>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-test-support</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.testcontainers</groupId>
-            <artifactId>testcontainers</artifactId>
-        </dependency>
-    </dependencies>
-</project>
diff --git a/integration-tests-support/testcontainers-support/src/main/java/org/apache/camel/quarkus/testcontainers/ContainerResourceLifecycleManager.java b/integration-tests-support/testcontainers-support/src/main/java/org/apache/camel/quarkus/testcontainers/ContainerResourceLifecycleManager.java
deleted file mode 100644
index d8033bf..0000000
--- a/integration-tests-support/testcontainers-support/src/main/java/org/apache/camel/quarkus/testcontainers/ContainerResourceLifecycleManager.java
+++ /dev/null
@@ -1,22 +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.testcontainers;
-
-import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
-
-public interface ContainerResourceLifecycleManager extends QuarkusTestResourceLifecycleManager {
-}
diff --git a/integration-tests-support/testcontainers-support/src/main/java/org/apache/camel/quarkus/testcontainers/ContainerSupport.java b/integration-tests-support/testcontainers-support/src/main/java/org/apache/camel/quarkus/testcontainers/ContainerSupport.java
deleted file mode 100644
index 26c9d1b..0000000
--- a/integration-tests-support/testcontainers-support/src/main/java/org/apache/camel/quarkus/testcontainers/ContainerSupport.java
+++ /dev/null
@@ -1,28 +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.testcontainers;
-
-import org.testcontainers.containers.GenericContainer;
-
-public final class ContainerSupport {
-    private ContainerSupport() {
-    }
-
-    public static String getHostAndPort(GenericContainer<?> container, int port) {
-        return container.getContainerIpAddress() + ":" + container.getMappedPort(port).toString();
-    }
-}
diff --git a/integration-tests-support/testcontainers-support/src/main/resources/testcontainers.properties b/integration-tests-support/testcontainers-support/src/main/resources/testcontainers.properties
deleted file mode 100644
index 3903aad..0000000
--- a/integration-tests-support/testcontainers-support/src/main/resources/testcontainers.properties
+++ /dev/null
@@ -1,18 +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.
-## ---------------------------------------------------------------------------
-
-pull.pause.timeout = 120
\ No newline at end of file
diff --git a/integration-tests/activemq/pom.xml b/integration-tests/activemq/pom.xml
index 95da731..ad4ec17 100644
--- a/integration-tests/activemq/pom.xml
+++ b/integration-tests/activemq/pom.xml
@@ -51,8 +51,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/amqp/pom.xml b/integration-tests/amqp/pom.xml
index 8b0e399..04f76c4 100644
--- a/integration-tests/amqp/pom.xml
+++ b/integration-tests/amqp/pom.xml
@@ -51,8 +51,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/arangodb/pom.xml b/integration-tests/arangodb/pom.xml
index fed2d6c..5252dbd 100644
--- a/integration-tests/arangodb/pom.xml
+++ b/integration-tests/arangodb/pom.xml
@@ -64,8 +64,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/arangodb/src/test/java/org/apache/camel/quarkus/component/arangodb/it/ArangodbTestResource.java b/integration-tests/arangodb/src/test/java/org/apache/camel/quarkus/component/arangodb/it/ArangodbTestResource.java
index d6e0d18..9b3a8dc 100644
--- a/integration-tests/arangodb/src/test/java/org/apache/camel/quarkus/component/arangodb/it/ArangodbTestResource.java
+++ b/integration-tests/arangodb/src/test/java/org/apache/camel/quarkus/component/arangodb/it/ArangodbTestResource.java
@@ -18,7 +18,7 @@ package org.apache.camel.quarkus.component.arangodb.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -26,7 +26,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class ArangodbTestResource implements ContainerResourceLifecycleManager {
+public class ArangodbTestResource implements QuarkusTestResourceLifecycleManager {
 
     private static final Logger LOGGER = LoggerFactory.getLogger(ArangodbTestResource.class);
     private GenericContainer container;
diff --git a/integration-tests/cassandraql/pom.xml b/integration-tests/cassandraql/pom.xml
index 5cda5f1..41643be 100644
--- a/integration-tests/cassandraql/pom.xml
+++ b/integration-tests/cassandraql/pom.xml
@@ -68,11 +68,6 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
             <groupId>org.testcontainers</groupId>
             <artifactId>cassandra</artifactId>
             <scope>test</scope>
diff --git a/integration-tests/cassandraql/src/test/java/org/apache/camel/quarkus/component/cassandraql/it/CassandraqlTestResource.java b/integration-tests/cassandraql/src/test/java/org/apache/camel/quarkus/component/cassandraql/it/CassandraqlTestResource.java
index af2f5ce..820538c 100644
--- a/integration-tests/cassandraql/src/test/java/org/apache/camel/quarkus/component/cassandraql/it/CassandraqlTestResource.java
+++ b/integration-tests/cassandraql/src/test/java/org/apache/camel/quarkus/component/cassandraql/it/CassandraqlTestResource.java
@@ -21,7 +21,7 @@ import java.util.Map;
 
 import com.datastax.driver.core.Cluster;
 import com.datastax.driver.core.Session;
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -29,7 +29,7 @@ import org.testcontainers.containers.CassandraContainer;
 import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class CassandraqlTestResource implements ContainerResourceLifecycleManager {
+public class CassandraqlTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(CassandraqlTestResource.class);
     private static final int PORT = 9042;
     private static final String DOCKER_IMAGE_NAME = "cassandra:3.11.2";
diff --git a/integration-tests/consul/pom.xml b/integration-tests/consul/pom.xml
index dcfc350..88c267e 100644
--- a/integration-tests/consul/pom.xml
+++ b/integration-tests/consul/pom.xml
@@ -55,8 +55,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/consul/src/test/java/org/apache/camel/quarkus/component/consul/it/ConsulTestResource.java b/integration-tests/consul/src/test/java/org/apache/camel/quarkus/component/consul/it/ConsulTestResource.java
index d746b9e..596b577 100644
--- a/integration-tests/consul/src/test/java/org/apache/camel/quarkus/component/consul/it/ConsulTestResource.java
+++ b/integration-tests/consul/src/test/java/org/apache/camel/quarkus/component/consul/it/ConsulTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.consul.it;
 import java.util.Map;
 
 import com.orbitz.consul.Consul;
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -27,7 +27,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class ConsulTestResource implements ContainerResourceLifecycleManager {
+public class ConsulTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(ConsulTestResource.class);
     private static final int CONTAINER_PORT = Consul.DEFAULT_HTTP_PORT;
     private static final String CONTAINER_IMAGE = "consul:1.6";
diff --git a/integration-tests/couchdb/pom.xml b/integration-tests/couchdb/pom.xml
index bea382c..920dc0d 100644
--- a/integration-tests/couchdb/pom.xml
+++ b/integration-tests/couchdb/pom.xml
@@ -59,11 +59,9 @@
             <artifactId>awaitility</artifactId>
             <scope>test</scope>
         </dependency>
-
-        <!-- test dependencies - camel-quarkus -->
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/couchdb/src/test/java/org/apache/camel/quarkus/component/couchdb/it/CouchdbTestResource.java b/integration-tests/couchdb/src/test/java/org/apache/camel/quarkus/component/couchdb/it/CouchdbTestResource.java
index e30f08e..e04b39d 100644
--- a/integration-tests/couchdb/src/test/java/org/apache/camel/quarkus/component/couchdb/it/CouchdbTestResource.java
+++ b/integration-tests/couchdb/src/test/java/org/apache/camel/quarkus/component/couchdb/it/CouchdbTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.couchdb.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -27,7 +27,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class CouchdbTestResource implements ContainerResourceLifecycleManager {
+public class CouchdbTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(CouchdbTestResource.class);
     private static final int COUCHDB_PORT = 5984;
     private static final String COUCHDB_IMAGE = "couchdb:2.3.1";
diff --git a/integration-tests/debezium/pom.xml b/integration-tests/debezium/pom.xml
index 12dde67..cb8f453 100644
--- a/integration-tests/debezium/pom.xml
+++ b/integration-tests/debezium/pom.xml
@@ -83,11 +83,6 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
             <groupId>org.testcontainers</groupId>
             <artifactId>postgresql</artifactId>
             <scope>test</scope>
diff --git a/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumTestResource.java b/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumTestResource.java
index 68f168a..72ddce3 100644
--- a/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumTestResource.java
+++ b/integration-tests/debezium/src/test/java/org/apache/camel/quarkus/component/debezium/common/it/AbstractDebeziumTestResource.java
@@ -21,7 +21,7 @@ import java.nio.file.Files;
 import java.nio.file.Path;
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -32,7 +32,7 @@ import org.testcontainers.utility.TestcontainersConfiguration;
  * Abstract parent for debezium test resources.
  * Parent starts using abstract method.
  */
-public abstract class AbstractDebeziumTestResource<T extends GenericContainer> implements ContainerResourceLifecycleManager {
+public abstract class AbstractDebeziumTestResource<T extends GenericContainer> implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(AbstractDebeziumTestResource.class);
 
     protected T container;
diff --git a/integration-tests/elasticsearch-rest/pom.xml b/integration-tests/elasticsearch-rest/pom.xml
index d204d54..a3794cc 100644
--- a/integration-tests/elasticsearch-rest/pom.xml
+++ b/integration-tests/elasticsearch-rest/pom.xml
@@ -51,8 +51,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/fhir/pom.xml b/integration-tests/fhir/pom.xml
index 31f746a..961864b 100644
--- a/integration-tests/fhir/pom.xml
+++ b/integration-tests/fhir/pom.xml
@@ -61,7 +61,12 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <artifactId>camel-quarkus-integration-test-support</artifactId>
+            <scope>test</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/fhir/src/test/java/org/apache/camel/quarkus/component/fhir/it/FhirTestResource.java b/integration-tests/fhir/src/test/java/org/apache/camel/quarkus/component/fhir/it/FhirTestResource.java
index 0fa5ad3..ff9627c 100644
--- a/integration-tests/fhir/src/test/java/org/apache/camel/quarkus/component/fhir/it/FhirTestResource.java
+++ b/integration-tests/fhir/src/test/java/org/apache/camel/quarkus/component/fhir/it/FhirTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.fhir.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -27,7 +27,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class FhirTestResource implements ContainerResourceLifecycleManager {
+public class FhirTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(FhirTestResource.class);
     private static final int CONTAINER_PORT = 8080;
     private static final String CONTAINER_IMAGE = "quay.io/lburgazzoli/hapi-fhir-jpaserver-starter:4.1.0";
diff --git a/integration-tests/google-pubsub/pom.xml b/integration-tests/google-pubsub/pom.xml
index f8a84cd..549446e 100644
--- a/integration-tests/google-pubsub/pom.xml
+++ b/integration-tests/google-pubsub/pom.xml
@@ -51,8 +51,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/infinispan/pom.xml b/integration-tests/infinispan/pom.xml
index 7b7ab8d..8059eaa 100644
--- a/integration-tests/infinispan/pom.xml
+++ b/integration-tests/infinispan/pom.xml
@@ -48,12 +48,6 @@
         </dependency>
 
         <!-- test dependencies -->
-
-        <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
-        </dependency>
         <dependency>
             <groupId>io.quarkus</groupId>
             <artifactId>quarkus-junit5</artifactId>
@@ -64,6 +58,11 @@
             <artifactId>rest-assured</artifactId>
             <scope>test</scope>
         </dependency>
+        <dependency>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
+            <scope>test</scope>
+        </dependency>
 
         <!-- 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>
diff --git a/integration-tests/infinispan/src/test/java/org/apache/camel/quarkus/component/infinispan/InfinispanServerTestResource.java b/integration-tests/infinispan/src/test/java/org/apache/camel/quarkus/component/infinispan/InfinispanServerTestResource.java
index 88bb76b..ed46075 100644
--- a/integration-tests/infinispan/src/test/java/org/apache/camel/quarkus/component/infinispan/InfinispanServerTestResource.java
+++ b/integration-tests/infinispan/src/test/java/org/apache/camel/quarkus/component/infinispan/InfinispanServerTestResource.java
@@ -18,7 +18,7 @@ package org.apache.camel.quarkus.component.infinispan;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -26,9 +26,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-import static org.apache.camel.quarkus.testcontainers.ContainerSupport.getHostAndPort;
-
-public class InfinispanServerTestResource implements ContainerResourceLifecycleManager {
+public class InfinispanServerTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(InfinispanServerTestResource.class);
     private static final String CONTAINER_IMAGE = "infinispan/server:10.1.5.Final";
     private static final int HOTROD_PORT = 11222;
@@ -50,8 +48,11 @@ public class InfinispanServerTestResource implements ContainerResourceLifecycleM
 
             container.start();
 
+            String serverList = String.format("%s:%s", container.getContainerIpAddress(),
+                    container.getMappedPort(HOTROD_PORT));
+
             return CollectionHelper.mapOf(
-                    "quarkus.infinispan-client.server-list", getHostAndPort(container, HOTROD_PORT),
+                    "quarkus.infinispan-client.server-list", serverList,
                     "quarkus.infinispan-client.near-cache-max-entries", "3",
                     "quarkus.infinispan-client.auth-username", USER,
                     "quarkus.infinispan-client.auth-password", PASS,
diff --git a/integration-tests/influxdb/pom.xml b/integration-tests/influxdb/pom.xml
index 6709e4e..ba5edb3 100644
--- a/integration-tests/influxdb/pom.xml
+++ b/integration-tests/influxdb/pom.xml
@@ -54,11 +54,9 @@
             <artifactId>rest-assured</artifactId>
             <scope>test</scope>
         </dependency>
-
-        <!-- test dependencies - camel-quarkus -->
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/influxdb/src/test/java/org/apache/camel/quarkus/component/influxdb/it/InfluxdbTestResource.java b/integration-tests/influxdb/src/test/java/org/apache/camel/quarkus/component/influxdb/it/InfluxdbTestResource.java
index d351335..164cd1a 100644
--- a/integration-tests/influxdb/src/test/java/org/apache/camel/quarkus/component/influxdb/it/InfluxdbTestResource.java
+++ b/integration-tests/influxdb/src/test/java/org/apache/camel/quarkus/component/influxdb/it/InfluxdbTestResource.java
@@ -19,8 +19,7 @@ package org.apache.camel.quarkus.component.influxdb.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
-import org.apache.camel.quarkus.testcontainers.ContainerSupport;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -28,7 +27,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class InfluxdbTestResource implements ContainerResourceLifecycleManager {
+public class InfluxdbTestResource implements QuarkusTestResourceLifecycleManager {
     public static final Logger LOGGER = LoggerFactory.getLogger(InfluxdbTestResource.class);
     public static final int INFLUXDB_PORT = 8086;
     public static final String INFLUXDB_VERSION = "1.7.10";
@@ -49,7 +48,8 @@ public class InfluxdbTestResource implements ContainerResourceLifecycleManager {
 
             return CollectionHelper.mapOf(
                     InfluxdbResource.INFLUXDB_CONNECTION_PROPERTY,
-                    "http://" + ContainerSupport.getHostAndPort(container, INFLUXDB_PORT));
+                    "http://" + String.format("%s:%s", container.getContainerIpAddress(),
+                            container.getMappedPort(INFLUXDB_PORT)));
         } catch (Exception e) {
             throw new RuntimeException(e);
         }
diff --git a/integration-tests/ipfs/pom.xml b/integration-tests/ipfs/pom.xml
index daafe3d..7ce82d8 100644
--- a/integration-tests/ipfs/pom.xml
+++ b/integration-tests/ipfs/pom.xml
@@ -51,8 +51,8 @@
             <artifactId>quarkus-resteasy</artifactId>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/jsch/pom.xml b/integration-tests/jsch/pom.xml
index 6993e34..40430d1 100644
--- a/integration-tests/jsch/pom.xml
+++ b/integration-tests/jsch/pom.xml
@@ -63,8 +63,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/jta/pom.xml b/integration-tests/jta/pom.xml
index 23db0ca..f20aa33 100644
--- a/integration-tests/jta/pom.xml
+++ b/integration-tests/jta/pom.xml
@@ -93,8 +93,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/kafka-sasl/pom.xml b/integration-tests/kafka-sasl/pom.xml
index 05ddd48..b822648 100644
--- a/integration-tests/kafka-sasl/pom.xml
+++ b/integration-tests/kafka-sasl/pom.xml
@@ -63,8 +63,7 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
+            <artifactId>camel-quarkus-integration-test-support</artifactId>
         </dependency>
         <dependency>
             <groupId>org.testcontainers</groupId>
diff --git a/integration-tests/kafka/pom.xml b/integration-tests/kafka/pom.xml
index b153d73..7922668 100644
--- a/integration-tests/kafka/pom.xml
+++ b/integration-tests/kafka/pom.xml
@@ -63,8 +63,7 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
+            <artifactId>camel-quarkus-integration-test-support</artifactId>
         </dependency>
         <dependency>
             <groupId>org.testcontainers</groupId>
diff --git a/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaTestResource.java b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaTestResource.java
index fd347c4..91d3db7 100644
--- a/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaTestResource.java
+++ b/integration-tests/kafka/src/test/java/org/apache/camel/quarkus/component/kafka/it/CamelKafkaTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.kafka.it;
 import java.util.Collections;
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.testcontainers.containers.KafkaContainer;
@@ -27,7 +27,7 @@ import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.DockerImageName;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class CamelKafkaTestResource implements ContainerResourceLifecycleManager {
+public class CamelKafkaTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(CamelKafkaTestResource.class);
     private static final String CONFLUENT_PLATFORM_VERSION = "5.4.3";
 
diff --git a/integration-tests/kudu/pom.xml b/integration-tests/kudu/pom.xml
index 57344bd..a773840 100644
--- a/integration-tests/kudu/pom.xml
+++ b/integration-tests/kudu/pom.xml
@@ -62,11 +62,9 @@
             <artifactId>rest-assured</artifactId>
             <scope>test</scope>
         </dependency>
-
-        <!-- test dependencies - camel-quarkus -->
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/kudu/src/test/java/org/apache/camel/quarkus/component/kudu/it/KuduTestResource.java b/integration-tests/kudu/src/test/java/org/apache/camel/quarkus/component/kudu/it/KuduTestResource.java
index 643a41c..e491bcb 100644
--- a/integration-tests/kudu/src/test/java/org/apache/camel/quarkus/component/kudu/it/KuduTestResource.java
+++ b/integration-tests/kudu/src/test/java/org/apache/camel/quarkus/component/kudu/it/KuduTestResource.java
@@ -24,7 +24,7 @@ import com.github.dockerjava.api.command.CreateContainerCmd;
 import com.github.dockerjava.api.model.ExposedPort;
 import com.github.dockerjava.api.model.HostConfig;
 import com.github.dockerjava.api.model.Ports;
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -36,7 +36,7 @@ import org.testcontainers.utility.TestcontainersConfiguration;
 
 import static org.apache.camel.quarkus.component.kudu.it.KuduInfrastructureTestHelper.KUDU_AUTHORITY_CONFIG_KEY;
 
-public class KuduTestResource implements ContainerResourceLifecycleManager {
+public class KuduTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOG = LoggerFactory.getLogger(KuduTestResource.class);
     private static final int KUDU_MASTER_RPC_PORT = 7051;
     private static final int KUDU_MASTER_HTTP_PORT = 8051;
diff --git a/integration-tests/lra/pom.xml b/integration-tests/lra/pom.xml
index cfb28cc..9192f4e 100644
--- a/integration-tests/lra/pom.xml
+++ b/integration-tests/lra/pom.xml
@@ -76,7 +76,7 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <artifactId>camel-quarkus-integration-test-support</artifactId>
             <scope>test</scope>
         </dependency>
         <dependency>
@@ -84,6 +84,11 @@
             <artifactId>awaitility</artifactId>
             <scope>test</scope>
         </dependency>
+        <dependency>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
+            <scope>test</scope>
+        </dependency>
 
         <!-- 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>
diff --git a/integration-tests/messaging/pom.xml b/integration-tests/messaging/pom.xml
index d7554b9..5e0369e 100644
--- a/integration-tests/messaging/pom.xml
+++ b/integration-tests/messaging/pom.xml
@@ -79,8 +79,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/minio/pom.xml b/integration-tests/minio/pom.xml
index 1e7035d..07663f8 100644
--- a/integration-tests/minio/pom.xml
+++ b/integration-tests/minio/pom.xml
@@ -64,13 +64,13 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.awaitility</groupId>
+            <artifactId>awaitility</artifactId>
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.awaitility</groupId>
-            <artifactId>awaitility</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/minio/src/test/java/org/apache/camel/quarkus/component/minio/it/MinioTestResource.java b/integration-tests/minio/src/test/java/org/apache/camel/quarkus/component/minio/it/MinioTestResource.java
index e5fd6a7..e276038 100644
--- a/integration-tests/minio/src/test/java/org/apache/camel/quarkus/component/minio/it/MinioTestResource.java
+++ b/integration-tests/minio/src/test/java/org/apache/camel/quarkus/component/minio/it/MinioTestResource.java
@@ -19,12 +19,12 @@ package org.apache.camel.quarkus.component.minio.it;
 import java.time.Duration;
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.HttpWaitStrategy;
 
-public class MinioTestResource implements ContainerResourceLifecycleManager {
+public class MinioTestResource implements QuarkusTestResourceLifecycleManager {
 
     public static final String CONTAINER_ACCESS_KEY = "MINIO_ACCESS_KEY";
     public static final String CONTAINER_SECRET_KEY = "MINIO_SECRET_KEY";
diff --git a/integration-tests/mongodb/pom.xml b/integration-tests/mongodb/pom.xml
index bf8cd3b..bbc34b1 100644
--- a/integration-tests/mongodb/pom.xml
+++ b/integration-tests/mongodb/pom.xml
@@ -58,11 +58,9 @@
             <artifactId>rest-assured</artifactId>
             <scope>test</scope>
         </dependency>
-
-        <!-- test dependencies - camel-quarkus -->
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/mongodb/src/test/java/org/apache/camel/quarkus/component/mongodb/it/MongoDbTestResource.java b/integration-tests/mongodb/src/test/java/org/apache/camel/quarkus/component/mongodb/it/MongoDbTestResource.java
index 729ac8c..c245260 100644
--- a/integration-tests/mongodb/src/test/java/org/apache/camel/quarkus/component/mongodb/it/MongoDbTestResource.java
+++ b/integration-tests/mongodb/src/test/java/org/apache/camel/quarkus/component/mongodb/it/MongoDbTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.mongodb.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -27,7 +27,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.TestcontainersConfiguration;
 
-public class MongoDbTestResource implements ContainerResourceLifecycleManager {
+public class MongoDbTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOGGER = LoggerFactory.getLogger(MongoDbTestResource.class);
     private static final int MONGODB_PORT = 27017;
     private static final String MONGO_IMAGE = "mongo:4.0";
diff --git a/integration-tests/nats/pom.xml b/integration-tests/nats/pom.xml
index 6096ef4..ab381f2 100644
--- a/integration-tests/nats/pom.xml
+++ b/integration-tests/nats/pom.xml
@@ -71,13 +71,13 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.awaitility</groupId>
+            <artifactId>awaitility</artifactId>
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.awaitility</groupId>
-            <artifactId>awaitility</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/nats/src/test/java/org/apache/camel/quarkus/component/nats/it/NatsTestResource.java b/integration-tests/nats/src/test/java/org/apache/camel/quarkus/component/nats/it/NatsTestResource.java
index 6a6344a..b52be5e 100644
--- a/integration-tests/nats/src/test/java/org/apache/camel/quarkus/component/nats/it/NatsTestResource.java
+++ b/integration-tests/nats/src/test/java/org/apache/camel/quarkus/component/nats/it/NatsTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.nats.it;
 import java.util.HashMap;
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.testcontainers.containers.BindMode;
@@ -34,7 +34,7 @@ import static org.apache.camel.quarkus.component.nats.it.NatsConfiguration.NATS_
 import static org.apache.camel.quarkus.component.nats.it.NatsConfiguration.NATS_BROKER_URL_TLS_AUTH_CONFIG_KEY;
 import static org.apache.camel.quarkus.component.nats.it.NatsConfiguration.NATS_BROKER_URL_TOKEN_AUTH_CONFIG_KEY;
 
-public class NatsTestResource implements ContainerResourceLifecycleManager {
+public class NatsTestResource implements QuarkusTestResourceLifecycleManager {
 
     private static final Logger LOG = LoggerFactory.getLogger(NatsTestResource.class);
     private static final String BASIC_AUTH_USERNAME = "admin";
diff --git a/integration-tests/nsq/pom.xml b/integration-tests/nsq/pom.xml
index 3ccf37a..35a67e3 100644
--- a/integration-tests/nsq/pom.xml
+++ b/integration-tests/nsq/pom.xml
@@ -72,8 +72,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/nsq/src/test/java/org/apache/camel/quarkus/component/nsq/it/NsqTestResource.java b/integration-tests/nsq/src/test/java/org/apache/camel/quarkus/component/nsq/it/NsqTestResource.java
index 764b3ac..d95a911 100644
--- a/integration-tests/nsq/src/test/java/org/apache/camel/quarkus/component/nsq/it/NsqTestResource.java
+++ b/integration-tests/nsq/src/test/java/org/apache/camel/quarkus/component/nsq/it/NsqTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.nsq.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.testcontainers.containers.FixedHostPortGenericContainer;
@@ -36,7 +36,7 @@ import static org.apache.camel.quarkus.component.nsq.it.NsqRoute.PRODUCER_HOST_C
 import static org.apache.camel.quarkus.component.nsq.it.NsqRoute.PRODUCER_PORT_CFG_KEY;
 import static org.apache.camel.util.CollectionHelper.mapOf;
 
-public class NsqTestResource implements ContainerResourceLifecycleManager {
+public class NsqTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOG = LoggerFactory.getLogger(NsqTestResource.class);
 
     public static final String CONTAINER_NSQ_IMAGE = "nsqio/nsq:v1.2.0";
diff --git a/integration-tests/paho-mqtt5/pom.xml b/integration-tests/paho-mqtt5/pom.xml
index 1fb9b2b..34fc019 100644
--- a/integration-tests/paho-mqtt5/pom.xml
+++ b/integration-tests/paho-mqtt5/pom.xml
@@ -64,8 +64,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/pg-replication-slot/pom.xml b/integration-tests/pg-replication-slot/pom.xml
index 548db97..bd7537e 100644
--- a/integration-tests/pg-replication-slot/pom.xml
+++ b/integration-tests/pg-replication-slot/pom.xml
@@ -72,8 +72,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/pg-replication-slot/src/test/java/org/apache/camel/quarkus/component/pg/replication/slot/it/PgReplicationSlotTestResource.java b/integration-tests/pg-replication-slot/src/test/java/org/apache/camel/quarkus/component/pg/replication/slot/it/PgReplicationSlotTestResource.java
index b99d067..902b28b 100644
--- a/integration-tests/pg-replication-slot/src/test/java/org/apache/camel/quarkus/component/pg/replication/slot/it/PgReplicationSlotTestResource.java
+++ b/integration-tests/pg-replication-slot/src/test/java/org/apache/camel/quarkus/component/pg/replication/slot/it/PgReplicationSlotTestResource.java
@@ -19,7 +19,7 @@ package org.apache.camel.quarkus.component.pg.replication.slot.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.testcontainers.containers.GenericContainer;
@@ -33,7 +33,7 @@ import static org.apache.camel.quarkus.component.pg.replication.slot.it.PgReplic
 import static org.apache.camel.quarkus.component.pg.replication.slot.it.PgReplicationSlotRoute.PG_USER_CFG_KEY;
 import static org.apache.camel.util.CollectionHelper.mapOf;
 
-public class PgReplicationSlotTestResource implements ContainerResourceLifecycleManager {
+public class PgReplicationSlotTestResource implements QuarkusTestResourceLifecycleManager {
     private static final Logger LOG = LoggerFactory.getLogger(PgReplicationSlotTestResource.class);
     private static final int POSTGRES_PORT = 5432;
     private static final String POSTGRES_IMAGE = "postgres:13.0";
diff --git a/integration-tests/pgevent/pom.xml b/integration-tests/pgevent/pom.xml
index 05851ae..ac7e0b1 100644
--- a/integration-tests/pgevent/pom.xml
+++ b/integration-tests/pgevent/pom.xml
@@ -75,13 +75,15 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
+
+        <!-- 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-mock-deployment</artifactId>
+            <artifactId>camel-quarkus-pgevent-deployment</artifactId>
             <version>${project.version}</version>
             <type>pom</type>
             <scope>test</scope>
@@ -92,11 +94,9 @@
                 </exclusion>
             </exclusions>
         </dependency>
-
-        <!-- 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-pgevent-deployment</artifactId>
+            <artifactId>camel-quarkus-direct-deployment</artifactId>
             <version>${project.version}</version>
             <type>pom</type>
             <scope>test</scope>
@@ -109,7 +109,7 @@
         </dependency>
         <dependency>
             <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-direct-deployment</artifactId>
+            <artifactId>camel-quarkus-mock-deployment</artifactId>
             <version>${project.version}</version>
             <type>pom</type>
             <scope>test</scope>
diff --git a/integration-tests/pgevent/src/test/java/org/apache/camel/quarkus/component/pgevent/it/PgEventTestResource.java b/integration-tests/pgevent/src/test/java/org/apache/camel/quarkus/component/pgevent/it/PgEventTestResource.java
index c585409..5828864 100644
--- a/integration-tests/pgevent/src/test/java/org/apache/camel/quarkus/component/pgevent/it/PgEventTestResource.java
+++ b/integration-tests/pgevent/src/test/java/org/apache/camel/quarkus/component/pgevent/it/PgEventTestResource.java
@@ -18,7 +18,7 @@ package org.apache.camel.quarkus.component.pgevent.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -26,7 +26,7 @@ import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.output.Slf4jLogConsumer;
 import org.testcontainers.containers.wait.strategy.Wait;
 
-public class PgEventTestResource implements ContainerResourceLifecycleManager {
+public class PgEventTestResource implements QuarkusTestResourceLifecycleManager {
 
     protected static final String CONTAINER_NAME = "pg-event";
     protected static final String POSTGRES_USER = "postgres";
@@ -71,13 +71,4 @@ public class PgEventTestResource implements ContainerResourceLifecycleManager {
                 .waitingFor(Wait.forListeningPort());
         return container;
     }
-
-    public Integer getMappedPort() {
-        return container.getMappedPort(POSTGRES_PORT);
-    }
-
-    public String getHost() {
-        return container.getHost();
-    }
-
 }
diff --git a/integration-tests/rabbitmq/pom.xml b/integration-tests/rabbitmq/pom.xml
index 7d0d6a4..ee8e85a 100644
--- a/integration-tests/rabbitmq/pom.xml
+++ b/integration-tests/rabbitmq/pom.xml
@@ -51,8 +51,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/solr/pom.xml b/integration-tests/solr/pom.xml
index 1997b06..30a0bf5 100644
--- a/integration-tests/solr/pom.xml
+++ b/integration-tests/solr/pom.xml
@@ -71,11 +71,6 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
             <groupId>org.testcontainers</groupId>
             <artifactId>solr</artifactId>
             <scope>test</scope>
diff --git a/integration-tests/solr/src/test/java/org/apache/camel/quarkus/component/solr/it/SolrTestResource.java b/integration-tests/solr/src/test/java/org/apache/camel/quarkus/component/solr/it/SolrTestResource.java
index 7fef3cc..206638c 100644
--- a/integration-tests/solr/src/test/java/org/apache/camel/quarkus/component/solr/it/SolrTestResource.java
+++ b/integration-tests/solr/src/test/java/org/apache/camel/quarkus/component/solr/it/SolrTestResource.java
@@ -18,7 +18,7 @@ package org.apache.camel.quarkus.component.solr.it;
 
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.apache.camel.util.CollectionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -27,7 +27,7 @@ import org.testcontainers.containers.SolrContainer;
 import org.testcontainers.containers.output.Slf4jLogConsumer;
 import org.testcontainers.utility.DockerImageName;
 
-public class SolrTestResource implements ContainerResourceLifecycleManager {
+public class SolrTestResource implements QuarkusTestResourceLifecycleManager {
 
     private static final Logger LOGGER = LoggerFactory.getLogger(SolrTestResource.class);
 
diff --git a/integration-tests/spring-rabbitmq/pom.xml b/integration-tests/spring-rabbitmq/pom.xml
index af1173f..5e4424a 100644
--- a/integration-tests/spring-rabbitmq/pom.xml
+++ b/integration-tests/spring-rabbitmq/pom.xml
@@ -55,6 +55,7 @@
             <groupId>org.apache.camel.quarkus</groupId>
             <artifactId>camel-quarkus-direct</artifactId>
         </dependency>
+
         <!-- test dependencies -->
         <dependency>
             <groupId>io.quarkus</groupId>
@@ -67,11 +68,6 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
             <groupId>org.awaitility</groupId>
             <artifactId>awaitility</artifactId>
             <scope>test</scope>
diff --git a/integration-tests/ssh/pom.xml b/integration-tests/ssh/pom.xml
index 538bfc0..53e198c 100644
--- a/integration-tests/ssh/pom.xml
+++ b/integration-tests/ssh/pom.xml
@@ -63,8 +63,8 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
+            <groupId>org.testcontainers</groupId>
+            <artifactId>testcontainers</artifactId>
             <scope>test</scope>
         </dependency>
 
diff --git a/integration-tests/vertx-kafka/pom.xml b/integration-tests/vertx-kafka/pom.xml
index 9e2de5c..512a7ea 100644
--- a/integration-tests/vertx-kafka/pom.xml
+++ b/integration-tests/vertx-kafka/pom.xml
@@ -64,11 +64,6 @@
             <scope>test</scope>
         </dependency>
         <dependency>
-            <groupId>org.apache.camel.quarkus</groupId>
-            <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-            <scope>test</scope>
-        </dependency>
-        <dependency>
             <groupId>org.testcontainers</groupId>
             <artifactId>kafka</artifactId>
             <scope>test</scope>
diff --git a/integration-tests/vertx-kafka/src/test/java/org/apache/camel/quarkus/component/vertx/kafka/it/VertxKafkaTestResource.java b/integration-tests/vertx-kafka/src/test/java/org/apache/camel/quarkus/component/vertx/kafka/it/VertxKafkaTestResource.java
index eeef17d..15364a8 100644
--- a/integration-tests/vertx-kafka/src/test/java/org/apache/camel/quarkus/component/vertx/kafka/it/VertxKafkaTestResource.java
+++ b/integration-tests/vertx-kafka/src/test/java/org/apache/camel/quarkus/component/vertx/kafka/it/VertxKafkaTestResource.java
@@ -19,12 +19,12 @@ package org.apache.camel.quarkus.component.vertx.kafka.it;
 import java.util.Collections;
 import java.util.Map;
 
-import org.apache.camel.quarkus.testcontainers.ContainerResourceLifecycleManager;
+import io.quarkus.test.common.QuarkusTestResourceLifecycleManager;
 import org.testcontainers.containers.KafkaContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
 import org.testcontainers.utility.DockerImageName;
 
-public class VertxKafkaTestResource implements ContainerResourceLifecycleManager {
+public class VertxKafkaTestResource implements QuarkusTestResourceLifecycleManager {
 
     private static final String KAFKA_IMAGE_NAME = "confluentinc/cp-kafka:5.4.3";
     private KafkaContainer container;
diff --git a/poms/bom-test/pom.xml b/poms/bom-test/pom.xml
index f7c94f7..b99e108 100644
--- a/poms/bom-test/pom.xml
+++ b/poms/bom-test/pom.xml
@@ -104,11 +104,6 @@
             </dependency>
             <dependency>
                 <groupId>org.apache.camel.quarkus</groupId>
-                <artifactId>camel-quarkus-integration-testcontainers-support</artifactId>
-                <version>${camel-quarkus.version}</version>
-            </dependency>
-            <dependency>
-                <groupId>org.apache.camel.quarkus</groupId>
                 <artifactId>camel-quarkus-integration-wiremock-support</artifactId>
                 <version>${camel-quarkus.version}</version>
             </dependency>