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/11/08 09:22:26 UTC

[camel-quarkus] branch camel-main updated (9604db1 -> 39c50bf)

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

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


    omit 9604db1  Disable AtlasMap native tests due to #3189
    omit de0087d  Use hard coded azure-bom version property since it has been removed from camel-parent & camel-dependencies
    omit ceef63c  Disable MllpTest.testCharsetFromMsh18 due to #3225
    omit 83a33fd  Upgrade Camel to 3.13.0
     add a2f9cf8  Expand route configurations test coverage #2978
     add 4bebde1  Updated CHANGELOG.md
     add dc433f7  Sql - enable stored procedure test for different db types #3080
     add 218bef4  Cannot run tests against alternative BOMs #3258
     add 5f666c7  Fixup 218bef4 Deactivate the virtualDepenencies profile via -DnoVirtualDependencies rather than !virtualDependencies #3258
     add 2874a60  Remove not needed anymore BeansWeakCache substitution. Closes #3226 (#3264)
     add bb1b3dc  Updated CHANGELOG.md
     add a331a0d5 avro: Fix the documentation about avro schema build time parsing #3270
     add 86e69db  Updated CHANGELOG.md
     add 792dad6  Upgrade Camel to 3.13.0
     add d34ce81  Use hard coded azure-bom version property since it has been removed from camel-parent & camel-dependencies
     add 39c50bf  Disable AtlasMap native tests due to #3189

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   (9604db1)
            \
             N -- N -- N   refs/heads/camel-main (39c50bf)

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.

No new revisions were added by this update.

Summary of changes:
 CHANGELOG.md                                       |  10 +
 .../ROOT/pages/reference/extensions/avro.adoc      |   2 +-
 .../runtime/graal/SubstituteBeansIntrospector.java |  30 --
 .../runtime/graal/SubstituteBeansWeakCache.java    |  65 ----
 .../avro/runtime/src/main/doc/configuration.adoc   |   2 +-
 .../aws2-quarkus-client/aws2-ddb/pom.xml           |  39 +-
 .../aws2-quarkus-client/aws2-s3/pom.xml            |  65 ++--
 .../aws2-quarkus-client/aws2-ses/pom.xml           |  39 +-
 .../aws2-quarkus-client/aws2-sqs-sns/pom.xml       |  65 ++--
 integration-test-groups/aws2/aws2-cw/pom.xml       |  39 +-
 integration-test-groups/aws2/aws2-ddb/pom.xml      |  39 +-
 integration-test-groups/aws2/aws2-kinesis/pom.xml  |  39 +-
 integration-test-groups/aws2/aws2-lambda/pom.xml   |  39 +-
 integration-test-groups/aws2/aws2-s3/pom.xml       |  65 ++--
 integration-test-groups/aws2/aws2-ses/pom.xml      |  39 +-
 integration-test-groups/aws2/aws2-sqs-sns/pom.xml  |  65 ++--
 .../azure/azure-eventhubs/pom.xml                  |  65 ++--
 .../azure/azure-storage-blob/pom.xml               |  39 +-
 .../azure/azure-storage-queue/pom.xml              |  39 +-
 integration-test-groups/foundation/bean/pom.xml    |  65 ++--
 integration-test-groups/foundation/browse/pom.xml  |  65 ++--
 .../foundation/component-name-resolver/pom.xml     |  91 +++--
 .../foundation/controlbus/pom.xml                  |  65 ++--
 .../foundation/core-annotations/pom.xml            |  65 ++--
 .../foundation/core-fault-tolerance/pom.xml        |  65 ++--
 .../foundation/core-languages/pom.xml              |  65 ++--
 .../foundation/core-thread-pools/pom.xml           |  39 +-
 integration-test-groups/foundation/core/pom.xml    |  39 +-
 integration-test-groups/foundation/direct/pom.xml  |  39 +-
 integration-test-groups/foundation/eip/pom.xml     |  65 ++--
 .../foundation/language/pom.xml                    |  65 ++--
 integration-test-groups/foundation/log/pom.xml     |  39 +-
 integration-test-groups/foundation/mock/pom.xml    |  91 +++--
 integration-test-groups/foundation/pom.xml         |   1 +
 integration-test-groups/foundation/ref/pom.xml     |  65 ++--
 .../foundation/route-configurations}/pom.xml       | 133 ++-----
 .../RouteConfigurationsConfigurationBuilder.java}  |  18 +-
 .../RouteConfigurationsException.java              |  21 +-
 .../RouteConfigurationsResource.java               |  35 +-
 .../RouteConfigurationsRouteBuilder.java           |  56 +++
 .../src/main}/resources/application.properties     |   3 +-
 .../src/main/resources/xml/routeConfigurations.xml |  15 +-
 .../src/main/resources/xml/routes.xml              |  12 +-
 .../main/resources/yaml/routeConfigurations.yaml   |  24 +-
 .../src/main/resources/yaml/routes.yaml            |  14 +-
 .../routeconfigurations/RouteConfigurationsIT.java |   4 +-
 .../RouteConfigurationsTest.java                   |  89 +++++
 .../foundation/scheduler/pom.xml                   |  39 +-
 integration-test-groups/foundation/seda/pom.xml    |  39 +-
 integration-test-groups/foundation/stream/pom.xml  |  39 +-
 integration-test-groups/foundation/timer/pom.xml   |  39 +-
 .../foundation/type-converter/pom.xml              |  39 +-
 .../mongodb/mongodb-gridfs/pom.xml                 |  39 +-
 integration-test-groups/mongodb/mongodb/pom.xml    |  39 +-
 integration-tests-jvm/asn1/pom.xml                 |  42 ++-
 integration-tests-jvm/asterisk/pom.xml             |  42 ++-
 integration-tests-jvm/atmos/pom.xml                |  42 ++-
 integration-tests-jvm/atomix/pom.xml               |  42 ++-
 integration-tests-jvm/aws-secrets-manager/pom.xml  |  42 ++-
 integration-tests-jvm/aws-xray/pom.xml             |  42 ++-
 integration-tests-jvm/azure-cosmosdb/pom.xml       |  42 ++-
 .../azure-storage-datalake/pom.xml                 |  42 ++-
 integration-tests-jvm/barcode/pom.xml              |  42 ++-
 integration-tests-jvm/beanio/pom.xml               |  42 ++-
 integration-tests-jvm/beanstalk/pom.xml            |  42 ++-
 integration-tests-jvm/bonita/pom.xml               |  42 ++-
 integration-tests-jvm/chatscript/pom.xml           |  42 ++-
 integration-tests-jvm/chunk/pom.xml                |  42 ++-
 integration-tests-jvm/cm-sms/pom.xml               |  42 ++-
 integration-tests-jvm/cmis/pom.xml                 |  42 ++-
 integration-tests-jvm/coap/pom.xml                 |  42 ++-
 integration-tests-jvm/cometd/pom.xml               |  42 ++-
 integration-tests-jvm/corda/pom.xml                |  42 ++-
 integration-tests-jvm/couchbase/pom.xml            |  42 ++-
 integration-tests-jvm/djl/pom.xml                  |  42 ++-
 integration-tests-jvm/dns/pom.xml                  |  42 ++-
 integration-tests-jvm/drill/pom.xml                |  42 ++-
 integration-tests-jvm/ehcache/pom.xml              |  42 ++-
 integration-tests-jvm/elsql/pom.xml                |  42 ++-
 integration-tests-jvm/etcd/pom.xml                 |  42 ++-
 integration-tests-jvm/etcd3/pom.xml                |  42 ++-
 integration-tests-jvm/facebook/pom.xml             |  42 ++-
 integration-tests-jvm/fastjson/pom.xml             |  42 ++-
 integration-tests-jvm/flink/pom.xml                |  42 ++-
 integration-tests-jvm/ganglia/pom.xml              |  42 ++-
 integration-tests-jvm/google-functions/pom.xml     |  42 ++-
 integration-tests-jvm/groovy-dsl/pom.xml           |  68 ++--
 integration-tests-jvm/groovy/pom.xml               |  68 ++--
 integration-tests-jvm/guava-eventbus/pom.xml       |  42 ++-
 integration-tests-jvm/hbase/pom.xml                |  42 ++-
 integration-tests-jvm/hdfs/pom.xml                 |  42 ++-
 integration-tests-jvm/huaweicloud-smn/pom.xml      |  42 ++-
 integration-tests-jvm/iec60870/pom.xml             |  42 ++-
 integration-tests-jvm/ignite/pom.xml               |  42 ++-
 integration-tests-jvm/iota/pom.xml                 |  42 ++-
 integration-tests-jvm/irc/pom.xml                  |  42 ++-
 integration-tests-jvm/jasypt/pom.xml               |  42 ++-
 integration-tests-jvm/java-joor-dsl/pom.xml        |  68 ++--
 integration-tests-jvm/jbpm/pom.xml                 |  42 ++-
 integration-tests-jvm/jcache/pom.xml               |  42 ++-
 integration-tests-jvm/jclouds/pom.xml              |  42 ++-
 integration-tests-jvm/jcr/pom.xml                  |  42 ++-
 integration-tests-jvm/jfr/pom.xml                  |  94 +++--
 integration-tests-jvm/jgroups-raft/pom.xml         |  42 ++-
 integration-tests-jvm/jgroups/pom.xml              |  42 ++-
 integration-tests-jvm/jooq/pom.xml                 |  42 ++-
 integration-tests-jvm/joor/pom.xml                 |  42 ++-
 integration-tests-jvm/jsonapi/pom.xml              |  42 ++-
 integration-tests-jvm/jt400/pom.xml                |  42 ++-
 integration-tests-jvm/kamelet-reify/pom.xml        |  42 ++-
 integration-tests-jvm/kotlin-dsl/pom.xml           |  68 ++--
 integration-tests-jvm/ldap/pom.xml                 |  42 ++-
 integration-tests-jvm/ldif/pom.xml                 |  42 ++-
 integration-tests-jvm/lucene/pom.xml               |  42 ++-
 integration-tests-jvm/management/pom.xml           |  68 ++--
 integration-tests-jvm/milo/pom.xml                 |  42 ++-
 integration-tests-jvm/mvel/pom.xml                 |  42 ++-
 integration-tests-jvm/mybatis/pom.xml              |  42 ++-
 integration-tests-jvm/ognl/pom.xml                 |  42 ++-
 integration-tests-jvm/printer/pom.xml              |  42 ++-
 integration-tests-jvm/pulsar/pom.xml               |  42 ++-
 integration-tests-jvm/quickfix/pom.xml             |  42 ++-
 integration-tests-jvm/redis/pom.xml                |  94 +++--
 integration-tests-jvm/ribbon/pom.xml               |  42 ++-
 integration-tests-jvm/robotframework/pom.xml       |  42 ++-
 integration-tests-jvm/schematron/pom.xml           |  42 ++-
 integration-tests-jvm/sip/pom.xml                  |  42 ++-
 integration-tests-jvm/smpp/pom.xml                 |  42 ++-
 integration-tests-jvm/snmp/pom.xml                 |  42 ++-
 integration-tests-jvm/soroush/pom.xml              |  42 ++-
 integration-tests-jvm/spark/pom.xml                |  39 +-
 integration-tests-jvm/splunk-hec/pom.xml           |  42 ++-
 integration-tests-jvm/stitch/pom.xml               |  42 ++-
 integration-tests-jvm/stomp/pom.xml                |  42 ++-
 integration-tests-jvm/stub/pom.xml                 |  42 ++-
 integration-tests-jvm/thrift/pom.xml               |  42 ++-
 integration-tests-jvm/web3j/pom.xml                |  42 ++-
 integration-tests-jvm/weka/pom.xml                 |  42 ++-
 integration-tests-jvm/wordpress/pom.xml            |  42 ++-
 integration-tests-jvm/workday/pom.xml              |  42 ++-
 integration-tests-jvm/xj/pom.xml                   |  42 ++-
 integration-tests-jvm/xmpp/pom.xml                 |  42 ++-
 integration-tests-jvm/xslt-saxon/pom.xml           |  42 ++-
 integration-tests-jvm/yammer/pom.xml               |  42 ++-
 integration-tests-jvm/zookeeper-master/pom.xml     |  42 ++-
 integration-tests-jvm/zookeeper/pom.xml            |  42 ++-
 integration-tests/activemq/pom.xml                 |  39 +-
 integration-tests/amqp/pom.xml                     |  39 +-
 integration-tests/arangodb/pom.xml                 |  39 +-
 integration-tests/as2/pom.xml                      |  39 +-
 integration-tests/atlasmap/pom.xml                 |  91 +++--
 integration-tests/avro-rpc/pom.xml                 |  39 +-
 integration-tests/avro/pom.xml                     |  65 ++--
 integration-tests/aws2-grouped/pom.xml             | 247 +++++++------
 .../aws2-quarkus-client-grouped/pom.xml            | 169 +++++----
 integration-tests/aws2/pom.xml                     | 377 ++++++++++---------
 integration-tests/azure-grouped/pom.xml            | 117 +++---
 integration-tests/base64/pom.xml                   |  65 ++--
 integration-tests/bean-validator/pom.xml           |  65 ++--
 integration-tests/bindy/pom.xml                    |  65 ++--
 integration-tests/box/pom.xml                      |  65 ++--
 integration-tests/braintree/pom.xml                |  39 +-
 integration-tests/caffeine/pom.xml                 |  39 +-
 integration-tests/cassandraql/pom.xml              |  39 +-
 integration-tests/cbor/pom.xml                     |  91 +++--
 integration-tests/compression/pom.xml              | 117 +++---
 integration-tests/consul/pom.xml                   |  39 +-
 integration-tests/core-discovery-disabled/pom.xml  |  65 ++--
 integration-tests/couchdb/pom.xml                  |  39 +-
 integration-tests/crypto/pom.xml                   |  65 ++--
 integration-tests/csimple/pom.xml                  |  91 +++--
 integration-tests/csv/pom.xml                      |  65 ++--
 integration-tests/dataformat/pom.xml               | 117 +++---
 integration-tests/dataformats-json/pom.xml         | 301 +++++++--------
 integration-tests/debezium/pom.xml                 |  65 ++--
 integration-tests/digitalocean/pom.xml             |  91 +++--
 integration-tests/disruptor/pom.xml                |  65 ++--
 integration-tests/dozer/pom.xml                    |  65 ++--
 integration-tests/dropbox/pom.xml                  |  39 +-
 integration-tests/elasticsearch-rest/pom.xml       |  65 ++--
 integration-tests/exec/pom.xml                     |  65 ++--
 integration-tests/fhir/pom.xml                     |  65 ++--
 integration-tests/file/pom.xml                     | 143 +++----
 integration-tests/flatpack/pom.xml                 |  91 +++--
 integration-tests/fop/pom.xml                      |  39 +-
 integration-tests/foundation-grouped/pom.xml       | 411 ++++++++++++---------
 integration-tests/freemarker/pom.xml               |  39 +-
 integration-tests/ftp/pom.xml                      |  65 ++--
 .../component/sftp/it/SftpTestResource.java        |   4 +-
 integration-tests/geocoder/pom.xml                 |  39 +-
 integration-tests/git/pom.xml                      |  39 +-
 integration-tests/github/pom.xml                   |  39 +-
 integration-tests/google-bigquery/pom.xml          |  39 +-
 integration-tests/google-pubsub/pom.xml            |  39 +-
 integration-tests/google-storage/pom.xml           |  65 ++--
 integration-tests/google/pom.xml                   | 117 +++---
 integration-tests/graphql/pom.xml                  |  39 +-
 integration-tests/grok/pom.xml                     |  91 +++--
 integration-tests/grpc/pom.xml                     |  91 +++--
 integration-tests/hazelcast/pom.xml                |  65 ++--
 integration-tests/headersmap/pom.xml               |  39 +-
 integration-tests/hl7/pom.xml                      | 143 +++----
 integration-tests/http/pom.xml                     | 169 +++++----
 integration-tests/hystrix/pom.xml                  |  91 +++--
 integration-tests/infinispan/pom.xml               |  91 +++--
 integration-tests/influxdb/pom.xml                 |  39 +-
 integration-tests/ipfs/pom.xml                     |  39 +-
 integration-tests/jackson-avro/pom.xml             |  65 ++--
 integration-tests/jackson-protobuf/pom.xml         |  65 ++--
 integration-tests/jaxb/pom.xml                     |  65 ++--
 integration-tests/jdbc/pom.xml                     |  65 ++--
 integration-tests/jing/pom.xml                     |  65 ++--
 integration-tests/jira/pom.xml                     |  65 ++--
 integration-tests/jms-artemis-client/pom.xml       |  39 +-
 integration-tests/jms-qpid-amqp-client/pom.xml     |  39 +-
 integration-tests/jolt/pom.xml                     |  39 +-
 integration-tests/jpa/pom.xml                      |  39 +-
 integration-tests/js-dsl/pom.xml                   |  65 ++--
 integration-tests/jsch/pom.xml                     |  39 +-
 integration-tests/jslt/pom.xml                     |  39 +-
 integration-tests/json-validator/pom.xml           |  65 ++--
 integration-tests/jsonata/pom.xml                  |  65 ++--
 integration-tests/jsonpath/pom.xml                 | 117 +++---
 integration-tests/jta/pom.xml                      | 169 +++++----
 integration-tests/kafka-sasl-ssl/pom.xml           |  65 ++--
 integration-tests/kafka-sasl/pom.xml               |  65 ++--
 integration-tests/kafka-ssl/pom.xml                |  65 ++--
 integration-tests/kafka/pom.xml                    | 143 +++----
 integration-tests/kamelet/pom.xml                  | 143 +++----
 integration-tests/kotlin/pom.xml                   |  91 +++--
 integration-tests/kubernetes/pom.xml               |  39 +-
 integration-tests/kudu/pom.xml                     | 117 +++---
 integration-tests/leveldb/pom.xml                  |  91 +++--
 integration-tests/lra/pom.xml                      | 117 +++---
 integration-tests/lumberjack/pom.xml               |  65 ++--
 integration-tests/mail/pom.xml                     |  65 ++--
 integration-tests/main-caffeine-lrucache/pom.xml   |  39 +-
 integration-tests/main-collector/pom.xml           |  94 +++--
 integration-tests/main-command-mode/pom.xml        |  65 ++--
 integration-tests/main-devmode/pom.xml             | 120 +++---
 integration-tests/main-discovery-disabled/pom.xml  |  65 ++--
 integration-tests/main-unknown-args-fail/pom.xml   |  65 ++--
 integration-tests/main-unknown-args-ignore/pom.xml |  65 ++--
 integration-tests/main-xml-io/pom.xml              | 169 +++++----
 integration-tests/main-xml-jaxb/pom.xml            | 195 +++++-----
 integration-tests/main-yaml/pom.xml                | 169 +++++----
 integration-tests/main/pom.xml                     | 143 +++----
 integration-tests/master/pom.xml                   | 143 +++----
 integration-tests/micrometer/pom.xml               |  91 +++--
 integration-tests/microprofile/pom.xml             | 143 +++----
 integration-tests/minio/pom.xml                    |  39 +-
 integration-tests/mllp/pom.xml                     |  91 +++--
 .../camel/quarkus/component/mllp/it/MllpTest.java  |   2 -
 integration-tests/mongodb-grouped/pom.xml          |  65 ++--
 integration-tests/msv/pom.xml                      |  65 ++--
 integration-tests/mustache/pom.xml                 |  39 +-
 integration-tests/nagios/pom.xml                   |  39 +-
 integration-tests/nats/pom.xml                     |  65 ++--
 integration-tests/netty/pom.xml                    |  91 +++--
 integration-tests/nitrite/pom.xml                  |  39 +-
 integration-tests/nsq/pom.xml                      |  65 ++--
 integration-tests/oaipmh/pom.xml                   | 117 +++---
 integration-tests/olingo4/pom.xml                  |  39 +-
 integration-tests/openapi-java/pom.xml             | 169 +++++----
 integration-tests/openstack/pom.xml                |  39 +-
 integration-tests/opentelemetry/pom.xml            | 117 +++---
 integration-tests/opentracing/pom.xml              |  91 +++--
 integration-tests/optaplanner/pom.xml              |  91 +++--
 integration-tests/paho-mqtt5/pom.xml               |  39 +-
 integration-tests/paho/pom.xml                     |  39 +-
 integration-tests/pdf/pom.xml                      |  39 +-
 integration-tests/pg-replication-slot/pom.xml      |  39 +-
 integration-tests/pgevent/pom.xml                  |  91 +++--
 integration-tests/platform-http-engine/pom.xml     |  39 +-
 integration-tests/platform-http/pom.xml            | 117 +++---
 integration-tests/protobuf/pom.xml                 |  65 ++--
 integration-tests/pubnub/pom.xml                   |  91 +++--
 integration-tests/quartz/pom.xml                   |  91 +++--
 integration-tests/qute/pom.xml                     |  65 ++--
 integration-tests/rabbitmq/pom.xml                 |  39 +-
 integration-tests/reactive-streams/pom.xml         |  65 ++--
 integration-tests/rest-openapi/pom.xml             |  91 +++--
 integration-tests/rest/pom.xml                     | 169 +++++----
 integration-tests/saga/pom.xml                     |  91 +++--
 integration-tests/salesforce/pom.xml               |  95 ++---
 integration-tests/sap-netweaver/pom.xml            |  91 +++--
 integration-tests/saxon/pom.xml                    |  91 +++--
 integration-tests/servicenow/pom.xml               |  39 +-
 integration-tests/servlet/pom.xml                  |  91 +++--
 integration-tests/shiro/pom.xml                    |  91 +++--
 integration-tests/sjms-artemis-client/pom.xml      |  39 +-
 integration-tests/sjms-qpid-amqp-client/pom.xml    |  39 +-
 integration-tests/sjms2-artemis-client/pom.xml     |  39 +-
 integration-tests/sjms2-qpid-amqp-client/pom.xml   |  39 +-
 integration-tests/slack/pom.xml                    |  65 ++--
 .../smallrye-reactive-messaging/pom.xml            |  91 +++--
 integration-tests/soap/pom.xml                     |  65 ++--
 integration-tests/solr/pom.xml                     |  39 +-
 integration-tests/splunk/pom.xml                   |  65 ++--
 integration-tests/spring-rabbitmq/pom.xml          |  67 ++--
 integration-tests/sql/README.adoc                  |   2 +-
 integration-tests/sql/pom.xml                      |  91 +++--
 .../quarkus/component/sql/it/SqlDbInitializer.java |   2 +-
 .../quarkus/component/sql/it/SqlResource.java      |  16 +-
 .../sql/src/main/resources/sql/db2/initDb.sql      |   7 +
 .../sql/src/main/resources/sql/mariadb/initDb.sql  |   8 +
 .../sql/src/main/resources/sql/mssql/initDb.sql    |   9 +-
 .../sql/src/main/resources/sql/mysql/initDb.sql    |   7 +
 .../src/main/resources/sql/postgresql/initDb.sql   |   1 +
 .../camel/quarkus/component/sql/it/SqlTest.java    |   2 +-
 integration-tests/ssh/pom.xml                      |  39 +-
 integration-tests/stax/pom.xml                     | 117 +++---
 integration-tests/stringtemplate/pom.xml           |  39 +-
 integration-tests/syndication/pom.xml              |  91 +++--
 integration-tests/syslog/pom.xml                   |  65 ++--
 integration-tests/tarfile/pom.xml                  |  65 ++--
 integration-tests/telegram/pom.xml                 |  91 +++--
 integration-tests/tika/pom.xml                     |  39 +-
 integration-tests/twilio/pom.xml                   |  39 +-
 integration-tests/twitter/pom.xml                  |  39 +-
 integration-tests/univocity-parsers/pom.xml        |  65 ++--
 integration-tests/validator/pom.xml                |  65 ++--
 integration-tests/velocity/pom.xml                 |  39 +-
 integration-tests/vertx-kafka/pom.xml              |  39 +-
 integration-tests/vertx-websocket/pom.xml          |  39 +-
 integration-tests/vertx/pom.xml                    |  65 ++--
 integration-tests/weather/pom.xml                  |  39 +-
 integration-tests/xchange/pom.xml                  |  39 +-
 integration-tests/xml/pom.xml                      | 169 +++++----
 integration-tests/xmlsecurity/pom.xml              |  65 ++--
 integration-tests/xpath/pom.xml                    |  91 +++--
 integration-tests/xstream/pom.xml                  |  91 +++--
 integration-tests/zendesk/pom.xml                  |  39 +-
 pom.xml                                            |   2 +-
 poms/build-parent-it/pom.xml                       |   3 +-
 335 files changed, 11823 insertions(+), 8727 deletions(-)
 delete mode 100644 extensions-support/common/runtime/src/main/java/org/apache/camel/quarkus/support/common/runtime/graal/SubstituteBeansIntrospector.java
 delete mode 100644 extensions-support/common/runtime/src/main/java/org/apache/camel/quarkus/support/common/runtime/graal/SubstituteBeansWeakCache.java
 copy {integration-tests/debezium => integration-test-groups/foundation/route-configurations}/pom.xml (53%)
 copy integration-test-groups/{aws2-quarkus-client/aws2-s3/src/test/java/org/apache/camel/quarkus/component/aws2/s3/it/Aws2S3QuarkusClientIT.java => foundation/route-configurations/src/main/java/org/apache/camel/quarkus/core/it/routeconfigurations/RouteConfigurationsConfigurationBuilder.java} (55%)
 copy integration-tests/dataformats-json/src/main/java/org/apache/camel/quarkus/component/dataformats/json/model/AnotherObject.java => integration-test-groups/foundation/route-configurations/src/main/java/org/apache/camel/quarkus/core/it/routeconfigurations/RouteConfigurationsException.java (66%)
 copy integration-tests/saxon/src/main/java/org/apache/camel/quarkus/component/saxon/it/SaxonXPathResource.java => integration-test-groups/foundation/route-configurations/src/main/java/org/apache/camel/quarkus/core/it/routeconfigurations/RouteConfigurationsResource.java (59%)
 create mode 100644 integration-test-groups/foundation/route-configurations/src/main/java/org/apache/camel/quarkus/core/it/routeconfigurations/RouteConfigurationsRouteBuilder.java
 copy {extensions/kafka/deployment/src/test => integration-test-groups/foundation/route-configurations/src/main}/resources/application.properties (85%)
 copy integration-tests/kamelet/src/main/resources/kamelets-runtime/upper-kamelet.xml => integration-test-groups/foundation/route-configurations/src/main/resources/xml/routeConfigurations.xml (69%)
 copy integration-tests/kamelet/src/main/resources/kamelets-runtime/upper-kamelet.xml => integration-test-groups/foundation/route-configurations/src/main/resources/xml/routes.xml (74%)
 copy .asf.yaml => integration-test-groups/foundation/route-configurations/src/main/resources/yaml/routeConfigurations.yaml (67%)
 copy integration-tests/main-yaml/src/main/resources/routes/my-rests.yaml => integration-test-groups/foundation/route-configurations/src/main/resources/yaml/routes.yaml (72%)
 copy integration-tests/digitalocean/src/test/java/org/apache/camel/quarkus/component/digitalocean/it/DigitaloceanDropletIT.java => integration-test-groups/foundation/route-configurations/src/test/java/org/apache/camel/quarkus/core/it/routeconfigurations/RouteConfigurationsIT.java (87%)
 create mode 100644 integration-test-groups/foundation/route-configurations/src/test/java/org/apache/camel/quarkus/core/it/routeconfigurations/RouteConfigurationsTest.java