You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by gi...@apache.org on 2020/09/01 01:23:04 UTC

[camel-kafka-connector] branch camel-master updated (ab8fbfd -> ec5bec4)

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

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


 discard ab8fbfd  [create-pull-request] automated change
    omit dd0365a  [create-pull-request] automated change
    omit f5bf8b5  [create-pull-request] automated change
    omit 95c865c  Fix cassandra for camel 3.5
    omit 1dbdd2b  Regen
    omit 8724490  Pointing the github actions to 3.5.0-SNAPSHOT
    omit 289c605  Point to 3.5.0-SNAPSHOT
     add be6dff5  #389 - Fix doc- Kubernetes command
     add 59c9ff4  Merge pull request #401 from rogeriob2br/master
     new 895f7c1  Point to 3.5.0-SNAPSHOT
     new b87ab80  Pointing the github actions to 3.5.0-SNAPSHOT
     new fa27344  Regen
     new 054de9d  Fix cassandra for camel 3.5
     new 34b4496  [create-pull-request] automated change
     new ed40b79  [create-pull-request] automated change
     new ec5bec4  [create-pull-request] automated change

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   (ab8fbfd)
            \
             N -- N -- N   refs/heads/camel-master (ec5bec4)

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

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

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


Summary of changes:
 docs/modules/ROOT/pages/try-it-out-on-kubernetes.adoc | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)


[camel-kafka-connector] 03/07: Regen

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

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

commit fa2734428ca1d88e42be3decd3986b9a521331c9
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Tue Aug 25 08:12:43 2020 +0200

    Regen
---
 .github/workflows/automatic-sync-camel-master.yml  |  63 ---
 .../docs/camel-activemq-kafka-sink-connector.adoc  |   4 +-
 .../camel-activemq-kafka-source-connector.adoc     |   4 +-
 .../activemq/CamelActivemqSinkConnectorConfig.java |   8 +
 .../CamelActivemqSourceConnectorConfig.java        |   8 +
 .../main/docs/camel-amqp-kafka-sink-connector.adoc |   4 +-
 .../docs/camel-amqp-kafka-source-connector.adoc    |   4 +-
 .../amqp/CamelAmqpSinkConnectorConfig.java         |   8 +
 .../amqp/CamelAmqpSourceConnectorConfig.java       |   8 +
 .../docs/camel-apns-kafka-source-connector.adoc    |   2 +-
 .../apns/CamelApnsSourceConnectorConfig.java       |   2 +-
 connectors/camel-arangodb-kafka-connector/pom.xml  | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 .../docs/camel-arangodb-kafka-sink-connector.adoc  |  53 +++
 .../CamelArangodbSinkConnector.properties}         |  10 +-
 .../arangodb/CamelArangodbSinkConnector.java       |  35 ++
 .../arangodb/CamelArangodbSinkConnectorConfig.java | 144 +++++++
 .../arangodb/CamelArangodbSinkTask.java            |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 .../main/docs/camel-as2-kafka-sink-connector.adoc  |   2 +-
 .../docs/camel-as2-kafka-source-connector.adoc     |   4 +-
 .../as2/CamelAs2SinkConnectorConfig.java           |   8 +-
 .../as2/CamelAs2SourceConnectorConfig.java         |  10 +-
 ...-atmosphere-websocket-kafka-sink-connector.adoc |  14 +-
 ...amelAtmospherewebsocketSinkConnectorConfig.java |  48 ---
 .../docs/camel-atom-kafka-source-connector.adoc    |   2 +-
 .../atom/CamelAtomSourceConnectorConfig.java       |   2 +-
 .../docs/camel-aws-cw-kafka-sink-connector.adoc    |   4 +-
 .../awscw/CamelAwscwSinkConnectorConfig.java       |   8 +
 .../docs/camel-aws-ddb-kafka-sink-connector.adoc   |   4 +-
 .../awsddb/CamelAwsddbSinkConnectorConfig.java     |   8 +
 ...camel-aws-ddbstream-kafka-source-connector.adoc |   6 +-
 .../CamelAwsddbstreamSourceConnectorConfig.java    |  10 +-
 ...-aws-kinesis-firehose-kafka-sink-connector.adoc |   4 +-
 ...CamelAwskinesisfirehoseSinkConnectorConfig.java |   8 +
 .../camel-aws-kinesis-kafka-sink-connector.adoc    |   4 +-
 .../camel-aws-kinesis-kafka-source-connector.adoc  |   6 +-
 .../CamelAwskinesisSinkConnectorConfig.java        |   8 +
 .../CamelAwskinesisSourceConnectorConfig.java      |  10 +-
 .../camel-aws-lambda-kafka-sink-connector.adoc     |   4 +-
 .../CamelAwslambdaSinkConnectorConfig.java         |   8 +
 .../docs/camel-aws-s3-kafka-sink-connector.adoc    |   4 +-
 .../docs/camel-aws-s3-kafka-source-connector.adoc  |   6 +-
 .../awss3/CamelAwss3SinkConnectorConfig.java       |   8 +
 .../awss3/CamelAwss3SourceConnectorConfig.java     |  10 +-
 .../docs/camel-aws-ses-kafka-sink-connector.adoc   |   4 +-
 .../awsses/CamelAwssesSinkConnectorConfig.java     |   8 +
 .../docs/camel-aws-sns-kafka-sink-connector.adoc   |   4 +-
 .../awssns/CamelAwssnsSinkConnectorConfig.java     |   8 +
 .../docs/camel-aws-sqs-kafka-sink-connector.adoc   |   4 +-
 .../docs/camel-aws-sqs-kafka-source-connector.adoc |   6 +-
 .../awssqs/CamelAwssqsSinkConnectorConfig.java     |   8 +
 .../awssqs/CamelAwssqsSourceConnectorConfig.java   |  10 +-
 .../camel-aws-translate-kafka-sink-connector.adoc  |   4 +-
 .../CamelAwstranslateSinkConnectorConfig.java      |   8 +
 .../camel-aws2-athena-kafka-sink-connector.adoc    |   6 +-
 .../CamelAws2athenaSinkConnectorConfig.java        |   8 +
 .../docs/camel-aws2-cw-kafka-sink-connector.adoc   |   6 +-
 .../aws2cw/CamelAws2cwSinkConnectorConfig.java     |  16 +
 .../docs/camel-aws2-ddb-kafka-sink-connector.adoc  |   6 +-
 .../aws2ddb/CamelAws2ddbSinkConnectorConfig.java   |  16 +
 ...amel-aws2-ddbstream-kafka-source-connector.adoc |   8 +-
 .../CamelAws2ddbstreamSourceConnectorConfig.java   |  18 +-
 ...aws2-kinesis-firehose-kafka-sink-connector.adoc |  10 +-
 ...amelAws2kinesisfirehoseSinkConnectorConfig.java |  24 ++
 .../camel-aws2-kinesis-kafka-sink-connector.adoc   |   8 +-
 .../camel-aws2-kinesis-kafka-source-connector.adoc |  10 +-
 .../CamelAws2kinesisSinkConnectorConfig.java       |  16 +
 .../CamelAws2kinesisSourceConnectorConfig.java     |  18 +-
 .../camel-aws2-lambda-kafka-sink-connector.adoc    |   6 +-
 .../CamelAws2lambdaSinkConnectorConfig.java        |  16 +
 .../docs/camel-aws2-s3-kafka-sink-connector.adoc   |  22 +-
 .../docs/camel-aws2-s3-kafka-source-connector.adoc |  18 +-
 .../aws2s3/CamelAws2s3SinkConnectorConfig.java     |  68 ++--
 .../aws2s3/CamelAws2s3SourceConnectorConfig.java   |  46 ++-
 .../docs/camel-aws2-ses-kafka-sink-connector.adoc  |   6 +-
 .../aws2ses/CamelAws2sesSinkConnectorConfig.java   |  16 +
 .../docs/camel-aws2-sns-kafka-sink-connector.adoc  |   6 +-
 .../aws2sns/CamelAws2snsSinkConnectorConfig.java   |  16 +
 .../docs/camel-aws2-sqs-kafka-sink-connector.adoc  |  10 +-
 .../camel-aws2-sqs-kafka-source-connector.adoc     |   8 +-
 .../aws2sqs/CamelAws2sqsSinkConnectorConfig.java   |  20 +-
 .../aws2sqs/CamelAws2sqsSourceConnectorConfig.java |  18 +-
 connectors/camel-aws2-sts-kafka-connector/pom.xml  | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 .../docs/camel-aws2-sts-kafka-sink-connector.adoc  |  57 +++
 .../examples/CamelAws2stsSinkConnector.properties} |  14 +-
 .../aws2sts/CamelAws2stsSinkConnector.java         |  35 ++
 .../aws2sts/CamelAws2stsSinkConnectorConfig.java   | 158 ++++++++
 .../aws2sts/CamelAws2stsSinkTask.java              |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 .../camel-aws2-translate-kafka-sink-connector.adoc |   6 +-
 .../CamelAws2translateSinkConnectorConfig.java     |  16 +
 .../camel-azure-eventhubs-kafka-connector/pom.xml  | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 ...camel-azure-eventhubs-kafka-sink-connector.adoc |  54 +++
 ...mel-azure-eventhubs-kafka-source-connector.adoc |  66 +++
 .../CamelAzureeventhubsSinkConnector.properties}   |   8 +-
 .../CamelAzureeventhubsSourceConnector.properties} |   6 +-
 .../CamelAzureeventhubsSinkConnector.java          |  35 ++
 .../CamelAzureeventhubsSinkConnectorConfig.java    | 149 +++++++
 .../CamelAzureeventhubsSinkTask.java               |  39 ++
 .../CamelAzureeventhubsSourceConnector.java        |  35 ++
 .../CamelAzureeventhubsSourceConnectorConfig.java  | 197 +++++++++
 .../CamelAzureeventhubsSourceTask.java             |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 ...el-azure-storage-blob-kafka-sink-connector.adoc |  26 +-
 ...-azure-storage-blob-kafka-source-connector.adoc |  12 +-
 .../CamelAzurestorageblobSinkConnectorConfig.java  |  88 ++++
 ...CamelAzurestorageblobSourceConnectorConfig.java |  32 ++
 ...l-azure-storage-queue-kafka-sink-connector.adoc |  12 +-
 ...azure-storage-queue-kafka-source-connector.adoc |  10 +-
 .../CamelAzurestoragequeueSinkConnectorConfig.java |  32 ++
 ...amelAzurestoragequeueSourceConnectorConfig.java |  24 ++
 .../docs/camel-beanstalk-kafka-sink-connector.adoc |   2 +-
 .../camel-beanstalk-kafka-source-connector.adoc    |   4 +-
 .../CamelBeanstalkSinkConnectorConfig.java         |   8 +-
 .../CamelBeanstalkSourceConnectorConfig.java       |  10 +-
 .../docs/camel-box-kafka-source-connector.adoc     |   2 +-
 .../box/CamelBoxSourceConnectorConfig.java         |   2 +-
 .../docs/camel-braintree-kafka-sink-connector.adoc |   2 +-
 .../camel-braintree-kafka-source-connector.adoc    |   4 +-
 .../CamelBraintreeSinkConnectorConfig.java         |   2 +-
 .../CamelBraintreeSourceConnectorConfig.java       |   4 +-
 .../main/docs/camel-cmis-kafka-sink-connector.adoc |   2 +-
 .../docs/camel-cmis-kafka-source-connector.adoc    |   2 +-
 .../cmis/CamelCmisSinkConnectorConfig.java         |   8 +-
 .../cmis/CamelCmisSourceConnectorConfig.java       |   8 +-
 .../docs/camel-couchbase-kafka-sink-connector.adoc |  13 +-
 .../camel-couchbase-kafka-source-connector.adoc    |  15 +-
 .../CamelCouchbaseSinkConnectorConfig.java         |  44 +-
 .../CamelCouchbaseSourceConnectorConfig.java       |  46 +--
 .../main/docs/camel-cql-kafka-sink-connector.adoc  |   6 +-
 .../docs/camel-cql-kafka-source-connector.adoc     |   8 +-
 .../cql/CamelCqlSinkConnectorConfig.java           |  18 +-
 .../cql/CamelCqlSourceConnectorConfig.java         |  20 +-
 ...el-debezium-mongodb-kafka-source-connector.adoc |  14 +-
 .../CamelDebeziummongodbSourceConnectorConfig.java |  48 +++
 ...amel-debezium-mysql-kafka-source-connector.adoc |  18 +-
 .../CamelDebeziummysqlSourceConnectorConfig.java   |  28 +-
 ...l-debezium-postgres-kafka-source-connector.adoc |  20 +-
 ...CamelDebeziumpostgresSourceConnectorConfig.java |  60 ++-
 ...-debezium-sqlserver-kafka-source-connector.adoc |  20 +-
 ...amelDebeziumsqlserverSourceConnectorConfig.java |  60 ++-
 .../docs/camel-elsql-kafka-source-connector.adoc   |   2 +-
 .../elsql/CamelElsqlSourceConnectorConfig.java     |   2 +-
 .../camel-etcd-stats-kafka-source-connector.adoc   |   2 +-
 .../CamelEtcdstatsSourceConnectorConfig.java       |   2 +-
 .../docs/camel-fhir-kafka-source-connector.adoc    |   2 +-
 .../fhir/CamelFhirSourceConnectorConfig.java       |   2 +-
 .../docs/camel-file-kafka-source-connector.adoc    |   2 +-
 .../file/CamelFileSourceConnectorConfig.java       |   2 +-
 .../camel-flatpack-kafka-source-connector.adoc     |   2 +-
 .../CamelFlatpackSourceConnectorConfig.java        |   2 +-
 .../docs/camel-flink-kafka-sink-connector.adoc     |   3 +-
 .../flink/CamelFlinkSinkConnectorConfig.java       |   4 -
 .../docs/camel-ftp-kafka-source-connector.adoc     |   2 +-
 .../ftp/CamelFtpSourceConnectorConfig.java         |   2 +-
 .../docs/camel-ftps-kafka-source-connector.adoc    |   2 +-
 .../ftps/CamelFtpsSourceConnectorConfig.java       |   2 +-
 ...mel-google-calendar-kafka-source-connector.adoc |   2 +-
 .../CamelGooglecalendarSourceConnectorConfig.java  |   2 +-
 ...gle-calendar-stream-kafka-source-connector.adoc |   2 +-
 ...lGooglecalendarstreamSourceConnectorConfig.java |   2 +-
 .../camel-google-drive-kafka-source-connector.adoc |   2 +-
 .../CamelGoogledriveSourceConnectorConfig.java     |   2 +-
 .../camel-google-mail-kafka-source-connector.adoc  |   2 +-
 .../CamelGooglemailSourceConnectorConfig.java      |   2 +-
 ...-google-mail-stream-kafka-source-connector.adoc |   2 +-
 ...CamelGooglemailstreamSourceConnectorConfig.java |   2 +-
 ...camel-google-sheets-kafka-source-connector.adoc |   2 +-
 .../CamelGooglesheetsSourceConnectorConfig.java    |   2 +-
 ...oogle-sheets-stream-kafka-source-connector.adoc |   2 +-
 ...melGooglesheetsstreamSourceConnectorConfig.java |   2 +-
 .../camel-guava-eventbus-kafka-sink-connector.adoc |   3 +-
 ...amel-guava-eventbus-kafka-source-connector.adoc |   2 +-
 .../CamelGuavaeventbusSinkConnectorConfig.java     |   4 -
 .../CamelGuavaeventbusSourceConnectorConfig.java   |   8 +-
 .../main/docs/camel-hdfs-kafka-sink-connector.adoc |   4 +-
 .../docs/camel-hdfs-kafka-source-connector.adoc    |   6 +-
 .../hdfs/CamelHdfsSinkConnectorConfig.java         |  16 +-
 .../hdfs/CamelHdfsSourceConnectorConfig.java       |  18 +-
 .../docs/camel-hipchat-kafka-source-connector.adoc |   2 +-
 .../hipchat/CamelHipchatSourceConnectorConfig.java |   2 +-
 .../main/docs/camel-http-kafka-sink-connector.adoc |  10 +-
 .../http/CamelHttpSinkConnectorConfig.java         |  32 ++
 .../docs/camel-https-kafka-sink-connector.adoc     |  10 +-
 .../https/CamelHttpsSinkConnectorConfig.java       |  32 ++
 .../camel-ignite-cache-kafka-sink-connector.adoc   |   6 +-
 .../camel-ignite-cache-kafka-source-connector.adoc |   6 +-
 .../CamelIgnitecacheSinkConnectorConfig.java       |   6 +-
 .../CamelIgnitecacheSourceConnectorConfig.java     |   6 +-
 .../camel-ignite-compute-kafka-sink-connector.adoc |   6 +-
 .../CamelIgnitecomputeSinkConnectorConfig.java     |   6 +-
 ...camel-ignite-events-kafka-source-connector.adoc |   6 +-
 .../CamelIgniteeventsSourceConnectorConfig.java    |   6 +-
 .../camel-ignite-idgen-kafka-sink-connector.adoc   |   6 +-
 .../CamelIgniteidgenSinkConnectorConfig.java       |   6 +-
 ...amel-ignite-messaging-kafka-sink-connector.adoc |   6 +-
 ...el-ignite-messaging-kafka-source-connector.adoc |   6 +-
 .../CamelIgnitemessagingSinkConnectorConfig.java   |   6 +-
 .../CamelIgnitemessagingSourceConnectorConfig.java |   6 +-
 .../camel-ignite-queue-kafka-sink-connector.adoc   |   6 +-
 .../CamelIgnitequeueSinkConnectorConfig.java       |   6 +-
 .../camel-ignite-set-kafka-sink-connector.adoc     |   6 +-
 .../CamelIgnitesetSinkConnectorConfig.java         |   6 +-
 .../docs/camel-imap-kafka-source-connector.adoc    |   2 +-
 .../imap/CamelImapSourceConnectorConfig.java       |   2 +-
 .../docs/camel-imaps-kafka-source-connector.adoc   |   2 +-
 .../imaps/CamelImapsSourceConnectorConfig.java     |   2 +-
 .../docs/camel-ironmq-kafka-source-connector.adoc  |   2 +-
 .../ironmq/CamelIronmqSourceConnectorConfig.java   |   2 +-
 .../main/docs/camel-jms-kafka-sink-connector.adoc  |   4 +-
 .../docs/camel-jms-kafka-source-connector.adoc     |   4 +-
 .../jms/CamelJmsSinkConnectorConfig.java           |   8 +
 .../jms/CamelJmsSourceConnectorConfig.java         |   8 +
 .../docs/camel-jooq-kafka-source-connector.adoc    |   2 +-
 .../jooq/CamelJooqSourceConnectorConfig.java       |   2 +-
 .../docs/camel-jpa-kafka-source-connector.adoc     |   2 +-
 .../jpa/CamelJpaSourceConnectorConfig.java         |   2 +-
 connectors/camel-jsonata-kafka-connector/pom.xml   | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 .../docs/camel-jsonata-kafka-sink-connector.adoc}  |  30 +-
 .../examples/CamelJsonataSinkConnector.properties} |  16 +-
 .../jsonata/CamelJsonataSinkConnector.java         |  35 ++
 .../jsonata/CamelJsonataSinkConnectorConfig.java   |  82 ++++
 .../jsonata/CamelJsonataSinkTask.java              |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 .../docs/camel-jt400-kafka-sink-connector.adoc     |  16 +-
 .../docs/camel-jt400-kafka-source-connector.adoc   |  19 +-
 .../examples/CamelJt400SinkConnector.properties    |   8 +-
 .../examples/CamelJt400SourceConnector.properties  |   8 +-
 .../jt400/CamelJt400SinkConnectorConfig.java       |  16 +-
 .../jt400/CamelJt400SourceConnectorConfig.java     |  20 +-
 .../docs/camel-kafka-kafka-sink-connector.adoc     |   4 +-
 .../docs/camel-kafka-kafka-source-connector.adoc   |   4 +-
 .../kafka/CamelKafkaSinkConnectorConfig.java       |   4 +-
 .../kafka/CamelKafkaSourceConnectorConfig.java     |   4 +-
 .../camel-milo-server-kafka-sink-connector.adoc    |  12 +-
 .../camel-milo-server-kafka-source-connector.adoc  |  12 +-
 .../CamelMiloserverSinkConnectorConfig.java        |  48 +--
 .../CamelMiloserverSourceConnectorConfig.java      |  48 +--
 connectors/camel-minio-kafka-connector/pom.xml     | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 .../docs/camel-minio-kafka-sink-connector.adoc     |  71 ++++
 .../docs/camel-minio-kafka-source-connector.adoc   | 129 ++++++
 .../examples/CamelMinioSinkConnector.properties}   |  10 +-
 .../examples/CamelMinioSourceConnector.properties} |   8 +-
 .../minio/CamelMinioSinkConnector.java             |  35 ++
 .../minio/CamelMinioSinkConnectorConfig.java       | 214 ++++++++++
 .../kafkaconnector/minio/CamelMinioSinkTask.java   |  39 ++
 .../minio/CamelMinioSourceConnector.java           |  35 ++
 .../minio/CamelMinioSourceConnectorConfig.java     | 448 +++++++++++++++++++++
 .../kafkaconnector/minio/CamelMinioSourceTask.java |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 .../docs/camel-mongodb-kafka-sink-connector.adoc   |   2 +-
 .../docs/camel-mongodb-kafka-source-connector.adoc |   2 +-
 .../mongodb/CamelMongodbSinkConnectorConfig.java   |   2 +-
 .../mongodb/CamelMongodbSourceConnectorConfig.java |   2 +-
 .../docs/camel-mybatis-kafka-source-connector.adoc |   2 +-
 .../mybatis/CamelMybatisSourceConnectorConfig.java |   2 +-
 connectors/camel-oaipmh-kafka-connector/pom.xml    | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 .../docs/camel-oaipmh-kafka-sink-connector.adoc    |  43 ++
 .../docs/camel-oaipmh-kafka-source-connector.adoc  |  38 +-
 .../examples/CamelOaipmhSinkConnector.properties}  |  10 +-
 .../CamelOaipmhSourceConnector.properties}         |   8 +-
 .../oaipmh/CamelOaipmhSinkConnector.java           |  35 ++
 .../oaipmh/CamelOaipmhSinkConnectorConfig.java     | 102 +++++
 .../kafkaconnector/oaipmh/CamelOaipmhSinkTask.java |  39 ++
 .../oaipmh/CamelOaipmhSourceConnector.java         |  35 ++
 .../oaipmh/CamelOaipmhSourceConnectorConfig.java   | 172 ++++++++
 .../oaipmh/CamelOaipmhSourceTask.java              |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 .../docs/camel-olingo2-kafka-sink-connector.adoc   |   6 +-
 .../docs/camel-olingo2-kafka-source-connector.adoc |   8 +-
 .../olingo2/CamelOlingo2SinkConnectorConfig.java   |  16 +
 .../olingo2/CamelOlingo2SourceConnectorConfig.java |  18 +-
 .../docs/camel-olingo4-kafka-source-connector.adoc |   2 +-
 .../olingo4/CamelOlingo4SourceConnectorConfig.java |   2 +-
 ...pg-replication-slot-kafka-source-connector.adoc |   2 +-
 ...amelPgreplicationslotSourceConnectorConfig.java |   2 +-
 .../docs/camel-pop3-kafka-source-connector.adoc    |   2 +-
 .../pop3/CamelPop3SourceConnectorConfig.java       |   2 +-
 .../docs/camel-pop3s-kafka-source-connector.adoc   |   2 +-
 .../pop3s/CamelPop3sSourceConnectorConfig.java     |   2 +-
 .../docs/camel-pulsar-kafka-source-connector.adoc  |   6 +-
 .../pulsar/CamelPulsarSourceConnectorConfig.java   |  16 +
 .../docs/camel-quartz-kafka-source-connector.adoc  |   4 +-
 .../examples/CamelQuartzSourceConnector.properties |   2 +-
 .../quartz/CamelQuartzSourceConnectorConfig.java   |   4 +-
 .../docs/camel-rabbitmq-kafka-sink-connector.adoc  |   7 +-
 .../camel-rabbitmq-kafka-source-connector.adoc     |   7 +-
 .../rabbitmq/CamelRabbitmqSinkConnectorConfig.java |   8 +-
 .../CamelRabbitmqSourceConnectorConfig.java        |   8 +-
 .../main/docs/camel-rest-kafka-sink-connector.adoc |   2 +-
 .../rest/CamelRestSinkConnectorConfig.java         |   2 +-
 .../docs/camel-resteasy-kafka-sink-connector.adoc  |  52 +--
 .../camel-resteasy-kafka-source-connector.adoc     |  35 +-
 .../resteasy/CamelResteasySinkConnectorConfig.java | 192 ---------
 .../CamelResteasySourceConnectorConfig.java        | 124 +-----
 ...amel-robotframework-kafka-source-connector.adoc |   2 +-
 .../CamelRobotframeworkSourceConnectorConfig.java  |   2 +-
 .../docs/camel-rss-kafka-source-connector.adoc     |   2 +-
 .../rss/CamelRssSourceConnectorConfig.java         |   2 +-
 .../camel-salesforce-kafka-sink-connector.adoc     |   2 +-
 .../camel-salesforce-kafka-source-connector.adoc   |   2 +-
 .../CamelSalesforceSinkConnectorConfig.java        |   2 +-
 .../CamelSalesforceSourceConnectorConfig.java      |   2 +-
 .../camel-scheduler-kafka-source-connector.adoc    |   2 +-
 .../CamelSchedulerSourceConnectorConfig.java       |   2 +-
 .../docs/camel-sftp-kafka-source-connector.adoc    |   2 +-
 .../sftp/CamelSftpSourceConnectorConfig.java       |   2 +-
 .../camel-sjms-batch-kafka-source-connector.adoc   |   2 +-
 .../CamelSjmsbatchSourceConnectorConfig.java       |   4 +-
 .../docs/camel-slack-kafka-sink-connector.adoc     |   2 +-
 .../docs/camel-slack-kafka-source-connector.adoc   |   4 +-
 .../slack/CamelSlackSinkConnectorConfig.java       |   8 +-
 .../slack/CamelSlackSourceConnectorConfig.java     |  10 +-
 .../docs/camel-smtp-kafka-source-connector.adoc    |   2 +-
 .../smtp/CamelSmtpSourceConnectorConfig.java       |   2 +-
 .../docs/camel-smtps-kafka-source-connector.adoc   |   2 +-
 .../smtps/CamelSmtpsSourceConnectorConfig.java     |   2 +-
 .../docs/camel-snmp-kafka-source-connector.adoc    |   2 +-
 .../snmp/CamelSnmpSourceConnectorConfig.java       |   2 +-
 .../docs/camel-splunk-kafka-source-connector.adoc  |   2 +-
 .../splunk/CamelSplunkSourceConnectorConfig.java   |   2 +-
 .../docs/camel-sql-kafka-source-connector.adoc     |   2 +-
 .../sql/CamelSqlSourceConnectorConfig.java         |   2 +-
 .../docs/camel-ssh-kafka-source-connector.adoc     |   2 +-
 .../ssh/CamelSshSourceConnectorConfig.java         |   2 +-
 .../docs/camel-telegram-kafka-sink-connector.adoc  |   3 +-
 .../camel-telegram-kafka-source-connector.adoc     |   5 +-
 .../telegram/CamelTelegramSinkConnectorConfig.java |   4 +
 .../CamelTelegramSourceConnectorConfig.java        |   6 +-
 .../docs/camel-twilio-kafka-source-connector.adoc  |   2 +-
 .../twilio/CamelTwilioSourceConnectorConfig.java   |   2 +-
 ...itter-directmessage-kafka-source-connector.adoc |   2 +-
 ...lTwitterdirectmessageSourceConnectorConfig.java |   2 +-
 ...amel-twitter-search-kafka-source-connector.adoc |   2 +-
 .../CamelTwittersearchSourceConnectorConfig.java   |   2 +-
 ...el-twitter-timeline-kafka-source-connector.adoc |   2 +-
 .../CamelTwittertimelineSourceConnectorConfig.java |   2 +-
 .../docs/camel-undertow-kafka-sink-connector.adoc  |   2 +-
 .../camel-undertow-kafka-source-connector.adoc     |   2 +-
 .../undertow/CamelUndertowSinkConnectorConfig.java |   2 +-
 .../CamelUndertowSourceConnectorConfig.java        |   2 +-
 .../camel-vertx-http-kafka-connector/pom.xml       | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 .../camel-vertx-http-kafka-sink-connector.adoc     |  70 ++++
 .../CamelVertxhttpSinkConnector.properties}        |  10 +-
 .../vertxhttp/CamelVertxhttpSinkConnector.java     |  35 ++
 .../CamelVertxhttpSinkConnectorConfig.java         | 212 ++++++++++
 .../vertxhttp/CamelVertxhttpSinkTask.java          |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 .../camel-vertx-websocket-kafka-connector/pom.xml  | 135 +++++++
 .../src/main/assembly/package.xml                  |  57 +++
 ...camel-vertx-websocket-kafka-sink-connector.adoc |  42 ++
 ...mel-vertx-websocket-kafka-source-connector.adoc |  45 +++
 .../CamelVertxwebsocketSinkConnector.properties}   |  10 +-
 .../CamelVertxwebsocketSourceConnector.properties} |   8 +-
 .../CamelVertxwebsocketSinkConnector.java          |  35 ++
 .../CamelVertxwebsocketSinkConnectorConfig.java    | 101 +++++
 .../CamelVertxwebsocketSinkTask.java               |  39 ++
 .../CamelVertxwebsocketSourceConnector.java        |  35 ++
 .../CamelVertxwebsocketSourceConnectorConfig.java  | 113 ++++++
 .../CamelVertxwebsocketSourceTask.java             |  39 ++
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ++++++++++
 .../src/main/resources/META-INF/NOTICE.txt         |  11 +
 .../docs/camel-weather-kafka-sink-connector.adoc   |   7 +-
 .../docs/camel-weather-kafka-source-connector.adoc |   9 +-
 .../weather/CamelWeatherSinkConnectorConfig.java   |  14 +-
 .../weather/CamelWeatherSourceConnectorConfig.java |  16 +-
 .../docs/camel-workday-kafka-sink-connector.adoc   |   2 +-
 .../examples/CamelWorkdaySinkConnector.properties  |   2 +-
 .../workday/CamelWorkdaySinkConnectorConfig.java   |   2 +-
 .../docs/camel-xquery-kafka-source-connector.adoc  |   2 +-
 .../xquery/CamelXquerySourceConnectorConfig.java   |   2 +-
 .../docs/camel-yammer-kafka-source-connector.adoc  |   2 +-
 .../yammer/CamelYammerSourceConnectorConfig.java   |   2 +-
 .../docs/camel-zendesk-kafka-source-connector.adoc |   2 +-
 .../zendesk/CamelZendeskSourceConnectorConfig.java |   2 +-
 connectors/pom.xml                                 |   8 +
 docs/modules/ROOT/pages/connectors.adoc            |  10 +-
 .../camel-activemq-kafka-sink-connector.adoc       |   4 +-
 .../camel-activemq-kafka-source-connector.adoc     |   4 +-
 .../camel-amqp-kafka-sink-connector.adoc           |   4 +-
 .../camel-amqp-kafka-source-connector.adoc         |   4 +-
 .../camel-apns-kafka-source-connector.adoc         |   2 +-
 .../camel-arangodb-kafka-sink-connector.adoc       |  53 +++
 .../connectors/camel-as2-kafka-sink-connector.adoc |   2 +-
 .../camel-as2-kafka-source-connector.adoc          |   4 +-
 ...-atmosphere-websocket-kafka-sink-connector.adoc |  14 +-
 .../camel-atom-kafka-source-connector.adoc         |   2 +-
 .../camel-aws-cw-kafka-sink-connector.adoc         |   4 +-
 .../camel-aws-ddb-kafka-sink-connector.adoc        |   4 +-
 ...camel-aws-ddbstream-kafka-source-connector.adoc |   6 +-
 ...-aws-kinesis-firehose-kafka-sink-connector.adoc |   4 +-
 .../camel-aws-kinesis-kafka-sink-connector.adoc    |   4 +-
 .../camel-aws-kinesis-kafka-source-connector.adoc  |   6 +-
 .../camel-aws-lambda-kafka-sink-connector.adoc     |   4 +-
 .../camel-aws-s3-kafka-sink-connector.adoc         |   4 +-
 .../camel-aws-s3-kafka-source-connector.adoc       |   6 +-
 .../camel-aws-ses-kafka-sink-connector.adoc        |   4 +-
 .../camel-aws-sns-kafka-sink-connector.adoc        |   4 +-
 .../camel-aws-sqs-kafka-sink-connector.adoc        |   4 +-
 .../camel-aws-sqs-kafka-source-connector.adoc      |   6 +-
 .../camel-aws-translate-kafka-sink-connector.adoc  |   4 +-
 .../camel-aws2-athena-kafka-sink-connector.adoc    |   6 +-
 .../camel-aws2-cw-kafka-sink-connector.adoc        |   6 +-
 .../camel-aws2-ddb-kafka-sink-connector.adoc       |   6 +-
 ...amel-aws2-ddbstream-kafka-source-connector.adoc |   8 +-
 ...aws2-kinesis-firehose-kafka-sink-connector.adoc |  10 +-
 .../camel-aws2-kinesis-kafka-sink-connector.adoc   |   8 +-
 .../camel-aws2-kinesis-kafka-source-connector.adoc |  10 +-
 .../camel-aws2-lambda-kafka-sink-connector.adoc    |   6 +-
 .../camel-aws2-s3-kafka-sink-connector.adoc        |  22 +-
 .../camel-aws2-s3-kafka-source-connector.adoc      |  18 +-
 .../camel-aws2-ses-kafka-sink-connector.adoc       |   6 +-
 .../camel-aws2-sns-kafka-sink-connector.adoc       |   6 +-
 .../camel-aws2-sqs-kafka-sink-connector.adoc       |  10 +-
 .../camel-aws2-sqs-kafka-source-connector.adoc     |   8 +-
 .../camel-aws2-sts-kafka-sink-connector.adoc       |  57 +++
 .../camel-aws2-translate-kafka-sink-connector.adoc |   6 +-
 ...camel-azure-eventhubs-kafka-sink-connector.adoc |  54 +++
 ...mel-azure-eventhubs-kafka-source-connector.adoc |  66 +++
 ...el-azure-storage-blob-kafka-sink-connector.adoc |  26 +-
 ...-azure-storage-blob-kafka-source-connector.adoc |  12 +-
 ...l-azure-storage-queue-kafka-sink-connector.adoc |  12 +-
 ...azure-storage-queue-kafka-source-connector.adoc |  10 +-
 .../camel-beanstalk-kafka-sink-connector.adoc      |   2 +-
 .../camel-beanstalk-kafka-source-connector.adoc    |   4 +-
 .../camel-box-kafka-source-connector.adoc          |   2 +-
 .../camel-braintree-kafka-sink-connector.adoc      |   2 +-
 .../camel-braintree-kafka-source-connector.adoc    |   4 +-
 .../camel-cmis-kafka-sink-connector.adoc           |   2 +-
 .../camel-cmis-kafka-source-connector.adoc         |   2 +-
 .../camel-couchbase-kafka-sink-connector.adoc      |  13 +-
 .../camel-couchbase-kafka-source-connector.adoc    |  15 +-
 .../connectors/camel-cql-kafka-sink-connector.adoc |   6 +-
 .../camel-cql-kafka-source-connector.adoc          |   8 +-
 ...el-debezium-mongodb-kafka-source-connector.adoc |  14 +-
 ...amel-debezium-mysql-kafka-source-connector.adoc |  18 +-
 ...l-debezium-postgres-kafka-source-connector.adoc |  20 +-
 ...-debezium-sqlserver-kafka-source-connector.adoc |  20 +-
 .../camel-elsql-kafka-source-connector.adoc        |   2 +-
 .../camel-etcd-stats-kafka-source-connector.adoc   |   2 +-
 .../camel-fhir-kafka-source-connector.adoc         |   2 +-
 .../camel-file-kafka-source-connector.adoc         |   2 +-
 .../camel-flatpack-kafka-source-connector.adoc     |   2 +-
 .../camel-flink-kafka-sink-connector.adoc          |   3 +-
 .../camel-ftp-kafka-source-connector.adoc          |   2 +-
 .../camel-ftps-kafka-source-connector.adoc         |   2 +-
 ...mel-google-calendar-kafka-source-connector.adoc |   2 +-
 ...gle-calendar-stream-kafka-source-connector.adoc |   2 +-
 .../camel-google-drive-kafka-source-connector.adoc |   2 +-
 .../camel-google-mail-kafka-source-connector.adoc  |   2 +-
 ...-google-mail-stream-kafka-source-connector.adoc |   2 +-
 ...camel-google-sheets-kafka-source-connector.adoc |   2 +-
 ...oogle-sheets-stream-kafka-source-connector.adoc |   2 +-
 .../camel-guava-eventbus-kafka-sink-connector.adoc |   3 +-
 ...amel-guava-eventbus-kafka-source-connector.adoc |   2 +-
 .../camel-hdfs-kafka-sink-connector.adoc           |   4 +-
 .../camel-hdfs-kafka-source-connector.adoc         |   6 +-
 .../camel-hipchat-kafka-source-connector.adoc      |   2 +-
 .../camel-http-kafka-sink-connector.adoc           |  10 +-
 .../camel-https-kafka-sink-connector.adoc          |  10 +-
 .../camel-ignite-cache-kafka-sink-connector.adoc   |   6 +-
 .../camel-ignite-cache-kafka-source-connector.adoc |   6 +-
 .../camel-ignite-compute-kafka-sink-connector.adoc |   6 +-
 ...camel-ignite-events-kafka-source-connector.adoc |   6 +-
 .../camel-ignite-idgen-kafka-sink-connector.adoc   |   6 +-
 ...amel-ignite-messaging-kafka-sink-connector.adoc |   6 +-
 ...el-ignite-messaging-kafka-source-connector.adoc |   6 +-
 .../camel-ignite-queue-kafka-sink-connector.adoc   |   6 +-
 .../camel-ignite-set-kafka-sink-connector.adoc     |   6 +-
 .../camel-imap-kafka-source-connector.adoc         |   2 +-
 .../camel-imaps-kafka-source-connector.adoc        |   2 +-
 .../camel-ironmq-kafka-source-connector.adoc       |   2 +-
 .../connectors/camel-jms-kafka-sink-connector.adoc |   4 +-
 .../camel-jms-kafka-source-connector.adoc          |   4 +-
 .../camel-jooq-kafka-source-connector.adoc         |   2 +-
 .../camel-jpa-kafka-source-connector.adoc          |   2 +-
 .../camel-jsonata-kafka-sink-connector.adoc        |  30 +-
 .../camel-jt400-kafka-sink-connector.adoc          |  16 +-
 .../camel-jt400-kafka-source-connector.adoc        |  19 +-
 .../camel-kafka-kafka-sink-connector.adoc          |   4 +-
 .../camel-kafka-kafka-source-connector.adoc        |   4 +-
 .../camel-milo-server-kafka-sink-connector.adoc    |  12 +-
 .../camel-milo-server-kafka-source-connector.adoc  |  12 +-
 .../camel-minio-kafka-sink-connector.adoc          |  71 ++++
 .../camel-minio-kafka-source-connector.adoc        | 129 ++++++
 .../camel-mongodb-kafka-sink-connector.adoc        |   2 +-
 .../camel-mongodb-kafka-source-connector.adoc      |   2 +-
 .../camel-mybatis-kafka-source-connector.adoc      |   2 +-
 .../camel-oaipmh-kafka-sink-connector.adoc         |  43 ++
 ...oc => camel-oaipmh-kafka-source-connector.adoc} |  38 +-
 .../camel-olingo2-kafka-sink-connector.adoc        |   6 +-
 .../camel-olingo2-kafka-source-connector.adoc      |   8 +-
 .../camel-olingo4-kafka-source-connector.adoc      |   2 +-
 ...pg-replication-slot-kafka-source-connector.adoc |   2 +-
 .../camel-pop3-kafka-source-connector.adoc         |   2 +-
 .../camel-pop3s-kafka-source-connector.adoc        |   2 +-
 .../camel-pulsar-kafka-source-connector.adoc       |   6 +-
 .../camel-quartz-kafka-source-connector.adoc       |   4 +-
 .../camel-rabbitmq-kafka-sink-connector.adoc       |   7 +-
 .../camel-rabbitmq-kafka-source-connector.adoc     |   7 +-
 .../camel-rest-kafka-sink-connector.adoc           |   2 +-
 .../camel-resteasy-kafka-sink-connector.adoc       |  52 +--
 .../camel-resteasy-kafka-source-connector.adoc     |  35 +-
 ...amel-robotframework-kafka-source-connector.adoc |   2 +-
 .../camel-rss-kafka-source-connector.adoc          |   2 +-
 .../camel-salesforce-kafka-sink-connector.adoc     |   2 +-
 .../camel-salesforce-kafka-source-connector.adoc   |   2 +-
 .../camel-scheduler-kafka-source-connector.adoc    |   2 +-
 .../camel-sftp-kafka-source-connector.adoc         |   2 +-
 .../camel-sjms-batch-kafka-source-connector.adoc   |   2 +-
 .../camel-slack-kafka-sink-connector.adoc          |   2 +-
 .../camel-slack-kafka-source-connector.adoc        |   4 +-
 .../camel-smtp-kafka-source-connector.adoc         |   2 +-
 .../camel-smtps-kafka-source-connector.adoc        |   2 +-
 .../camel-snmp-kafka-source-connector.adoc         |   2 +-
 .../camel-splunk-kafka-source-connector.adoc       |   2 +-
 .../camel-sql-kafka-source-connector.adoc          |   2 +-
 .../camel-ssh-kafka-source-connector.adoc          |   2 +-
 .../camel-telegram-kafka-sink-connector.adoc       |   3 +-
 .../camel-telegram-kafka-source-connector.adoc     |   5 +-
 .../camel-twilio-kafka-source-connector.adoc       |   2 +-
 ...itter-directmessage-kafka-source-connector.adoc |   2 +-
 ...amel-twitter-search-kafka-source-connector.adoc |   2 +-
 ...el-twitter-timeline-kafka-source-connector.adoc |   2 +-
 .../camel-undertow-kafka-sink-connector.adoc       |   2 +-
 .../camel-undertow-kafka-source-connector.adoc     |   2 +-
 .../camel-vertx-http-kafka-sink-connector.adoc     |  70 ++++
 ...camel-vertx-websocket-kafka-sink-connector.adoc |  42 ++
 ...mel-vertx-websocket-kafka-source-connector.adoc |  45 +++
 .../camel-weather-kafka-sink-connector.adoc        |   7 +-
 .../camel-weather-kafka-source-connector.adoc      |   9 +-
 .../camel-workday-kafka-sink-connector.adoc        |   2 +-
 .../camel-xquery-kafka-source-connector.adoc       |   2 +-
 .../camel-yammer-kafka-source-connector.adoc       |   2 +-
 .../camel-zendesk-kafka-source-connector.adoc      |   2 +-
 549 files changed, 9840 insertions(+), 1683 deletions(-)

diff --git a/.github/workflows/automatic-sync-camel-master.yml b/.github/workflows/automatic-sync-camel-master.yml
deleted file mode 100644
index 4bda00e..0000000
--- a/.github/workflows/automatic-sync-camel-master.yml
+++ /dev/null
@@ -1,63 +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.
-#
-
-name: Sync Camel Kafka Connector camel-master Branch
-
-on:
-  schedule:
-    # Run at 2 AM every day
-    - cron:  '0 2 * * *'
-jobs:
-  build:
-    name: Sync Camel Kafka Connector camel-master Branch
-    runs-on: ubuntu-latest
-    strategy:
-      matrix:
-        java: [ '11' ]
-    steps:
-      - name: Checkout Camel project
-        uses: actions/checkout@v2
-        with:
-          repository: apache/camel
-          ref: master
-          path: camel
-      - name: Set Up Java
-        uses: actions/setup-java@v1
-        with:
-          java-version: ${{ matrix.java }}
-      - name: Build Camel Project
-        run: ./mvnw -V --no-transfer-progress clean install -DskipTests
-        working-directory: ${{ github.workspace }}/camel
-      - name: Checkout camel-kafka-connector project
-        uses: actions/checkout@v2
-        with:
-          ref: camel-master
-          fetch-depth: 0
-      - name: Build Camel-kafka-connector Project
-        run: |
-          ./mvnw -V --no-transfer-progress -DskipTests --projects org.apache.camel.kafkaconnector:parent,org.apache.camel.kafkaconnector:camel-kafka-connector-aggregator,org.apache.camel.kafkaconnector:camel-buildtools clean install
-          ./mvnw -V --no-transfer-progress --projects org.apache.camel.kafkaconnector:camel-kafka-connector-generator-maven-plugin -Dcheckstyle.failOnViolation=true -Psourcecheck -DskipTests clean install
-          ./mvnw -V --no-transfer-progress --projects '!org.apache.camel.kafkaconnector:camel-kafka-connector-generator-maven-plugin' -Dcheckstyle.failOnViolation=true -Psourcecheck -DskipIntegrationTests=false clean test
-      - name: Create Pull Request
-        uses: peter-evans/create-pull-request@v2.4.1
-        with:
-          token: ${{ secrets.GITHUB_TOKEN }}
-          branch: automatic-periodic-sync
-          title: '[Github Actions] Periodic Sync Camel-kafka-connector camel-master Branch'
-          body: |
-            Periodic Sync of Camel Kafka connector camel-master Branch with main Camel Master.
-            see https://github.com/apache/camel-kafka-connector/blob/master/.github/workflows/automatic-sync-camel-master.yml
diff --git a/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-sink-connector.adoc b/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-sink-connector.adoc
index 6a93bc2..b1ee9f3 100644
--- a/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-sink-connector.adoc
+++ b/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-activemq-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-activemq sink connector supports 145 options, which are listed below.
+The camel-activemq sink connector supports 147 options, which are listed below.
 
 
 
@@ -88,6 +88,7 @@ The camel-activemq sink connector supports 145 options, which are listed below.
 | *camel.sink.endpoint.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.sink.endpoint.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.sink.endpoint.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.sink.endpoint.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context, the [...]
 | *camel.sink.endpoint.lazyCreateTransactionManager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.sink.endpoint.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.sink.endpoint.transactionName* | The name of the transaction to use. | null | MEDIUM
@@ -163,6 +164,7 @@ The camel-activemq sink connector supports 145 options, which are listed below.
 | *camel.component.activemq.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.activemq.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.activemq.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.component.activemq.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context [...]
 | *camel.component.activemq.lazyCreateTransaction Manager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.component.activemq.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.component.activemq.transactionName* | The name of the transaction to use. | null | MEDIUM
diff --git a/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-source-connector.adoc b/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-source-connector.adoc
index 82c1d1c..dc19b79 100644
--- a/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-source-connector.adoc
+++ b/connectors/camel-activemq-kafka-connector/src/main/docs/camel-activemq-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-activemq-kafka-connector as source make sure to use the followi
 ----
 
 
-The camel-activemq source connector supports 145 options, which are listed below.
+The camel-activemq source connector supports 147 options, which are listed below.
 
 
 
@@ -89,6 +89,7 @@ The camel-activemq source connector supports 145 options, which are listed below
 | *camel.source.endpoint.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.source.endpoint.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.source.endpoint.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.source.endpoint.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context, t [...]
 | *camel.source.endpoint.lazyCreateTransactionManager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.source.endpoint.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.source.endpoint.transactionName* | The name of the transaction to use. | null | MEDIUM
@@ -163,6 +164,7 @@ The camel-activemq source connector supports 145 options, which are listed below
 | *camel.component.activemq.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.activemq.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.activemq.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.component.activemq.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context [...]
 | *camel.component.activemq.lazyCreateTransaction Manager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.component.activemq.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.component.activemq.transactionName* | The name of the transaction to use. | null | MEDIUM
diff --git a/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSinkConnectorConfig.java b/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSinkConnectorConfig.java
index 48d739d..6698670 100644
--- a/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSinkConnectorConfig.java
+++ b/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSinkConnectorConfig.java
@@ -224,6 +224,9 @@ public class CamelActivemqSinkConnectorConfig
     public static final String CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_CONF = "camel.sink.endpoint.transacted";
     public static final String CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_CONF = "camel.sink.endpoint.transactedInOut";
+    public static final String CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depend [...]
+    public static final Boolean CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SINK_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.sink.endpoint.lazyCreateTransactionManager";
     public static final String CAMEL_SINK_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SINK_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -449,6 +452,9 @@ public class CamelActivemqSinkConnectorConfig
     public static final String CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_CONF = "camel.component.activemq.transacted";
     public static final String CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_CONF = "camel.component.activemq.transactedInOut";
+    public static final String CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depen [...]
+    public static final Boolean CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SINK_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.component.activemq.lazyCreateTransactionManager";
     public static final String CAMEL_SINK_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SINK_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -540,6 +546,7 @@ public class CamelActivemqSinkConnectorConfig
         conf.define(CAMEL_SINK_ACTIVEMQ_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_ENDPOINT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_ENDPOINT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_ENDPOINT_USERNAME_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_DOC);
+        conf.define(CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_ENDPOINT_TRANSACTION_NAME_DOC);
@@ -615,6 +622,7 @@ public class CamelActivemqSinkConnectorConfig
         conf.define(CAMEL_SINK_ACTIVEMQ_COMPONENT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_COMPONENT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_COMPONENT_PASSWORD_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_COMPONENT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_COMPONENT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_COMPONENT_USERNAME_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_DOC);
+        conf.define(CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ACTIVEMQ_COMPONENT_TRANSACTION_NAME_DOC);
diff --git a/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSourceConnectorConfig.java b/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSourceConnectorConfig.java
index 36657c7..2eb3f92 100644
--- a/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSourceConnectorConfig.java
+++ b/connectors/camel-activemq-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/activemq/CamelActivemqSourceConnectorConfig.java
@@ -227,6 +227,9 @@ public class CamelActivemqSourceConnectorConfig
     public static final String CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_CONF = "camel.source.endpoint.transacted";
     public static final String CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_CONF = "camel.source.endpoint.transactedInOut";
+    public static final String CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depe [...]
+    public static final Boolean CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.source.endpoint.lazyCreateTransactionManager";
     public static final String CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -449,6 +452,9 @@ public class CamelActivemqSourceConnectorConfig
     public static final String CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_CONF = "camel.component.activemq.transacted";
     public static final String CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_CONF = "camel.component.activemq.transactedInOut";
+    public static final String CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Dep [...]
+    public static final Boolean CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SOURCE_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.component.activemq.lazyCreateTransactionManager";
     public static final String CAMEL_SOURCE_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SOURCE_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -541,6 +547,7 @@ public class CamelActivemqSourceConnectorConfig
         conf.define(CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_USERNAME_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_DOC);
+        conf.define(CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_ENDPOINT_TRANSACTION_NAME_DOC);
@@ -615,6 +622,7 @@ public class CamelActivemqSourceConnectorConfig
         conf.define(CAMEL_SOURCE_ACTIVEMQ_COMPONENT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_PASSWORD_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_COMPONENT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_USERNAME_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_DOC);
+        conf.define(CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_ACTIVEMQ_COMPONENT_TRANSACTION_NAME_DOC);
diff --git a/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-sink-connector.adoc b/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-sink-connector.adoc
index 29b709c..affc736 100644
--- a/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-sink-connector.adoc
+++ b/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-amqp-kafka-connector as sink make sure to use the following Mav
 ----
 
 
-The camel-amqp sink connector supports 142 options, which are listed below.
+The camel-amqp sink connector supports 144 options, which are listed below.
 
 
 
@@ -88,6 +88,7 @@ The camel-amqp sink connector supports 142 options, which are listed below.
 | *camel.sink.endpoint.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.sink.endpoint.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.sink.endpoint.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.sink.endpoint.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context, the [...]
 | *camel.sink.endpoint.lazyCreateTransactionManager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.sink.endpoint.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.sink.endpoint.transactionName* | The name of the transaction to use. | null | MEDIUM
@@ -160,6 +161,7 @@ The camel-amqp sink connector supports 142 options, which are listed below.
 | *camel.component.amqp.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.amqp.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.amqp.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.component.amqp.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context, th [...]
 | *camel.component.amqp.lazyCreateTransactionManager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.component.amqp.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.component.amqp.transactionName* | The name of the transaction to use. | null | MEDIUM
diff --git a/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-source-connector.adoc b/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-source-connector.adoc
index 4a3e783..7ae0f4c 100644
--- a/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-source-connector.adoc
+++ b/connectors/camel-amqp-kafka-connector/src/main/docs/camel-amqp-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-amqp-kafka-connector as source make sure to use the following M
 ----
 
 
-The camel-amqp source connector supports 142 options, which are listed below.
+The camel-amqp source connector supports 144 options, which are listed below.
 
 
 
@@ -89,6 +89,7 @@ The camel-amqp source connector supports 142 options, which are listed below.
 | *camel.source.endpoint.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.source.endpoint.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.source.endpoint.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.source.endpoint.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context, t [...]
 | *camel.source.endpoint.lazyCreateTransactionManager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.source.endpoint.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.source.endpoint.transactionName* | The name of the transaction to use. | null | MEDIUM
@@ -160,6 +161,7 @@ The camel-amqp source connector supports 142 options, which are listed below.
 | *camel.component.amqp.password* | Password to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.amqp.username* | Username to use with the ConnectionFactory. You can also configure username/password directly on the ConnectionFactory. | null | MEDIUM
 | *camel.component.amqp.transacted* | Specifies whether to use transacted mode | false | MEDIUM
+| *camel.component.amqp.transactedInOut* | Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending on the Java EE transaction context, th [...]
 | *camel.component.amqp.lazyCreateTransactionManager* | If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true. | true | MEDIUM
 | *camel.component.amqp.transactionManager* | The Spring transaction manager to use. | null | MEDIUM
 | *camel.component.amqp.transactionName* | The name of the transaction to use. | null | MEDIUM
diff --git a/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSinkConnectorConfig.java b/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSinkConnectorConfig.java
index 86b1005..c07ee7c 100644
--- a/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSinkConnectorConfig.java
+++ b/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSinkConnectorConfig.java
@@ -222,6 +222,9 @@ public class CamelAmqpSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_CONF = "camel.sink.endpoint.transacted";
     public static final String CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_IN_OUT_CONF = "camel.sink.endpoint.transactedInOut";
+    public static final String CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending  [...]
+    public static final Boolean CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SINK_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.sink.endpoint.lazyCreateTransactionManager";
     public static final String CAMEL_SINK_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SINK_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -438,6 +441,9 @@ public class CamelAmqpSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_CONF = "camel.component.amqp.transacted";
     public static final String CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_IN_OUT_CONF = "camel.component.amqp.transactedInOut";
+    public static final String CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Depending [...]
+    public static final Boolean CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SINK_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.component.amqp.lazyCreateTransactionManager";
     public static final String CAMEL_SINK_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SINK_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -529,6 +535,7 @@ public class CamelAmqpSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AMQP_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SINK_AMQP_ENDPOINT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_ENDPOINT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_ENDPOINT_USERNAME_DOC);
         conf.define(CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_DOC);
+        conf.define(CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SINK_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_AMQP_ENDPOINT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_AMQP_ENDPOINT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_ENDPOINT_TRANSACTION_NAME_DOC);
@@ -601,6 +608,7 @@ public class CamelAmqpSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AMQP_COMPONENT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_COMPONENT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_COMPONENT_PASSWORD_DOC);
         conf.define(CAMEL_SINK_AMQP_COMPONENT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_COMPONENT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_COMPONENT_USERNAME_DOC);
         conf.define(CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_DOC);
+        conf.define(CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_COMPONENT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SINK_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_AMQP_COMPONENT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_COMPONENT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_COMPONENT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SINK_AMQP_COMPONENT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AMQP_COMPONENT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AMQP_COMPONENT_TRANSACTION_NAME_DOC);
diff --git a/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSourceConnectorConfig.java b/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSourceConnectorConfig.java
index 9ab361d..f7f88d8 100644
--- a/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSourceConnectorConfig.java
+++ b/connectors/camel-amqp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/amqp/CamelAmqpSourceConnectorConfig.java
@@ -227,6 +227,9 @@ public class CamelAmqpSourceConnectorConfig
     public static final String CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_CONF = "camel.source.endpoint.transacted";
     public static final String CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_IN_OUT_CONF = "camel.source.endpoint.transactedInOut";
+    public static final String CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Dependin [...]
+    public static final Boolean CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SOURCE_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.source.endpoint.lazyCreateTransactionManager";
     public static final String CAMEL_SOURCE_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SOURCE_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -440,6 +443,9 @@ public class CamelAmqpSourceConnectorConfig
     public static final String CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_CONF = "camel.component.amqp.transacted";
     public static final String CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_DOC = "Specifies whether to use transacted mode";
     public static final Boolean CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_IN_OUT_CONF = "camel.component.amqp.transactedInOut";
+    public static final String CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_IN_OUT_DOC = "Specifies whether InOut operations (request reply) default to using transacted mode If this flag is set to true, then Spring JmsTemplate will have sessionTransacted set to true, and the acknowledgeMode as transacted on the JmsTemplate used for InOut operations. Note from Spring JMS: that within a JTA transaction, the parameters passed to createQueue, createTopic methods are not taken into account. Dependi [...]
+    public static final Boolean CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_IN_OUT_DEFAULT = false;
     public static final String CAMEL_SOURCE_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF = "camel.component.amqp.lazyCreateTransactionManager";
     public static final String CAMEL_SOURCE_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC = "If true, Camel will create a JmsTransactionManager, if there is no transactionManager injected when option transacted=true.";
     public static final Boolean CAMEL_SOURCE_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT = true;
@@ -532,6 +538,7 @@ public class CamelAmqpSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AMQP_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SOURCE_AMQP_ENDPOINT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_ENDPOINT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_ENDPOINT_USERNAME_DOC);
         conf.define(CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_DOC);
+        conf.define(CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SOURCE_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_ENDPOINT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_ENDPOINT_TRANSACTION_NAME_DOC);
@@ -603,6 +610,7 @@ public class CamelAmqpSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AMQP_COMPONENT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_COMPONENT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_COMPONENT_PASSWORD_DOC);
         conf.define(CAMEL_SOURCE_AMQP_COMPONENT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_COMPONENT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_COMPONENT_USERNAME_DOC);
         conf.define(CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_DOC);
+        conf.define(CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_IN_OUT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_IN_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTED_IN_OUT_DOC);
         conf.define(CAMEL_SOURCE_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_COMPONENT_LAZY_CREATE_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTION_MANAGER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTION_MANAGER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTION_MANAGER_DOC);
         conf.define(CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AMQP_COMPONENT_TRANSACTION_NAME_DOC);
diff --git a/connectors/camel-apns-kafka-connector/src/main/docs/camel-apns-kafka-source-connector.adoc b/connectors/camel-apns-kafka-connector/src/main/docs/camel-apns-kafka-source-connector.adoc
index 1a82fc4..21a5298 100644
--- a/connectors/camel-apns-kafka-connector/src/main/docs/camel-apns-kafka-source-connector.adoc
+++ b/connectors/camel-apns-kafka-connector/src/main/docs/camel-apns-kafka-source-connector.adoc
@@ -40,7 +40,7 @@ The camel-apns source connector supports 26 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-apns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/apns/CamelApnsSourceConnectorConfig.java b/connectors/camel-apns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/apns/CamelApnsSourceConnectorConfig.java
index 27cd1d6..029b801 100644
--- a/connectors/camel-apns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/apns/CamelApnsSourceConnectorConfig.java
+++ b/connectors/camel-apns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/apns/CamelApnsSourceConnectorConfig.java
@@ -81,7 +81,7 @@ public class CamelApnsSourceConnectorConfig
     public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_APNS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-arangodb-kafka-connector/pom.xml b/connectors/camel-arangodb-kafka-connector/pom.xml
new file mode 100644
index 0000000..cafd729
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/pom.xml
@@ -0,0 +1,135 @@
+<?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">
+  <modelVersion>4.0.0</modelVersion>
+  <parent>
+    <groupId>org.apache.camel.kafkaconnector</groupId>
+    <artifactId>connectors</artifactId>
+    <version>0.5.0-SNAPSHOT</version>
+  </parent>
+  <artifactId>camel-arangodb-kafka-connector</artifactId>
+  <name>Camel-Kafka-Connector :: arangodb</name>
+  <description>Camel Kafka Connector for arangodb</description>
+  <dependencies>
+    <!-- Kafka -->
+    <dependency>
+      <groupId>org.apache.kafka</groupId>
+      <artifactId>connect-api</artifactId>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.kafka</groupId>
+      <artifactId>connect-transforms</artifactId>
+      <scope>provided</scope>
+    </dependency>
+    <!-- Camel -->
+    <dependency>
+      <groupId>org.apache.camel</groupId>
+      <artifactId>camel-arangodb</artifactId>
+    </dependency>
+    <!--START OF GENERATED CODE-->
+    <dependency>
+      <groupId>org.apache.camel.kafkaconnector</groupId>
+      <artifactId>camel-kafka-connector</artifactId>
+    </dependency>
+    <!--END OF GENERATED CODE-->
+  </dependencies>
+  <build>
+    <plugins>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-surefire-plugin</artifactId>
+        <version>${version.maven.surefire.plugin}</version>
+        <configuration>
+          <failIfNoTests>false</failIfNoTests>
+        </configuration>
+      </plugin>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-jar-plugin</artifactId>
+        <version>${version.maven.jar}</version>
+        <configuration>
+          <archive>
+            <manifest>
+              <addDefaultImplementationEntries>true</addDefaultImplementationEntries>
+              <addDefaultSpecificationEntries>true</addDefaultSpecificationEntries>
+            </manifest>
+          </archive>
+        </configuration>
+      </plugin>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-compiler-plugin</artifactId>
+        <version>2.5.1</version>
+        <inherited>true</inherited>
+        <configuration>
+          <source>1.8</source>
+          <target>1.8</target>
+        </configuration>
+      </plugin>
+      <plugin>
+        <artifactId>maven-assembly-plugin</artifactId>
+        <version>2.5.3</version>
+        <configuration>
+          <descriptors>
+            <descriptor>src/main/assembly/package.xml</descriptor>
+          </descriptors>
+        </configuration>
+        <executions>
+          <execution>
+            <id>make-assembly</id>
+            <phase>package</phase>
+            <goals>
+              <goal>single</goal>
+            </goals>
+          </execution>
+        </executions>
+      </plugin>
+    </plugins>
+  </build>
+  <!--START OF GENERATED CODE-->
+  <repositories>
+    <!-- camel-jira -->
+    <repository>
+      <id>atlassian-public</id>
+      <url>https://packages.atlassian.com/maven-external</url>
+      <name>Atlassian Public Repo</name>
+      <snapshots>
+        <enabled>false</enabled>
+      </snapshots>
+      <releases>
+        <enabled>true</enabled>
+      </releases>
+    </repository>
+    <!-- camel-ipfs and camel-weka -->
+    <repository>
+      <id>jboss.thirdparty</id>
+      <name>JBoss Thirdparty Repository</name>
+      <url>https://repository.jboss.org/nexus/service/local/repositories/thirdparty-releases/content/</url>
+      <snapshots>
+        <enabled>false</enabled>
+      </snapshots>
+      <releases>
+        <enabled>true</enabled>
+      </releases>
+    </repository>
+  </repositories>
+  <!--END OF GENERATED CODE-->
+</project>
diff --git a/connectors/camel-arangodb-kafka-connector/src/main/assembly/package.xml b/connectors/camel-arangodb-kafka-connector/src/main/assembly/package.xml
new file mode 100644
index 0000000..4fd2529
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/src/main/assembly/package.xml
@@ -0,0 +1,57 @@
+<?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.
+
+-->
+<assembly>
+  <!-- Assembles a packaged version targeting OS installation. -->
+  <id>package</id>
+  <formats>
+    <format>zip</format>
+    <format>tar.gz</format>
+  </formats>
+  <includeBaseDirectory>false</includeBaseDirectory>
+  <fileSets>
+    <fileSet>
+      <directory>${project.basedir}/../..</directory>
+      <outputDirectory>${project.artifactId}/</outputDirectory>
+      <includes>
+        <include>README*</include>
+        <include>LICENSE*</include>
+        <include>NOTICE*</include>
+        <include>licenses/</include>
+      </includes>
+    </fileSet>
+    <fileSet>
+      <directory>${project.basedir}/src/main/docs</directory>
+      <outputDirectory>docs/</outputDirectory>
+      <includes>
+        <include>**/*</include>
+      </includes>
+    </fileSet>
+  </fileSets>
+  <dependencySets>
+    <dependencySet>
+      <outputDirectory>${project.artifactId}/</outputDirectory>
+      <useProjectArtifact>true</useProjectArtifact>
+      <useTransitiveFiltering>true</useTransitiveFiltering>
+      <excludes>
+        <exclude>org.apache.kafka:connect-api</exclude>
+      </excludes>
+    </dependencySet>
+  </dependencySets>
+</assembly>
diff --git a/connectors/camel-arangodb-kafka-connector/src/main/docs/camel-arangodb-kafka-sink-connector.adoc b/connectors/camel-arangodb-kafka-connector/src/main/docs/camel-arangodb-kafka-sink-connector.adoc
new file mode 100644
index 0000000..8fa9152
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/src/main/docs/camel-arangodb-kafka-sink-connector.adoc
@@ -0,0 +1,53 @@
+// kafka-connector options: START
+[[camel-arangodb-kafka-connector-sink]]
+= camel-arangodb-kafka-connector sink configuration
+
+When using camel-arangodb-kafka-connector as sink make sure to use the following Maven dependency to have support for the connector:
+
+[source,xml]
+----
+<dependency>
+  <groupId>org.apache.camel.kafkaconnector</groupId>
+  <artifactId>camel-arangodb-kafka-connector</artifactId>
+  <version>x.x.x</version>
+  <!-- use the same version as your Camel Kafka connector version -->
+</dependency>
+----
+
+
+The camel-arangodb sink connector supports 25 options, which are listed below.
+
+
+
+[width="100%",cols="2,5,^1,2",options="header"]
+|===
+| Name | Description | Default | Priority
+| *camel.sink.path.database* | database name | null | HIGH
+| *camel.sink.endpoint.documentCollection* | Collection name, when using ArangoDb as a Document Database. Set the documentCollection name when using the CRUD operation on the document database collections (SAVE_DOCUMENT , FIND_DOCUMENT_BY_KEY, UPDATE_DOCUMENT, DELETE_DOCUMENT). | null | MEDIUM
+| *camel.sink.endpoint.edgeCollection* | Collection name of vertices, when using ArangoDb as a Graph Database. Set the edgeCollection name to perform CRUD operation on edges using these operations : SAVE_VERTEX, FIND_VERTEX_BY_KEY, UPDATE_VERTEX, DELETE_VERTEX. The graph attribute is mandatory. | null | MEDIUM
+| *camel.sink.endpoint.graph* | Graph name, when using ArangoDb as a Graph Database. Combine this attribute with one of the two attributes vertexCollection and edgeCollection. | null | MEDIUM
+| *camel.sink.endpoint.host* | ArangoDB host. If host and port are default, this field is Optional. | null | MEDIUM
+| *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
+| *camel.sink.endpoint.operation* | Operations to perform on ArangoDb. For the operation AQL_QUERY, no need to specify a collection or graph. One of: [SAVE_DOCUMENT] [FIND_DOCUMENT_BY_KEY] [UPDATE_DOCUMENT] [DELETE_DOCUMENT] [AQL_QUERY] [SAVE_VERTEX] [FIND_VERTEX_BY_KEY] [UPDATE_VERTEX] [DELETE_VERTEX] [SAVE_EDGE] [FIND_EDGE_BY_KEY] [UPDATE_EDGE] [DELETE_EDGE] | null | MEDIUM
+| *camel.sink.endpoint.port* | ArangoDB exposed port. If host and port are default, this field is Optional. | null | MEDIUM
+| *camel.sink.endpoint.vertexCollection* | Collection name of vertices, when using ArangoDb as a Graph Database. Set the vertexCollection name to perform CRUD operation on vertices using these operations : SAVE_EDGE, FIND_EDGE_BY_KEY, UPDATE_EDGE, DELETE_EDGE. The graph attribute is mandatory. | null | MEDIUM
+| *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
+| *camel.sink.endpoint.password* | ArangoDB password. If user and password are default, this field is Optional. | null | MEDIUM
+| *camel.sink.endpoint.user* | ArangoDB user. If user and password are default, this field is Optional. | null | MEDIUM
+| *camel.component.arangodb.configuration* | Component configuration | null | MEDIUM
+| *camel.component.arangodb.documentCollection* | Collection name, when using ArangoDb as a Document Database. Set the documentCollection name when using the CRUD operation on the document database collections (SAVE_DOCUMENT , FIND_DOCUMENT_BY_KEY, UPDATE_DOCUMENT, DELETE_DOCUMENT). | null | MEDIUM
+| *camel.component.arangodb.edgeCollection* | Collection name of vertices, when using ArangoDb as a Graph Database. Set the edgeCollection name to perform CRUD operation on edges using these operations : SAVE_VERTEX, FIND_VERTEX_BY_KEY, UPDATE_VERTEX, DELETE_VERTEX. The graph attribute is mandatory. | null | MEDIUM
+| *camel.component.arangodb.graph* | Graph name, when using ArangoDb as a Graph Database. Combine this attribute with one of the two attributes vertexCollection and edgeCollection. | null | MEDIUM
+| *camel.component.arangodb.host* | ArangoDB host. If host and port are default, this field is Optional. | null | MEDIUM
+| *camel.component.arangodb.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
+| *camel.component.arangodb.operation* | Operations to perform on ArangoDb. For the operation AQL_QUERY, no need to specify a collection or graph. One of: [SAVE_DOCUMENT] [FIND_DOCUMENT_BY_KEY] [UPDATE_DOCUMENT] [DELETE_DOCUMENT] [AQL_QUERY] [SAVE_VERTEX] [FIND_VERTEX_BY_KEY] [UPDATE_VERTEX] [DELETE_VERTEX] [SAVE_EDGE] [FIND_EDGE_BY_KEY] [UPDATE_EDGE] [DELETE_EDGE] | null | MEDIUM
+| *camel.component.arangodb.port* | ArangoDB exposed port. If host and port are default, this field is Optional. | null | MEDIUM
+| *camel.component.arangodb.vertexCollection* | Collection name of vertices, when using ArangoDb as a Graph Database. Set the vertexCollection name to perform CRUD operation on vertices using these operations : SAVE_EDGE, FIND_EDGE_BY_KEY, UPDATE_EDGE, DELETE_EDGE. The graph attribute is mandatory. | null | MEDIUM
+| *camel.component.arangodb.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.arangodb.password* | ArangoDB password. If user and password are default, this field is Optional. | null | MEDIUM
+| *camel.component.arangodb.user* | ArangoDB user. If user and password are default, this field is Optional. | null | MEDIUM
+|===
+
+
+// kafka-connector options: END
diff --git a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties b/connectors/camel-arangodb-kafka-connector/src/main/docs/examples/CamelArangodbSinkConnector.properties
similarity index 81%
copy from connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
copy to connectors/camel-arangodb-kafka-connector/src/main/docs/examples/CamelArangodbSinkConnector.properties
index 4d29762..690fd84 100644
--- a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
+++ b/connectors/camel-arangodb-kafka-connector/src/main/docs/examples/CamelArangodbSinkConnector.properties
@@ -15,19 +15,19 @@
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
 
-name=CamelQuartzSourceConnector
-connector.class=org.apache.camel.kafkaconnector.quartz.CamelQuartzSourceConnector
+name=CamelArangodbSinkConnector
+connector.class=org.apache.camel.kafkaconnector.arangodb.CamelArangodbSinkConnector
 tasks.max=1
 
 # use the kafka converters that better suit your needs, these are just defaults:
 key.converter=org.apache.kafka.connect.storage.StringConverter
 value.converter=org.apache.kafka.connect.storage.StringConverter
 
-# comma separated topics to send messages into
+# comma separated topics to get messages from
 topics=
 
 # mandatory properties (for a complete properties list see the connector documentation):
 
-# The quartz timer name to use. The combination of group name and timer name should be unique.
-camel.source.path.triggerName=
+# database name
+camel.sink.path.database=
 
diff --git a/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkConnector.java b/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkConnector.java
new file mode 100644
index 0000000..936ef71
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkConnector.java
@@ -0,0 +1,35 @@
+/*
+ * 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.kafkaconnector.arangodb;
+
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnector;
+import org.apache.kafka.common.config.ConfigDef;
+import org.apache.kafka.connect.connector.Task;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelArangodbSinkConnector extends CamelSinkConnector {
+
+    @Override
+    public ConfigDef config() {
+        return CamelArangodbSinkConnectorConfig.conf();
+    }
+    @Override
+    public Class<? extends Task> taskClass() {
+        return CamelArangodbSinkTask.class;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkConnectorConfig.java b/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkConnectorConfig.java
new file mode 100644
index 0000000..8ae6d2d
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkConnectorConfig.java
@@ -0,0 +1,144 @@
+/*
+ * 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.kafkaconnector.arangodb;
+
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnectorConfig;
+import org.apache.kafka.common.config.ConfigDef;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelArangodbSinkConnectorConfig
+        extends
+            CamelSinkConnectorConfig {
+
+    public static final String CAMEL_SINK_ARANGODB_PATH_DATABASE_CONF = "camel.sink.path.database";
+    public static final String CAMEL_SINK_ARANGODB_PATH_DATABASE_DOC = "database name";
+    public static final String CAMEL_SINK_ARANGODB_PATH_DATABASE_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_DOCUMENT_COLLECTION_CONF = "camel.sink.endpoint.documentCollection";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_DOCUMENT_COLLECTION_DOC = "Collection name, when using ArangoDb as a Document Database. Set the documentCollection name when using the CRUD operation on the document database collections (SAVE_DOCUMENT , FIND_DOCUMENT_BY_KEY, UPDATE_DOCUMENT, DELETE_DOCUMENT).";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_DOCUMENT_COLLECTION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_EDGE_COLLECTION_CONF = "camel.sink.endpoint.edgeCollection";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_EDGE_COLLECTION_DOC = "Collection name of vertices, when using ArangoDb as a Graph Database. Set the edgeCollection name to perform CRUD operation on edges using these operations : SAVE_VERTEX, FIND_VERTEX_BY_KEY, UPDATE_VERTEX, DELETE_VERTEX. The graph attribute is mandatory.";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_EDGE_COLLECTION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_GRAPH_CONF = "camel.sink.endpoint.graph";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_GRAPH_DOC = "Graph name, when using ArangoDb as a Graph Database. Combine this attribute with one of the two attributes vertexCollection and edgeCollection.";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_GRAPH_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_HOST_CONF = "camel.sink.endpoint.host";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_HOST_DOC = "ArangoDB host. If host and port are default, this field is Optional.";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_HOST_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that w [...]
+    public static final Boolean CAMEL_SINK_ARANGODB_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_OPERATION_CONF = "camel.sink.endpoint.operation";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_OPERATION_DOC = "Operations to perform on ArangoDb. For the operation AQL_QUERY, no need to specify a collection or graph. One of: [SAVE_DOCUMENT] [FIND_DOCUMENT_BY_KEY] [UPDATE_DOCUMENT] [DELETE_DOCUMENT] [AQL_QUERY] [SAVE_VERTEX] [FIND_VERTEX_BY_KEY] [UPDATE_VERTEX] [DELETE_VERTEX] [SAVE_EDGE] [FIND_EDGE_BY_KEY] [UPDATE_EDGE] [DELETE_EDGE]";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_OPERATION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_PORT_CONF = "camel.sink.endpoint.port";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_PORT_DOC = "ArangoDB exposed port. If host and port are default, this field is Optional.";
+    public static final Integer CAMEL_SINK_ARANGODB_ENDPOINT_PORT_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_VERTEX_COLLECTION_CONF = "camel.sink.endpoint.vertexCollection";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_VERTEX_COLLECTION_DOC = "Collection name of vertices, when using ArangoDb as a Graph Database. Set the vertexCollection name to perform CRUD operation on vertices using these operations : SAVE_EDGE, FIND_EDGE_BY_KEY, UPDATE_EDGE, DELETE_EDGE. The graph attribute is mandatory.";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_VERTEX_COLLECTION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SINK_ARANGODB_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
+    public static final Boolean CAMEL_SINK_ARANGODB_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_PASSWORD_CONF = "camel.sink.endpoint.password";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_PASSWORD_DOC = "ArangoDB password. If user and password are default, this field is Optional.";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_PASSWORD_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_USER_CONF = "camel.sink.endpoint.user";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_USER_DOC = "ArangoDB user. If user and password are default, this field is Optional.";
+    public static final String CAMEL_SINK_ARANGODB_ENDPOINT_USER_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_CONFIGURATION_CONF = "camel.component.arangodb.configuration";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_CONFIGURATION_DOC = "Component configuration";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_CONFIGURATION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_DOCUMENT_COLLECTION_CONF = "camel.component.arangodb.documentCollection";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_DOCUMENT_COLLECTION_DOC = "Collection name, when using ArangoDb as a Document Database. Set the documentCollection name when using the CRUD operation on the document database collections (SAVE_DOCUMENT , FIND_DOCUMENT_BY_KEY, UPDATE_DOCUMENT, DELETE_DOCUMENT).";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_DOCUMENT_COLLECTION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_EDGE_COLLECTION_CONF = "camel.component.arangodb.edgeCollection";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_EDGE_COLLECTION_DOC = "Collection name of vertices, when using ArangoDb as a Graph Database. Set the edgeCollection name to perform CRUD operation on edges using these operations : SAVE_VERTEX, FIND_VERTEX_BY_KEY, UPDATE_VERTEX, DELETE_VERTEX. The graph attribute is mandatory.";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_EDGE_COLLECTION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_GRAPH_CONF = "camel.component.arangodb.graph";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_GRAPH_DOC = "Graph name, when using ArangoDb as a Graph Database. Combine this attribute with one of the two attributes vertexCollection and edgeCollection.";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_GRAPH_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_HOST_CONF = "camel.component.arangodb.host";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_HOST_DOC = "ArangoDB host. If host and port are default, this field is Optional.";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_HOST_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.arangodb.lazyStartProducer";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that  [...]
+    public static final Boolean CAMEL_SINK_ARANGODB_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_OPERATION_CONF = "camel.component.arangodb.operation";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_OPERATION_DOC = "Operations to perform on ArangoDb. For the operation AQL_QUERY, no need to specify a collection or graph. One of: [SAVE_DOCUMENT] [FIND_DOCUMENT_BY_KEY] [UPDATE_DOCUMENT] [DELETE_DOCUMENT] [AQL_QUERY] [SAVE_VERTEX] [FIND_VERTEX_BY_KEY] [UPDATE_VERTEX] [DELETE_VERTEX] [SAVE_EDGE] [FIND_EDGE_BY_KEY] [UPDATE_EDGE] [DELETE_EDGE]";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_OPERATION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_PORT_CONF = "camel.component.arangodb.port";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_PORT_DOC = "ArangoDB exposed port. If host and port are default, this field is Optional.";
+    public static final Integer CAMEL_SINK_ARANGODB_COMPONENT_PORT_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_VERTEX_COLLECTION_CONF = "camel.component.arangodb.vertexCollection";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_VERTEX_COLLECTION_DOC = "Collection name of vertices, when using ArangoDb as a Graph Database. Set the vertexCollection name to perform CRUD operation on vertices using these operations : SAVE_EDGE, FIND_EDGE_BY_KEY, UPDATE_EDGE, DELETE_EDGE. The graph attribute is mandatory.";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_VERTEX_COLLECTION_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.arangodb.basicPropertyBinding";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SINK_ARANGODB_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_PASSWORD_CONF = "camel.component.arangodb.password";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_PASSWORD_DOC = "ArangoDB password. If user and password are default, this field is Optional.";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_PASSWORD_DEFAULT = null;
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_USER_CONF = "camel.component.arangodb.user";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_USER_DOC = "ArangoDB user. If user and password are default, this field is Optional.";
+    public static final String CAMEL_SINK_ARANGODB_COMPONENT_USER_DEFAULT = null;
+
+    public CamelArangodbSinkConnectorConfig(
+            ConfigDef config,
+            Map<String, String> parsedConfig) {
+        super(config, parsedConfig);
+    }
+
+    public CamelArangodbSinkConnectorConfig(Map<String, String> parsedConfig) {
+        this(conf(), parsedConfig);
+    }
+
+    public static ConfigDef conf() {
+        ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
+        conf.define(CAMEL_SINK_ARANGODB_PATH_DATABASE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_PATH_DATABASE_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_ARANGODB_PATH_DATABASE_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_DOCUMENT_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_DOCUMENT_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_DOCUMENT_COLLECTION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_EDGE_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_EDGE_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_EDGE_COLLECTION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_GRAPH_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_GRAPH_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_GRAPH_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_HOST_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ARANGODB_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_OPERATION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_PORT_CONF, ConfigDef.Type.INT, CAMEL_SINK_ARANGODB_ENDPOINT_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_PORT_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_VERTEX_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_VERTEX_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_VERTEX_COLLECTION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ARANGODB_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ARANGODB_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_SYNCHRONOUS_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_PASSWORD_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_ENDPOINT_USER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_ENDPOINT_USER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_ENDPOINT_USER_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_CONFIGURATION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_DOCUMENT_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_DOCUMENT_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_DOCUMENT_COLLECTION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_EDGE_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_EDGE_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_EDGE_COLLECTION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_GRAPH_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_GRAPH_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_GRAPH_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_HOST_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ARANGODB_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_OPERATION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_PORT_CONF, ConfigDef.Type.INT, CAMEL_SINK_ARANGODB_COMPONENT_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_PORT_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_VERTEX_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_VERTEX_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_VERTEX_COLLECTION_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ARANGODB_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_PASSWORD_DOC);
+        conf.define(CAMEL_SINK_ARANGODB_COMPONENT_USER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ARANGODB_COMPONENT_USER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ARANGODB_COMPONENT_USER_DOC);
+        return conf;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkTask.java b/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkTask.java
new file mode 100644
index 0000000..b540017
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/arangodb/CamelArangodbSinkTask.java
@@ -0,0 +1,39 @@
+/*
+ * 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.kafkaconnector.arangodb;
+
+import java.util.HashMap;
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnectorConfig;
+import org.apache.camel.kafkaconnector.CamelSinkTask;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelArangodbSinkTask extends CamelSinkTask {
+
+    @Override
+    protected CamelSinkConnectorConfig getCamelSinkConnectorConfig(
+            Map<String, String> props) {
+        return new CamelArangodbSinkConnectorConfig(props);
+    }
+    @Override
+    protected Map<String, String> getDefaultConfig() {
+        return new HashMap<String, String>() {{
+            put(CamelSinkConnectorConfig.CAMEL_SINK_COMPONENT_CONF, "arangodb");
+        }};
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-arangodb-kafka-connector/src/main/resources/META-INF/LICENSE.txt b/connectors/camel-arangodb-kafka-connector/src/main/resources/META-INF/LICENSE.txt
new file mode 100644
index 0000000..6b0b127
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/src/main/resources/META-INF/LICENSE.txt
@@ -0,0 +1,203 @@
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+   END OF TERMS AND CONDITIONS
+
+   APPENDIX: How to apply the Apache License to your work.
+
+      To apply the Apache License to your work, attach the following
+      boilerplate notice, with the fields enclosed by brackets "[]"
+      replaced with your own identifying information. (Don't include
+      the brackets!)  The text should be enclosed in the appropriate
+      comment syntax for the file format. We also recommend that a
+      file or class name and description of purpose be included on the
+      same "printed page" as the copyright notice for easier
+      identification within third-party archives.
+
+   Copyright [yyyy] [name of copyright owner]
+
+   Licensed 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.
+
diff --git a/connectors/camel-arangodb-kafka-connector/src/main/resources/META-INF/NOTICE.txt b/connectors/camel-arangodb-kafka-connector/src/main/resources/META-INF/NOTICE.txt
new file mode 100644
index 0000000..2e215bf
--- /dev/null
+++ b/connectors/camel-arangodb-kafka-connector/src/main/resources/META-INF/NOTICE.txt
@@ -0,0 +1,11 @@
+   =========================================================================
+   ==  NOTICE file corresponding to the section 4 d of                    ==
+   ==  the Apache License, Version 2.0,                                   ==
+   ==  in this case for the Apache Camel distribution.                    ==
+   =========================================================================
+
+   This product includes software developed by
+   The Apache Software Foundation (http://www.apache.org/).
+
+   Please read the different LICENSE files present in the licenses directory of
+   this distribution.
diff --git a/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-sink-connector.adoc b/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-sink-connector.adoc
index 44c191e..a7645a3 100644
--- a/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-sink-connector.adoc
+++ b/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-sink-connector.adoc
@@ -54,8 +54,8 @@ The camel-as2 sink connector supports 35 options, which are listed below.
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.component.as2.configuration* | To use the shared configuration | null | MEDIUM
 | *camel.component.as2.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.component.as2.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.as2.configuration* | Component configuration | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-source-connector.adoc b/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-source-connector.adoc
index 6ddadc5..1f9af0c 100644
--- a/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-source-connector.adoc
+++ b/connectors/camel-as2-kafka-connector/src/main/docs/camel-as2-kafka-source-connector.adoc
@@ -67,13 +67,13 @@ The camel-as2 source connector supports 53 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
 | *camel.source.endpoint.useFixedDelay* | Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details. | true | MEDIUM
-| *camel.component.as2.configuration* | To use the shared configuration | null | MEDIUM
 | *camel.component.as2.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.as2.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.as2.configuration* | Component configuration | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SinkConnectorConfig.java b/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SinkConnectorConfig.java
index 2f77d82..208e922 100644
--- a/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SinkConnectorConfig.java
+++ b/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SinkConnectorConfig.java
@@ -120,15 +120,15 @@ public class CamelAs2SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AS2_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
     public static final String CAMEL_SINK_AS2_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SINK_AS2_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
-    public static final String CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_CONF = "camel.component.as2.configuration";
-    public static final String CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DOC = "To use the shared configuration";
-    public static final String CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DEFAULT = null;
     public static final String CAMEL_SINK_AS2_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.as2.lazyStartProducer";
     public static final String CAMEL_SINK_AS2_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when  [...]
     public static final Boolean CAMEL_SINK_AS2_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_AS2_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.as2.basicPropertyBinding";
     public static final String CAMEL_SINK_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_CONF = "camel.component.as2.configuration";
+    public static final String CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DOC = "Component configuration";
+    public static final String CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DEFAULT = null;
 
     public CamelAs2SinkConnectorConfig(
             ConfigDef config,
@@ -174,9 +174,9 @@ public class CamelAs2SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AS2_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AS2_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AS2_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AS2_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AS2_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AS2_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AS2_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AS2_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AS2_ENDPOINT_SYNCHRONOUS_DOC);
-        conf.define(CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AS2_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AS2_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AS2_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AS2_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AS2_COMPONENT_CONFIGURATION_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SourceConnectorConfig.java b/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SourceConnectorConfig.java
index eb9712c..05e0a62 100644
--- a/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SourceConnectorConfig.java
+++ b/connectors/camel-as2-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/as2/CamelAs2SourceConnectorConfig.java
@@ -160,7 +160,7 @@ public class CamelAs2SourceConnectorConfig extends CamelSourceConnectorConfig {
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -174,15 +174,15 @@ public class CamelAs2SourceConnectorConfig extends CamelSourceConnectorConfig {
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_USE_FIXED_DELAY_CONF = "camel.source.endpoint.useFixedDelay";
     public static final String CAMEL_SOURCE_AS2_ENDPOINT_USE_FIXED_DELAY_DOC = "Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details.";
     public static final Boolean CAMEL_SOURCE_AS2_ENDPOINT_USE_FIXED_DELAY_DEFAULT = true;
-    public static final String CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_CONF = "camel.component.as2.configuration";
-    public static final String CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DOC = "To use the shared configuration";
-    public static final String CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DEFAULT = null;
     public static final String CAMEL_SOURCE_AS2_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.as2.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_AS2_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
     public static final Boolean CAMEL_SOURCE_AS2_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
     public static final String CAMEL_SOURCE_AS2_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.as2.basicPropertyBinding";
     public static final String CAMEL_SOURCE_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_CONF = "camel.component.as2.configuration";
+    public static final String CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DOC = "Component configuration";
+    public static final String CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DEFAULT = null;
 
     public CamelAs2SourceConnectorConfig(
             ConfigDef config,
@@ -246,9 +246,9 @@ public class CamelAs2SourceConnectorConfig extends CamelSourceConnectorConfig {
         conf.define(CAMEL_SOURCE_AS2_ENDPOINT_START_SCHEDULER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AS2_ENDPOINT_START_SCHEDULER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AS2_ENDPOINT_START_SCHEDULER_DOC);
         conf.define(CAMEL_SOURCE_AS2_ENDPOINT_TIME_UNIT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AS2_ENDPOINT_TIME_UNIT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AS2_ENDPOINT_TIME_UNIT_DOC);
         conf.define(CAMEL_SOURCE_AS2_ENDPOINT_USE_FIXED_DELAY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AS2_ENDPOINT_USE_FIXED_DELAY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AS2_ENDPOINT_USE_FIXED_DELAY_DOC);
-        conf.define(CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AS2_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AS2_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AS2_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AS2_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AS2_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AS2_COMPONENT_CONFIGURATION_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-atmosphere-websocket-kafka-connector/src/main/docs/camel-atmosphere-websocket-kafka-sink-connector.adoc b/connectors/camel-atmosphere-websocket-kafka-connector/src/main/docs/camel-atmosphere-websocket-kafka-sink-connector.adoc
index 99d09ca..3f2a3b3 100644
--- a/connectors/camel-atmosphere-websocket-kafka-connector/src/main/docs/camel-atmosphere-websocket-kafka-sink-connector.adoc
+++ b/connectors/camel-atmosphere-websocket-kafka-connector/src/main/docs/camel-atmosphere-websocket-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-atmosphere-websocket-kafka-connector as sink make sure to use t
 ----
 
 
-The camel-atmosphere-websocket sink connector supports 33 options, which are listed below.
+The camel-atmosphere-websocket sink connector supports 21 options, which are listed below.
 
 
 
@@ -31,24 +31,12 @@ The camel-atmosphere-websocket sink connector supports 33 options, which are lis
 | *camel.sink.endpoint.useStreaming* | To enable streaming to send data as multiple text fragments. | false | MEDIUM
 | *camel.sink.endpoint.httpBinding* | To use a custom HttpBinding to control the mapping between Camel message and HttpClient. | null | MEDIUM
 | *camel.sink.endpoint.bridgeEndpoint* | If the option is true, HttpProducer will ignore the Exchange.HTTP_URI header, and use the endpoint's URI for request. You may also set the option throwExceptionOnFailure to be false to let the HttpProducer send all the fault response back. | false | MEDIUM
-| *camel.sink.endpoint.connectionClose* | Specifies whether a Connection Close header must be added to HTTP Request. By default connectionClose is false. | false | MEDIUM
-| *camel.sink.endpoint.copyHeaders* | If this option is true then IN exchange headers will be copied to OUT exchange headers according to copy strategy. Setting this to false, allows to only include the headers from the HTTP response (not propagating IN headers). | true | MEDIUM
-| *camel.sink.endpoint.httpMethod* | Configure the HTTP method to use. The HttpMethod header cannot override this option if set. One of: [GET] [POST] [PUT] [DELETE] [HEAD] [OPTIONS] [TRACE] [PATCH] | null | MEDIUM
-| *camel.sink.endpoint.ignoreResponseBody* | If this option is true, The http producer won't read response body and cache the input stream | false | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
-| *camel.sink.endpoint.preserveHostHeader* | If the option is true, HttpProducer will set the Host header to the value contained in the current exchange Host header, useful in reverse proxy applications where you want the Host header received by the downstream server to reflect the URL called by the upstream client, this allows applications which use the Host header to generate accurate URL's for a proxied service | false | MEDIUM
-| *camel.sink.endpoint.throwExceptionOnFailure* | Option to disable throwing the HttpOperationFailedException in case of failed responses from the remote server. This allows you to get all responses regardless of the HTTP status code. | true | MEDIUM
-| *camel.sink.endpoint.cookieHandler* | Configure a cookie handler to maintain a HTTP session | null | MEDIUM
-| *camel.sink.endpoint.okStatusCodeRange* | The status codes which are considered a success response. The values are inclusive. Multiple ranges can be defined, separated by comma, e.g. 200-204,209,301-304. Each range must be a single number or from-to with the dash included. | "200-299" | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.mapHttpMessageBody* | If this option is true then IN exchange Body of the exchange will be mapped to HTTP body. Setting this to false will avoid the HTTP mapping. | true | MEDIUM
 | *camel.sink.endpoint.mapHttpMessageFormUrlEncoded Body* | If this option is true then IN exchange Form Encoded body of the exchange will be mapped to HTTP. Setting this to false will avoid the HTTP Form Encoded body mapping. | true | MEDIUM
 | *camel.sink.endpoint.mapHttpMessageHeaders* | If this option is true then IN exchange Headers of the exchange will be mapped to HTTP headers. Setting this to false will avoid the HTTP Headers mapping. | true | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.sink.endpoint.proxyAuthScheme* | Proxy authentication scheme to use One of: [http] [https] | null | MEDIUM
-| *camel.sink.endpoint.proxyHost* | Proxy hostname to use | null | MEDIUM
-| *camel.sink.endpoint.proxyPort* | Proxy port to use | null | MEDIUM
-| *camel.sink.endpoint.authHost* | Authentication host to use with NTML | null | MEDIUM
 | *camel.component.atmosphere-websocket.lazyStart Producer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is  [...]
 | *camel.component.atmosphere-websocket.allowJava SerializedObject* | Whether to allow java serialization when a request uses context-type=application/x-java-serialized-object. This is by default turned off. If you enable this then be aware that Java will deserialize the incoming data from the request to Java and that can be a potential security risk. | false | MEDIUM
 | *camel.component.atmosphere-websocket.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
diff --git a/connectors/camel-atmosphere-websocket-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atmospherewebsocket/CamelAtmospherewebsocketSinkConnectorConfig.java b/connectors/camel-atmosphere-websocket-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atmospherewebsocket/CamelAtmospherewebsocketSinkConnectorConfig.java
index 8de5c5a..6362f33 100644
--- a/connectors/camel-atmosphere-websocket-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atmospherewebsocket/CamelAtmospherewebsocketSinkConnectorConfig.java
+++ b/connectors/camel-atmosphere-websocket-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atmospherewebsocket/CamelAtmospherewebsocketSinkConnectorConfig.java
@@ -53,33 +53,9 @@ public class CamelAtmospherewebsocketSinkConnectorConfig
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BRIDGE_ENDPOINT_CONF = "camel.sink.endpoint.bridgeEndpoint";
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BRIDGE_ENDPOINT_DOC = "If the option is true, HttpProducer will ignore the Exchange.HTTP_URI header, and use the endpoint's URI for request. You may also set the option throwExceptionOnFailure to be false to let the HttpProducer send all the fault response back.";
     public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BRIDGE_ENDPOINT_DEFAULT = false;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_CONNECTION_CLOSE_CONF = "camel.sink.endpoint.connectionClose";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_CONNECTION_CLOSE_DOC = "Specifies whether a Connection Close header must be added to HTTP Request. By default connectionClose is false.";
-    public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_CONNECTION_CLOSE_DEFAULT = false;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COPY_HEADERS_CONF = "camel.sink.endpoint.copyHeaders";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COPY_HEADERS_DOC = "If this option is true then IN exchange headers will be copied to OUT exchange headers according to copy strategy. Setting this to false, allows to only include the headers from the HTTP response (not propagating IN headers).";
-    public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COPY_HEADERS_DEFAULT = true;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_METHOD_CONF = "camel.sink.endpoint.httpMethod";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_METHOD_DOC = "Configure the HTTP method to use. The HttpMethod header cannot override this option if set. One of: [GET] [POST] [PUT] [DELETE] [HEAD] [OPTIONS] [TRACE] [PATCH]";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_METHOD_DEFAULT = null;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_IGNORE_RESPONSE_BODY_CONF = "camel.sink.endpoint.ignoreResponseBody";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_IGNORE_RESPONSE_BODY_DOC = "If this option is true, The http producer won't read response body and cache the input stream";
-    public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_IGNORE_RESPONSE_BODY_DEFAULT = false;
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Be [...]
     public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PRESERVE_HOST_HEADER_CONF = "camel.sink.endpoint.preserveHostHeader";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PRESERVE_HOST_HEADER_DOC = "If the option is true, HttpProducer will set the Host header to the value contained in the current exchange Host header, useful in reverse proxy applications where you want the Host header received by the downstream server to reflect the URL called by the upstream client, this allows applications which use the Host header to generate accurate URL's for a proxied service";
-    public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PRESERVE_HOST_HEADER_DEFAULT = false;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_THROW_EXCEPTION_ON_FAILURE_CONF = "camel.sink.endpoint.throwExceptionOnFailure";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_THROW_EXCEPTION_ON_FAILURE_DOC = "Option to disable throwing the HttpOperationFailedException in case of failed responses from the remote server. This allows you to get all responses regardless of the HTTP status code.";
-    public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_THROW_EXCEPTION_ON_FAILURE_DEFAULT = true;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COOKIE_HANDLER_CONF = "camel.sink.endpoint.cookieHandler";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COOKIE_HANDLER_DOC = "Configure a cookie handler to maintain a HTTP session";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COOKIE_HANDLER_DEFAULT = null;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_OK_STATUS_CODE_RANGE_CONF = "camel.sink.endpoint.okStatusCodeRange";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_OK_STATUS_CODE_RANGE_DOC = "The status codes which are considered a success response. The values are inclusive. Multiple ranges can be defined, separated by comma, e.g. 200-204,209,301-304. Each range must be a single number or from-to with the dash included.";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_OK_STATUS_CODE_RANGE_DEFAULT = "200-299";
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -95,18 +71,6 @@ public class CamelAtmospherewebsocketSinkConnectorConfig
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_AUTH_SCHEME_CONF = "camel.sink.endpoint.proxyAuthScheme";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_AUTH_SCHEME_DOC = "Proxy authentication scheme to use One of: [http] [https]";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_AUTH_SCHEME_DEFAULT = null;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_HOST_CONF = "camel.sink.endpoint.proxyHost";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_HOST_DOC = "Proxy hostname to use";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_HOST_DEFAULT = null;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_PORT_CONF = "camel.sink.endpoint.proxyPort";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_PORT_DOC = "Proxy port to use";
-    public static final Integer CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_PORT_DEFAULT = null;
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_AUTH_HOST_CONF = "camel.sink.endpoint.authHost";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_AUTH_HOST_DOC = "Authentication host to use with NTML";
-    public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_AUTH_HOST_DEFAULT = null;
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.atmosphere-websocket.lazyStartProducer";
     public static final String CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. B [...]
     public static final Boolean CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -148,24 +112,12 @@ public class CamelAtmospherewebsocketSinkConnectorConfig
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_USE_STREAMING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_USE_STREAMING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_USE_STREAMING_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_BINDING_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_BINDING_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BRIDGE_ENDPOINT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BRIDGE_ENDPOINT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BRIDGE_ENDPOINT_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_CONNECTION_CLOSE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_CONNECTION_CLOSE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_CONNECTION_CLOSE_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COPY_HEADERS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COPY_HEADERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COPY_HEADERS_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_METHOD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_METHOD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_HTTP_METHOD_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_IGNORE_RESPONSE_BODY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_IGNORE_RESPONSE_BODY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_IGNORE_RESPONSE_BODY_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_LAZY_START_PRODUCER_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PRESERVE_HOST_HEADER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PRESERVE_HOST_HEADER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PRESERVE_HOST_HEADER_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_THROW_EXCEPTION_ON_FAILURE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_THROW_EXCEPTION_ON_FAILURE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_THROW_EXCEPTION_ON_FAILURE_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COOKIE_HANDLER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COOKIE_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_COOKIE_HANDLER_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_OK_STATUS_CODE_RANGE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_OK_STATUS_CODE_RANGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_OK_STATUS_CODE_RANGE_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_BODY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_BODY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_BODY_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_FORM_URL_ENCODED_BODY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_FORM_URL_ENCODED_BODY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_FORM_URL_ENCODED_BODY_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_HEADERS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_HEADERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_MAP_HTTP_MESSAGE_HEADERS_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_SYNCHRONOUS_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_AUTH_SCHEME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_AUTH_SCHEME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_AUTH_SCHEME_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_HOST_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.INT, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_PROXY_PORT_DOC);
-        conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_AUTH_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_AUTH_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_ENDPOINT_AUTH_HOST_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_ALLOW_JAVA_SERIALIZED_OBJECT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_ALLOW_JAVA_SERIALIZED_OBJECT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_ALLOW_JAVA_SERIALIZED_OBJECT_DOC);
         conf.define(CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_ATMOSPHEREWEBSOCKET_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
diff --git a/connectors/camel-atom-kafka-connector/src/main/docs/camel-atom-kafka-source-connector.adoc b/connectors/camel-atom-kafka-connector/src/main/docs/camel-atom-kafka-source-connector.adoc
index ac497f2..725ae22 100644
--- a/connectors/camel-atom-kafka-connector/src/main/docs/camel-atom-kafka-source-connector.adoc
+++ b/connectors/camel-atom-kafka-connector/src/main/docs/camel-atom-kafka-source-connector.adoc
@@ -47,7 +47,7 @@ The camel-atom source connector supports 32 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-atom-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atom/CamelAtomSourceConnectorConfig.java b/connectors/camel-atom-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atom/CamelAtomSourceConnectorConfig.java
index b8c2e77..43727e7 100644
--- a/connectors/camel-atom-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atom/CamelAtomSourceConnectorConfig.java
+++ b/connectors/camel-atom-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/atom/CamelAtomSourceConnectorConfig.java
@@ -102,7 +102,7 @@ public class CamelAtomSourceConnectorConfig
     public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_ATOM_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-aws-cw-kafka-connector/src/main/docs/camel-aws-cw-kafka-sink-connector.adoc b/connectors/camel-aws-cw-kafka-connector/src/main/docs/camel-aws-cw-kafka-sink-connector.adoc
index ec1cdda..d6a6e64 100644
--- a/connectors/camel-aws-cw-kafka-connector/src/main/docs/camel-aws-cw-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-cw-kafka-connector/src/main/docs/camel-aws-cw-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-cw-kafka-connector as sink make sure to use the following M
 ----
 
 
-The camel-aws-cw sink connector supports 29 options, which are listed below.
+The camel-aws-cw sink connector supports 31 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws-cw sink connector supports 29 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.sink.path.namespace* | The metric namespace | null | HIGH
 | *camel.sink.endpoint.amazonCwClient* | To use the AmazonCloudWatch as the client | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.name* | The metric name | null | MEDIUM
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the CW client | null | MEDIUM
@@ -38,6 +39,7 @@ The camel-aws-cw sink connector supports 29 options, which are listed below.
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-cw.amazonCwClient* | To use the AmazonCloudWatch as the client | null | MEDIUM
+| *camel.component.aws-cw.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-cw.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-cw.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then  [...]
 | *camel.component.aws-cw.name* | The metric name | null | MEDIUM
diff --git a/connectors/camel-aws-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awscw/CamelAwscwSinkConnectorConfig.java b/connectors/camel-aws-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awscw/CamelAwscwSinkConnectorConfig.java
index 1459802..0cc9662 100644
--- a/connectors/camel-aws-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awscw/CamelAwscwSinkConnectorConfig.java
+++ b/connectors/camel-aws-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awscw/CamelAwscwSinkConnectorConfig.java
@@ -30,6 +30,9 @@ public class CamelAwscwSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSCW_ENDPOINT_AMAZON_CW_CLIENT_CONF = "camel.sink.endpoint.amazonCwClient";
     public static final String CAMEL_SINK_AWSCW_ENDPOINT_AMAZON_CW_CLIENT_DOC = "To use the AmazonCloudWatch as the client";
     public static final String CAMEL_SINK_AWSCW_ENDPOINT_AMAZON_CW_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSCW_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSCW_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSCW_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSCW_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWSCW_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when [...]
     public static final Boolean CAMEL_SINK_AWSCW_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -72,6 +75,9 @@ public class CamelAwscwSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSCW_COMPONENT_AMAZON_CW_CLIENT_CONF = "camel.component.aws-cw.amazonCwClient";
     public static final String CAMEL_SINK_AWSCW_COMPONENT_AMAZON_CW_CLIENT_DOC = "To use the AmazonCloudWatch as the client";
     public static final String CAMEL_SINK_AWSCW_COMPONENT_AMAZON_CW_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSCW_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-cw.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSCW_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSCW_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSCW_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-cw.configuration";
     public static final String CAMEL_SINK_AWSCW_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSCW_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -126,6 +132,7 @@ public class CamelAwscwSinkConnectorConfig extends CamelSinkConnectorConfig {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWSCW_PATH_NAMESPACE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_PATH_NAMESPACE_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSCW_PATH_NAMESPACE_DOC);
         conf.define(CAMEL_SINK_AWSCW_ENDPOINT_AMAZON_CW_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_ENDPOINT_AMAZON_CW_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_ENDPOINT_AMAZON_CW_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSCW_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSCW_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSCW_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSCW_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSCW_ENDPOINT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_ENDPOINT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_ENDPOINT_NAME_DOC);
         conf.define(CAMEL_SINK_AWSCW_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_ENDPOINT_PROXY_HOST_DOC);
@@ -140,6 +147,7 @@ public class CamelAwscwSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSCW_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSCW_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWSCW_COMPONENT_AMAZON_CW_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_COMPONENT_AMAZON_CW_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_COMPONENT_AMAZON_CW_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSCW_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSCW_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSCW_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSCW_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSCW_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSCW_COMPONENT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSCW_COMPONENT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSCW_COMPONENT_NAME_DOC);
diff --git a/connectors/camel-aws-ddb-kafka-connector/src/main/docs/camel-aws-ddb-kafka-sink-connector.adoc b/connectors/camel-aws-ddb-kafka-connector/src/main/docs/camel-aws-ddb-kafka-sink-connector.adoc
index 2c4720f..581b313 100644
--- a/connectors/camel-aws-ddb-kafka-connector/src/main/docs/camel-aws-ddb-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-ddb-kafka-connector/src/main/docs/camel-aws-ddb-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-ddb-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws-ddb sink connector supports 33 options, which are listed below.
+The camel-aws-ddb sink connector supports 35 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws-ddb sink connector supports 33 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.sink.path.tableName* | The name of the table currently worked with. | null | HIGH
 | *camel.sink.endpoint.amazonDDBClient* | To use the AmazonDynamoDB as the client | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.consistentRead* | Determines whether or not strong consistency should be enforced when data is read. | false | MEDIUM
 | *camel.sink.endpoint.keyAttributeName* | Attribute name when creating table | null | MEDIUM
 | *camel.sink.endpoint.keyAttributeType* | Attribute type when creating table | null | MEDIUM
@@ -40,6 +41,7 @@ The camel-aws-ddb sink connector supports 33 options, which are listed below.
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-ddb.amazonDDBClient* | To use the AmazonDynamoDB as the client | null | MEDIUM
+| *camel.component.aws-ddb.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-ddb.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-ddb.consistentRead* | Determines whether or not strong consistency should be enforced when data is read. | false | MEDIUM
 | *camel.component.aws-ddb.keyAttributeName* | Attribute name when creating table | null | MEDIUM
diff --git a/connectors/camel-aws-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddb/CamelAwsddbSinkConnectorConfig.java b/connectors/camel-aws-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddb/CamelAwsddbSinkConnectorConfig.java
index df94fe0..cefd67d 100644
--- a/connectors/camel-aws-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddb/CamelAwsddbSinkConnectorConfig.java
+++ b/connectors/camel-aws-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddb/CamelAwsddbSinkConnectorConfig.java
@@ -30,6 +30,9 @@ public class CamelAwsddbSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSDDB_ENDPOINT_AMAZON_DDBCLIENT_CONF = "camel.sink.endpoint.amazonDDBClient";
     public static final String CAMEL_SINK_AWSDDB_ENDPOINT_AMAZON_DDBCLIENT_DOC = "To use the AmazonDynamoDB as the client";
     public static final String CAMEL_SINK_AWSDDB_ENDPOINT_AMAZON_DDBCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSDDB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSDDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSDDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSDDB_ENDPOINT_CONSISTENT_READ_CONF = "camel.sink.endpoint.consistentRead";
     public static final String CAMEL_SINK_AWSDDB_ENDPOINT_CONSISTENT_READ_DOC = "Determines whether or not strong consistency should be enforced when data is read.";
     public static final Boolean CAMEL_SINK_AWSDDB_ENDPOINT_CONSISTENT_READ_DEFAULT = false;
@@ -78,6 +81,9 @@ public class CamelAwsddbSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSDDB_COMPONENT_AMAZON_DDBCLIENT_CONF = "camel.component.aws-ddb.amazonDDBClient";
     public static final String CAMEL_SINK_AWSDDB_COMPONENT_AMAZON_DDBCLIENT_DOC = "To use the AmazonDynamoDB as the client";
     public static final String CAMEL_SINK_AWSDDB_COMPONENT_AMAZON_DDBCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSDDB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-ddb.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSDDB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSDDB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSDDB_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-ddb.configuration";
     public static final String CAMEL_SINK_AWSDDB_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSDDB_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -138,6 +144,7 @@ public class CamelAwsddbSinkConnectorConfig extends CamelSinkConnectorConfig {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWSDDB_PATH_TABLE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_PATH_TABLE_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSDDB_PATH_TABLE_NAME_DOC);
         conf.define(CAMEL_SINK_AWSDDB_ENDPOINT_AMAZON_DDBCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_ENDPOINT_AMAZON_DDBCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_ENDPOINT_AMAZON_DDBCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSDDB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSDDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSDDB_ENDPOINT_CONSISTENT_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSDDB_ENDPOINT_CONSISTENT_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_ENDPOINT_CONSISTENT_READ_DOC);
         conf.define(CAMEL_SINK_AWSDDB_ENDPOINT_KEY_ATTRIBUTE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_ENDPOINT_KEY_ATTRIBUTE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_ENDPOINT_KEY_ATTRIBUTE_NAME_DOC);
         conf.define(CAMEL_SINK_AWSDDB_ENDPOINT_KEY_ATTRIBUTE_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_ENDPOINT_KEY_ATTRIBUTE_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_ENDPOINT_KEY_ATTRIBUTE_TYPE_DOC);
@@ -154,6 +161,7 @@ public class CamelAwsddbSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSDDB_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSDDB_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWSDDB_COMPONENT_AMAZON_DDBCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_COMPONENT_AMAZON_DDBCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_COMPONENT_AMAZON_DDBCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSDDB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSDDB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSDDB_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSDDB_COMPONENT_CONSISTENT_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSDDB_COMPONENT_CONSISTENT_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_COMPONENT_CONSISTENT_READ_DOC);
         conf.define(CAMEL_SINK_AWSDDB_COMPONENT_KEY_ATTRIBUTE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSDDB_COMPONENT_KEY_ATTRIBUTE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSDDB_COMPONENT_KEY_ATTRIBUTE_NAME_DOC);
diff --git a/connectors/camel-aws-ddbstream-kafka-connector/src/main/docs/camel-aws-ddbstream-kafka-source-connector.adoc b/connectors/camel-aws-ddbstream-kafka-connector/src/main/docs/camel-aws-ddbstream-kafka-source-connector.adoc
index 32e0623..63b8571 100644
--- a/connectors/camel-aws-ddbstream-kafka-connector/src/main/docs/camel-aws-ddbstream-kafka-source-connector.adoc
+++ b/connectors/camel-aws-ddbstream-kafka-connector/src/main/docs/camel-aws-ddbstream-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-ddbstream-kafka-connector as source make sure to use the fo
 ----
 
 
-The camel-aws-ddbstream source connector supports 45 options, which are listed below.
+The camel-aws-ddbstream source connector supports 47 options, which are listed below.
 
 
 
@@ -23,6 +23,7 @@ The camel-aws-ddbstream source connector supports 45 options, which are listed b
 |===
 | Name | Description | Default | Priority
 | *camel.source.path.tableName* | Name of the dynamodb table | null | HIGH
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.source.endpoint.amazonDynamoDbStreamsClient* | Amazon DynamoDB client to use for all requests for this endpoint | null | MEDIUM
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.iteratorType* | Defines where in the DynaboDB stream to start getting records. Note that using TRIM_HORIZON can cause a significant delay before the stream has caught up to real-time. if {AT,AFTER}_SEQUENCE_NUMBER are used, then a sequenceNumberProvider MUST be supplied. One of: [TRIM_HORIZON] [LATEST] [AT_SEQUENCE_NUMBER] [AFTER_SEQUENCE_NUMBER] | "LATEST" | MEDIUM
@@ -47,13 +48,14 @@ The camel-aws-ddbstream source connector supports 45 options, which are listed b
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
 | *camel.source.endpoint.useFixedDelay* | Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details. | true | MEDIUM
 | *camel.source.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.source.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
+| *camel.component.aws-ddbstream.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws-ddbstream.amazonDynamoDb StreamsClient* | Amazon DynamoDB client to use for all requests for this endpoint | null | MEDIUM
 | *camel.component.aws-ddbstream.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.aws-ddbstream.configuration* | The component configuration | null | MEDIUM
diff --git a/connectors/camel-aws-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddbstream/CamelAwsddbstreamSourceConnectorConfig.java b/connectors/camel-aws-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddbstream/CamelAwsddbstreamSourceConnectorConfig.java
index aaf2cd6..b35f8b0 100644
--- a/connectors/camel-aws-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddbstream/CamelAwsddbstreamSourceConnectorConfig.java
+++ b/connectors/camel-aws-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsddbstream/CamelAwsddbstreamSourceConnectorConfig.java
@@ -29,6 +29,9 @@ public class CamelAwsddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_PATH_TABLE_NAME_CONF = "camel.source.path.tableName";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_PATH_TABLE_NAME_DOC = "Name of the dynamodb table";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_PATH_TABLE_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF = "camel.source.endpoint.amazonDynamoDbStreamsClient";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC = "Amazon DynamoDB client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT = null;
@@ -102,7 +105,7 @@ public class CamelAwsddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -122,6 +125,9 @@ public class CamelAwsddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SECRET_KEY_CONF = "camel.source.endpoint.secretKey";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SECRET_KEY_DOC = "Amazon AWS Secret Key";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SECRET_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-ddbstream.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF = "camel.component.aws-ddbstream.amazonDynamoDbStreamsClient";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC = "Amazon DynamoDB client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT = null;
@@ -176,6 +182,7 @@ public class CamelAwsddbstreamSourceConnectorConfig
     public static ConfigDef conf() {
         ConfigDef conf = new ConfigDef(CamelSourceConnectorConfig.conf());
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_PATH_TABLE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSDDBSTREAM_PATH_TABLE_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_AWSDDBSTREAM_PATH_TABLE_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_ITERATOR_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_ITERATOR_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_ITERATOR_TYPE_DOC);
@@ -207,6 +214,7 @@ public class CamelAwsddbstreamSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_USE_FIXED_DELAY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_USE_FIXED_DELAY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_USE_FIXED_DELAY_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_ENDPOINT_SECRET_KEY_DOC);
+        conf.define(CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSDDBSTREAM_COMPONENT_CONFIGURATION_DOC);
diff --git a/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/docs/camel-aws-kinesis-firehose-kafka-sink-connector.adoc b/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/docs/camel-aws-kinesis-firehose-kafka-sink-connector.adoc
index 0b7eeb7..3fbaad9 100644
--- a/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/docs/camel-aws-kinesis-firehose-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/docs/camel-aws-kinesis-firehose-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-kinesis-firehose-kafka-connector as sink make sure to use t
 ----
 
 
-The camel-aws-kinesis-firehose sink connector supports 21 options, which are listed below.
+The camel-aws-kinesis-firehose sink connector supports 23 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws-kinesis-firehose sink connector supports 21 options, which are lis
 | Name | Description | Default | Priority
 | *camel.sink.path.streamName* | Name of the stream | null | HIGH
 | *camel.sink.endpoint.amazonKinesisFirehoseClient* | Amazon Kinesis Firehose client to use for all requests for this endpoint | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the Kinesis Firehose client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the Kinesis Firehose client | null | MEDIUM
@@ -34,6 +35,7 @@ The camel-aws-kinesis-firehose sink connector supports 21 options, which are lis
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-kinesis-firehose.amazonKinesis FirehoseClient* | Amazon Kinesis Firehose client to use for all requests for this endpoint | null | MEDIUM
+| *camel.component.aws-kinesis-firehose.autoDiscover Client* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws-kinesis-firehose.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-kinesis-firehose.lazyStart Producer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is  [...]
 | *camel.component.aws-kinesis-firehose.proxyHost* | To define a proxy host when instantiating the Kinesis Firehose client | null | MEDIUM
diff --git a/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesisfirehose/CamelAwskinesisfirehoseSinkConnectorConfig.java b/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesisfirehose/CamelAwskinesisfirehoseSinkConnectorConfig.java
index 2a84f59..f055d35 100644
--- a/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesisfirehose/CamelAwskinesisfirehoseSinkConnectorConfig.java
+++ b/connectors/camel-aws-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesisfirehose/CamelAwskinesisfirehoseSinkConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAwskinesisfirehoseSinkConnectorConfig
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF = "camel.sink.endpoint.amazonKinesisFirehoseClient";
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC = "Amazon Kinesis Firehose client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Bew [...]
     public static final Boolean CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -62,6 +65,9 @@ public class CamelAwskinesisfirehoseSinkConnectorConfig
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF = "camel.component.aws-kinesis-firehose.amazonKinesisFirehoseClient";
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC = "Amazon Kinesis Firehose client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-kinesis-firehose.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-kinesis-firehose.configuration";
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -105,6 +111,7 @@ public class CamelAwskinesisfirehoseSinkConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_PATH_STREAM_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_PATH_STREAM_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSKINESISFIREHOSE_PATH_STREAM_NAME_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_PROXY_PORT_DOC);
@@ -115,6 +122,7 @@ public class CamelAwskinesisfirehoseSinkConnectorConfig
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESISFIREHOSE_COMPONENT_PROXY_HOST_DOC);
diff --git a/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-sink-connector.adoc b/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-sink-connector.adoc
index 9810ba2..480583d 100644
--- a/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-kinesis-kafka-connector as sink make sure to use the follow
 ----
 
 
-The camel-aws-kinesis sink connector supports 21 options, which are listed below.
+The camel-aws-kinesis sink connector supports 23 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws-kinesis sink connector supports 21 options, which are listed below
 | Name | Description | Default | Priority
 | *camel.sink.path.streamName* | Name of the stream | null | HIGH
 | *camel.sink.endpoint.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the Kinesis client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
@@ -34,6 +35,7 @@ The camel-aws-kinesis sink connector supports 21 options, which are listed below
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-kinesis.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.component.aws-kinesis.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws-kinesis.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-kinesis.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.component.aws-kinesis.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
diff --git a/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-source-connector.adoc b/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-source-connector.adoc
index c45f92d..96a20be 100644
--- a/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-source-connector.adoc
+++ b/connectors/camel-aws-kinesis-kafka-connector/src/main/docs/camel-aws-kinesis-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-kinesis-kafka-connector as source make sure to use the foll
 ----
 
 
-The camel-aws-kinesis source connector supports 49 options, which are listed below.
+The camel-aws-kinesis source connector supports 51 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws-kinesis source connector supports 49 options, which are listed bel
 | Name | Description | Default | Priority
 | *camel.source.path.streamName* | Name of the stream | null | HIGH
 | *camel.source.endpoint.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.source.endpoint.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.source.endpoint.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
 | *camel.source.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the Kinesis client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
@@ -49,7 +50,7 @@ The camel-aws-kinesis source connector supports 49 options, which are listed bel
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
@@ -57,6 +58,7 @@ The camel-aws-kinesis source connector supports 49 options, which are listed bel
 | *camel.source.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.source.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-kinesis.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.component.aws-kinesis.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws-kinesis.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-kinesis.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.component.aws-kinesis.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
diff --git a/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSinkConnectorConfig.java b/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSinkConnectorConfig.java
index 76da56a..921a4a5 100644
--- a/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSinkConnectorConfig.java
+++ b/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSinkConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAwskinesisSinkConnectorConfig
     public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF = "camel.sink.endpoint.amazonKinesisClient";
     public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_HOST_CONF = "camel.sink.endpoint.proxyHost";
     public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_HOST_DOC = "To define a proxy host when instantiating the Kinesis client";
     public static final String CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_HOST_DEFAULT = null;
@@ -62,6 +65,9 @@ public class CamelAwskinesisSinkConnectorConfig
     public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF = "camel.component.aws-kinesis.amazonKinesisClient";
     public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-kinesis.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-kinesis.configuration";
     public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSKINESIS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -104,6 +110,7 @@ public class CamelAwskinesisSinkConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWSKINESIS_PATH_STREAM_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_PATH_STREAM_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSKINESIS_PATH_STREAM_NAME_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_PORT_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_ENDPOINT_PROXY_PROTOCOL_DOC);
@@ -114,6 +121,7 @@ public class CamelAwskinesisSinkConnectorConfig
         conf.define(CAMEL_SINK_AWSKINESIS_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_COMPONENT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWSKINESIS_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSKINESIS_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSKINESIS_COMPONENT_PROXY_PORT_DOC);
diff --git a/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSourceConnectorConfig.java b/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSourceConnectorConfig.java
index 5b16c5f..3efa69d 100644
--- a/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSourceConnectorConfig.java
+++ b/connectors/camel-aws-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awskinesis/CamelAwskinesisSourceConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAwskinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF = "camel.source.endpoint.amazonKinesisClient";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_HOST_CONF = "camel.source.endpoint.proxyHost";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_HOST_DOC = "To define a proxy host when instantiating the Kinesis client";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_HOST_DEFAULT = null;
@@ -108,7 +111,7 @@ public class CamelAwskinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -131,6 +134,9 @@ public class CamelAwskinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF = "camel.component.aws-kinesis.amazonKinesisClient";
     public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-kinesis.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-kinesis.configuration";
     public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SOURCE_AWSKINESIS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -188,6 +194,7 @@ public class CamelAwskinesisSourceConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSourceConnectorConfig.conf());
         conf.define(CAMEL_SOURCE_AWSKINESIS_PATH_STREAM_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_PATH_STREAM_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_AWSKINESIS_PATH_STREAM_NAME_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_PORT_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_PROXY_PROTOCOL_DOC);
@@ -221,6 +228,7 @@ public class CamelAwskinesisSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWSKINESIS_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_COMPONENT_PROXY_HOST_DOC);
         conf.define(CAMEL_SOURCE_AWSKINESIS_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSKINESIS_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSKINESIS_COMPONENT_PROXY_PORT_DOC);
diff --git a/connectors/camel-aws-lambda-kafka-connector/src/main/docs/camel-aws-lambda-kafka-sink-connector.adoc b/connectors/camel-aws-lambda-kafka-connector/src/main/docs/camel-aws-lambda-kafka-sink-connector.adoc
index af66372..c8bb93a 100644
--- a/connectors/camel-aws-lambda-kafka-connector/src/main/docs/camel-aws-lambda-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-lambda-kafka-connector/src/main/docs/camel-aws-lambda-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-lambda-kafka-connector as sink make sure to use the followi
 ----
 
 
-The camel-aws-lambda sink connector supports 23 options, which are listed below.
+The camel-aws-lambda sink connector supports 25 options, which are listed below.
 
 
 
@@ -23,6 +23,7 @@ The camel-aws-lambda sink connector supports 23 options, which are listed below.
 |===
 | Name | Description | Default | Priority
 | *camel.sink.path.function* | Name of the Lambda function. | null | HIGH
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.operation* | The operation to perform. It can be listFunctions, getFunction, createFunction, deleteFunction or invokeFunction One of: [listFunctions] [getFunction] [createAlias] [deleteAlias] [getAlias] [listAliases] [createFunction] [deleteFunction] [invokeFunction] [updateFunction] [createEventSourceMapping] [deleteEventSourceMapping] [listEventSourceMapping] [listTags] [tagResource] [untagResource] [publishVersion] [listVersions] | "invokeFunction" | MEDIUM
 | *camel.sink.endpoint.region* | Amazon AWS Region. When using this parameter, the configuration will expect the capitalized name of the region (for example AP_EAST_1) You'll need to use the name Regions.EU_WEST_1.name() | null | MEDIUM
@@ -34,6 +35,7 @@ The camel-aws-lambda sink connector supports 23 options, which are listed below.
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the Lambda client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
+| *camel.component.aws-lambda.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-lambda.configuration* | The AWS Lambda default configuration | null | MEDIUM
 | *camel.component.aws-lambda.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed t [...]
 | *camel.component.aws-lambda.operation* | The operation to perform. It can be listFunctions, getFunction, createFunction, deleteFunction or invokeFunction One of: [listFunctions] [getFunction] [createAlias] [deleteAlias] [getAlias] [listAliases] [createFunction] [deleteFunction] [invokeFunction] [updateFunction] [createEventSourceMapping] [deleteEventSourceMapping] [listEventSourceMapping] [listTags] [tagResource] [untagResource] [publishVersion] [listVersions] | "invokeFunction" | MEDIUM
diff --git a/connectors/camel-aws-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awslambda/CamelAwslambdaSinkConnectorConfig.java b/connectors/camel-aws-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awslambda/CamelAwslambdaSinkConnectorConfig.java
index 7ca0931..f9144f9 100644
--- a/connectors/camel-aws-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awslambda/CamelAwslambdaSinkConnectorConfig.java
+++ b/connectors/camel-aws-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awslambda/CamelAwslambdaSinkConnectorConfig.java
@@ -29,6 +29,9 @@ public class CamelAwslambdaSinkConnectorConfig
     public static final String CAMEL_SINK_AWSLAMBDA_PATH_FUNCTION_CONF = "camel.sink.path.function";
     public static final String CAMEL_SINK_AWSLAMBDA_PATH_FUNCTION_DOC = "Name of the Lambda function.";
     public static final String CAMEL_SINK_AWSLAMBDA_PATH_FUNCTION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSLAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSLAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSLAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSLAMBDA_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWSLAMBDA_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that  [...]
     public static final Boolean CAMEL_SINK_AWSLAMBDA_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -62,6 +65,9 @@ public class CamelAwslambdaSinkConnectorConfig
     public static final String CAMEL_SINK_AWSLAMBDA_ENDPOINT_SECRET_KEY_CONF = "camel.sink.endpoint.secretKey";
     public static final String CAMEL_SINK_AWSLAMBDA_ENDPOINT_SECRET_KEY_DOC = "Amazon AWS Secret Key";
     public static final String CAMEL_SINK_AWSLAMBDA_ENDPOINT_SECRET_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSLAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-lambda.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSLAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSLAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSLAMBDA_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-lambda.configuration";
     public static final String CAMEL_SINK_AWSLAMBDA_COMPONENT_CONFIGURATION_DOC = "The AWS Lambda default configuration";
     public static final String CAMEL_SINK_AWSLAMBDA_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -109,6 +115,7 @@ public class CamelAwslambdaSinkConnectorConfig
     public static ConfigDef conf() {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWSLAMBDA_PATH_FUNCTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_PATH_FUNCTION_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSLAMBDA_PATH_FUNCTION_DOC);
+        conf.define(CAMEL_SINK_AWSLAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSLAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSLAMBDA_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_ENDPOINT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_ENDPOINT_REGION_DOC);
@@ -120,6 +127,7 @@ public class CamelAwslambdaSinkConnectorConfig
         conf.define(CAMEL_SINK_AWSLAMBDA_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_ENDPOINT_SECRET_KEY_DOC);
+        conf.define(CAMEL_SINK_AWSLAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSLAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSLAMBDA_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSLAMBDA_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSLAMBDA_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSLAMBDA_COMPONENT_OPERATION_DOC);
diff --git a/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-sink-connector.adoc b/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-sink-connector.adoc
index 8082861..28cb65a 100644
--- a/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-s3-kafka-connector as sink make sure to use the following M
 ----
 
 
-The camel-aws-s3 sink connector supports 63 options, which are listed below.
+The camel-aws-s3 sink connector supports 65 options, which are listed below.
 
 
 
@@ -25,6 +25,7 @@ The camel-aws-s3 sink connector supports 63 options, which are listed below.
 | *camel.sink.path.bucketNameOrArn* | Bucket name or ARN | null | HIGH
 | *camel.sink.endpoint.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
 | *camel.sink.endpoint.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.endpointConfiguration* | Amazon AWS Endpoint Configuration | null | MEDIUM
 | *camel.sink.endpoint.pathStyleAccess* | Whether or not the S3 client should use path style access | false | MEDIUM
 | *camel.sink.endpoint.policy* | The policy for this queue to set in the com.amazonaws.services.s3.AmazonS3#setBucketPolicy() method. | null | MEDIUM
@@ -56,6 +57,7 @@ The camel-aws-s3 sink connector supports 63 options, which are listed below.
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-s3.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
 | *camel.component.aws-s3.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.component.aws-s3.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-s3.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-s3.endpointConfiguration* | Amazon AWS Endpoint Configuration | null | MEDIUM
 | *camel.component.aws-s3.pathStyleAccess* | Whether or not the S3 client should use path style access | false | MEDIUM
diff --git a/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-source-connector.adoc b/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-source-connector.adoc
index b59fbad..7b7708b 100644
--- a/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-source-connector.adoc
+++ b/connectors/camel-aws-s3-kafka-connector/src/main/docs/camel-aws-s3-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-s3-kafka-connector as source make sure to use the following
 ----
 
 
-The camel-aws-s3 source connector supports 77 options, which are listed below.
+The camel-aws-s3 source connector supports 79 options, which are listed below.
 
 
 
@@ -25,6 +25,7 @@ The camel-aws-s3 source connector supports 77 options, which are listed below.
 | *camel.source.path.bucketNameOrArn* | Bucket name or ARN | null | HIGH
 | *camel.source.endpoint.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
 | *camel.source.endpoint.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.source.endpoint.endpointConfiguration* | Amazon AWS Endpoint Configuration | null | MEDIUM
 | *camel.source.endpoint.pathStyleAccess* | Whether or not the S3 client should use path style access | false | MEDIUM
 | *camel.source.endpoint.policy* | The policy for this queue to set in the com.amazonaws.services.s3.AmazonS3#setBucketPolicy() method. | null | MEDIUM
@@ -64,7 +65,7 @@ The camel-aws-s3 source connector supports 77 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
@@ -73,6 +74,7 @@ The camel-aws-s3 source connector supports 77 options, which are listed below.
 | *camel.source.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-s3.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
 | *camel.component.aws-s3.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.component.aws-s3.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-s3.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-s3.endpointConfiguration* | Amazon AWS Endpoint Configuration | null | MEDIUM
 | *camel.component.aws-s3.pathStyleAccess* | Whether or not the S3 client should use path style access | false | MEDIUM
diff --git a/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SinkConnectorConfig.java b/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SinkConnectorConfig.java
index 66e2e27..d139dd2 100644
--- a/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SinkConnectorConfig.java
+++ b/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SinkConnectorConfig.java
@@ -33,6 +33,9 @@ public class CamelAwss3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_CONF = "camel.sink.endpoint.autoCreateBucket";
     public static final String CAMEL_SINK_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
     public static final Boolean CAMEL_SINK_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SINK_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_CONF = "camel.sink.endpoint.endpointConfiguration";
     public static final String CAMEL_SINK_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DOC = "Amazon AWS Endpoint Configuration";
     public static final String CAMEL_SINK_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DEFAULT = null;
@@ -126,6 +129,9 @@ public class CamelAwss3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_CONF = "camel.component.aws-s3.autoCreateBucket";
     public static final String CAMEL_SINK_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
     public static final Boolean CAMEL_SINK_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SINK_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-s3.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSS3_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-s3.configuration";
     public static final String CAMEL_SINK_AWSS3_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSS3_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -229,6 +235,7 @@ public class CamelAwss3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSS3_PATH_BUCKET_NAME_OR_ARN_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_PATH_BUCKET_NAME_OR_ARN_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSS3_PATH_BUCKET_NAME_OR_ARN_DOC);
         conf.define(CAMEL_SINK_AWSS3_ENDPOINT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_ENDPOINT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_ENDPOINT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SINK_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSS3_ENDPOINT_PATH_STYLE_ACCESS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSS3_ENDPOINT_PATH_STYLE_ACCESS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_ENDPOINT_PATH_STYLE_ACCESS_DOC);
         conf.define(CAMEL_SINK_AWSS3_ENDPOINT_POLICY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_ENDPOINT_POLICY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_ENDPOINT_POLICY_DOC);
@@ -260,6 +267,7 @@ public class CamelAwss3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSS3_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWSS3_COMPONENT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_COMPONENT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_COMPONENT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SINK_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSS3_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSS3_COMPONENT_ENDPOINT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSS3_COMPONENT_ENDPOINT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_COMPONENT_ENDPOINT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSS3_COMPONENT_PATH_STYLE_ACCESS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSS3_COMPONENT_PATH_STYLE_ACCESS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSS3_COMPONENT_PATH_STYLE_ACCESS_DOC);
diff --git a/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SourceConnectorConfig.java b/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SourceConnectorConfig.java
index 4fefb3a..5965be7 100644
--- a/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SourceConnectorConfig.java
+++ b/connectors/camel-aws-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awss3/CamelAwss3SourceConnectorConfig.java
@@ -35,6 +35,9 @@ public class CamelAwss3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_CONF = "camel.source.endpoint.autoCreateBucket";
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
     public static final Boolean CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_CONF = "camel.source.endpoint.endpointConfiguration";
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DOC = "Amazon AWS Endpoint Configuration";
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DEFAULT = null;
@@ -153,7 +156,7 @@ public class CamelAwss3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWSS3_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -179,6 +182,9 @@ public class CamelAwss3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_CONF = "camel.component.aws-s3.autoCreateBucket";
     public static final String CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
     public static final Boolean CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-s3.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSS3_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-s3.configuration";
     public static final String CAMEL_SOURCE_AWSS3_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SOURCE_AWSS3_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -273,6 +279,7 @@ public class CamelAwss3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWSS3_PATH_BUCKET_NAME_OR_ARN_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_PATH_BUCKET_NAME_OR_ARN_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_AWSS3_PATH_BUCKET_NAME_OR_ARN_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_ENDPOINT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_ENDPOINT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_ENDPOINT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_ENDPOINT_ENDPOINT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_ENDPOINT_PATH_STYLE_ACCESS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSS3_ENDPOINT_PATH_STYLE_ACCESS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_ENDPOINT_PATH_STYLE_ACCESS_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_ENDPOINT_POLICY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_ENDPOINT_POLICY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_ENDPOINT_POLICY_DOC);
@@ -321,6 +328,7 @@ public class CamelAwss3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWSS3_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_COMPONENT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_COMPONENT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_COMPONENT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_COMPONENT_ENDPOINT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSS3_COMPONENT_ENDPOINT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_COMPONENT_ENDPOINT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWSS3_COMPONENT_PATH_STYLE_ACCESS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSS3_COMPONENT_PATH_STYLE_ACCESS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSS3_COMPONENT_PATH_STYLE_ACCESS_DOC);
diff --git a/connectors/camel-aws-ses-kafka-connector/src/main/docs/camel-aws-ses-kafka-sink-connector.adoc b/connectors/camel-aws-ses-kafka-connector/src/main/docs/camel-aws-ses-kafka-sink-connector.adoc
index 0e342b6..a7b574c 100644
--- a/connectors/camel-aws-ses-kafka-connector/src/main/docs/camel-aws-ses-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-ses-kafka-connector/src/main/docs/camel-aws-ses-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-ses-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws-ses sink connector supports 29 options, which are listed below.
+The camel-aws-ses sink connector supports 31 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws-ses sink connector supports 29 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.sink.path.from* | The sender's email address. | null | HIGH
 | *camel.sink.endpoint.amazonSESClient* | To use the AmazonSimpleEmailService as the client | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the SES client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the SES client | null | MEDIUM
@@ -38,6 +39,7 @@ The camel-aws-ses sink connector supports 29 options, which are listed below.
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws-ses.amazonSESClient* | To use the AmazonSimpleEmailService as the client | null | MEDIUM
+| *camel.component.aws-ses.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-ses.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-ses.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then [...]
 | *camel.component.aws-ses.proxyHost* | To define a proxy host when instantiating the SES client | null | MEDIUM
diff --git a/connectors/camel-aws-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsses/CamelAwssesSinkConnectorConfig.java b/connectors/camel-aws-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsses/CamelAwssesSinkConnectorConfig.java
index ee1ef3a..b0bd6d3 100644
--- a/connectors/camel-aws-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsses/CamelAwssesSinkConnectorConfig.java
+++ b/connectors/camel-aws-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awsses/CamelAwssesSinkConnectorConfig.java
@@ -30,6 +30,9 @@ public class CamelAwssesSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSSES_ENDPOINT_AMAZON_SESCLIENT_CONF = "camel.sink.endpoint.amazonSESClient";
     public static final String CAMEL_SINK_AWSSES_ENDPOINT_AMAZON_SESCLIENT_DOC = "To use the AmazonSimpleEmailService as the client";
     public static final String CAMEL_SINK_AWSSES_ENDPOINT_AMAZON_SESCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSSES_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSSES_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSSES_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSSES_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWSSES_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that whe [...]
     public static final Boolean CAMEL_SINK_AWSSES_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -72,6 +75,9 @@ public class CamelAwssesSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSSES_COMPONENT_AMAZON_SESCLIENT_CONF = "camel.component.aws-ses.amazonSESClient";
     public static final String CAMEL_SINK_AWSSES_COMPONENT_AMAZON_SESCLIENT_DOC = "To use the AmazonSimpleEmailService as the client";
     public static final String CAMEL_SINK_AWSSES_COMPONENT_AMAZON_SESCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSSES_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-ses.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSSES_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSSES_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSSES_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-ses.configuration";
     public static final String CAMEL_SINK_AWSSES_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSSES_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -126,6 +132,7 @@ public class CamelAwssesSinkConnectorConfig extends CamelSinkConnectorConfig {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWSSES_PATH_FROM_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_PATH_FROM_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSSES_PATH_FROM_DOC);
         conf.define(CAMEL_SINK_AWSSES_ENDPOINT_AMAZON_SESCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_ENDPOINT_AMAZON_SESCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_ENDPOINT_AMAZON_SESCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSSES_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSES_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSES_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSES_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSSES_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWSSES_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_ENDPOINT_PROXY_PORT_DOC);
@@ -140,6 +147,7 @@ public class CamelAwssesSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSSES_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSSES_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWSSES_COMPONENT_AMAZON_SESCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_COMPONENT_AMAZON_SESCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_COMPONENT_AMAZON_SESCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWSSES_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSES_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSES_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSSES_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSES_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWSSES_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSES_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSES_COMPONENT_PROXY_HOST_DOC);
diff --git a/connectors/camel-aws-sns-kafka-connector/src/main/docs/camel-aws-sns-kafka-sink-connector.adoc b/connectors/camel-aws-sns-kafka-connector/src/main/docs/camel-aws-sns-kafka-sink-connector.adoc
index e1b433b..c33b457 100644
--- a/connectors/camel-aws-sns-kafka-connector/src/main/docs/camel-aws-sns-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-sns-kafka-connector/src/main/docs/camel-aws-sns-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-sns-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws-sns sink connector supports 40 options, which are listed below.
+The camel-aws-sns sink connector supports 42 options, which are listed below.
 
 
 
@@ -26,6 +26,7 @@ The camel-aws-sns sink connector supports 40 options, which are listed below.
 | *camel.sink.endpoint.amazonSNSClient* | To use the AmazonSNS as the client | null | MEDIUM
 | *camel.sink.endpoint.amazonSQSClient* | An SQS Client to use as bridge between SNS and SQS | null | MEDIUM
 | *camel.sink.endpoint.autoCreateTopic* | Setting the autocreation of the topic | true | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.headerFilterStrategy* | To use a custom HeaderFilterStrategy to map headers to/from Camel. | null | MEDIUM
 | *camel.sink.endpoint.kmsMasterKeyId* | The ID of an AWS-managed customer master key (CMK) for Amazon SNS or a custom CMK. | null | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
@@ -46,6 +47,7 @@ The camel-aws-sns sink connector supports 40 options, which are listed below.
 | *camel.component.aws-sns.amazonSNSClient* | To use the AmazonSNS as the client | null | MEDIUM
 | *camel.component.aws-sns.amazonSQSClient* | An SQS Client to use as bridge between SNS and SQS | null | MEDIUM
 | *camel.component.aws-sns.autoCreateTopic* | Setting the autocreation of the topic | true | MEDIUM
+| *camel.component.aws-sns.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-sns.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-sns.kmsMasterKeyId* | The ID of an AWS-managed customer master key (CMK) for Amazon SNS or a custom CMK. | null | MEDIUM
 | *camel.component.aws-sns.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then [...]
diff --git a/connectors/camel-aws-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssns/CamelAwssnsSinkConnectorConfig.java b/connectors/camel-aws-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssns/CamelAwssnsSinkConnectorConfig.java
index d4ac65e..5d12286 100644
--- a/connectors/camel-aws-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssns/CamelAwssnsSinkConnectorConfig.java
+++ b/connectors/camel-aws-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssns/CamelAwssnsSinkConnectorConfig.java
@@ -36,6 +36,9 @@ public class CamelAwssnsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_CREATE_TOPIC_CONF = "camel.sink.endpoint.autoCreateTopic";
     public static final String CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_CREATE_TOPIC_DOC = "Setting the autocreation of the topic";
     public static final Boolean CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_CREATE_TOPIC_DEFAULT = true;
+    public static final String CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSSNS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF = "camel.sink.endpoint.headerFilterStrategy";
     public static final String CAMEL_SINK_AWSSNS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC = "To use a custom HeaderFilterStrategy to map headers to/from Camel.";
     public static final String CAMEL_SINK_AWSSNS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT = null;
@@ -96,6 +99,9 @@ public class CamelAwssnsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSSNS_COMPONENT_AUTO_CREATE_TOPIC_CONF = "camel.component.aws-sns.autoCreateTopic";
     public static final String CAMEL_SINK_AWSSNS_COMPONENT_AUTO_CREATE_TOPIC_DOC = "Setting the autocreation of the topic";
     public static final Boolean CAMEL_SINK_AWSSNS_COMPONENT_AUTO_CREATE_TOPIC_DEFAULT = true;
+    public static final String CAMEL_SINK_AWSSNS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-sns.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSSNS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSSNS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSSNS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-sns.configuration";
     public static final String CAMEL_SINK_AWSSNS_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSSNS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -161,6 +167,7 @@ public class CamelAwssnsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSSNS_ENDPOINT_AMAZON_SNSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_ENDPOINT_AMAZON_SNSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_ENDPOINT_AMAZON_SNSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSNS_ENDPOINT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_ENDPOINT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_ENDPOINT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_CREATE_TOPIC_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_CREATE_TOPIC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_CREATE_TOPIC_DOC);
+        conf.define(CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSNS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC);
         conf.define(CAMEL_SINK_AWSSNS_ENDPOINT_KMS_MASTER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_ENDPOINT_KMS_MASTER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_ENDPOINT_KMS_MASTER_KEY_ID_DOC);
         conf.define(CAMEL_SINK_AWSSNS_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSNS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_ENDPOINT_LAZY_START_PRODUCER_DOC);
@@ -181,6 +188,7 @@ public class CamelAwssnsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSSNS_COMPONENT_AMAZON_SNSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_COMPONENT_AMAZON_SNSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_COMPONENT_AMAZON_SNSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSNS_COMPONENT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_COMPONENT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_COMPONENT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSNS_COMPONENT_AUTO_CREATE_TOPIC_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSNS_COMPONENT_AUTO_CREATE_TOPIC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_COMPONENT_AUTO_CREATE_TOPIC_DOC);
+        conf.define(CAMEL_SINK_AWSSNS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSNS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSNS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSSNS_COMPONENT_KMS_MASTER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSNS_COMPONENT_KMS_MASTER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_COMPONENT_KMS_MASTER_KEY_ID_DOC);
         conf.define(CAMEL_SINK_AWSSNS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSNS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSNS_COMPONENT_LAZY_START_PRODUCER_DOC);
diff --git a/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-sink-connector.adoc b/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-sink-connector.adoc
index e9fc8c2..1d5f4a5 100644
--- a/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-sqs-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws-sqs sink connector supports 52 options, which are listed below.
+The camel-aws-sqs sink connector supports 54 options, which are listed below.
 
 
 
@@ -26,6 +26,7 @@ The camel-aws-sqs sink connector supports 52 options, which are listed below.
 | *camel.sink.endpoint.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.sink.endpoint.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.sink.endpoint.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.headerFilterStrategy* | To use a custom HeaderFilterStrategy to map headers to/from Camel. | null | MEDIUM
 | *camel.sink.endpoint.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
@@ -52,6 +53,7 @@ The camel-aws-sqs sink connector supports 52 options, which are listed below.
 | *camel.component.aws-sqs.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.component.aws-sqs.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.component.aws-sqs.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.component.aws-sqs.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-sqs.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-sqs.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.component.aws-sqs.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
diff --git a/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-source-connector.adoc b/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-source-connector.adoc
index 9bdbff2..5f0d356 100644
--- a/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-source-connector.adoc
+++ b/connectors/camel-aws-sqs-kafka-connector/src/main/docs/camel-aws-sqs-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-sqs-kafka-connector as source make sure to use the followin
 ----
 
 
-The camel-aws-sqs source connector supports 87 options, which are listed below.
+The camel-aws-sqs source connector supports 89 options, which are listed below.
 
 
 
@@ -26,6 +26,7 @@ The camel-aws-sqs source connector supports 87 options, which are listed below.
 | *camel.source.endpoint.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.source.endpoint.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.source.endpoint.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.source.endpoint.headerFilterStrategy* | To use a custom HeaderFilterStrategy to map headers to/from Camel. | null | MEDIUM
 | *camel.source.endpoint.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.source.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
@@ -69,7 +70,7 @@ The camel-aws-sqs source connector supports 87 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
@@ -79,6 +80,7 @@ The camel-aws-sqs source connector supports 87 options, which are listed below.
 | *camel.component.aws-sqs.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.component.aws-sqs.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.component.aws-sqs.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.component.aws-sqs.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-sqs.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws-sqs.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.component.aws-sqs.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
diff --git a/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSinkConnectorConfig.java b/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSinkConnectorConfig.java
index 4d2d6f1..80409b9 100644
--- a/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSinkConnectorConfig.java
+++ b/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSinkConnectorConfig.java
@@ -36,6 +36,9 @@ public class CamelAwssqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF = "camel.sink.endpoint.autoCreateQueue";
     public static final String CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF = "camel.sink.endpoint.headerFilterStrategy";
     public static final String CAMEL_SINK_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC = "To use a custom HeaderFilterStrategy to map headers to/from Camel.";
     public static final String CAMEL_SINK_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT = null;
@@ -114,6 +117,9 @@ public class CamelAwssqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_CONF = "camel.component.aws-sqs.autoCreateQueue";
     public static final String CAMEL_SINK_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SINK_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SINK_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-sqs.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSSQS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-sqs.configuration";
     public static final String CAMEL_SINK_AWSSQS_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWSSQS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -197,6 +203,7 @@ public class CamelAwssqsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSSQS_ENDPOINT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_ENDPOINT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_ENDPOINT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SINK_AWSSQS_ENDPOINT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_ENDPOINT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_ENDPOINT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC);
         conf.define(CAMEL_SINK_AWSSQS_ENDPOINT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_ENDPOINT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_ENDPOINT_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWSSQS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_ENDPOINT_PROXY_PROTOCOL_DOC);
@@ -223,6 +230,7 @@ public class CamelAwssqsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWSSQS_COMPONENT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_COMPONENT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_COMPONENT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SINK_AWSSQS_COMPONENT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_COMPONENT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_COMPONENT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SINK_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSSQS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWSSQS_COMPONENT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_COMPONENT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_COMPONENT_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWSSQS_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSSQS_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSSQS_COMPONENT_PROXY_PROTOCOL_DOC);
diff --git a/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSourceConnectorConfig.java b/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSourceConnectorConfig.java
index 6929ff2..a0a5246 100644
--- a/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSourceConnectorConfig.java
+++ b/connectors/camel-aws-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awssqs/CamelAwssqsSourceConnectorConfig.java
@@ -38,6 +38,9 @@ public class CamelAwssqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF = "camel.source.endpoint.autoCreateQueue";
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF = "camel.source.endpoint.headerFilterStrategy";
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC = "To use a custom HeaderFilterStrategy to map headers to/from Camel.";
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT = null;
@@ -168,7 +171,7 @@ public class CamelAwssqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWSSQS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -197,6 +200,9 @@ public class CamelAwssqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_CONF = "camel.component.aws-sqs.autoCreateQueue";
     public static final String CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-sqs.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWSSQS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws-sqs.configuration";
     public static final String CAMEL_SOURCE_AWSSQS_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SOURCE_AWSSQS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -304,6 +310,7 @@ public class CamelAwssqsSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWSSQS_ENDPOINT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_ENDPOINT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_ENDPOINT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_ENDPOINT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_ENDPOINT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_ENDPOINT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_ENDPOINT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_ENDPOINT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_ENDPOINT_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_ENDPOINT_PROXY_PROTOCOL_DOC);
@@ -357,6 +364,7 @@ public class CamelAwssqsSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWSSQS_COMPONENT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_COMPONENT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_COMPONENT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_COMPONENT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_COMPONENT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_COMPONENT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_COMPONENT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_COMPONENT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_COMPONENT_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWSSQS_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWSSQS_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWSSQS_COMPONENT_PROXY_PROTOCOL_DOC);
diff --git a/connectors/camel-aws-translate-kafka-connector/src/main/docs/camel-aws-translate-kafka-sink-connector.adoc b/connectors/camel-aws-translate-kafka-connector/src/main/docs/camel-aws-translate-kafka-sink-connector.adoc
index fcc0b8d..4bd7d65 100644
--- a/connectors/camel-aws-translate-kafka-connector/src/main/docs/camel-aws-translate-kafka-sink-connector.adoc
+++ b/connectors/camel-aws-translate-kafka-connector/src/main/docs/camel-aws-translate-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws-translate-kafka-connector as sink make sure to use the foll
 ----
 
 
-The camel-aws-translate sink connector supports 29 options, which are listed below.
+The camel-aws-translate sink connector supports 31 options, which are listed below.
 
 
 
@@ -23,6 +23,7 @@ The camel-aws-translate sink connector supports 29 options, which are listed bel
 |===
 | Name | Description | Default | Priority
 | *camel.sink.path.label* | Logical name | null | HIGH
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.autodetectSourceLanguage* | Being able to autodetect the source language | false | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
@@ -37,6 +38,7 @@ The camel-aws-translate sink connector supports 29 options, which are listed bel
 | *camel.sink.endpoint.translateClient* | To use a existing configured AWS Translate as client | null | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
+| *camel.component.aws-translate.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws-translate.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws-translate.autodetectSource Language* | Being able to autodetect the source language | false | MEDIUM
 | *camel.component.aws-translate.configuration* | The component configuration | null | MEDIUM
diff --git a/connectors/camel-aws-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awstranslate/CamelAwstranslateSinkConnectorConfig.java b/connectors/camel-aws-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awstranslate/CamelAwstranslateSinkConnectorConfig.java
index 328d66e..173b6dc 100644
--- a/connectors/camel-aws-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awstranslate/CamelAwstranslateSinkConnectorConfig.java
+++ b/connectors/camel-aws-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/awstranslate/CamelAwstranslateSinkConnectorConfig.java
@@ -29,6 +29,9 @@ public class CamelAwstranslateSinkConnectorConfig
     public static final String CAMEL_SINK_AWSTRANSLATE_PATH_LABEL_CONF = "camel.sink.path.label";
     public static final String CAMEL_SINK_AWSTRANSLATE_PATH_LABEL_DOC = "Logical name";
     public static final String CAMEL_SINK_AWSTRANSLATE_PATH_LABEL_DEFAULT = null;
+    public static final String CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSTRANSLATE_ENDPOINT_ACCESS_KEY_CONF = "camel.sink.endpoint.accessKey";
     public static final String CAMEL_SINK_AWSTRANSLATE_ENDPOINT_ACCESS_KEY_DOC = "Amazon AWS Access Key";
     public static final String CAMEL_SINK_AWSTRANSLATE_ENDPOINT_ACCESS_KEY_DEFAULT = null;
@@ -71,6 +74,9 @@ public class CamelAwstranslateSinkConnectorConfig
     public static final String CAMEL_SINK_AWSTRANSLATE_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
     public static final String CAMEL_SINK_AWSTRANSLATE_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SINK_AWSTRANSLATE_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
+    public static final String CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws-translate.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWSTRANSLATE_COMPONENT_ACCESS_KEY_CONF = "camel.component.aws-translate.accessKey";
     public static final String CAMEL_SINK_AWSTRANSLATE_COMPONENT_ACCESS_KEY_DOC = "Amazon AWS Access Key";
     public static final String CAMEL_SINK_AWSTRANSLATE_COMPONENT_ACCESS_KEY_DEFAULT = null;
@@ -127,6 +133,7 @@ public class CamelAwstranslateSinkConnectorConfig
     public static ConfigDef conf() {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWSTRANSLATE_PATH_LABEL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSTRANSLATE_PATH_LABEL_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWSTRANSLATE_PATH_LABEL_DOC);
+        conf.define(CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_LAZY_START_PRODUCER_DOC);
@@ -141,6 +148,7 @@ public class CamelAwstranslateSinkConnectorConfig
         conf.define(CAMEL_SINK_AWSTRANSLATE_ENDPOINT_TRANSLATE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_TRANSLATE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_TRANSLATE_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_ENDPOINT_SYNCHRONOUS_DOC);
+        conf.define(CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSTRANSLATE_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_COMPONENT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_DOC);
         conf.define(CAMEL_SINK_AWSTRANSLATE_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWSTRANSLATE_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWSTRANSLATE_COMPONENT_CONFIGURATION_DOC);
diff --git a/connectors/camel-aws2-athena-kafka-connector/src/main/docs/camel-aws2-athena-kafka-sink-connector.adoc b/connectors/camel-aws2-athena-kafka-connector/src/main/docs/camel-aws2-athena-kafka-sink-connector.adoc
index 35b370e..59a8f80 100644
--- a/connectors/camel-aws2-athena-kafka-connector/src/main/docs/camel-aws2-athena-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-athena-kafka-connector/src/main/docs/camel-aws2-athena-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-athena-kafka-connector as sink make sure to use the follow
 ----
 
 
-The camel-aws2-athena sink connector supports 59 options, which are listed below.
+The camel-aws2-athena sink connector supports 61 options, which are listed below.
 
 
 
@@ -23,6 +23,7 @@ The camel-aws2-athena sink connector supports 59 options, which are listed below
 |===
 | Name | Description | Default | Priority
 | *camel.sink.path.label* | Logical name | null | HIGH
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key. | null | MEDIUM
 | *camel.sink.endpoint.amazonAthenaClient* | The AmazonAthena instance to use as the client. | null | MEDIUM
 | *camel.sink.endpoint.database* | The Athena database to use. | null | MEDIUM
@@ -54,6 +55,7 @@ The camel-aws2-athena sink connector supports 59 options, which are listed below
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.component.aws2-athena.accessKey* | Amazon AWS Access Key. | null | MEDIUM
 | *camel.component.aws2-athena.amazonAthenaClient* | The AmazonAthena instance to use as the client. | null | MEDIUM
+| *camel.component.aws2-athena.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws2-athena.configuration* | The component configuration. | null | MEDIUM
 | *camel.component.aws2-athena.database* | The Athena database to use. | null | MEDIUM
 | *camel.component.aws2-athena.delay* | Milliseconds before the next poll for query execution status. See the section 'Waiting for Query Completion and Retrying Failed Queries' to learn more. | 2000L | MEDIUM
@@ -82,6 +84,4 @@ The camel-aws2-athena sink connector supports 59 options, which are listed below
 | *camel.component.aws2-athena.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-athena.clientRequestToken* | A unique string to ensure issues queries are idempotent. It is unlikely you will need to set this. | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-aws2-athena-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2athena/CamelAws2athenaSinkConnectorConfig.java b/connectors/camel-aws2-athena-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2athena/CamelAws2athenaSinkConnectorConfig.java
index 8f1fab8..5107758 100644
--- a/connectors/camel-aws2-athena-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2athena/CamelAws2athenaSinkConnectorConfig.java
+++ b/connectors/camel-aws2-athena-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2athena/CamelAws2athenaSinkConnectorConfig.java
@@ -29,6 +29,9 @@ public class CamelAws2athenaSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2ATHENA_PATH_LABEL_CONF = "camel.sink.path.label";
     public static final String CAMEL_SINK_AWS2ATHENA_PATH_LABEL_DOC = "Logical name";
     public static final String CAMEL_SINK_AWS2ATHENA_PATH_LABEL_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2ATHENA_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2ATHENA_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWS2ATHENA_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2ATHENA_ENDPOINT_ACCESS_KEY_CONF = "camel.sink.endpoint.accessKey";
     public static final String CAMEL_SINK_AWS2ATHENA_ENDPOINT_ACCESS_KEY_DOC = "Amazon AWS Access Key.";
     public static final String CAMEL_SINK_AWS2ATHENA_ENDPOINT_ACCESS_KEY_DEFAULT = null;
@@ -122,6 +125,9 @@ public class CamelAws2athenaSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_AMAZON_ATHENA_CLIENT_CONF = "camel.component.aws2-athena.amazonAthenaClient";
     public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_AMAZON_ATHENA_CLIENT_DOC = "The AmazonAthena instance to use as the client.";
     public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_AMAZON_ATHENA_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-athena.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWS2ATHENA_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-athena.configuration";
     public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_CONFIGURATION_DOC = "The component configuration.";
     public static final String CAMEL_SINK_AWS2ATHENA_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -217,6 +223,7 @@ public class CamelAws2athenaSinkConnectorConfig
     public static ConfigDef conf() {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2ATHENA_PATH_LABEL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_PATH_LABEL_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2ATHENA_PATH_LABEL_DOC);
+        conf.define(CAMEL_SINK_AWS2ATHENA_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2ATHENA_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_ENDPOINT_AMAZON_ATHENA_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_ENDPOINT_AMAZON_ATHENA_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_ENDPOINT_AMAZON_ATHENA_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_ENDPOINT_DATABASE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_ENDPOINT_DATABASE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_ENDPOINT_DATABASE_DOC);
@@ -248,6 +255,7 @@ public class CamelAws2athenaSinkConnectorConfig
         conf.define(CAMEL_SINK_AWS2ATHENA_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2ATHENA_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_COMPONENT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_COMPONENT_AMAZON_ATHENA_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_COMPONENT_AMAZON_ATHENA_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_COMPONENT_AMAZON_ATHENA_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2ATHENA_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2ATHENA_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_COMPONENT_DATABASE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2ATHENA_COMPONENT_DATABASE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_COMPONENT_DATABASE_DOC);
         conf.define(CAMEL_SINK_AWS2ATHENA_COMPONENT_DELAY_CONF, ConfigDef.Type.LONG, CAMEL_SINK_AWS2ATHENA_COMPONENT_DELAY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2ATHENA_COMPONENT_DELAY_DOC);
diff --git a/connectors/camel-aws2-cw-kafka-connector/src/main/docs/camel-aws2-cw-kafka-sink-connector.adoc b/connectors/camel-aws2-cw-kafka-connector/src/main/docs/camel-aws2-cw-kafka-sink-connector.adoc
index d425f42..786bd62 100644
--- a/connectors/camel-aws2-cw-kafka-connector/src/main/docs/camel-aws2-cw-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-cw-kafka-connector/src/main/docs/camel-aws2-cw-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-cw-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws2-cw sink connector supports 29 options, which are listed below.
+The camel-aws2-cw sink connector supports 33 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws2-cw sink connector supports 29 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.sink.path.namespace* | The metric namespace | null | HIGH
 | *camel.sink.endpoint.amazonCwClient* | To use the AmazonCloudWatch as the client | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.name* | The metric name | null | MEDIUM
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the CW client | null | MEDIUM
@@ -31,6 +32,7 @@ The camel-aws2-cw sink connector supports 29 options, which are listed below.
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the CW client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.region* | The region in which EKS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
 | *camel.sink.endpoint.timestamp* | The metric timestamp | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.unit* | The metric unit | null | MEDIUM
 | *camel.sink.endpoint.value* | The metric value | null | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
@@ -38,6 +40,7 @@ The camel-aws2-cw sink connector supports 29 options, which are listed below.
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-cw.amazonCwClient* | To use the AmazonCloudWatch as the client | null | MEDIUM
+| *camel.component.aws2-cw.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-cw.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws2-cw.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then [...]
 | *camel.component.aws2-cw.name* | The metric name | null | MEDIUM
@@ -46,6 +49,7 @@ The camel-aws2-cw sink connector supports 29 options, which are listed below.
 | *camel.component.aws2-cw.proxyProtocol* | To define a proxy protocol when instantiating the CW client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-cw.region* | The region in which EKS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
 | *camel.component.aws2-cw.timestamp* | The metric timestamp | null | MEDIUM
+| *camel.component.aws2-cw.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-cw.unit* | The metric unit | null | MEDIUM
 | *camel.component.aws2-cw.value* | The metric value | null | MEDIUM
 | *camel.component.aws2-cw.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
diff --git a/connectors/camel-aws2-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2cw/CamelAws2cwSinkConnectorConfig.java b/connectors/camel-aws2-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2cw/CamelAws2cwSinkConnectorConfig.java
index a2e1dde..ad0cb96 100644
--- a/connectors/camel-aws2-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2cw/CamelAws2cwSinkConnectorConfig.java
+++ b/connectors/camel-aws2-cw-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2cw/CamelAws2cwSinkConnectorConfig.java
@@ -30,6 +30,9 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_AMAZON_CW_CLIENT_CONF = "camel.sink.endpoint.amazonCwClient";
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_AMAZON_CW_CLIENT_DOC = "To use the AmazonCloudWatch as the client";
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_AMAZON_CW_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2CW_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2CW_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2CW_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that whe [...]
     public static final Boolean CAMEL_SINK_AWS2CW_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -51,6 +54,9 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_TIMESTAMP_CONF = "camel.sink.endpoint.timestamp";
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_TIMESTAMP_DOC = "The metric timestamp";
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_TIMESTAMP_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2CW_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2CW_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2CW_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_UNIT_CONF = "camel.sink.endpoint.unit";
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_UNIT_DOC = "The metric unit";
     public static final String CAMEL_SINK_AWS2CW_ENDPOINT_UNIT_DEFAULT = null;
@@ -72,6 +78,9 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_AMAZON_CW_CLIENT_CONF = "camel.component.aws2-cw.amazonCwClient";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_AMAZON_CW_CLIENT_DOC = "To use the AmazonCloudWatch as the client";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_AMAZON_CW_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2CW_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-cw.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2CW_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2CW_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-cw.configuration";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -96,6 +105,9 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_TIMESTAMP_CONF = "camel.component.aws2-cw.timestamp";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_TIMESTAMP_DOC = "The metric timestamp";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_TIMESTAMP_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2CW_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-cw.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2CW_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2CW_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_UNIT_CONF = "camel.component.aws2-cw.unit";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_UNIT_DOC = "The metric unit";
     public static final String CAMEL_SINK_AWS2CW_COMPONENT_UNIT_DEFAULT = null;
@@ -126,6 +138,7 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2CW_PATH_NAMESPACE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_PATH_NAMESPACE_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2CW_PATH_NAMESPACE_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_AMAZON_CW_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_AMAZON_CW_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_AMAZON_CW_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_NAME_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_PROXY_HOST_DOC);
@@ -133,6 +146,7 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_REGION_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_TIMESTAMP_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_TIMESTAMP_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_TIMESTAMP_DOC);
+        conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_UNIT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_UNIT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_UNIT_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_VALUE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_VALUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_VALUE_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
@@ -140,6 +154,7 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2CW_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_AMAZON_CW_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_AMAZON_CW_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_AMAZON_CW_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2CW_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_NAME_DOC);
@@ -148,6 +163,7 @@ public class CamelAws2cwSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_REGION_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_TIMESTAMP_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_TIMESTAMP_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_TIMESTAMP_DOC);
+        conf.define(CAMEL_SINK_AWS2CW_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_UNIT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_UNIT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_UNIT_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_VALUE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2CW_COMPONENT_VALUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_VALUE_DOC);
         conf.define(CAMEL_SINK_AWS2CW_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2CW_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2CW_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
diff --git a/connectors/camel-aws2-ddb-kafka-connector/src/main/docs/camel-aws2-ddb-kafka-sink-connector.adoc b/connectors/camel-aws2-ddb-kafka-connector/src/main/docs/camel-aws2-ddb-kafka-sink-connector.adoc
index 031d6f5..acb175d 100644
--- a/connectors/camel-aws2-ddb-kafka-connector/src/main/docs/camel-aws2-ddb-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-ddb-kafka-connector/src/main/docs/camel-aws2-ddb-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-ddb-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws2-ddb sink connector supports 33 options, which are listed below.
+The camel-aws2-ddb sink connector supports 37 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws2-ddb sink connector supports 33 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.sink.path.tableName* | The name of the table currently worked with. | null | HIGH
 | *camel.sink.endpoint.amazonDDBClient* | To use the AmazonDynamoDB as the client | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.consistentRead* | Determines whether or not strong consistency should be enforced when data is read. | false | MEDIUM
 | *camel.sink.endpoint.keyAttributeName* | Attribute name when creating table | null | MEDIUM
 | *camel.sink.endpoint.keyAttributeType* | Attribute type when creating table | null | MEDIUM
@@ -34,12 +35,14 @@ The camel-aws2-ddb sink connector supports 33 options, which are listed below.
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the DDB client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.readCapacity* | The provisioned throughput to reserve for reading resources from your table | null | MEDIUM
 | *camel.sink.endpoint.region* | The region in which DDB client needs to work | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.writeCapacity* | The provisioned throughput to reserved for writing resources to your table | null | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-ddb.amazonDDBClient* | To use the AmazonDynamoDB as the client | null | MEDIUM
+| *camel.component.aws2-ddb.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-ddb.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws2-ddb.consistentRead* | Determines whether or not strong consistency should be enforced when data is read. | false | MEDIUM
 | *camel.component.aws2-ddb.keyAttributeName* | Attribute name when creating table | null | MEDIUM
@@ -51,6 +54,7 @@ The camel-aws2-ddb sink connector supports 33 options, which are listed below.
 | *camel.component.aws2-ddb.proxyProtocol* | To define a proxy protocol when instantiating the DDB client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-ddb.readCapacity* | The provisioned throughput to reserve for reading resources from your table | null | MEDIUM
 | *camel.component.aws2-ddb.region* | The region in which DDB client needs to work | null | MEDIUM
+| *camel.component.aws2-ddb.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-ddb.writeCapacity* | The provisioned throughput to reserved for writing resources to your table | null | MEDIUM
 | *camel.component.aws2-ddb.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-ddb.accessKey* | Amazon AWS Access Key | null | MEDIUM
diff --git a/connectors/camel-aws2-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddb/CamelAws2ddbSinkConnectorConfig.java b/connectors/camel-aws2-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddb/CamelAws2ddbSinkConnectorConfig.java
index f2de6de..40fae0b 100644
--- a/connectors/camel-aws2-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddb/CamelAws2ddbSinkConnectorConfig.java
+++ b/connectors/camel-aws2-ddb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddb/CamelAws2ddbSinkConnectorConfig.java
@@ -30,6 +30,9 @@ public class CamelAws2ddbSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_AMAZON_DDBCLIENT_CONF = "camel.sink.endpoint.amazonDDBClient";
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_AMAZON_DDBCLIENT_DOC = "To use the AmazonDynamoDB as the client";
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_AMAZON_DDBCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2DDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_CONSISTENT_READ_CONF = "camel.sink.endpoint.consistentRead";
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_CONSISTENT_READ_DOC = "Determines whether or not strong consistency should be enforced when data is read.";
     public static final Boolean CAMEL_SINK_AWS2DDB_ENDPOINT_CONSISTENT_READ_DEFAULT = false;
@@ -60,6 +63,9 @@ public class CamelAws2ddbSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_REGION_CONF = "camel.sink.endpoint.region";
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_REGION_DOC = "The region in which DDB client needs to work";
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2DDB_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_WRITE_CAPACITY_CONF = "camel.sink.endpoint.writeCapacity";
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_WRITE_CAPACITY_DOC = "The provisioned throughput to reserved for writing resources to your table";
     public static final String CAMEL_SINK_AWS2DDB_ENDPOINT_WRITE_CAPACITY_DEFAULT = null;
@@ -78,6 +84,9 @@ public class CamelAws2ddbSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_AMAZON_DDBCLIENT_CONF = "camel.component.aws2-ddb.amazonDDBClient";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_AMAZON_DDBCLIENT_DOC = "To use the AmazonDynamoDB as the client";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_AMAZON_DDBCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2DDB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-ddb.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2DDB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2DDB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-ddb.configuration";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -111,6 +120,9 @@ public class CamelAws2ddbSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_REGION_CONF = "camel.component.aws2-ddb.region";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_REGION_DOC = "The region in which DDB client needs to work";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2DDB_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-ddb.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2DDB_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2DDB_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_WRITE_CAPACITY_CONF = "camel.component.aws2-ddb.writeCapacity";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_WRITE_CAPACITY_DOC = "The provisioned throughput to reserved for writing resources to your table";
     public static final String CAMEL_SINK_AWS2DDB_COMPONENT_WRITE_CAPACITY_DEFAULT = null;
@@ -138,6 +150,7 @@ public class CamelAws2ddbSinkConnectorConfig extends CamelSinkConnectorConfig {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2DDB_PATH_TABLE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_PATH_TABLE_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2DDB_PATH_TABLE_NAME_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_AMAZON_DDBCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_AMAZON_DDBCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_AMAZON_DDBCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_CONSISTENT_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_ENDPOINT_CONSISTENT_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_CONSISTENT_READ_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_KEY_ATTRIBUTE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_KEY_ATTRIBUTE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_KEY_ATTRIBUTE_NAME_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_KEY_ATTRIBUTE_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_KEY_ATTRIBUTE_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_KEY_ATTRIBUTE_TYPE_DOC);
@@ -148,12 +161,14 @@ public class CamelAws2ddbSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_READ_CAPACITY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_READ_CAPACITY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_READ_CAPACITY_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_WRITE_CAPACITY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_WRITE_CAPACITY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_WRITE_CAPACITY_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_AMAZON_DDBCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_AMAZON_DDBCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_AMAZON_DDBCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_CONSISTENT_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_COMPONENT_CONSISTENT_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_CONSISTENT_READ_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_KEY_ATTRIBUTE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_KEY_ATTRIBUTE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_KEY_ATTRIBUTE_NAME_DOC);
@@ -165,6 +180,7 @@ public class CamelAws2ddbSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_READ_CAPACITY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_READ_CAPACITY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_READ_CAPACITY_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_WRITE_CAPACITY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_WRITE_CAPACITY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_WRITE_CAPACITY_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2DDB_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2DDB_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2DDB_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2DDB_COMPONENT_ACCESS_KEY_DOC);
diff --git a/connectors/camel-aws2-ddbstream-kafka-connector/src/main/docs/camel-aws2-ddbstream-kafka-source-connector.adoc b/connectors/camel-aws2-ddbstream-kafka-connector/src/main/docs/camel-aws2-ddbstream-kafka-source-connector.adoc
index e15de75..5c619a9 100644
--- a/connectors/camel-aws2-ddbstream-kafka-connector/src/main/docs/camel-aws2-ddbstream-kafka-source-connector.adoc
+++ b/connectors/camel-aws2-ddbstream-kafka-connector/src/main/docs/camel-aws2-ddbstream-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-ddbstream-kafka-connector as source make sure to use the f
 ----
 
 
-The camel-aws2-ddbstream source connector supports 45 options, which are listed below.
+The camel-aws2-ddbstream source connector supports 49 options, which are listed below.
 
 
 
@@ -23,6 +23,7 @@ The camel-aws2-ddbstream source connector supports 45 options, which are listed
 |===
 | Name | Description | Default | Priority
 | *camel.source.path.tableName* | Name of the dynamodb table | null | HIGH
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.source.endpoint.amazonDynamoDbStreamsClient* | Amazon DynamoDB client to use for all requests for this endpoint | null | MEDIUM
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.iteratorType* | Defines where in the DynaboDB stream to start getting records. Note that using TRIM_HORIZON can cause a significant delay before the stream has caught up to real-time. if {AT,AFTER}_SEQUENCE_NUMBER are used, then a sequenceNumberProvider MUST be supplied. One of: [TRIM_HORIZON] [LATEST] [AT_SEQUENCE_NUMBER] [AFTER_SEQUENCE_NUMBER] [null] | "LATEST" | MEDIUM
@@ -33,6 +34,7 @@ The camel-aws2-ddbstream source connector supports 45 options, which are listed
 | *camel.source.endpoint.region* | The region in which DDBStreams client needs to work | null | MEDIUM
 | *camel.source.endpoint.sendEmptyMessageWhenIdle* | If the polling consumer did not poll any files, you can enable this option to send an empty message (no body) instead. | false | MEDIUM
 | *camel.source.endpoint.sequenceNumberProvider* | Provider for the sequence number when using one of the two ShardIteratorType.{AT,AFTER}_SEQUENCE_NUMBER iterator types. Can be a registry reference or a literal sequence number. | null | MEDIUM
+| *camel.source.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.source.endpoint.exceptionHandler* | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored. | null | MEDIUM
 | *camel.source.endpoint.exchangePattern* | Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut] | null | MEDIUM
 | *camel.source.endpoint.pollStrategy* | A pluggable org.apache.camel.PollingConsumerPollingStrategy allowing you to provide your custom implementation to control error handling usually occurred during the poll operation before an Exchange have been created and being routed in Camel. | null | MEDIUM
@@ -47,13 +49,14 @@ The camel-aws2-ddbstream source connector supports 45 options, which are listed
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
 | *camel.source.endpoint.useFixedDelay* | Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details. | true | MEDIUM
 | *camel.source.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.source.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
+| *camel.component.aws2-ddbstream.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws2-ddbstream.amazonDynamoDb StreamsClient* | Amazon DynamoDB client to use for all requests for this endpoint | null | MEDIUM
 | *camel.component.aws2-ddbstream.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.aws2-ddbstream.configuration* | The component configuration | null | MEDIUM
@@ -64,6 +67,7 @@ The camel-aws2-ddbstream source connector supports 45 options, which are listed
 | *camel.component.aws2-ddbstream.proxyProtocol* | To define a proxy protocol when instantiating the DDBStreams client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-ddbstream.region* | The region in which DDBStreams client needs to work | null | MEDIUM
 | *camel.component.aws2-ddbstream.sequenceNumber Provider* | Provider for the sequence number when using one of the two ShardIteratorType.{AT,AFTER}_SEQUENCE_NUMBER iterator types. Can be a registry reference or a literal sequence number. | null | MEDIUM
+| *camel.component.aws2-ddbstream.trustAll Certificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-ddbstream.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-ddbstream.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-ddbstream.secretKey* | Amazon AWS Secret Key | null | MEDIUM
diff --git a/connectors/camel-aws2-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddbstream/CamelAws2ddbstreamSourceConnectorConfig.java b/connectors/camel-aws2-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddbstream/CamelAws2ddbstreamSourceConnectorConfig.java
index 2d02db0..4b9d5b9 100644
--- a/connectors/camel-aws2-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddbstream/CamelAws2ddbstreamSourceConnectorConfig.java
+++ b/connectors/camel-aws2-ddbstream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ddbstream/CamelAws2ddbstreamSourceConnectorConfig.java
@@ -29,6 +29,9 @@ public class CamelAws2ddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_PATH_TABLE_NAME_CONF = "camel.source.path.tableName";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_PATH_TABLE_NAME_DOC = "Name of the dynamodb table";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_PATH_TABLE_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF = "camel.source.endpoint.amazonDynamoDbStreamsClient";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC = "Amazon DynamoDB client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT = null;
@@ -59,6 +62,9 @@ public class CamelAws2ddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEQUENCE_NUMBER_PROVIDER_CONF = "camel.source.endpoint.sequenceNumberProvider";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEQUENCE_NUMBER_PROVIDER_DOC = "Provider for the sequence number when using one of the two ShardIteratorType.{AT,AFTER}_SEQUENCE_NUMBER iterator types. Can be a registry reference or a literal sequence number.";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEQUENCE_NUMBER_PROVIDER_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.source.endpoint.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCEPTION_HANDLER_CONF = "camel.source.endpoint.exceptionHandler";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCEPTION_HANDLER_DOC = "To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCEPTION_HANDLER_DEFAULT = null;
@@ -102,7 +108,7 @@ public class CamelAws2ddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -122,6 +128,9 @@ public class CamelAws2ddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SECRET_KEY_CONF = "camel.source.endpoint.secretKey";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SECRET_KEY_DOC = "Amazon AWS Secret Key";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SECRET_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-ddbstream.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF = "camel.component.aws2-ddbstream.amazonDynamoDbStreamsClient";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC = "Amazon DynamoDB client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT = null;
@@ -152,6 +161,9 @@ public class CamelAws2ddbstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SEQUENCE_NUMBER_PROVIDER_CONF = "camel.component.aws2-ddbstream.sequenceNumberProvider";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SEQUENCE_NUMBER_PROVIDER_DOC = "Provider for the sequence number when using one of the two ShardIteratorType.{AT,AFTER}_SEQUENCE_NUMBER iterator types. Can be a registry reference or a literal sequence number.";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SEQUENCE_NUMBER_PROVIDER_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-ddbstream.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.aws2-ddbstream.basicPropertyBinding";
     public static final String CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -176,6 +188,7 @@ public class CamelAws2ddbstreamSourceConnectorConfig
     public static ConfigDef conf() {
         ConfigDef conf = new ConfigDef(CamelSourceConnectorConfig.conf());
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_PATH_TABLE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_PATH_TABLE_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_AWS2DDBSTREAM_PATH_TABLE_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_ITERATOR_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_ITERATOR_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_ITERATOR_TYPE_DOC);
@@ -186,6 +199,7 @@ public class CamelAws2ddbstreamSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_REGION_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEND_EMPTY_MESSAGE_WHEN_IDLE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEND_EMPTY_MESSAGE_WHEN_IDLE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEND_EMPTY_MESSAGE_WHEN_IDLE_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEQUENCE_NUMBER_PROVIDER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEQUENCE_NUMBER_PROVIDER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SEQUENCE_NUMBER_PROVIDER_DOC);
+        conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCEPTION_HANDLER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCEPTION_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCEPTION_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCHANGE_PATTERN_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCHANGE_PATTERN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_EXCHANGE_PATTERN_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_POLL_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_POLL_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_POLL_STRATEGY_DOC);
@@ -207,6 +221,7 @@ public class CamelAws2ddbstreamSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_USE_FIXED_DELAY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_USE_FIXED_DELAY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_USE_FIXED_DELAY_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_ENDPOINT_SECRET_KEY_DOC);
+        conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_AMAZON_DYNAMO_DB_STREAMS_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_CONFIGURATION_DOC);
@@ -217,6 +232,7 @@ public class CamelAws2ddbstreamSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_REGION_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SEQUENCE_NUMBER_PROVIDER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SEQUENCE_NUMBER_PROVIDER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SEQUENCE_NUMBER_PROVIDER_DOC);
+        conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2DDBSTREAM_COMPONENT_SECRET_KEY_DOC);
diff --git a/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/docs/camel-aws2-kinesis-firehose-kafka-sink-connector.adoc b/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/docs/camel-aws2-kinesis-firehose-kafka-sink-connector.adoc
index 9fb25d3..16136bf 100644
--- a/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/docs/camel-aws2-kinesis-firehose-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/docs/camel-aws2-kinesis-firehose-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-kinesis-firehose-kafka-connector as sink make sure to use
 ----
 
 
-The camel-aws2-kinesis-firehose sink connector supports 21 options, which are listed below.
+The camel-aws2-kinesis-firehose sink connector supports 27 options, which are listed below.
 
 
 
@@ -24,26 +24,30 @@ The camel-aws2-kinesis-firehose sink connector supports 21 options, which are li
 | Name | Description | Default | Priority
 | *camel.sink.path.streamName* | Name of the stream | null | HIGH
 | *camel.sink.endpoint.amazonKinesisFirehoseClient* | Amazon Kinesis Firehose client to use for all requests for this endpoint | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
+| *camel.sink.endpoint.operation* | The operation to do in case the user don't want to send only a record One of: [sendBatchRecord] [createDeliveryStream] [deleteDeliveryStream] [updateDestination] | null | MEDIUM
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the Kinesis Firehose client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the Kinesis Firehose client | null | MEDIUM
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the Kinesis Firehose client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.region* | The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-kinesis-firehose.amazon KinesisFirehoseClient* | Amazon Kinesis Firehose client to use for all requests for this endpoint | null | MEDIUM
+| *camel.component.aws2-kinesis-firehose.autoDiscover Client* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | * camel.component.aws2-kinesis-firehose.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-kinesis-firehose.lazyStart Producer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is [...]
+| *camel.component.aws2-kinesis-firehose.operation* | The operation to do in case the user don't want to send only a record One of: [sendBatchRecord] [createDeliveryStream] [deleteDeliveryStream] [updateDestination] | null | MEDIUM
 | *camel.component.aws2-kinesis-firehose.proxyHost* | To define a proxy host when instantiating the Kinesis Firehose client | null | MEDIUM
 | *camel.component.aws2-kinesis-firehose.proxyPort* | To define a proxy port when instantiating the Kinesis Firehose client | null | MEDIUM
 | *camel.component.aws2-kinesis-firehose.proxy Protocol* | To define a proxy protocol when instantiating the Kinesis Firehose client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-kinesis-firehose.region* | The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-kinesis-firehose.trustAll Certificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-kinesis-firehose.basic PropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-kinesis-firehose.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-kinesis-firehose.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesisfirehose/CamelAws2kinesisfirehoseSinkConnectorConfig.java b/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesisfirehose/CamelAws2kinesisfirehoseSinkConnectorConfig.java
index 27287e0..381b3a2 100644
--- a/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesisfirehose/CamelAws2kinesisfirehoseSinkConnectorConfig.java
+++ b/connectors/camel-aws2-kinesis-firehose-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesisfirehose/CamelAws2kinesisfirehoseSinkConnectorConfig.java
@@ -32,9 +32,15 @@ public class CamelAws2kinesisfirehoseSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF = "camel.sink.endpoint.amazonKinesisFirehoseClient";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC = "Amazon Kinesis Firehose client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Be [...]
     public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_OPERATION_CONF = "camel.sink.endpoint.operation";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_OPERATION_DOC = "The operation to do in case the user don't want to send only a record One of: [sendBatchRecord] [createDeliveryStream] [deleteDeliveryStream] [updateDestination]";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_OPERATION_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_HOST_CONF = "camel.sink.endpoint.proxyHost";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_HOST_DOC = "To define a proxy host when instantiating the Kinesis Firehose client";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_HOST_DEFAULT = null;
@@ -47,6 +53,9 @@ public class CamelAws2kinesisfirehoseSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_REGION_CONF = "camel.sink.endpoint.region";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_REGION_DOC = "The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -62,12 +71,18 @@ public class CamelAws2kinesisfirehoseSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF = "camel.component.aws2-kinesis-firehose.amazonKinesisFirehoseClient";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC = "Amazon Kinesis Firehose client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-kinesis-firehose.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-kinesis-firehose.configuration";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_CONFIGURATION_DOC = "Component configuration";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_CONFIGURATION_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.aws2-kinesis-firehose.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. B [...]
     public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_OPERATION_CONF = "camel.component.aws2-kinesis-firehose.operation";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_OPERATION_DOC = "The operation to do in case the user don't want to send only a record One of: [sendBatchRecord] [createDeliveryStream] [deleteDeliveryStream] [updateDestination]";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_OPERATION_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_HOST_CONF = "camel.component.aws2-kinesis-firehose.proxyHost";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_HOST_DOC = "To define a proxy host when instantiating the Kinesis Firehose client";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_HOST_DEFAULT = null;
@@ -80,6 +95,9 @@ public class CamelAws2kinesisfirehoseSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_REGION_CONF = "camel.component.aws2-kinesis-firehose.region";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_REGION_DOC = "The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-kinesis-firehose.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.aws2-kinesis-firehose.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -105,22 +123,28 @@ public class CamelAws2kinesisfirehoseSinkConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_PATH_STREAM_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_PATH_STREAM_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2KINESISFIREHOSE_PATH_STREAM_NAME_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_PORT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AMAZON_KINESIS_FIREHOSE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_PORT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESISFIREHOSE_COMPONENT_SECRET_KEY_DOC);
diff --git a/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-sink-connector.adoc b/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-sink-connector.adoc
index 9c849a4..12573f5 100644
--- a/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-kinesis-kafka-connector as sink make sure to use the follo
 ----
 
 
-The camel-aws2-kinesis sink connector supports 21 options, which are listed below.
+The camel-aws2-kinesis sink connector supports 25 options, which are listed below.
 
 
 
@@ -24,26 +24,28 @@ The camel-aws2-kinesis sink connector supports 21 options, which are listed belo
 | Name | Description | Default | Priority
 | *camel.sink.path.streamName* | Name of the stream | null | HIGH
 | *camel.sink.endpoint.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the Kinesis client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.region* | The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-kinesis.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.component.aws2-kinesis.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws2-kinesis.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-kinesis.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.component.aws2-kinesis.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
 | *camel.component.aws2-kinesis.proxyProtocol* | To define a proxy protocol when instantiating the Kinesis client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-kinesis.region* | The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-kinesis.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-kinesis.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed [...]
 | *camel.component.aws2-kinesis.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-kinesis.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-kinesis.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-source-connector.adoc b/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-source-connector.adoc
index e488150..6de1c39 100644
--- a/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-source-connector.adoc
+++ b/connectors/camel-aws2-kinesis-kafka-connector/src/main/docs/camel-aws2-kinesis-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-kinesis-kafka-connector as source make sure to use the fol
 ----
 
 
-The camel-aws2-kinesis source connector supports 49 options, which are listed below.
+The camel-aws2-kinesis source connector supports 53 options, which are listed below.
 
 
 
@@ -24,10 +24,12 @@ The camel-aws2-kinesis source connector supports 49 options, which are listed be
 | Name | Description | Default | Priority
 | *camel.source.path.streamName* | Name of the stream | null | HIGH
 | *camel.source.endpoint.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.source.endpoint.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.source.endpoint.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
 | *camel.source.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the Kinesis client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.source.endpoint.region* | The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.source.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.iteratorType* | Defines where in the Kinesis stream to start getting records One of: [AT_SEQUENCE_NUMBER] [AFTER_SEQUENCE_NUMBER] [TRIM_HORIZON] [LATEST] [AT_TIMESTAMP] [null] | "TRIM_HORIZON" | MEDIUM
 | *camel.source.endpoint.maxResultsPerRequest* | Maximum number of records that will be fetched in each poll | 1 | MEDIUM
@@ -49,7 +51,7 @@ The camel-aws2-kinesis source connector supports 49 options, which are listed be
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
@@ -57,11 +59,13 @@ The camel-aws2-kinesis source connector supports 49 options, which are listed be
 | *camel.source.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.source.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-kinesis.amazonKinesisClient* | Amazon Kinesis client to use for all requests for this endpoint | null | MEDIUM
+| *camel.component.aws2-kinesis.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking | true | MEDIUM
 | *camel.component.aws2-kinesis.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-kinesis.proxyHost* | To define a proxy host when instantiating the Kinesis client | null | MEDIUM
 | *camel.component.aws2-kinesis.proxyPort* | To define a proxy port when instantiating the Kinesis client | null | MEDIUM
 | *camel.component.aws2-kinesis.proxyProtocol* | To define a proxy protocol when instantiating the Kinesis client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-kinesis.region* | The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-kinesis.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-kinesis.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.aws2-kinesis.iteratorType* | Defines where in the Kinesis stream to start getting records One of: [AT_SEQUENCE_NUMBER] [AFTER_SEQUENCE_NUMBER] [TRIM_HORIZON] [LATEST] [AT_TIMESTAMP] [null] | "TRIM_HORIZON" | MEDIUM
 | *camel.component.aws2-kinesis.maxResultsPerRequest* | Maximum number of records that will be fetched in each poll | 1 | MEDIUM
@@ -72,6 +76,4 @@ The camel-aws2-kinesis source connector supports 49 options, which are listed be
 | *camel.component.aws2-kinesis.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-kinesis.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSinkConnectorConfig.java b/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSinkConnectorConfig.java
index ef0b07e..99a0490 100644
--- a/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSinkConnectorConfig.java
+++ b/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSinkConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAws2kinesisSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF = "camel.sink.endpoint.amazonKinesisClient";
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_HOST_CONF = "camel.sink.endpoint.proxyHost";
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_HOST_DOC = "To define a proxy host when instantiating the Kinesis client";
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_HOST_DEFAULT = null;
@@ -44,6 +47,9 @@ public class CamelAws2kinesisSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_REGION_CONF = "camel.sink.endpoint.region";
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_REGION_DOC = "The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2KINESIS_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware tha [...]
     public static final Boolean CAMEL_SINK_AWS2KINESIS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -62,6 +68,9 @@ public class CamelAws2kinesisSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF = "camel.component.aws2-kinesis.amazonKinesisClient";
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-kinesis.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SINK_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-kinesis.configuration";
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_CONFIGURATION_DOC = "Component configuration";
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -77,6 +86,9 @@ public class CamelAws2kinesisSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_REGION_CONF = "camel.component.aws2-kinesis.region";
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_REGION_DOC = "The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-kinesis.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.aws2-kinesis.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2KINESIS_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware th [...]
     public static final Boolean CAMEL_SINK_AWS2KINESIS_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -104,21 +116,25 @@ public class CamelAws2kinesisSinkConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2KINESIS_PATH_STREAM_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_PATH_STREAM_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2KINESIS_PATH_STREAM_NAME_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_PORT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_PORT_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2KINESIS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2KINESIS_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2KINESIS_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2KINESIS_COMPONENT_ACCESS_KEY_DOC);
diff --git a/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSourceConnectorConfig.java b/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSourceConnectorConfig.java
index c7f3cb2..da0b03b 100644
--- a/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSourceConnectorConfig.java
+++ b/connectors/camel-aws2-kinesis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2kinesis/CamelAws2kinesisSourceConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAws2kinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF = "camel.source.endpoint.amazonKinesisClient";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_HOST_CONF = "camel.source.endpoint.proxyHost";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_HOST_DOC = "To define a proxy host when instantiating the Kinesis client";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_HOST_DEFAULT = null;
@@ -44,6 +47,9 @@ public class CamelAws2kinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_REGION_CONF = "camel.source.endpoint.region";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_REGION_DOC = "The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.source.endpoint.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF = "camel.source.endpoint.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and [...]
     public static final Boolean CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
@@ -108,7 +114,7 @@ public class CamelAws2kinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -131,6 +137,9 @@ public class CamelAws2kinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF = "camel.component.aws2-kinesis.amazonKinesisClient";
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC = "Amazon Kinesis client to use for all requests for this endpoint";
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-kinesis.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking";
+    public static final Boolean CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-kinesis.configuration";
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_CONFIGURATION_DOC = "Component configuration";
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -146,6 +155,9 @@ public class CamelAws2kinesisSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_REGION_CONF = "camel.component.aws2-kinesis.region";
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_REGION_DOC = "The region in which Kinesis Firehose client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-kinesis.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.aws2-kinesis.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_AWS2KINESIS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level an [...]
     public static final Boolean CAMEL_SOURCE_AWS2KINESIS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
@@ -189,10 +201,12 @@ public class CamelAws2kinesisSourceConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSourceConnectorConfig.conf());
         conf.define(CAMEL_SOURCE_AWS2KINESIS_PATH_STREAM_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_PATH_STREAM_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_AWS2KINESIS_PATH_STREAM_NAME_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_PORT_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_ITERATOR_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_ITERATOR_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_ITERATOR_TYPE_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_MAX_RESULTS_PER_REQUEST_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_MAX_RESULTS_PER_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_MAX_RESULTS_PER_REQUEST_DOC);
@@ -222,11 +236,13 @@ public class CamelAws2kinesisSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AMAZON_KINESIS_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_HOST_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_PORT_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_ITERATOR_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_ITERATOR_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_ITERATOR_TYPE_DOC);
         conf.define(CAMEL_SOURCE_AWS2KINESIS_COMPONENT_MAX_RESULTS_PER_REQUEST_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_MAX_RESULTS_PER_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2KINESIS_COMPONENT_MAX_RESULTS_PER_REQUEST_DOC);
diff --git a/connectors/camel-aws2-lambda-kafka-connector/src/main/docs/camel-aws2-lambda-kafka-sink-connector.adoc b/connectors/camel-aws2-lambda-kafka-connector/src/main/docs/camel-aws2-lambda-kafka-sink-connector.adoc
index f14b2c3..f23c78c 100644
--- a/connectors/camel-aws2-lambda-kafka-connector/src/main/docs/camel-aws2-lambda-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-lambda-kafka-connector/src/main/docs/camel-aws2-lambda-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-lambda-kafka-connector as sink make sure to use the follow
 ----
 
 
-The camel-aws2-lambda sink connector supports 25 options, which are listed below.
+The camel-aws2-lambda sink connector supports 29 options, which are listed below.
 
 
 
@@ -23,10 +23,12 @@ The camel-aws2-lambda sink connector supports 25 options, which are listed below
 |===
 | Name | Description | Default | Priority
 | *camel.sink.path.function* | Name of the Lambda function. | null | HIGH
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.operation* | The operation to perform. It can be listFunctions, getFunction, createFunction, deleteFunction or invokeFunction One of: [listFunctions] [getFunction] [createAlias] [deleteAlias] [getAlias] [listAliases] [createFunction] [deleteFunction] [invokeFunction] [updateFunction] [createEventSourceMapping] [deleteEventSourceMapping] [listEventSourceMapping] [listTags] [tagResource] [untagResource] [publishVersion] [listVersions] | "invokeFunction" | MEDIUM
 | *camel.sink.endpoint.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.sink.endpoint.region* | The region in which ECS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.awsLambdaClient* | To use a existing configured AwsLambdaClient as client | null | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
@@ -35,11 +37,13 @@ The camel-aws2-lambda sink connector supports 25 options, which are listed below
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the Lambda client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
+| *camel.component.aws2-lambda.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-lambda.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-lambda.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed  [...]
 | *camel.component.aws2-lambda.operation* | The operation to perform. It can be listFunctions, getFunction, createFunction, deleteFunction or invokeFunction One of: [listFunctions] [getFunction] [createAlias] [deleteAlias] [getAlias] [listAliases] [createFunction] [deleteFunction] [invokeFunction] [updateFunction] [createEventSourceMapping] [deleteEventSourceMapping] [listEventSourceMapping] [listTags] [tagResource] [untagResource] [publishVersion] [listVersions] | "invokeFunction" | MEDIUM
 | *camel.component.aws2-lambda.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.component.aws2-lambda.region* | The region in which ECS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-lambda.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-lambda.awsLambdaClient* | To use a existing configured AwsLambdaClient as client | null | MEDIUM
 | *camel.component.aws2-lambda.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-lambda.proxyHost* | To define a proxy host when instantiating the Lambda client | null | MEDIUM
diff --git a/connectors/camel-aws2-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2lambda/CamelAws2lambdaSinkConnectorConfig.java b/connectors/camel-aws2-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2lambda/CamelAws2lambdaSinkConnectorConfig.java
index 78687d6..3b781c5 100644
--- a/connectors/camel-aws2-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2lambda/CamelAws2lambdaSinkConnectorConfig.java
+++ b/connectors/camel-aws2-lambda-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2lambda/CamelAws2lambdaSinkConnectorConfig.java
@@ -29,6 +29,9 @@ public class CamelAws2lambdaSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2LAMBDA_PATH_FUNCTION_CONF = "camel.sink.path.function";
     public static final String CAMEL_SINK_AWS2LAMBDA_PATH_FUNCTION_DOC = "Name of the Lambda function.";
     public static final String CAMEL_SINK_AWS2LAMBDA_PATH_FUNCTION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that [...]
     public static final Boolean CAMEL_SINK_AWS2LAMBDA_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -41,6 +44,9 @@ public class CamelAws2lambdaSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_REGION_CONF = "camel.sink.endpoint.region";
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_REGION_DOC = "The region in which ECS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2LAMBDA_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AWS_LAMBDA_CLIENT_CONF = "camel.sink.endpoint.awsLambdaClient";
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AWS_LAMBDA_CLIENT_DOC = "To use a existing configured AwsLambdaClient as client";
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AWS_LAMBDA_CLIENT_DEFAULT = null;
@@ -65,6 +71,9 @@ public class CamelAws2lambdaSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SECRET_KEY_CONF = "camel.sink.endpoint.secretKey";
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SECRET_KEY_DOC = "Amazon AWS Secret Key";
     public static final String CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SECRET_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-lambda.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2LAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-lambda.configuration";
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_CONFIGURATION_DOC = "Component configuration";
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -80,6 +89,9 @@ public class CamelAws2lambdaSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_REGION_CONF = "camel.component.aws2-lambda.region";
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_REGION_DOC = "The region in which ECS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-lambda.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2LAMBDA_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_AWS_LAMBDA_CLIENT_CONF = "camel.component.aws2-lambda.awsLambdaClient";
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_AWS_LAMBDA_CLIENT_DOC = "To use a existing configured AwsLambdaClient as client";
     public static final String CAMEL_SINK_AWS2LAMBDA_COMPONENT_AWS_LAMBDA_CLIENT_DEFAULT = null;
@@ -115,10 +127,12 @@ public class CamelAws2lambdaSinkConnectorConfig
     public static ConfigDef conf() {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2LAMBDA_PATH_FUNCTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_PATH_FUNCTION_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2LAMBDA_PATH_FUNCTION_DOC);
+        conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_POJO_REQUEST_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AWS_LAMBDA_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AWS_LAMBDA_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_AWS_LAMBDA_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SYNCHRONOUS_DOC);
@@ -127,11 +141,13 @@ public class CamelAws2lambdaSinkConnectorConfig
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_ENDPOINT_SECRET_KEY_DOC);
+        conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_COMPONENT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_POJO_REQUEST_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_AWS_LAMBDA_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_COMPONENT_AWS_LAMBDA_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_AWS_LAMBDA_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2LAMBDA_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2LAMBDA_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2LAMBDA_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2LAMBDA_COMPONENT_PROXY_HOST_DOC);
diff --git a/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-sink-connector.adoc b/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-sink-connector.adoc
index f718fe4..54af525 100644
--- a/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-s3-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws2-s3 sink connector supports 57 options, which are listed below.
+The camel-aws2-s3 sink connector supports 61 options, which are listed below.
 
 
 
@@ -24,7 +24,8 @@ The camel-aws2-s3 sink connector supports 57 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.sink.path.bucketNameOrArn* | Bucket name or ARN | null | HIGH
 | *camel.sink.endpoint.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
-| *camel.sink.endpoint.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.sink.endpoint.autoCreateBucket* | Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already. | true | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.overrideEndpoint* | Set the need for overidding the endpoint. This option needs to be used in combination with uriEndpointOverride option | false | MEDIUM
 | *camel.sink.endpoint.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.sink.endpoint.policy* | The policy for this queue to set in the com.amazonaws.services.s3.AmazonS3#setBucketPolicy() method. | null | MEDIUM
@@ -32,8 +33,12 @@ The camel-aws2-s3 sink connector supports 57 options, which are listed below.
 | *camel.sink.endpoint.proxyPort* | Specify a proxy port to be used inside the client definition. | null | MEDIUM
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the S3 client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.region* | The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.uriEndpointOverride* | Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option | null | MEDIUM
 | *camel.sink.endpoint.useIAMCredentials* | Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in. | false | MEDIUM
+| *camel.sink.endpoint.customerAlgorithm* | Define the customer algorithm to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.sink.endpoint.customerKeyId* | Define the id of Customer key to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.sink.endpoint.customerKeyMD5* | Define the MD5 of Customer key to use in case CustomerKey is enabled | null | MEDIUM
 | *camel.sink.endpoint.deleteAfterWrite* | Delete file object after the S3 file has been uploaded | false | MEDIUM
 | *camel.sink.endpoint.keyName* | Setting the key name for an element in the bucket through endpoint parameter | null | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
@@ -42,9 +47,6 @@ The camel-aws2-s3 sink connector supports 57 options, which are listed below.
 | *camel.sink.endpoint.partSize* | Setup the partSize which is used in multi part upload, the default size is 25M. | 26214400L | MEDIUM
 | *camel.sink.endpoint.storageClass* | The storage class to set in the com.amazonaws.services.s3.model.PutObjectRequest request. | null | MEDIUM
 | *camel.sink.endpoint.awsKMSKeyId* | Define the id of KMS key to use in case KMS is enabled | null | MEDIUM
-| *camel.sink.endpoint.customerAlgorithm* | Define the customer algorithm to use in case CustomerKey is enabled | null | MEDIUM
-| *camel.sink.endpoint.customerKeyId* | Define the id of Customer key to use in case CustomerKey is enabled | null | MEDIUM
-| *camel.sink.endpoint.customerKeyMD5* | Define the MD5 of Customer key to use in case CustomerKey is enabled | null | MEDIUM
 | *camel.sink.endpoint.useAwsKMS* | Define if KMS must be used or not | false | MEDIUM
 | *camel.sink.endpoint.useCustomerKey* | Define if Customer Key must be used or not | false | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
@@ -52,7 +54,8 @@ The camel-aws2-s3 sink connector supports 57 options, which are listed below.
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-s3.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
-| *camel.component.aws2-s3.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.component.aws2-s3.autoCreateBucket* | Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already. | true | MEDIUM
+| *camel.component.aws2-s3.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-s3.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws2-s3.overrideEndpoint* | Set the need for overidding the endpoint. This option needs to be used in combination with uriEndpointOverride option | false | MEDIUM
 | *camel.component.aws2-s3.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
@@ -61,8 +64,12 @@ The camel-aws2-s3 sink connector supports 57 options, which are listed below.
 | *camel.component.aws2-s3.proxyPort* | Specify a proxy port to be used inside the client definition. | null | MEDIUM
 | *camel.component.aws2-s3.proxyProtocol* | To define a proxy protocol when instantiating the S3 client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-s3.region* | The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-s3.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-s3.uriEndpointOverride* | Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option | null | MEDIUM
 | *camel.component.aws2-s3.useIAMCredentials* | Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in. | false | MEDIUM
+| *camel.component.aws2-s3.customerAlgorithm* | Define the customer algorithm to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.component.aws2-s3.customerKeyId* | Define the id of Customer key to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.component.aws2-s3.customerKeyMD5* | Define the MD5 of Customer key to use in case CustomerKey is enabled | null | MEDIUM
 | *camel.component.aws2-s3.deleteAfterWrite* | Delete file object after the S3 file has been uploaded | false | MEDIUM
 | *camel.component.aws2-s3.keyName* | Setting the key name for an element in the bucket through endpoint parameter | null | MEDIUM
 | *camel.component.aws2-s3.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then [...]
@@ -71,9 +78,6 @@ The camel-aws2-s3 sink connector supports 57 options, which are listed below.
 | *camel.component.aws2-s3.partSize* | Setup the partSize which is used in multi part upload, the default size is 25M. | 26214400L | MEDIUM
 | *camel.component.aws2-s3.storageClass* | The storage class to set in the com.amazonaws.services.s3.model.PutObjectRequest request. | null | MEDIUM
 | *camel.component.aws2-s3.awsKMSKeyId* | Define the id of KMS key to use in case KMS is enabled | null | MEDIUM
-| *camel.component.aws2-s3.customerAlgorithm* | Define the customer algorithm to use in case CustomerKey is enabled | null | MEDIUM
-| *camel.component.aws2-s3.customerKeyId* | Define the id of Customer key to use in case CustomerKey is enabled | null | MEDIUM
-| *camel.component.aws2-s3.customerKeyMD5* | Define the MD5 of Customer key to use in case CustomerKey is enabled | null | MEDIUM
 | *camel.component.aws2-s3.useAwsKMS* | Define if KMS must be used or not | false | MEDIUM
 | *camel.component.aws2-s3.useCustomerKey* | Define if Customer Key must be used or not | false | MEDIUM
 | *camel.component.aws2-s3.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
diff --git a/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc b/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc
index 94665dc..ed7935d 100644
--- a/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc
+++ b/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-s3-kafka-connector as source make sure to use the followin
 ----
 
 
-The camel-aws2-s3 source connector supports 71 options, which are listed below.
+The camel-aws2-s3 source connector supports 81 options, which are listed below.
 
 
 
@@ -24,7 +24,8 @@ The camel-aws2-s3 source connector supports 71 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.source.path.bucketNameOrArn* | Bucket name or ARN | null | HIGH
 | *camel.source.endpoint.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
-| *camel.source.endpoint.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.source.endpoint.autoCreateBucket* | Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already. | true | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.source.endpoint.overrideEndpoint* | Set the need for overidding the endpoint. This option needs to be used in combination with uriEndpointOverride option | false | MEDIUM
 | *camel.source.endpoint.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.source.endpoint.policy* | The policy for this queue to set in the com.amazonaws.services.s3.AmazonS3#setBucketPolicy() method. | null | MEDIUM
@@ -32,8 +33,12 @@ The camel-aws2-s3 source connector supports 71 options, which are listed below.
 | *camel.source.endpoint.proxyPort* | Specify a proxy port to be used inside the client definition. | null | MEDIUM
 | *camel.source.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the S3 client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.source.endpoint.region* | The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.source.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.source.endpoint.uriEndpointOverride* | Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option | null | MEDIUM
 | *camel.source.endpoint.useIAMCredentials* | Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in. | false | MEDIUM
+| *camel.source.endpoint.customerAlgorithm* | Define the customer algorithm to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.source.endpoint.customerKeyId* | Define the id of Customer key to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.source.endpoint.customerKeyMD5* | Define the MD5 of Customer key to use in case CustomerKey is enabled | null | MEDIUM
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.deleteAfterRead* | Delete objects from S3 after they have been retrieved. The delete is only performed if the Exchange is committed. If a rollback occurs, the object is not deleted. If this option is false, then the same objects will be retrieve over and over again on the polls. Therefore you need to use the Idempotent Consumer EIP in the route to filter out duplicates. You can filter using the AWS2S3Constants#BUCKET_NAME and AWS2S3Constants#KEY headers, or only  [...]
 | *camel.source.endpoint.delimiter* | The delimiter which is used in the com.amazonaws.services.s3.model.ListObjectsRequest to only consume objects we are interested in. | null | MEDIUM
@@ -61,7 +66,7 @@ The camel-aws2-s3 source connector supports 71 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
@@ -69,7 +74,8 @@ The camel-aws2-s3 source connector supports 71 options, which are listed below.
 | *camel.source.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.source.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-s3.amazonS3Client* | Reference to a com.amazonaws.services.s3.AmazonS3 in the registry. | null | MEDIUM
-| *camel.component.aws2-s3.autoCreateBucket* | Setting the autocreation of the bucket | true | MEDIUM
+| *camel.component.aws2-s3.autoCreateBucket* | Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already. | true | MEDIUM
+| *camel.component.aws2-s3.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-s3.configuration* | The component configuration | null | MEDIUM
 | *camel.component.aws2-s3.overrideEndpoint* | Set the need for overidding the endpoint. This option needs to be used in combination with uriEndpointOverride option | false | MEDIUM
 | *camel.component.aws2-s3.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
@@ -78,8 +84,12 @@ The camel-aws2-s3 source connector supports 71 options, which are listed below.
 | *camel.component.aws2-s3.proxyPort* | Specify a proxy port to be used inside the client definition. | null | MEDIUM
 | *camel.component.aws2-s3.proxyProtocol* | To define a proxy protocol when instantiating the S3 client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-s3.region* | The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-s3.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-s3.uriEndpointOverride* | Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option | null | MEDIUM
 | *camel.component.aws2-s3.useIAMCredentials* | Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in. | false | MEDIUM
+| *camel.component.aws2-s3.customerAlgorithm* | Define the customer algorithm to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.component.aws2-s3.customerKeyId* | Define the id of Customer key to use in case CustomerKey is enabled | null | MEDIUM
+| *camel.component.aws2-s3.customerKeyMD5* | Define the MD5 of Customer key to use in case CustomerKey is enabled | null | MEDIUM
 | *camel.component.aws2-s3.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.aws2-s3.deleteAfterRead* | Delete objects from S3 after they have been retrieved. The delete is only performed if the Exchange is committed. If a rollback occurs, the object is not deleted. If this option is false, then the same objects will be retrieve over and over again on the polls. Therefore you need to use the Idempotent Consumer EIP in the route to filter out duplicates. You can filter using the AWS2S3Constants#BUCKET_NAME and AWS2S3Constants#KEY headers, or onl [...]
 | *camel.component.aws2-s3.delimiter* | The delimiter which is used in the com.amazonaws.services.s3.model.ListObjectsRequest to only consume objects we are interested in. | null | MEDIUM
diff --git a/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SinkConnectorConfig.java b/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SinkConnectorConfig.java
index a6265cc..d205905 100644
--- a/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SinkConnectorConfig.java
+++ b/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SinkConnectorConfig.java
@@ -31,8 +31,11 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DOC = "Reference to a com.amazonaws.services.s3.AmazonS3 in the registry.";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_CONF = "camel.sink.endpoint.autoCreateBucket";
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already.";
     public static final Boolean CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_CONF = "camel.sink.endpoint.overrideEndpoint";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DOC = "Set the need for overidding the endpoint. This option needs to be used in combination with uriEndpointOverride option";
     public static final Boolean CAMEL_SINK_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DEFAULT = false;
@@ -54,12 +57,24 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_REGION_CONF = "camel.sink.endpoint.region";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_REGION_DOC = "The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_CONF = "camel.sink.endpoint.uriEndpointOverride";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DOC = "Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_CONF = "camel.sink.endpoint.useIAMCredentials";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DOC = "Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in.";
     public static final Boolean CAMEL_SINK_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_CONF = "camel.sink.endpoint.customerAlgorithm";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DOC = "Define the customer algorithm to use in case CustomerKey is enabled";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_CONF = "camel.sink.endpoint.customerKeyId";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DOC = "Define the id of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5CONF = "camel.sink.endpoint.customerKeyMD5";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DOC = "Define the MD5 of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_DELETE_AFTER_WRITE_CONF = "camel.sink.endpoint.deleteAfterWrite";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_DELETE_AFTER_WRITE_DOC = "Delete file object after the S3 file has been uploaded";
     public static final Boolean CAMEL_SINK_AWS2S3_ENDPOINT_DELETE_AFTER_WRITE_DEFAULT = false;
@@ -84,15 +99,6 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AWS_KMSKEY_ID_CONF = "camel.sink.endpoint.awsKMSKeyId";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AWS_KMSKEY_ID_DOC = "Define the id of KMS key to use in case KMS is enabled";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_AWS_KMSKEY_ID_DEFAULT = null;
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_CONF = "camel.sink.endpoint.customerAlgorithm";
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DOC = "Define the customer algorithm to use in case CustomerKey is enabled";
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DEFAULT = null;
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_CONF = "camel.sink.endpoint.customerKeyId";
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DOC = "Define the id of Customer key to use in case CustomerKey is enabled";
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DEFAULT = null;
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5CONF = "camel.sink.endpoint.customerKeyMD5";
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DOC = "Define the MD5 of Customer key to use in case CustomerKey is enabled";
-    public static final String CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_USE_AWS_KMSCONF = "camel.sink.endpoint.useAwsKMS";
     public static final String CAMEL_SINK_AWS2S3_ENDPOINT_USE_AWS_KMSDOC = "Define if KMS must be used or not";
     public static final Boolean CAMEL_SINK_AWS2S3_ENDPOINT_USE_AWS_KMSDEFAULT = false;
@@ -115,8 +121,11 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DOC = "Reference to a com.amazonaws.services.s3.AmazonS3 in the registry.";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_CONF = "camel.component.aws2-s3.autoCreateBucket";
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already.";
     public static final Boolean CAMEL_SINK_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-s3.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-s3.configuration";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -141,12 +150,24 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_REGION_CONF = "camel.component.aws2-s3.region";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_REGION_DOC = "The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-s3.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_CONF = "camel.component.aws2-s3.uriEndpointOverride";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DOC = "Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_CONF = "camel.component.aws2-s3.useIAMCredentials";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DOC = "Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in.";
     public static final Boolean CAMEL_SINK_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_CONF = "camel.component.aws2-s3.customerAlgorithm";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DOC = "Define the customer algorithm to use in case CustomerKey is enabled";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_CONF = "camel.component.aws2-s3.customerKeyId";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DOC = "Define the id of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5CONF = "camel.component.aws2-s3.customerKeyMD5";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DOC = "Define the MD5 of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_DELETE_AFTER_WRITE_CONF = "camel.component.aws2-s3.deleteAfterWrite";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_DELETE_AFTER_WRITE_DOC = "Delete file object after the S3 file has been uploaded";
     public static final Boolean CAMEL_SINK_AWS2S3_COMPONENT_DELETE_AFTER_WRITE_DEFAULT = false;
@@ -171,15 +192,6 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_AWS_KMSKEY_ID_CONF = "camel.component.aws2-s3.awsKMSKeyId";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_AWS_KMSKEY_ID_DOC = "Define the id of KMS key to use in case KMS is enabled";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_AWS_KMSKEY_ID_DEFAULT = null;
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_CONF = "camel.component.aws2-s3.customerAlgorithm";
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DOC = "Define the customer algorithm to use in case CustomerKey is enabled";
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DEFAULT = null;
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_CONF = "camel.component.aws2-s3.customerKeyId";
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DOC = "Define the id of Customer key to use in case CustomerKey is enabled";
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DEFAULT = null;
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5CONF = "camel.component.aws2-s3.customerKeyMD5";
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DOC = "Define the MD5 of Customer key to use in case CustomerKey is enabled";
-    public static final String CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DEFAULT = null;
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_USE_AWS_KMSCONF = "camel.component.aws2-s3.useAwsKMS";
     public static final String CAMEL_SINK_AWS2S3_COMPONENT_USE_AWS_KMSDOC = "Define if KMS must be used or not";
     public static final Boolean CAMEL_SINK_AWS2S3_COMPONENT_USE_AWS_KMSDEFAULT = false;
@@ -211,6 +223,7 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2S3_PATH_BUCKET_NAME_OR_ARN_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_PATH_BUCKET_NAME_OR_ARN_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2S3_PATH_BUCKET_NAME_OR_ARN_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_POJO_REQUEST_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_POLICY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_POLICY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_POLICY_DOC);
@@ -218,8 +231,12 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_PROXY_PORT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_DELETE_AFTER_WRITE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_DELETE_AFTER_WRITE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_DELETE_AFTER_WRITE_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_KEY_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_KEY_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_KEY_NAME_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_LAZY_START_PRODUCER_DOC);
@@ -228,9 +245,6 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_PART_SIZE_CONF, ConfigDef.Type.LONG, CAMEL_SINK_AWS2S3_ENDPOINT_PART_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_PART_SIZE_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_STORAGE_CLASS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_STORAGE_CLASS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_STORAGE_CLASS_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_AWS_KMSKEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_AWS_KMSKEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_AWS_KMSKEY_ID_DOC);
-        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DOC);
-        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DOC);
-        conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_USE_AWS_KMSCONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_USE_AWS_KMSDEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_USE_AWS_KMSDOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_USE_CUSTOMER_KEY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_USE_CUSTOMER_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_USE_CUSTOMER_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
@@ -239,6 +253,7 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2S3_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_OVERRIDE_ENDPOINT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_OVERRIDE_ENDPOINT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_OVERRIDE_ENDPOINT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_POJO_REQUEST_DOC);
@@ -247,8 +262,12 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_PROXY_PORT_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DOC);
+        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_DELETE_AFTER_WRITE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_DELETE_AFTER_WRITE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_DELETE_AFTER_WRITE_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_KEY_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_KEY_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_KEY_NAME_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_LAZY_START_PRODUCER_DOC);
@@ -257,9 +276,6 @@ public class CamelAws2s3SinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_PART_SIZE_CONF, ConfigDef.Type.LONG, CAMEL_SINK_AWS2S3_COMPONENT_PART_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_PART_SIZE_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_STORAGE_CLASS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_STORAGE_CLASS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_STORAGE_CLASS_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_AWS_KMSKEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_AWS_KMSKEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_AWS_KMSKEY_ID_DOC);
-        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DOC);
-        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DOC);
-        conf.define(CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_USE_AWS_KMSCONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_USE_AWS_KMSDEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_USE_AWS_KMSDOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_USE_CUSTOMER_KEY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_USE_CUSTOMER_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_USE_CUSTOMER_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2S3_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2S3_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2S3_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
diff --git a/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java b/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java
index 469ee1b..f2f9492 100644
--- a/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java
+++ b/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java
@@ -33,8 +33,11 @@ public class CamelAws2s3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DOC = "Reference to a com.amazonaws.services.s3.AmazonS3 in the registry.";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_CONF = "camel.source.endpoint.autoCreateBucket";
-    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already.";
     public static final Boolean CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_CONF = "camel.source.endpoint.overrideEndpoint";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DOC = "Set the need for overidding the endpoint. This option needs to be used in combination with uriEndpointOverride option";
     public static final Boolean CAMEL_SOURCE_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DEFAULT = false;
@@ -56,12 +59,24 @@ public class CamelAws2s3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_REGION_CONF = "camel.source.endpoint.region";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_REGION_DOC = "The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.source.endpoint.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_CONF = "camel.source.endpoint.uriEndpointOverride";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DOC = "Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_CONF = "camel.source.endpoint.useIAMCredentials";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DOC = "Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in.";
     public static final Boolean CAMEL_SOURCE_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_CONF = "camel.source.endpoint.customerAlgorithm";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DOC = "Define the customer algorithm to use in case CustomerKey is enabled";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_CONF = "camel.source.endpoint.customerKeyId";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DOC = "Define the id of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5CONF = "camel.source.endpoint.customerKeyMD5";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DOC = "Define the MD5 of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF = "camel.source.endpoint.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
     public static final Boolean CAMEL_SOURCE_AWS2S3_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
@@ -144,7 +159,7 @@ public class CamelAws2s3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -168,8 +183,11 @@ public class CamelAws2s3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DOC = "Reference to a com.amazonaws.services.s3.AmazonS3 in the registry.";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_CONF = "camel.component.aws2-s3.autoCreateBucket";
-    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the bucket";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DOC = "Setting the autocreation of the S3 bucket bucketName. This will apply also in case of moveAfterRead option enabled and it will create the destinationBucket if it doesn't exist already.";
     public static final Boolean CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-s3.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-s3.configuration";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CONFIGURATION_DOC = "The component configuration";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -194,12 +212,24 @@ public class CamelAws2s3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_REGION_CONF = "camel.component.aws2-s3.region";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_REGION_DOC = "The region in which S3 client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-s3.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_CONF = "camel.component.aws2-s3.uriEndpointOverride";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DOC = "Set the overriding uri endpoint. This option needs to be used in combination with overrideEndpoint option";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_CONF = "camel.component.aws2-s3.useIAMCredentials";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DOC = "Set whether the S3 client should expect to load credentials on an EC2 instance or to expect static credentials to be passed in.";
     public static final Boolean CAMEL_SOURCE_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_CONF = "camel.component.aws2-s3.customerAlgorithm";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DOC = "Define the customer algorithm to use in case CustomerKey is enabled";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_CONF = "camel.component.aws2-s3.customerKeyId";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DOC = "Define the id of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5CONF = "camel.component.aws2-s3.customerKeyMD5";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DOC = "Define the MD5 of Customer key to use in case CustomerKey is enabled";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.aws2-s3.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
     public static final Boolean CAMEL_SOURCE_AWS2S3_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
@@ -255,6 +285,7 @@ public class CamelAws2s3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2S3_PATH_BUCKET_NAME_OR_ARN_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_PATH_BUCKET_NAME_OR_ARN_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_AWS2S3_PATH_BUCKET_NAME_OR_ARN_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_OVERRIDE_ENDPOINT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_POJO_REQUEST_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_POLICY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_POLICY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_POLICY_DOC);
@@ -262,8 +293,12 @@ public class CamelAws2s3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_PROXY_PORT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_URI_ENDPOINT_OVERRIDE_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_USE_IAMCREDENTIALS_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_ALGORITHM_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_ID_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_CUSTOMER_KEY_MD5DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_DELETE_AFTER_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELETE_AFTER_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELETE_AFTER_READ_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_DELIMITER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELIMITER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELIMITER_DOC);
@@ -300,6 +335,7 @@ public class CamelAws2s3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_AMAZON_S3CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_AMAZON_S3CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_CREATE_BUCKET_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_OVERRIDE_ENDPOINT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_OVERRIDE_ENDPOINT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_OVERRIDE_ENDPOINT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_POJO_REQUEST_DOC);
@@ -308,8 +344,12 @@ public class CamelAws2s3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_PROXY_PORT_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_URI_ENDPOINT_OVERRIDE_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_USE_IAMCREDENTIALS_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_ALGORITHM_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_ID_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_CUSTOMER_KEY_MD5DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_DELETE_AFTER_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_DELETE_AFTER_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_DELETE_AFTER_READ_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_DELIMITER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_DELIMITER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_DELIMITER_DOC);
diff --git a/connectors/camel-aws2-ses-kafka-connector/src/main/docs/camel-aws2-ses-kafka-sink-connector.adoc b/connectors/camel-aws2-ses-kafka-connector/src/main/docs/camel-aws2-ses-kafka-sink-connector.adoc
index 5cece27..2c8f3da 100644
--- a/connectors/camel-aws2-ses-kafka-connector/src/main/docs/camel-aws2-ses-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-ses-kafka-connector/src/main/docs/camel-aws2-ses-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-ses-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws2-ses sink connector supports 29 options, which are listed below.
+The camel-aws2-ses sink connector supports 33 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws2-ses sink connector supports 29 options, which are listed below.
 | Name | Description | Default | Priority
 | *camel.sink.path.from* | The sender's email address. | null | HIGH
 | *camel.sink.endpoint.amazonSESClient* | To use the AmazonSimpleEmailService as the client | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the SES client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the SES client | null | MEDIUM
@@ -33,11 +34,13 @@ The camel-aws2-ses sink connector supports 29 options, which are listed below.
 | *camel.sink.endpoint.returnPath* | The email address to which bounce notifications are to be forwarded, override it using 'CamelAwsSesReturnPath' header. | null | MEDIUM
 | *camel.sink.endpoint.subject* | The subject which is used if the message header 'CamelAwsSesSubject' is not present. | null | MEDIUM
 | *camel.sink.endpoint.to* | List of destination email address. Can be overriden with 'CamelAwsSesTo' header. | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-ses.amazonSESClient* | To use the AmazonSimpleEmailService as the client | null | MEDIUM
+| *camel.component.aws2-ses.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-ses.configuration* | component configuration | null | MEDIUM
 | *camel.component.aws2-ses.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
 | *camel.component.aws2-ses.proxyHost* | To define a proxy host when instantiating the SES client | null | MEDIUM
@@ -48,6 +51,7 @@ The camel-aws2-ses sink connector supports 29 options, which are listed below.
 | *camel.component.aws2-ses.returnPath* | The email address to which bounce notifications are to be forwarded, override it using 'CamelAwsSesReturnPath' header. | null | MEDIUM
 | *camel.component.aws2-ses.subject* | The subject which is used if the message header 'CamelAwsSesSubject' is not present. | null | MEDIUM
 | *camel.component.aws2-ses.to* | List of destination email address. Can be overriden with 'CamelAwsSesTo' header. | null | MEDIUM
+| *camel.component.aws2-ses.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-ses.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-ses.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-ses.secretKey* | Amazon AWS Secret Key | null | MEDIUM
diff --git a/connectors/camel-aws2-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ses/CamelAws2sesSinkConnectorConfig.java b/connectors/camel-aws2-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ses/CamelAws2sesSinkConnectorConfig.java
index 5a6a279..79b0ef6 100644
--- a/connectors/camel-aws2-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ses/CamelAws2sesSinkConnectorConfig.java
+++ b/connectors/camel-aws2-ses-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2ses/CamelAws2sesSinkConnectorConfig.java
@@ -30,6 +30,9 @@ public class CamelAws2sesSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_AMAZON_SESCLIENT_CONF = "camel.sink.endpoint.amazonSESClient";
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_AMAZON_SESCLIENT_DOC = "To use the AmazonSimpleEmailService as the client";
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_AMAZON_SESCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2SES_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2SES_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2SES_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that wh [...]
     public static final Boolean CAMEL_SINK_AWS2SES_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -57,6 +60,9 @@ public class CamelAws2sesSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_TO_CONF = "camel.sink.endpoint.to";
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_TO_DOC = "List of destination email address. Can be overriden with 'CamelAwsSesTo' header.";
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_TO_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2SES_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2SES_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2SES_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2SES_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2SES_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -72,6 +78,9 @@ public class CamelAws2sesSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_AMAZON_SESCLIENT_CONF = "camel.component.aws2-ses.amazonSESClient";
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_AMAZON_SESCLIENT_DOC = "To use the AmazonSimpleEmailService as the client";
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_AMAZON_SESCLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2SES_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-ses.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2SES_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2SES_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-ses.configuration";
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_CONFIGURATION_DOC = "component configuration";
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -102,6 +111,9 @@ public class CamelAws2sesSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_TO_CONF = "camel.component.aws2-ses.to";
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_TO_DOC = "List of destination email address. Can be overriden with 'CamelAwsSesTo' header.";
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_TO_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2SES_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-ses.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2SES_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2SES_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.aws2-ses.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2SES_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2SES_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -126,6 +138,7 @@ public class CamelAws2sesSinkConnectorConfig extends CamelSinkConnectorConfig {
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2SES_PATH_FROM_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_PATH_FROM_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2SES_PATH_FROM_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_AMAZON_SESCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_AMAZON_SESCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_AMAZON_SESCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_PROXY_HOST_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_PROXY_PORT_DOC);
@@ -135,11 +148,13 @@ public class CamelAws2sesSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_RETURN_PATH_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_RETURN_PATH_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_RETURN_PATH_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_SUBJECT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_SUBJECT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_SUBJECT_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_TO_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_TO_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_TO_DOC);
+        conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2SES_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_AMAZON_SESCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_AMAZON_SESCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_AMAZON_SESCLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2SES_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_PROXY_HOST_DOC);
@@ -150,6 +165,7 @@ public class CamelAws2sesSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_RETURN_PATH_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_RETURN_PATH_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_RETURN_PATH_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_SUBJECT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_SUBJECT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_SUBJECT_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_TO_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_TO_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_TO_DOC);
+        conf.define(CAMEL_SINK_AWS2SES_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SES_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2SES_COMPONENT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SES_COMPONENT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SES_COMPONENT_SECRET_KEY_DOC);
diff --git a/connectors/camel-aws2-sns-kafka-connector/src/main/docs/camel-aws2-sns-kafka-sink-connector.adoc b/connectors/camel-aws2-sns-kafka-connector/src/main/docs/camel-aws2-sns-kafka-sink-connector.adoc
index d089e67..6691179 100644
--- a/connectors/camel-aws2-sns-kafka-connector/src/main/docs/camel-aws2-sns-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-sns-kafka-connector/src/main/docs/camel-aws2-sns-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-sns-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws2-sns sink connector supports 38 options, which are listed below.
+The camel-aws2-sns sink connector supports 42 options, which are listed below.
 
 
 
@@ -25,6 +25,7 @@ The camel-aws2-sns sink connector supports 38 options, which are listed below.
 | *camel.sink.path.topicNameOrArn* | Topic name or ARN | null | HIGH
 | *camel.sink.endpoint.amazonSNSClient* | To use the AmazonSNS as the client | null | MEDIUM
 | *camel.sink.endpoint.autoCreateTopic* | Setting the autocreation of the topic | true | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.headerFilterStrategy* | To use a custom HeaderFilterStrategy to map headers to/from Camel. | null | MEDIUM
 | *camel.sink.endpoint.kmsMasterKeyId* | The ID of an AWS-managed customer master key (CMK) for Amazon SNS or a custom CMK. | null | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
@@ -38,12 +39,14 @@ The camel-aws2-sns sink connector supports 38 options, which are listed below.
 | *camel.sink.endpoint.serverSideEncryptionEnabled* | Define if Server Side Encryption is enabled or not on the topic | false | MEDIUM
 | *camel.sink.endpoint.subject* | The subject which is used if the message header 'CamelAwsSnsSubject' is not present. | null | MEDIUM
 | *camel.sink.endpoint.subscribeSNStoSQS* | Define if the subscription between SNS Topic and SQS must be done or not | false | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-sns.amazonSNSClient* | To use the AmazonSNS as the client | null | MEDIUM
 | *camel.component.aws2-sns.autoCreateTopic* | Setting the autocreation of the topic | true | MEDIUM
+| *camel.component.aws2-sns.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-sns.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-sns.kmsMasterKeyId* | The ID of an AWS-managed customer master key (CMK) for Amazon SNS or a custom CMK. | null | MEDIUM
 | *camel.component.aws2-sns.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
@@ -57,6 +60,7 @@ The camel-aws2-sns sink connector supports 38 options, which are listed below.
 | *camel.component.aws2-sns.serverSideEncryption Enabled* | Define if Server Side Encryption is enabled or not on the topic | false | MEDIUM
 | *camel.component.aws2-sns.subject* | The subject which is used if the message header 'CamelAwsSnsSubject' is not present. | null | MEDIUM
 | *camel.component.aws2-sns.subscribeSNStoSQS* | Define if the subscription between SNS Topic and SQS must be done or not | false | MEDIUM
+| *camel.component.aws2-sns.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-sns.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-sns.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-sns.secretKey* | Amazon AWS Secret Key | null | MEDIUM
diff --git a/connectors/camel-aws2-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sns/CamelAws2snsSinkConnectorConfig.java b/connectors/camel-aws2-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sns/CamelAws2snsSinkConnectorConfig.java
index e04ece2..5f4f520 100644
--- a/connectors/camel-aws2-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sns/CamelAws2snsSinkConnectorConfig.java
+++ b/connectors/camel-aws2-sns-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sns/CamelAws2snsSinkConnectorConfig.java
@@ -33,6 +33,9 @@ public class CamelAws2snsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_CREATE_TOPIC_CONF = "camel.sink.endpoint.autoCreateTopic";
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_CREATE_TOPIC_DOC = "Setting the autocreation of the topic";
     public static final Boolean CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_CREATE_TOPIC_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF = "camel.sink.endpoint.headerFilterStrategy";
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC = "To use a custom HeaderFilterStrategy to map headers to/from Camel.";
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT = null;
@@ -72,6 +75,9 @@ public class CamelAws2snsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_SUBSCRIBE_SNSTO_SQSCONF = "camel.sink.endpoint.subscribeSNStoSQS";
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_SUBSCRIBE_SNSTO_SQSDOC = "Define if the subscription between SNS Topic and SQS must be done or not";
     public static final Boolean CAMEL_SINK_AWS2SNS_ENDPOINT_SUBSCRIBE_SNSTO_SQSDEFAULT = false;
+    public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2SNS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2SNS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2SNS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -90,6 +96,9 @@ public class CamelAws2snsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_CREATE_TOPIC_CONF = "camel.component.aws2-sns.autoCreateTopic";
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_CREATE_TOPIC_DOC = "Setting the autocreation of the topic";
     public static final Boolean CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_CREATE_TOPIC_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-sns.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-sns.configuration";
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_CONFIGURATION_DOC = "Component configuration";
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -129,6 +138,9 @@ public class CamelAws2snsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_SUBSCRIBE_SNSTO_SQSCONF = "camel.component.aws2-sns.subscribeSNStoSQS";
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_SUBSCRIBE_SNSTO_SQSDOC = "Define if the subscription between SNS Topic and SQS must be done or not";
     public static final Boolean CAMEL_SINK_AWS2SNS_COMPONENT_SUBSCRIBE_SNSTO_SQSDEFAULT = false;
+    public static final String CAMEL_SINK_AWS2SNS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-sns.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2SNS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2SNS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.aws2-sns.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2SNS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2SNS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -154,6 +166,7 @@ public class CamelAws2snsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SNS_PATH_TOPIC_NAME_OR_ARN_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_PATH_TOPIC_NAME_OR_ARN_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2SNS_PATH_TOPIC_NAME_OR_ARN_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_AMAZON_SNSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_ENDPOINT_AMAZON_SNSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_AMAZON_SNSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_CREATE_TOPIC_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_CREATE_TOPIC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_CREATE_TOPIC_DOC);
+        conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_KMS_MASTER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_ENDPOINT_KMS_MASTER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_KMS_MASTER_KEY_ID_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_LAZY_START_PRODUCER_DOC);
@@ -167,12 +180,14 @@ public class CamelAws2snsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_SERVER_SIDE_ENCRYPTION_ENABLED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_SERVER_SIDE_ENCRYPTION_ENABLED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_SERVER_SIDE_ENCRYPTION_ENABLED_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_SUBJECT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_ENDPOINT_SUBJECT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_SUBJECT_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_SUBSCRIBE_SNSTO_SQSCONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_SUBSCRIBE_SNSTO_SQSDEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_SUBSCRIBE_SNSTO_SQSDOC);
+        conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_AMAZON_SNSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_COMPONENT_AMAZON_SNSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_AMAZON_SNSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_CREATE_TOPIC_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_CREATE_TOPIC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_CREATE_TOPIC_DOC);
+        conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_KMS_MASTER_KEY_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_COMPONENT_KMS_MASTER_KEY_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_KMS_MASTER_KEY_ID_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_LAZY_START_PRODUCER_DOC);
@@ -186,6 +201,7 @@ public class CamelAws2snsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_SERVER_SIDE_ENCRYPTION_ENABLED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_COMPONENT_SERVER_SIDE_ENCRYPTION_ENABLED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_SERVER_SIDE_ENCRYPTION_ENABLED_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_SUBJECT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_COMPONENT_SUBJECT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_SUBJECT_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_SUBSCRIBE_SNSTO_SQSCONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_COMPONENT_SUBSCRIBE_SNSTO_SQSDEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_SUBSCRIBE_SNSTO_SQSDOC);
+        conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SNS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2SNS_COMPONENT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SNS_COMPONENT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SNS_COMPONENT_SECRET_KEY_DOC);
diff --git a/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc b/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc
index d75a469..c1f3d28 100644
--- a/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-sqs-kafka-connector as sink make sure to use the following
 ----
 
 
-The camel-aws2-sqs sink connector supports 52 options, which are listed below.
+The camel-aws2-sqs sink connector supports 56 options, which are listed below.
 
 
 
@@ -26,16 +26,18 @@ The camel-aws2-sqs sink connector supports 52 options, which are listed below.
 | *camel.sink.endpoint.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.sink.endpoint.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.sink.endpoint.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.headerFilterStrategy* | To use a custom HeaderFilterStrategy to map headers to/from Camel. | null | MEDIUM
 | *camel.sink.endpoint.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.sink.endpoint.queueOwnerAWSAccountId* | Specify the queue owner aws account id when you need to connect the queue with different account owner. | null | MEDIUM
 | *camel.sink.endpoint.region* | The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.delaySeconds* | Delay sending messages for a number of seconds. | null | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.messageDeduplicationIdStrategy* | Only for FIFO queues. Strategy for setting the messageDeduplicationId on the message. Can be one of the following options: useExchangeId, useContentBasedDeduplication. For the useContentBasedDeduplication option, no messageDeduplicationId will be set on the message. One of: [useExchangeId] [useContentBasedDeduplication] | "useExchangeId" | MEDIUM
 | *camel.sink.endpoint.messageGroupIdStrategy* | Only for FIFO queues. Strategy for setting the messageGroupId on the message. Can be one of the following options: useConstant, useExchangeId, usePropertyValue. For the usePropertyValue option, the value of property CamelAwsMessageGroupId will be used. One of: [useConstant] [useExchangeId] [usePropertyValue] | null | MEDIUM
-| *camel.sink.endpoint.operation* | The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues] | null | MEDIUM
+| *camel.sink.endpoint.operation* | The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues] [purgeQueue] | null | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.delayQueue* | Define if you want to apply delaySeconds option to the queue or on single messages | false | MEDIUM
 | *camel.sink.endpoint.queueUrl* | To define the queueUrl explicitly. All other parameters, which would influence the queueUrl, are ignored. This parameter is intended to be used, to connect to a mock implementation of SQS, for testing purposes. | null | MEDIUM
@@ -52,16 +54,18 @@ The camel-aws2-sqs sink connector supports 52 options, which are listed below.
 | *camel.component.aws2-sqs.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.component.aws2-sqs.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.component.aws2-sqs.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.component.aws2-sqs.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-sqs.configuration* | The AWS SQS default configuration | null | MEDIUM
 | *camel.component.aws2-sqs.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.component.aws2-sqs.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-sqs.queueOwnerAWSAccountId* | Specify the queue owner aws account id when you need to connect the queue with different account owner. | null | MEDIUM
 | *camel.component.aws2-sqs.region* | The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-sqs.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-sqs.delaySeconds* | Delay sending messages for a number of seconds. | null | MEDIUM
 | *camel.component.aws2-sqs.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
 | *camel.component.aws2-sqs.messageDeduplicationId Strategy* | Only for FIFO queues. Strategy for setting the messageDeduplicationId on the message. Can be one of the following options: useExchangeId, useContentBasedDeduplication. For the useContentBasedDeduplication option, no messageDeduplicationId will be set on the message. One of: [useExchangeId] [useContentBasedDeduplication] | "useExchangeId" | MEDIUM
 | *camel.component.aws2-sqs.messageGroupIdStrategy* | Only for FIFO queues. Strategy for setting the messageGroupId on the message. Can be one of the following options: useConstant, useExchangeId, usePropertyValue. For the usePropertyValue option, the value of property CamelAwsMessageGroupId will be used. One of: [useConstant] [useExchangeId] [usePropertyValue] | null | MEDIUM
-| *camel.component.aws2-sqs.operation* | The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues] | null | MEDIUM
+| *camel.component.aws2-sqs.operation* | The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues] [purgeQueue] | null | MEDIUM
 | *camel.component.aws2-sqs.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-sqs.delayQueue* | Define if you want to apply delaySeconds option to the queue or on single messages | false | MEDIUM
 | *camel.component.aws2-sqs.queueUrl* | To define the queueUrl explicitly. All other parameters, which would influence the queueUrl, are ignored. This parameter is intended to be used, to connect to a mock implementation of SQS, for testing purposes. | null | MEDIUM
diff --git a/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-source-connector.adoc b/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-source-connector.adoc
index 592b923..f488e8d 100644
--- a/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-source-connector.adoc
+++ b/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-sqs-kafka-connector as source make sure to use the followi
 ----
 
 
-The camel-aws2-sqs source connector supports 87 options, which are listed below.
+The camel-aws2-sqs source connector supports 91 options, which are listed below.
 
 
 
@@ -26,11 +26,13 @@ The camel-aws2-sqs source connector supports 87 options, which are listed below.
 | *camel.source.endpoint.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.source.endpoint.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.source.endpoint.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.source.endpoint.headerFilterStrategy* | To use a custom HeaderFilterStrategy to map headers to/from Camel. | null | MEDIUM
 | *camel.source.endpoint.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.source.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.source.endpoint.queueOwnerAWSAccountId* | Specify the queue owner aws account id when you need to connect the queue with different account owner. | null | MEDIUM
 | *camel.source.endpoint.region* | The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.source.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.source.endpoint.attributeNames* | A list of attribute names to receive when consuming. Multiple names can be separated by comma. | null | MEDIUM
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.concurrentConsumers* | Allows you to use multiple threads to poll the sqs queue to increase throughput | 1 | MEDIUM
@@ -69,7 +71,7 @@ The camel-aws2-sqs source connector supports 87 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
@@ -79,11 +81,13 @@ The camel-aws2-sqs source connector supports 87 options, which are listed below.
 | *camel.component.aws2-sqs.amazonAWSHost* | The hostname of the Amazon AWS cloud. | "amazonaws.com" | MEDIUM
 | *camel.component.aws2-sqs.amazonSQSClient* | To use the AmazonSQS as client | null | MEDIUM
 | *camel.component.aws2-sqs.autoCreateQueue* | Setting the autocreation of the queue | true | MEDIUM
+| *camel.component.aws2-sqs.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-sqs.configuration* | The AWS SQS default configuration | null | MEDIUM
 | *camel.component.aws2-sqs.protocol* | The underlying protocol used to communicate with SQS | "https" | MEDIUM
 | *camel.component.aws2-sqs.proxyProtocol* | To define a proxy protocol when instantiating the SQS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
 | *camel.component.aws2-sqs.queueOwnerAWSAccountId* | Specify the queue owner aws account id when you need to connect the queue with different account owner. | null | MEDIUM
 | *camel.component.aws2-sqs.region* | The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | MEDIUM
+| *camel.component.aws2-sqs.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-sqs.attributeNames* | A list of attribute names to receive when consuming. Multiple names can be separated by comma. | null | MEDIUM
 | *camel.component.aws2-sqs.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.aws2-sqs.concurrentConsumers* | Allows you to use multiple threads to poll the sqs queue to increase throughput | 1 | MEDIUM
diff --git a/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java b/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java
index da432bb..0694a53 100644
--- a/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java
+++ b/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java
@@ -36,6 +36,9 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF = "camel.sink.endpoint.autoCreateQueue";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF = "camel.sink.endpoint.headerFilterStrategy";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC = "To use a custom HeaderFilterStrategy to map headers to/from Camel.";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT = null;
@@ -51,6 +54,9 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_CONF = "camel.sink.endpoint.region";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_DOC = "The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_CONF = "camel.sink.endpoint.delaySeconds";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DOC = "Delay sending messages for a number of seconds.";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DEFAULT = null;
@@ -64,7 +70,7 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_GROUP_ID_STRATEGY_DOC = "Only for FIFO queues. Strategy for setting the messageGroupId on the message. Can be one of the following options: useConstant, useExchangeId, usePropertyValue. For the usePropertyValue option, the value of property CamelAwsMessageGroupId will be used. One of: [useConstant] [useExchangeId] [usePropertyValue]";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_GROUP_ID_STRATEGY_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_OPERATION_CONF = "camel.sink.endpoint.operation";
-    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_OPERATION_DOC = "The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues]";
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_OPERATION_DOC = "The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues] [purgeQueue]";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_OPERATION_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
@@ -114,6 +120,9 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_CONF = "camel.component.aws2-sqs.autoCreateQueue";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-sqs.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-sqs.configuration";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_CONFIGURATION_DOC = "The AWS SQS default configuration";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -129,6 +138,9 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_REGION_CONF = "camel.component.aws2-sqs.region";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_REGION_DOC = "The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-sqs.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_CONF = "camel.component.aws2-sqs.delaySeconds";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DOC = "Delay sending messages for a number of seconds.";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DEFAULT = null;
@@ -142,7 +154,7 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_GROUP_ID_STRATEGY_DOC = "Only for FIFO queues. Strategy for setting the messageGroupId on the message. Can be one of the following options: useConstant, useExchangeId, usePropertyValue. For the usePropertyValue option, the value of property CamelAwsMessageGroupId will be used. One of: [useConstant] [useExchangeId] [usePropertyValue]";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_GROUP_ID_STRATEGY_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_OPERATION_CONF = "camel.component.aws2-sqs.operation";
-    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_OPERATION_DOC = "The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues]";
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_OPERATION_DOC = "The operation to do in case the user don't want to send only a message One of: [sendBatchMessage] [deleteMessage] [listQueues] [purgeQueue]";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_OPERATION_DEFAULT = null;
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.aws2-sqs.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
@@ -197,11 +209,13 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_QUEUE_OWNER_AWSACCOUNT_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_QUEUE_OWNER_AWSACCOUNT_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_QUEUE_OWNER_AWSACCOUNT_ID_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_DEDUPLICATION_ID_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DOC);
@@ -223,11 +237,13 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_QUEUE_OWNER_AWSACCOUNT_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_QUEUE_OWNER_AWSACCOUNT_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_QUEUE_OWNER_AWSACCOUNT_ID_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_DEDUPLICATION_ID_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DOC);
diff --git a/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSourceConnectorConfig.java b/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSourceConnectorConfig.java
index fa2d0e3..e05c629 100644
--- a/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSourceConnectorConfig.java
+++ b/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSourceConnectorConfig.java
@@ -38,6 +38,9 @@ public class CamelAws2sqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF = "camel.source.endpoint.autoCreateQueue";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF = "camel.source.endpoint.headerFilterStrategy";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC = "To use a custom HeaderFilterStrategy to map headers to/from Camel.";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT = null;
@@ -53,6 +56,9 @@ public class CamelAws2sqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_REGION_CONF = "camel.source.endpoint.region";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_REGION_DOC = "The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_REGION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.source.endpoint.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_ATTRIBUTE_NAMES_CONF = "camel.source.endpoint.attributeNames";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_ATTRIBUTE_NAMES_DOC = "A list of attribute names to receive when consuming. Multiple names can be separated by comma.";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_ATTRIBUTE_NAMES_DEFAULT = null;
@@ -168,7 +174,7 @@ public class CamelAws2sqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_AWS2SQS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -197,6 +203,9 @@ public class CamelAws2sqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_CONF = "camel.component.aws2-sqs.autoCreateQueue";
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DOC = "Setting the autocreation of the queue";
     public static final Boolean CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-sqs.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-sqs.configuration";
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_CONFIGURATION_DOC = "The AWS SQS default configuration";
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -212,6 +221,9 @@ public class CamelAws2sqsSourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_REGION_CONF = "camel.component.aws2-sqs.region";
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_REGION_DOC = "The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_REGION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-sqs.trustAllCertificates";
+    public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SOURCE_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_ATTRIBUTE_NAMES_CONF = "camel.component.aws2-sqs.attributeNames";
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_ATTRIBUTE_NAMES_DOC = "A list of attribute names to receive when consuming. Multiple names can be separated by comma.";
     public static final String CAMEL_SOURCE_AWS2SQS_COMPONENT_ATTRIBUTE_NAMES_DEFAULT = null;
@@ -304,11 +316,13 @@ public class CamelAws2sqsSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_HEADER_FILTER_STRATEGY_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_QUEUE_OWNER_AWSACCOUNT_ID_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_QUEUE_OWNER_AWSACCOUNT_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_QUEUE_OWNER_AWSACCOUNT_ID_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_ATTRIBUTE_NAMES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_ENDPOINT_ATTRIBUTE_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_ATTRIBUTE_NAMES_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_ENDPOINT_CONCURRENT_CONSUMERS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AWS2SQS_ENDPOINT_CONCURRENT_CONSUMERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_ENDPOINT_CONCURRENT_CONSUMERS_DOC);
@@ -357,11 +371,13 @@ public class CamelAws2sqsSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_AMAZON_AWSHOST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_AMAZON_AWSHOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_AMAZON_AWSHOST_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_AMAZON_SQSCLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_AMAZON_SQSCLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_AMAZON_SQSCLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_CREATE_QUEUE_DOC);
+        conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_PROXY_PROTOCOL_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_QUEUE_OWNER_AWSACCOUNT_ID_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_QUEUE_OWNER_AWSACCOUNT_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_QUEUE_OWNER_AWSACCOUNT_ID_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_ATTRIBUTE_NAMES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2SQS_COMPONENT_ATTRIBUTE_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_ATTRIBUTE_NAMES_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2SQS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AWS2SQS_COMPONENT_CONCURRENT_CONSUMERS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AWS2SQS_COMPONENT_CONCURRENT_CONSUMERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2SQS_COMPONENT_CONCURRENT_CONSUMERS_DOC);
diff --git a/connectors/camel-aws2-sts-kafka-connector/pom.xml b/connectors/camel-aws2-sts-kafka-connector/pom.xml
new file mode 100644
index 0000000..8741520
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/pom.xml
@@ -0,0 +1,135 @@
+<?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">
+  <modelVersion>4.0.0</modelVersion>
+  <parent>
+    <groupId>org.apache.camel.kafkaconnector</groupId>
+    <artifactId>connectors</artifactId>
+    <version>0.5.0-SNAPSHOT</version>
+  </parent>
+  <artifactId>camel-aws2-sts-kafka-connector</artifactId>
+  <name>Camel-Kafka-Connector :: aws2-sts</name>
+  <description>Camel Kafka Connector for aws2-sts</description>
+  <dependencies>
+    <!-- Kafka -->
+    <dependency>
+      <groupId>org.apache.kafka</groupId>
+      <artifactId>connect-api</artifactId>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.kafka</groupId>
+      <artifactId>connect-transforms</artifactId>
+      <scope>provided</scope>
+    </dependency>
+    <!-- Camel -->
+    <dependency>
+      <groupId>org.apache.camel</groupId>
+      <artifactId>camel-aws2-sts</artifactId>
+    </dependency>
+    <!--START OF GENERATED CODE-->
+    <dependency>
+      <groupId>org.apache.camel.kafkaconnector</groupId>
+      <artifactId>camel-kafka-connector</artifactId>
+    </dependency>
+    <!--END OF GENERATED CODE-->
+  </dependencies>
+  <build>
+    <plugins>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-surefire-plugin</artifactId>
+        <version>${version.maven.surefire.plugin}</version>
+        <configuration>
+          <failIfNoTests>false</failIfNoTests>
+        </configuration>
+      </plugin>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-jar-plugin</artifactId>
+        <version>${version.maven.jar}</version>
+        <configuration>
+          <archive>
+            <manifest>
+              <addDefaultImplementationEntries>true</addDefaultImplementationEntries>
+              <addDefaultSpecificationEntries>true</addDefaultSpecificationEntries>
+            </manifest>
+          </archive>
+        </configuration>
+      </plugin>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-compiler-plugin</artifactId>
+        <version>2.5.1</version>
+        <inherited>true</inherited>
+        <configuration>
+          <source>1.8</source>
+          <target>1.8</target>
+        </configuration>
+      </plugin>
+      <plugin>
+        <artifactId>maven-assembly-plugin</artifactId>
+        <version>2.5.3</version>
+        <configuration>
+          <descriptors>
+            <descriptor>src/main/assembly/package.xml</descriptor>
+          </descriptors>
+        </configuration>
+        <executions>
+          <execution>
+            <id>make-assembly</id>
+            <phase>package</phase>
+            <goals>
+              <goal>single</goal>
+            </goals>
+          </execution>
+        </executions>
+      </plugin>
+    </plugins>
+  </build>
+  <!--START OF GENERATED CODE-->
+  <repositories>
+    <!-- camel-jira -->
+    <repository>
+      <id>atlassian-public</id>
+      <url>https://packages.atlassian.com/maven-external</url>
+      <name>Atlassian Public Repo</name>
+      <snapshots>
+        <enabled>false</enabled>
+      </snapshots>
+      <releases>
+        <enabled>true</enabled>
+      </releases>
+    </repository>
+    <!-- camel-ipfs and camel-weka -->
+    <repository>
+      <id>jboss.thirdparty</id>
+      <name>JBoss Thirdparty Repository</name>
+      <url>https://repository.jboss.org/nexus/service/local/repositories/thirdparty-releases/content/</url>
+      <snapshots>
+        <enabled>false</enabled>
+      </snapshots>
+      <releases>
+        <enabled>true</enabled>
+      </releases>
+    </repository>
+  </repositories>
+  <!--END OF GENERATED CODE-->
+</project>
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/assembly/package.xml b/connectors/camel-aws2-sts-kafka-connector/src/main/assembly/package.xml
new file mode 100644
index 0000000..4fd2529
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/assembly/package.xml
@@ -0,0 +1,57 @@
+<?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.
+
+-->
+<assembly>
+  <!-- Assembles a packaged version targeting OS installation. -->
+  <id>package</id>
+  <formats>
+    <format>zip</format>
+    <format>tar.gz</format>
+  </formats>
+  <includeBaseDirectory>false</includeBaseDirectory>
+  <fileSets>
+    <fileSet>
+      <directory>${project.basedir}/../..</directory>
+      <outputDirectory>${project.artifactId}/</outputDirectory>
+      <includes>
+        <include>README*</include>
+        <include>LICENSE*</include>
+        <include>NOTICE*</include>
+        <include>licenses/</include>
+      </includes>
+    </fileSet>
+    <fileSet>
+      <directory>${project.basedir}/src/main/docs</directory>
+      <outputDirectory>docs/</outputDirectory>
+      <includes>
+        <include>**/*</include>
+      </includes>
+    </fileSet>
+  </fileSets>
+  <dependencySets>
+    <dependencySet>
+      <outputDirectory>${project.artifactId}/</outputDirectory>
+      <useProjectArtifact>true</useProjectArtifact>
+      <useTransitiveFiltering>true</useTransitiveFiltering>
+      <excludes>
+        <exclude>org.apache.kafka:connect-api</exclude>
+      </excludes>
+    </dependencySet>
+  </dependencySets>
+</assembly>
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc
new file mode 100644
index 0000000..204c475
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc
@@ -0,0 +1,57 @@
+// kafka-connector options: START
+[[camel-aws2-sts-kafka-connector-sink]]
+= camel-aws2-sts-kafka-connector sink configuration
+
+When using camel-aws2-sts-kafka-connector as sink make sure to use the following Maven dependency to have support for the connector:
+
+[source,xml]
+----
+<dependency>
+  <groupId>org.apache.camel.kafkaconnector</groupId>
+  <artifactId>camel-aws2-sts-kafka-connector</artifactId>
+  <version>x.x.x</version>
+  <!-- use the same version as your Camel Kafka connector version -->
+</dependency>
+----
+
+
+The camel-aws2-sts sink connector supports 29 options, which are listed below.
+
+
+
+[width="100%",cols="2,5,^1,2",options="header"]
+|===
+| Name | Description | Default | Priority
+| *camel.sink.path.label* | Logical name | null | HIGH
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
+| *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
+| *camel.sink.endpoint.operation* | The operation to perform One of: [assumeRole] [getSessionToken] | "assumeRole" | HIGH
+| *camel.sink.endpoint.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
+| *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the STS client | null | MEDIUM
+| *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the STS client | null | MEDIUM
+| *camel.sink.endpoint.proxyProtocol* | To define a proxy protocol when instantiating the STS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
+| *camel.sink.endpoint.region* | The region in which STS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | "aws-global" | MEDIUM
+| *camel.sink.endpoint.stsClient* | To use a existing configured AWS STS as client | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
+| *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
+| *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
+| *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
+| *camel.component.aws2-sts.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
+| *camel.component.aws2-sts.configuration* | Component configuration | null | MEDIUM
+| *camel.component.aws2-sts.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
+| *camel.component.aws2-sts.operation* | The operation to perform One of: [assumeRole] [getSessionToken] | "assumeRole" | HIGH
+| *camel.component.aws2-sts.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
+| *camel.component.aws2-sts.proxyHost* | To define a proxy host when instantiating the STS client | null | MEDIUM
+| *camel.component.aws2-sts.proxyPort* | To define a proxy port when instantiating the STS client | null | MEDIUM
+| *camel.component.aws2-sts.proxyProtocol* | To define a proxy protocol when instantiating the STS client One of: [HTTP] [HTTPS] | "HTTPS" | MEDIUM
+| *camel.component.aws2-sts.region* | The region in which STS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | "aws-global" | MEDIUM
+| *camel.component.aws2-sts.stsClient* | To use a existing configured AWS STS as client | null | MEDIUM
+| *camel.component.aws2-sts.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
+| *camel.component.aws2-sts.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.aws2-sts.accessKey* | Amazon AWS Access Key | null | MEDIUM
+| *camel.component.aws2-sts.secretKey* | Amazon AWS Secret Key | null | MEDIUM
+|===
+
+
+// kafka-connector options: END
diff --git a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/examples/CamelAws2stsSinkConnector.properties
similarity index 76%
copy from connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
copy to connectors/camel-aws2-sts-kafka-connector/src/main/docs/examples/CamelAws2stsSinkConnector.properties
index 4d29762..3954446 100644
--- a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/examples/CamelAws2stsSinkConnector.properties
@@ -15,19 +15,23 @@
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
 
-name=CamelQuartzSourceConnector
-connector.class=org.apache.camel.kafkaconnector.quartz.CamelQuartzSourceConnector
+name=CamelAws2-stsSinkConnector
+connector.class=org.apache.camel.kafkaconnector.aws2sts.CamelAws2stsSinkConnector
 tasks.max=1
 
 # use the kafka converters that better suit your needs, these are just defaults:
 key.converter=org.apache.kafka.connect.storage.StringConverter
 value.converter=org.apache.kafka.connect.storage.StringConverter
 
-# comma separated topics to send messages into
+# comma separated topics to get messages from
 topics=
 
 # mandatory properties (for a complete properties list see the connector documentation):
 
-# The quartz timer name to use. The combination of group name and timer name should be unique.
-camel.source.path.triggerName=
+# The operation to perform One of: [assumeRole] [getSessionToken]
+camel.component.aws2-sts.operation=
+# The operation to perform One of: [assumeRole] [getSessionToken]
+camel.sink.endpoint.operation=
+# Logical name
+camel.sink.path.label=
 
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnector.java b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnector.java
new file mode 100644
index 0000000..588d9b8
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnector.java
@@ -0,0 +1,35 @@
+/*
+ * 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.kafkaconnector.aws2sts;
+
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnector;
+import org.apache.kafka.common.config.ConfigDef;
+import org.apache.kafka.connect.connector.Task;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAws2stsSinkConnector extends CamelSinkConnector {
+
+    @Override
+    public ConfigDef config() {
+        return CamelAws2stsSinkConnectorConfig.conf();
+    }
+    @Override
+    public Class<? extends Task> taskClass() {
+        return CamelAws2stsSinkTask.class;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java
new file mode 100644
index 0000000..66ef528
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java
@@ -0,0 +1,158 @@
+/*
+ * 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.kafkaconnector.aws2sts;
+
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnectorConfig;
+import org.apache.kafka.common.config.ConfigDef;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAws2stsSinkConnectorConfig extends CamelSinkConnectorConfig {
+
+    public static final String CAMEL_SINK_AWS2STS_PATH_LABEL_CONF = "camel.sink.path.label";
+    public static final String CAMEL_SINK_AWS2STS_PATH_LABEL_DOC = "Logical name";
+    public static final String CAMEL_SINK_AWS2STS_PATH_LABEL_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2STS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that wh [...]
+    public static final Boolean CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_CONF = "camel.sink.endpoint.operation";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_DOC = "The operation to perform One of: [assumeRole] [getSessionToken]";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_DEFAULT = "assumeRole";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_CONF = "camel.sink.endpoint.pojoRequest";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_DOC = "If we want to use a POJO request as body or not";
+    public static final Boolean CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_HOST_CONF = "camel.sink.endpoint.proxyHost";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_HOST_DOC = "To define a proxy host when instantiating the STS client";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_HOST_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PORT_CONF = "camel.sink.endpoint.proxyPort";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PORT_DOC = "To define a proxy port when instantiating the STS client";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PORT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PROTOCOL_CONF = "camel.sink.endpoint.proxyProtocol";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PROTOCOL_DOC = "To define a proxy protocol when instantiating the STS client One of: [HTTP] [HTTPS]";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PROTOCOL_DEFAULT = "HTTPS";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_REGION_CONF = "camel.sink.endpoint.region";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_REGION_DOC = "The region in which STS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_REGION_DEFAULT = "aws-global";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_STS_CLIENT_CONF = "camel.sink.endpoint.stsClient";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_STS_CLIENT_DOC = "To use a existing configured AWS STS as client";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_STS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2STS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SINK_AWS2STS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
+    public static final Boolean CAMEL_SINK_AWS2STS_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_ACCESS_KEY_CONF = "camel.sink.endpoint.accessKey";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_ACCESS_KEY_DOC = "Amazon AWS Access Key";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_SECRET_KEY_CONF = "camel.sink.endpoint.secretKey";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_SECRET_KEY_DOC = "Amazon AWS Secret Key";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_SECRET_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-sts.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2STS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-sts.configuration";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_CONFIGURATION_DOC = "Component configuration";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_CONFIGURATION_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.aws2-sts.lazyStartProducer";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that w [...]
+    public static final Boolean CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_CONF = "camel.component.aws2-sts.operation";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_DOC = "The operation to perform One of: [assumeRole] [getSessionToken]";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_DEFAULT = "assumeRole";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_CONF = "camel.component.aws2-sts.pojoRequest";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_DOC = "If we want to use a POJO request as body or not";
+    public static final Boolean CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_HOST_CONF = "camel.component.aws2-sts.proxyHost";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_HOST_DOC = "To define a proxy host when instantiating the STS client";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_HOST_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PORT_CONF = "camel.component.aws2-sts.proxyPort";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PORT_DOC = "To define a proxy port when instantiating the STS client";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PORT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PROTOCOL_CONF = "camel.component.aws2-sts.proxyProtocol";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PROTOCOL_DOC = "To define a proxy protocol when instantiating the STS client One of: [HTTP] [HTTPS]";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PROTOCOL_DEFAULT = "HTTPS";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_REGION_CONF = "camel.component.aws2-sts.region";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_REGION_DOC = "The region in which STS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id()";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_REGION_DEFAULT = "aws-global";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_STS_CLIENT_CONF = "camel.component.aws2-sts.stsClient";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_STS_CLIENT_DOC = "To use a existing configured AWS STS as client";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_STS_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-sts.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2STS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.aws2-sts.basicPropertyBinding";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SINK_AWS2STS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_ACCESS_KEY_CONF = "camel.component.aws2-sts.accessKey";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_ACCESS_KEY_DOC = "Amazon AWS Access Key";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_SECRET_KEY_CONF = "camel.component.aws2-sts.secretKey";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_SECRET_KEY_DOC = "Amazon AWS Secret Key";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_SECRET_KEY_DEFAULT = null;
+
+    public CamelAws2stsSinkConnectorConfig(
+            ConfigDef config,
+            Map<String, String> parsedConfig) {
+        super(config, parsedConfig);
+    }
+
+    public CamelAws2stsSinkConnectorConfig(Map<String, String> parsedConfig) {
+        this(conf(), parsedConfig);
+    }
+
+    public static ConfigDef conf() {
+        ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
+        conf.define(CAMEL_SINK_AWS2STS_PATH_LABEL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_PATH_LABEL_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2STS_PATH_LABEL_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_HOST_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PORT_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_PROXY_PROTOCOL_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_STS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_STS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_STS_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_SYNCHRONOUS_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_ENDPOINT_SECRET_KEY_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_CONFIGURATION_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_PROXY_HOST_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_PROXY_HOST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_PROXY_HOST_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PORT_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PROTOCOL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PROTOCOL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_PROXY_PROTOCOL_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_REGION_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_STS_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_STS_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_STS_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2STS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SINK_AWS2STS_COMPONENT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2STS_COMPONENT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2STS_COMPONENT_SECRET_KEY_DOC);
+        return conf;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkTask.java b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkTask.java
new file mode 100644
index 0000000..6ea5987
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkTask.java
@@ -0,0 +1,39 @@
+/*
+ * 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.kafkaconnector.aws2sts;
+
+import java.util.HashMap;
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnectorConfig;
+import org.apache.camel.kafkaconnector.CamelSinkTask;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAws2stsSinkTask extends CamelSinkTask {
+
+    @Override
+    protected CamelSinkConnectorConfig getCamelSinkConnectorConfig(
+            Map<String, String> props) {
+        return new CamelAws2stsSinkConnectorConfig(props);
+    }
+    @Override
+    protected Map<String, String> getDefaultConfig() {
+        return new HashMap<String, String>() {{
+            put(CamelSinkConnectorConfig.CAMEL_SINK_COMPONENT_CONF, "aws2-sts");
+        }};
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/resources/META-INF/LICENSE.txt b/connectors/camel-aws2-sts-kafka-connector/src/main/resources/META-INF/LICENSE.txt
new file mode 100644
index 0000000..6b0b127
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/resources/META-INF/LICENSE.txt
@@ -0,0 +1,203 @@
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+   END OF TERMS AND CONDITIONS
+
+   APPENDIX: How to apply the Apache License to your work.
+
+      To apply the Apache License to your work, attach the following
+      boilerplate notice, with the fields enclosed by brackets "[]"
+      replaced with your own identifying information. (Don't include
+      the brackets!)  The text should be enclosed in the appropriate
+      comment syntax for the file format. We also recommend that a
+      file or class name and description of purpose be included on the
+      same "printed page" as the copyright notice for easier
+      identification within third-party archives.
+
+   Copyright [yyyy] [name of copyright owner]
+
+   Licensed 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.
+
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/resources/META-INF/NOTICE.txt b/connectors/camel-aws2-sts-kafka-connector/src/main/resources/META-INF/NOTICE.txt
new file mode 100644
index 0000000..2e215bf
--- /dev/null
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/resources/META-INF/NOTICE.txt
@@ -0,0 +1,11 @@
+   =========================================================================
+   ==  NOTICE file corresponding to the section 4 d of                    ==
+   ==  the Apache License, Version 2.0,                                   ==
+   ==  in this case for the Apache Camel distribution.                    ==
+   =========================================================================
+
+   This product includes software developed by
+   The Apache Software Foundation (http://www.apache.org/).
+
+   Please read the different LICENSE files present in the licenses directory of
+   this distribution.
diff --git a/connectors/camel-aws2-translate-kafka-connector/src/main/docs/camel-aws2-translate-kafka-sink-connector.adoc b/connectors/camel-aws2-translate-kafka-connector/src/main/docs/camel-aws2-translate-kafka-sink-connector.adoc
index a1208a0..bfcbbd0 100644
--- a/connectors/camel-aws2-translate-kafka-connector/src/main/docs/camel-aws2-translate-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-translate-kafka-connector/src/main/docs/camel-aws2-translate-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-translate-kafka-connector as sink make sure to use the fol
 ----
 
 
-The camel-aws2-translate sink connector supports 31 options, which are listed below.
+The camel-aws2-translate sink connector supports 35 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-aws2-translate sink connector supports 31 options, which are listed be
 | Name | Description | Default | Priority
 | *camel.sink.path.label* | Logical name | null | HIGH
 | *camel.sink.endpoint.autodetectSourceLanguage* | Being able to autodetect the source language | false | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.operation* | The operation to perform One of: [translateText] | "translateText" | HIGH
 | *camel.sink.endpoint.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
@@ -34,11 +35,13 @@ The camel-aws2-translate sink connector supports 31 options, which are listed be
 | *camel.sink.endpoint.sourceLanguage* | Source language to use | null | MEDIUM
 | *camel.sink.endpoint.targetLanguage* | Target language to use | null | MEDIUM
 | *camel.sink.endpoint.translateClient* | To use a existing configured AWS Translate as client | null | MEDIUM
+| *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.sink.endpoint.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 | *camel.component.aws2-translate.autodetectSource Language* | Being able to autodetect the source language | false | MEDIUM
+| *camel.component.aws2-translate.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-translate.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-translate.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is process [...]
 | *camel.component.aws2-translate.operation* | The operation to perform One of: [translateText] | "translateText" | HIGH
@@ -50,6 +53,7 @@ The camel-aws2-translate sink connector supports 31 options, which are listed be
 | *camel.component.aws2-translate.sourceLanguage* | Source language to use | null | MEDIUM
 | *camel.component.aws2-translate.targetLanguage* | Target language to use | null | MEDIUM
 | *camel.component.aws2-translate.translateClient* | To use a existing configured AWS Translate as client | null | MEDIUM
+| *camel.component.aws2-translate.trustAll Certificates* | If we want to trust all certificates in case of overriding the endpoint | false | MEDIUM
 | *camel.component.aws2-translate.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.aws2-translate.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-translate.secretKey* | Amazon AWS Secret Key | null | MEDIUM
diff --git a/connectors/camel-aws2-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2translate/CamelAws2translateSinkConnectorConfig.java b/connectors/camel-aws2-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2translate/CamelAws2translateSinkConnectorConfig.java
index fde00a4..0b1a46d 100644
--- a/connectors/camel-aws2-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2translate/CamelAws2translateSinkConnectorConfig.java
+++ b/connectors/camel-aws2-translate-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2translate/CamelAws2translateSinkConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAws2translateSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_CONF = "camel.sink.endpoint.autodetectSourceLanguage";
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_DOC = "Being able to autodetect the source language";
     public static final Boolean CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware t [...]
     public static final Boolean CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -62,6 +65,9 @@ public class CamelAws2translateSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRANSLATE_CLIENT_CONF = "camel.sink.endpoint.translateClient";
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRANSLATE_CLIENT_DOC = "To use a existing configured AWS Translate as client";
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRANSLATE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF = "camel.sink.endpoint.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -77,6 +83,9 @@ public class CamelAws2translateSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_CONF = "camel.component.aws2-translate.autodetectSourceLanguage";
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_DOC = "Being able to autodetect the source language";
     public static final Boolean CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.aws2-translate.autoDiscoverClient";
+    public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_CONFIGURATION_CONF = "camel.component.aws2-translate.configuration";
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_CONFIGURATION_DOC = "Component configuration";
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -110,6 +119,9 @@ public class CamelAws2translateSinkConnectorConfig
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRANSLATE_CLIENT_CONF = "camel.component.aws2-translate.translateClient";
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRANSLATE_CLIENT_DOC = "To use a existing configured AWS Translate as client";
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRANSLATE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRUST_ALL_CERTIFICATES_CONF = "camel.component.aws2-translate.trustAllCertificates";
+    public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRUST_ALL_CERTIFICATES_DOC = "If we want to trust all certificates in case of overriding the endpoint";
+    public static final Boolean CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.aws2-translate.basicPropertyBinding";
     public static final String CAMEL_SINK_AWS2TRANSLATE_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AWS2TRANSLATE_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -135,6 +147,7 @@ public class CamelAws2translateSinkConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AWS2TRANSLATE_PATH_LABEL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_PATH_LABEL_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2TRANSLATE_PATH_LABEL_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTODETECT_SOURCE_LANGUAGE_DOC);
+        conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_POJO_REQUEST_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_POJO_REQUEST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_POJO_REQUEST_DOC);
@@ -145,11 +158,13 @@ public class CamelAws2translateSinkConnectorConfig
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SOURCE_LANGUAGE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SOURCE_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SOURCE_LANGUAGE_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TARGET_LANGUAGE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TARGET_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TARGET_LANGUAGE_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRANSLATE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRANSLATE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRANSLATE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_ENDPOINT_SECRET_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTODETECT_SOURCE_LANGUAGE_DOC);
+        conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_OPERATION_DOC);
@@ -161,6 +176,7 @@ public class CamelAws2translateSinkConnectorConfig
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_SOURCE_LANGUAGE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_SOURCE_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_SOURCE_LANGUAGE_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TARGET_LANGUAGE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TARGET_LANGUAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TARGET_LANGUAGE_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRANSLATE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRANSLATE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRANSLATE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AWS2TRANSLATE_COMPONENT_SECRET_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_SECRET_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2TRANSLATE_COMPONENT_SECRET_KEY_DOC);
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/pom.xml b/connectors/camel-azure-eventhubs-kafka-connector/pom.xml
new file mode 100644
index 0000000..fcd2365
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/pom.xml
@@ -0,0 +1,135 @@
+<?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">
+  <modelVersion>4.0.0</modelVersion>
+  <parent>
+    <groupId>org.apache.camel.kafkaconnector</groupId>
+    <artifactId>connectors</artifactId>
+    <version>0.5.0-SNAPSHOT</version>
+  </parent>
+  <artifactId>camel-azure-eventhubs-kafka-connector</artifactId>
+  <name>Camel-Kafka-Connector :: azure-eventhubs</name>
+  <description>Camel Kafka Connector for azure-eventhubs</description>
+  <dependencies>
+    <!-- Kafka -->
+    <dependency>
+      <groupId>org.apache.kafka</groupId>
+      <artifactId>connect-api</artifactId>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.kafka</groupId>
+      <artifactId>connect-transforms</artifactId>
+      <scope>provided</scope>
+    </dependency>
+    <!-- Camel -->
+    <dependency>
+      <groupId>org.apache.camel</groupId>
+      <artifactId>camel-azure-eventhubs</artifactId>
+    </dependency>
+    <!--START OF GENERATED CODE-->
+    <dependency>
+      <groupId>org.apache.camel.kafkaconnector</groupId>
+      <artifactId>camel-kafka-connector</artifactId>
+    </dependency>
+    <!--END OF GENERATED CODE-->
+  </dependencies>
+  <build>
+    <plugins>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-surefire-plugin</artifactId>
+        <version>${version.maven.surefire.plugin}</version>
+        <configuration>
+          <failIfNoTests>false</failIfNoTests>
+        </configuration>
+      </plugin>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-jar-plugin</artifactId>
+        <version>${version.maven.jar}</version>
+        <configuration>
+          <archive>
+            <manifest>
+              <addDefaultImplementationEntries>true</addDefaultImplementationEntries>
+              <addDefaultSpecificationEntries>true</addDefaultSpecificationEntries>
+            </manifest>
+          </archive>
+        </configuration>
+      </plugin>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-compiler-plugin</artifactId>
+        <version>2.5.1</version>
+        <inherited>true</inherited>
+        <configuration>
+          <source>1.8</source>
+          <target>1.8</target>
+        </configuration>
+      </plugin>
+      <plugin>
+        <artifactId>maven-assembly-plugin</artifactId>
+        <version>2.5.3</version>
+        <configuration>
+          <descriptors>
+            <descriptor>src/main/assembly/package.xml</descriptor>
+          </descriptors>
+        </configuration>
+        <executions>
+          <execution>
+            <id>make-assembly</id>
+            <phase>package</phase>
+            <goals>
+              <goal>single</goal>
+            </goals>
+          </execution>
+        </executions>
+      </plugin>
+    </plugins>
+  </build>
+  <!--START OF GENERATED CODE-->
+  <repositories>
+    <!-- camel-jira -->
+    <repository>
+      <id>atlassian-public</id>
+      <url>https://packages.atlassian.com/maven-external</url>
+      <name>Atlassian Public Repo</name>
+      <snapshots>
+        <enabled>false</enabled>
+      </snapshots>
+      <releases>
+        <enabled>true</enabled>
+      </releases>
+    </repository>
+    <!-- camel-ipfs and camel-weka -->
+    <repository>
+      <id>jboss.thirdparty</id>
+      <name>JBoss Thirdparty Repository</name>
+      <url>https://repository.jboss.org/nexus/service/local/repositories/thirdparty-releases/content/</url>
+      <snapshots>
+        <enabled>false</enabled>
+      </snapshots>
+      <releases>
+        <enabled>true</enabled>
+      </releases>
+    </repository>
+  </repositories>
+  <!--END OF GENERATED CODE-->
+</project>
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/assembly/package.xml b/connectors/camel-azure-eventhubs-kafka-connector/src/main/assembly/package.xml
new file mode 100644
index 0000000..4fd2529
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/assembly/package.xml
@@ -0,0 +1,57 @@
+<?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.
+
+-->
+<assembly>
+  <!-- Assembles a packaged version targeting OS installation. -->
+  <id>package</id>
+  <formats>
+    <format>zip</format>
+    <format>tar.gz</format>
+  </formats>
+  <includeBaseDirectory>false</includeBaseDirectory>
+  <fileSets>
+    <fileSet>
+      <directory>${project.basedir}/../..</directory>
+      <outputDirectory>${project.artifactId}/</outputDirectory>
+      <includes>
+        <include>README*</include>
+        <include>LICENSE*</include>
+        <include>NOTICE*</include>
+        <include>licenses/</include>
+      </includes>
+    </fileSet>
+    <fileSet>
+      <directory>${project.basedir}/src/main/docs</directory>
+      <outputDirectory>docs/</outputDirectory>
+      <includes>
+        <include>**/*</include>
+      </includes>
+    </fileSet>
+  </fileSets>
+  <dependencySets>
+    <dependencySet>
+      <outputDirectory>${project.artifactId}/</outputDirectory>
+      <useProjectArtifact>true</useProjectArtifact>
+      <useTransitiveFiltering>true</useTransitiveFiltering>
+      <excludes>
+        <exclude>org.apache.kafka:connect-api</exclude>
+      </excludes>
+    </dependencySet>
+  </dependencySets>
+</assembly>
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/camel-azure-eventhubs-kafka-sink-connector.adoc b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/camel-azure-eventhubs-kafka-sink-connector.adoc
new file mode 100644
index 0000000..9b3e1fb
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/camel-azure-eventhubs-kafka-sink-connector.adoc
@@ -0,0 +1,54 @@
+// kafka-connector options: START
+[[camel-azure-eventhubs-kafka-connector-sink]]
+= camel-azure-eventhubs-kafka-connector sink configuration
+
+When using camel-azure-eventhubs-kafka-connector as sink make sure to use the following Maven dependency to have support for the connector:
+
+[source,xml]
+----
+<dependency>
+  <groupId>org.apache.camel.kafkaconnector</groupId>
+  <artifactId>camel-azure-eventhubs-kafka-connector</artifactId>
+  <version>x.x.x</version>
+  <!-- use the same version as your Camel Kafka connector version -->
+</dependency>
+----
+
+
+The camel-azure-eventhubs sink connector supports 26 options, which are listed below.
+
+
+
+[width="100%",cols="2,5,^1,2",options="header"]
+|===
+| Name | Description | Default | Priority
+| *camel.sink.path.namespace* | EventHubs namespace created in Azure Portal | null | MEDIUM
+| *camel.sink.path.eventHubName* | EventHubs name under a specific namcespace | null | MEDIUM
+| *camel.sink.endpoint.amqpRetryOptions* | Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used. | null | MEDIUM
+| *camel.sink.endpoint.amqpTransportType* | Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets] | "AMQP" | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
+| *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
+| *camel.sink.endpoint.partitionId* | Sets the identifier of the Event Hub partition that the {link EventData events} will be sent to. If the identifier is not specified, the Event Hubs service will be responsible for routing events that are sent to an available partition. | null | MEDIUM
+| *camel.sink.endpoint.partitionKey* | Sets a hashing key to be provided for the batch of events, which instructs the Event Hubs service to map this key to a specific partition. The selection of a partition is stable for a given partition hashing key. Should any other batches of events be sent using the same exact partition hashing key, the Event Hubs service will route them all to the same partition. This should be specified only when there is a need to group events by partition, but th [...]
+| *camel.sink.endpoint.producerAsyncClient* | Sets the EventHubProducerAsyncClient.An asynchronous producer responsible for transmitting EventData to a specific Event Hub, grouped together in batches. Depending on the {link CreateBatchOptions options} specified when creating an \{linkEventDataBatch\}, the events may be automatically routed to an available partition or specific to a partition. Use by this component to produce the data in camel producer. | null | MEDIUM
+| *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
+| *camel.sink.endpoint.connectionString* | Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: \https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-get-connection-string | null | MEDIUM
+| *camel.sink.endpoint.sharedAccessKey* | The generated value for the SharedAccessName | null | MEDIUM
+| *camel.sink.endpoint.sharedAccessName* | The name you chose for your EventHubs SAS keys | null | MEDIUM
+| *camel.component.azure-eventhubs.amqpRetryOptions* | Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used. | null | MEDIUM
+| *camel.component.azure-eventhubs.amqpTransportType* | Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets] | "AMQP" | MEDIUM
+| *camel.component.azure-eventhubs.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
+| *camel.component.azure-eventhubs.configuration* | The component configurations | null | MEDIUM
+| *camel.component.azure-eventhubs.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is proces [...]
+| *camel.component.azure-eventhubs.partitionId* | Sets the identifier of the Event Hub partition that the {link EventData events} will be sent to. If the identifier is not specified, the Event Hubs service will be responsible for routing events that are sent to an available partition. | null | MEDIUM
+| *camel.component.azure-eventhubs.partitionKey* | Sets a hashing key to be provided for the batch of events, which instructs the Event Hubs service to map this key to a specific partition. The selection of a partition is stable for a given partition hashing key. Should any other batches of events be sent using the same exact partition hashing key, the Event Hubs service will route them all to the same partition. This should be specified only when there is a need to group events by parti [...]
+| *camel.component.azure-eventhubs.producerAsync Client* | Sets the EventHubProducerAsyncClient.An asynchronous producer responsible for transmitting EventData to a specific Event Hub, grouped together in batches. Depending on the {link CreateBatchOptions options} specified when creating an \{linkEventDataBatch\}, the events may be automatically routed to an available partition or specific to a partition. Use by this component to produce the data in camel producer. | null | MEDIUM
+| *camel.component.azure-eventhubs.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.azure-eventhubs.connectionString* | Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: \https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-get-connection-string | null | MEDIUM
+| *camel.component.azure-eventhubs.sharedAccessKey* | The generated value for the SharedAccessName | null | MEDIUM
+| *camel.component.azure-eventhubs.sharedAccessName* | The name you chose for your EventHubs SAS keys | null | MEDIUM
+|===
+
+
+// kafka-connector options: END
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/camel-azure-eventhubs-kafka-source-connector.adoc b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/camel-azure-eventhubs-kafka-source-connector.adoc
new file mode 100644
index 0000000..ac07005
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/camel-azure-eventhubs-kafka-source-connector.adoc
@@ -0,0 +1,66 @@
+// kafka-connector options: START
+[[camel-azure-eventhubs-kafka-connector-source]]
+= camel-azure-eventhubs-kafka-connector source configuration
+
+When using camel-azure-eventhubs-kafka-connector as source make sure to use the following Maven dependency to have support for the connector:
+
+[source,xml]
+----
+<dependency>
+  <groupId>org.apache.camel.kafkaconnector</groupId>
+  <artifactId>camel-azure-eventhubs-kafka-connector</artifactId>
+  <version>x.x.x</version>
+  <!-- use the same version as your Camel Kafka connector version -->
+</dependency>
+----
+
+
+The camel-azure-eventhubs source connector supports 38 options, which are listed below.
+
+
+
+[width="100%",cols="2,5,^1,2",options="header"]
+|===
+| Name | Description | Default | Priority
+| *camel.source.path.namespace* | EventHubs namespace created in Azure Portal | null | MEDIUM
+| *camel.source.path.eventHubName* | EventHubs name under a specific namcespace | null | MEDIUM
+| *camel.source.endpoint.amqpRetryOptions* | Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used. | null | MEDIUM
+| *camel.source.endpoint.amqpTransportType* | Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets] | "AMQP" | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
+| *camel.source.endpoint.blobAccessKey* | In case you chose the default BlobCheckpointStore, this sets access key for the associated azure account name to be used for authentication with azure blob services | null | MEDIUM
+| *camel.source.endpoint.blobAccountName* | In case you chose the default BlobCheckpointStore, this sets Azure account name to be used for authentication with azure blob services. | null | MEDIUM
+| *camel.source.endpoint.blobContainerName* | In case you chose the default BlobCheckpointStore, this sets the blob container that shall be used by the BlobCheckpointStore to store the checkpoint offsets | null | MEDIUM
+| *camel.source.endpoint.blobStorageSharedKey Credential* | In case you chose the default BlobCheckpointStore, StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
+| *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
+| *camel.source.endpoint.checkpointStore* | Sets the CheckpointStore the EventProcessorClient will use for storing partition ownership and checkpoint information. Users can, optionally, provide their own implementation of CheckpointStore which will store ownership and checkpoint information. By default it set to use com.azure.messaging.eventhubs.checkpointstore.blob.BlobCheckpointStore which stores all checkpoint offsets into Azure Blob Storage | "BlobCheckpointStore" | MEDIUM
+| *camel.source.endpoint.consumerGroupName* | Sets the name of the consumer group this consumer is associated with. Events are read in the context of this group. The name of the consumer group that is created by default is {link #DEFAULT_CONSUMER_GROUP_NAME \$Default}. | "$Default" | MEDIUM
+| *camel.source.endpoint.eventPosition* | Sets the map containing the event position to use for each partition if a checkpoint for the partition does not exist in CheckpointStore. This map is keyed off of the partition id. If there is no checkpoint in CheckpointStore and there is no entry in this map, the processing of the partition will start from {link EventPosition#latest() latest} position. | null | MEDIUM
+| *camel.source.endpoint.prefetchCount* | Sets the count used by the receiver to control the number of events the Event Hub consumer will actively receive and queue locally without regard to whether a receive operation is currently active. | 500 | MEDIUM
+| *camel.source.endpoint.exceptionHandler* | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored. | null | MEDIUM
+| *camel.source.endpoint.exchangePattern* | Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut] | null | MEDIUM
+| *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
+| *camel.source.endpoint.connectionString* | Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: \https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-get-connection-string | null | MEDIUM
+| *camel.source.endpoint.sharedAccessKey* | The generated value for the SharedAccessName | null | MEDIUM
+| *camel.source.endpoint.sharedAccessName* | The name you chose for your EventHubs SAS keys | null | MEDIUM
+| *camel.component.azure-eventhubs.amqpRetryOptions* | Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used. | null | MEDIUM
+| *camel.component.azure-eventhubs.amqpTransportType* | Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets] | "AMQP" | MEDIUM
+| *camel.component.azure-eventhubs.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
+| *camel.component.azure-eventhubs.configuration* | The component configurations | null | MEDIUM
+| *camel.component.azure-eventhubs.blobAccessKey* | In case you chose the default BlobCheckpointStore, this sets access key for the associated azure account name to be used for authentication with azure blob services | null | MEDIUM
+| *camel.component.azure-eventhubs.blobAccountName* | In case you chose the default BlobCheckpointStore, this sets Azure account name to be used for authentication with azure blob services. | null | MEDIUM
+| *camel.component.azure-eventhubs.blobContainerName* | In case you chose the default BlobCheckpointStore, this sets the blob container that shall be used by the BlobCheckpointStore to store the checkpoint offsets | null | MEDIUM
+| *camel.component.azure-eventhubs.blobStorageShared KeyCredential* | In case you chose the default BlobCheckpointStore, StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
+| *camel.component.azure-eventhubs.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
+| *camel.component.azure-eventhubs.checkpointStore* | Sets the CheckpointStore the EventProcessorClient will use for storing partition ownership and checkpoint information. Users can, optionally, provide their own implementation of CheckpointStore which will store ownership and checkpoint information. By default it set to use com.azure.messaging.eventhubs.checkpointstore.blob.BlobCheckpointStore which stores all checkpoint offsets into Azure Blob Storage | "BlobCheckpointStore" | MEDIUM
+| *camel.component.azure-eventhubs.consumerGroupName* | Sets the name of the consumer group this consumer is associated with. Events are read in the context of this group. The name of the consumer group that is created by default is {link #DEFAULT_CONSUMER_GROUP_NAME \$Default}. | "$Default" | MEDIUM
+| *camel.component.azure-eventhubs.eventPosition* | Sets the map containing the event position to use for each partition if a checkpoint for the partition does not exist in CheckpointStore. This map is keyed off of the partition id. If there is no checkpoint in CheckpointStore and there is no entry in this map, the processing of the partition will start from {link EventPosition#latest() latest} position. | null | MEDIUM
+| *camel.component.azure-eventhubs.prefetchCount* | Sets the count used by the receiver to control the number of events the Event Hub consumer will actively receive and queue locally without regard to whether a receive operation is currently active. | 500 | MEDIUM
+| *camel.component.azure-eventhubs.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.azure-eventhubs.connectionString* | Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: \https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-get-connection-string | null | MEDIUM
+| *camel.component.azure-eventhubs.sharedAccessKey* | The generated value for the SharedAccessName | null | MEDIUM
+| *camel.component.azure-eventhubs.sharedAccessName* | The name you chose for your EventHubs SAS keys | null | MEDIUM
+|===
+
+
+// kafka-connector options: END
diff --git a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/examples/CamelAzureeventhubsSinkConnector.properties
similarity index 81%
copy from connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
copy to connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/examples/CamelAzureeventhubsSinkConnector.properties
index 4d29762..1ad6469 100644
--- a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/examples/CamelAzureeventhubsSinkConnector.properties
@@ -15,19 +15,17 @@
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
 
-name=CamelQuartzSourceConnector
-connector.class=org.apache.camel.kafkaconnector.quartz.CamelQuartzSourceConnector
+name=CamelAzure-eventhubsSinkConnector
+connector.class=org.apache.camel.kafkaconnector.azureeventhubs.CamelAzureeventhubsSinkConnector
 tasks.max=1
 
 # use the kafka converters that better suit your needs, these are just defaults:
 key.converter=org.apache.kafka.connect.storage.StringConverter
 value.converter=org.apache.kafka.connect.storage.StringConverter
 
-# comma separated topics to send messages into
+# comma separated topics to get messages from
 topics=
 
 # mandatory properties (for a complete properties list see the connector documentation):
 
-# The quartz timer name to use. The combination of group name and timer name should be unique.
-camel.source.path.triggerName=
 
diff --git a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/examples/CamelAzureeventhubsSourceConnector.properties
similarity index 84%
copy from connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
copy to connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/examples/CamelAzureeventhubsSourceConnector.properties
index 4d29762..35f5a0f 100644
--- a/connectors/camel-quartz-kafka-connector/src/main/docs/examples/CamelQuartzSourceConnector.properties
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/docs/examples/CamelAzureeventhubsSourceConnector.properties
@@ -15,8 +15,8 @@
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
 
-name=CamelQuartzSourceConnector
-connector.class=org.apache.camel.kafkaconnector.quartz.CamelQuartzSourceConnector
+name=CamelAzure-eventhubsSourceConnector
+connector.class=org.apache.camel.kafkaconnector.azureeventhubs.CamelAzureeventhubsSourceConnector
 tasks.max=1
 
 # use the kafka converters that better suit your needs, these are just defaults:
@@ -28,6 +28,4 @@ topics=
 
 # mandatory properties (for a complete properties list see the connector documentation):
 
-# The quartz timer name to use. The combination of group name and timer name should be unique.
-camel.source.path.triggerName=
 
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkConnector.java b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkConnector.java
new file mode 100644
index 0000000..7b39505
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkConnector.java
@@ -0,0 +1,35 @@
+/*
+ * 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.kafkaconnector.azureeventhubs;
+
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnector;
+import org.apache.kafka.common.config.ConfigDef;
+import org.apache.kafka.connect.connector.Task;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAzureeventhubsSinkConnector extends CamelSinkConnector {
+
+    @Override
+    public ConfigDef config() {
+        return CamelAzureeventhubsSinkConnectorConfig.conf();
+    }
+    @Override
+    public Class<? extends Task> taskClass() {
+        return CamelAzureeventhubsSinkTask.class;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkConnectorConfig.java b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkConnectorConfig.java
new file mode 100644
index 0000000..f306625
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkConnectorConfig.java
@@ -0,0 +1,149 @@
+/*
+ * 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.kafkaconnector.azureeventhubs;
+
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnectorConfig;
+import org.apache.kafka.common.config.ConfigDef;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAzureeventhubsSinkConnectorConfig
+        extends
+            CamelSinkConnectorConfig {
+
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_PATH_NAMESPACE_CONF = "camel.sink.path.namespace";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_PATH_NAMESPACE_DOC = "EventHubs namespace created in Azure Portal";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_PATH_NAMESPACE_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_CONF = "camel.sink.path.eventHubName";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DOC = "EventHubs name under a specific namcespace";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_CONF = "camel.sink.endpoint.amqpRetryOptions";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DOC = "Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used.";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_CONF = "camel.sink.endpoint.amqpTransportType";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DOC = "Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets]";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DEFAULT = "AMQP";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware  [...]
+    public static final Boolean CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_ID_CONF = "camel.sink.endpoint.partitionId";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_ID_DOC = "Sets the identifier of the Event Hub partition that the {link EventData events} will be sent to. If the identifier is not specified, the Event Hubs service will be responsible for routing events that are sent to an available partition.";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_ID_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_KEY_CONF = "camel.sink.endpoint.partitionKey";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_KEY_DOC = "Sets a hashing key to be provided for the batch of events, which instructs the Event Hubs service to map this key to a specific partition. The selection of a partition is stable for a given partition hashing key. Should any other batches of events be sent using the same exact partition hashing key, the Event Hubs service will route them all to the same partition. This should be specified only when ther [...]
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PRODUCER_ASYNC_CLIENT_CONF = "camel.sink.endpoint.producerAsyncClient";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PRODUCER_ASYNC_CLIENT_DOC = "Sets the EventHubProducerAsyncClient.An asynchronous producer responsible for transmitting EventData to a specific Event Hub, grouped together in batches. Depending on the {link CreateBatchOptions options} specified when creating an {linkEventDataBatch}, the events may be automatically routed to an available partition or specific to a partition. Use by this component to produce the data in came [...]
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PRODUCER_ASYNC_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
+    public static final Boolean CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_CONF = "camel.sink.endpoint.connectionString";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DOC = "Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-get- [...]
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_CONF = "camel.sink.endpoint.sharedAccessKey";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DOC = "The generated value for the SharedAccessName";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_CONF = "camel.sink.endpoint.sharedAccessName";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DOC = "The name you chose for your EventHubs SAS keys";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_CONF = "camel.component.azure-eventhubs.amqpRetryOptions";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DOC = "Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used.";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_CONF = "camel.component.azure-eventhubs.amqpTransportType";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DOC = "Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets]";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DEFAULT = "AMQP";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.azure-eventhubs.autoDiscoverClient";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_CONF = "camel.component.azure-eventhubs.configuration";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DOC = "The component configurations";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.azure-eventhubs.lazyStartProducer";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware [...]
+    public static final Boolean CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_ID_CONF = "camel.component.azure-eventhubs.partitionId";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_ID_DOC = "Sets the identifier of the Event Hub partition that the {link EventData events} will be sent to. If the identifier is not specified, the Event Hubs service will be responsible for routing events that are sent to an available partition.";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_ID_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_KEY_CONF = "camel.component.azure-eventhubs.partitionKey";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_KEY_DOC = "Sets a hashing key to be provided for the batch of events, which instructs the Event Hubs service to map this key to a specific partition. The selection of a partition is stable for a given partition hashing key. Should any other batches of events be sent using the same exact partition hashing key, the Event Hubs service will route them all to the same partition. This should be specified only when the [...]
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PRODUCER_ASYNC_CLIENT_CONF = "camel.component.azure-eventhubs.producerAsyncClient";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PRODUCER_ASYNC_CLIENT_DOC = "Sets the EventHubProducerAsyncClient.An asynchronous producer responsible for transmitting EventData to a specific Event Hub, grouped together in batches. Depending on the {link CreateBatchOptions options} specified when creating an {linkEventDataBatch}, the events may be automatically routed to an available partition or specific to a partition. Use by this component to produce the data in cam [...]
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PRODUCER_ASYNC_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.azure-eventhubs.basicPropertyBinding";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_CONF = "camel.component.azure-eventhubs.connectionString";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DOC = "Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-get [...]
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_CONF = "camel.component.azure-eventhubs.sharedAccessKey";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DOC = "The generated value for the SharedAccessName";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_CONF = "camel.component.azure-eventhubs.sharedAccessName";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DOC = "The name you chose for your EventHubs SAS keys";
+    public static final String CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DEFAULT = null;
+
+    public CamelAzureeventhubsSinkConnectorConfig(
+            ConfigDef config,
+            Map<String, String> parsedConfig) {
+        super(config, parsedConfig);
+    }
+
+    public CamelAzureeventhubsSinkConnectorConfig(
+            Map<String, String> parsedConfig) {
+        this(conf(), parsedConfig);
+    }
+
+    public static ConfigDef conf() {
+        ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_PATH_NAMESPACE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_PATH_NAMESPACE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_PATH_NAMESPACE_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_ID_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PARTITION_KEY_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PRODUCER_ASYNC_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PRODUCER_ASYNC_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_PRODUCER_ASYNC_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_LAZY_START_PRODUCER_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_ID_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PARTITION_KEY_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PRODUCER_ASYNC_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PRODUCER_ASYNC_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_PRODUCER_ASYNC_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DOC);
+        return conf;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkTask.java b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkTask.java
new file mode 100644
index 0000000..06f7df9
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSinkTask.java
@@ -0,0 +1,39 @@
+/*
+ * 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.kafkaconnector.azureeventhubs;
+
+import java.util.HashMap;
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSinkConnectorConfig;
+import org.apache.camel.kafkaconnector.CamelSinkTask;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAzureeventhubsSinkTask extends CamelSinkTask {
+
+    @Override
+    protected CamelSinkConnectorConfig getCamelSinkConnectorConfig(
+            Map<String, String> props) {
+        return new CamelAzureeventhubsSinkConnectorConfig(props);
+    }
+    @Override
+    protected Map<String, String> getDefaultConfig() {
+        return new HashMap<String, String>() {{
+            put(CamelSinkConnectorConfig.CAMEL_SINK_COMPONENT_CONF, "azure-eventhubs");
+        }};
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceConnector.java b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceConnector.java
new file mode 100644
index 0000000..0af97df
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceConnector.java
@@ -0,0 +1,35 @@
+/*
+ * 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.kafkaconnector.azureeventhubs;
+
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSourceConnector;
+import org.apache.kafka.common.config.ConfigDef;
+import org.apache.kafka.connect.connector.Task;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAzureeventhubsSourceConnector extends CamelSourceConnector {
+
+    @Override
+    public ConfigDef config() {
+        return CamelAzureeventhubsSourceConnectorConfig.conf();
+    }
+    @Override
+    public Class<? extends Task> taskClass() {
+        return CamelAzureeventhubsSourceTask.class;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceConnectorConfig.java b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceConnectorConfig.java
new file mode 100644
index 0000000..bbb09bb
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceConnectorConfig.java
@@ -0,0 +1,197 @@
+/*
+ * 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.kafkaconnector.azureeventhubs;
+
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSourceConnectorConfig;
+import org.apache.kafka.common.config.ConfigDef;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAzureeventhubsSourceConnectorConfig
+        extends
+            CamelSourceConnectorConfig {
+
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_PATH_NAMESPACE_CONF = "camel.source.path.namespace";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_PATH_NAMESPACE_DOC = "EventHubs namespace created in Azure Portal";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_PATH_NAMESPACE_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_CONF = "camel.source.path.eventHubName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DOC = "EventHubs name under a specific namcespace";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_CONF = "camel.source.endpoint.amqpRetryOptions";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DOC = "Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_CONF = "camel.source.endpoint.amqpTransportType";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DOC = "Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets]";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DEFAULT = "AMQP";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCESS_KEY_CONF = "camel.source.endpoint.blobAccessKey";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCESS_KEY_DOC = "In case you chose the default BlobCheckpointStore, this sets access key for the associated azure account name to be used for authentication with azure blob services";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCOUNT_NAME_CONF = "camel.source.endpoint.blobAccountName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCOUNT_NAME_DOC = "In case you chose the default BlobCheckpointStore, this sets Azure account name to be used for authentication with azure blob services.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCOUNT_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_CONTAINER_NAME_CONF = "camel.source.endpoint.blobContainerName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_CONTAINER_NAME_DOC = "In case you chose the default BlobCheckpointStore, this sets the blob container that shall be used by the BlobCheckpointStore to store the checkpoint offsets";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_CONTAINER_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_CONF = "camel.source.endpoint.blobStorageSharedKeyCredential";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DOC = "In case you chose the default BlobCheckpointStore, StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF = "camel.source.endpoint.bridgeErrorHandler";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level  [...]
+    public static final Boolean CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CHECKPOINT_STORE_CONF = "camel.source.endpoint.checkpointStore";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CHECKPOINT_STORE_DOC = "Sets the CheckpointStore the EventProcessorClient will use for storing partition ownership and checkpoint information. Users can, optionally, provide their own implementation of CheckpointStore which will store ownership and checkpoint information. By default it set to use com.azure.messaging.eventhubs.checkpointstore.blob.BlobCheckpointStore which stores all checkpoint offsets into Azure Blob Storage";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CHECKPOINT_STORE_DEFAULT = "BlobCheckpointStore";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONSUMER_GROUP_NAME_CONF = "camel.source.endpoint.consumerGroupName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONSUMER_GROUP_NAME_DOC = "Sets the name of the consumer group this consumer is associated with. Events are read in the context of this group. The name of the consumer group that is created by default is {link #DEFAULT_CONSUMER_GROUP_NAME $Default}.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONSUMER_GROUP_NAME_DEFAULT = "$Default";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EVENT_POSITION_CONF = "camel.source.endpoint.eventPosition";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EVENT_POSITION_DOC = "Sets the map containing the event position to use for each partition if a checkpoint for the partition does not exist in CheckpointStore. This map is keyed off of the partition id. If there is no checkpoint in CheckpointStore and there is no entry in this map, the processing of the partition will start from {link EventPosition#latest() latest} position.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EVENT_POSITION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_PREFETCH_COUNT_CONF = "camel.source.endpoint.prefetchCount";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_PREFETCH_COUNT_DOC = "Sets the count used by the receiver to control the number of events the Event Hub consumer will actively receive and queue locally without regard to whether a receive operation is currently active.";
+    public static final Integer CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_PREFETCH_COUNT_DEFAULT = 500;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCEPTION_HANDLER_CONF = "camel.source.endpoint.exceptionHandler";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCEPTION_HANDLER_DOC = "To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCEPTION_HANDLER_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCHANGE_PATTERN_CONF = "camel.source.endpoint.exchangePattern";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCHANGE_PATTERN_DOC = "Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut]";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCHANGE_PATTERN_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.source.endpoint.basicPropertyBinding";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_CONF = "camel.source.endpoint.synchronous";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
+    public static final Boolean CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_CONF = "camel.source.endpoint.connectionString";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DOC = "Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-ge [...]
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_CONF = "camel.source.endpoint.sharedAccessKey";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DOC = "The generated value for the SharedAccessName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_CONF = "camel.source.endpoint.sharedAccessName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DOC = "The name you chose for your EventHubs SAS keys";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_CONF = "camel.component.azure-eventhubs.amqpRetryOptions";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DOC = "Sets the retry policy for EventHubAsyncClient. If not specified, the default retry options are used.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_CONF = "camel.component.azure-eventhubs.amqpTransportType";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DOC = "Sets the transport type by which all the communication with Azure Event Hubs occurs. Default value is AmqpTransportType#AMQP. One of: [Amqp] [AmqpWebSockets]";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DEFAULT = "AMQP";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.azure-eventhubs.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_CONF = "camel.component.azure-eventhubs.configuration";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DOC = "The component configurations";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCESS_KEY_CONF = "camel.component.azure-eventhubs.blobAccessKey";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCESS_KEY_DOC = "In case you chose the default BlobCheckpointStore, this sets access key for the associated azure account name to be used for authentication with azure blob services";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCOUNT_NAME_CONF = "camel.component.azure-eventhubs.blobAccountName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCOUNT_NAME_DOC = "In case you chose the default BlobCheckpointStore, this sets Azure account name to be used for authentication with azure blob services.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCOUNT_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_CONTAINER_NAME_CONF = "camel.component.azure-eventhubs.blobContainerName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_CONTAINER_NAME_DOC = "In case you chose the default BlobCheckpointStore, this sets the blob container that shall be used by the BlobCheckpointStore to store the checkpoint offsets";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_CONTAINER_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_CONF = "camel.component.azure-eventhubs.blobStorageSharedKeyCredential";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DOC = "In case you chose the default BlobCheckpointStore, StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.azure-eventhubs.bridgeErrorHandler";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level [...]
+    public static final Boolean CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CHECKPOINT_STORE_CONF = "camel.component.azure-eventhubs.checkpointStore";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CHECKPOINT_STORE_DOC = "Sets the CheckpointStore the EventProcessorClient will use for storing partition ownership and checkpoint information. Users can, optionally, provide their own implementation of CheckpointStore which will store ownership and checkpoint information. By default it set to use com.azure.messaging.eventhubs.checkpointstore.blob.BlobCheckpointStore which stores all checkpoint offsets into Azure Blob Storage";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CHECKPOINT_STORE_DEFAULT = "BlobCheckpointStore";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONSUMER_GROUP_NAME_CONF = "camel.component.azure-eventhubs.consumerGroupName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONSUMER_GROUP_NAME_DOC = "Sets the name of the consumer group this consumer is associated with. Events are read in the context of this group. The name of the consumer group that is created by default is {link #DEFAULT_CONSUMER_GROUP_NAME $Default}.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONSUMER_GROUP_NAME_DEFAULT = "$Default";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_EVENT_POSITION_CONF = "camel.component.azure-eventhubs.eventPosition";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_EVENT_POSITION_DOC = "Sets the map containing the event position to use for each partition if a checkpoint for the partition does not exist in CheckpointStore. This map is keyed off of the partition id. If there is no checkpoint in CheckpointStore and there is no entry in this map, the processing of the partition will start from {link EventPosition#latest() latest} position.";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_EVENT_POSITION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_PREFETCH_COUNT_CONF = "camel.component.azure-eventhubs.prefetchCount";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_PREFETCH_COUNT_DOC = "Sets the count used by the receiver to control the number of events the Event Hub consumer will actively receive and queue locally without regard to whether a receive operation is currently active.";
+    public static final Integer CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_PREFETCH_COUNT_DEFAULT = 500;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.azure-eventhubs.basicPropertyBinding";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
+    public static final Boolean CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_CONF = "camel.component.azure-eventhubs.connectionString";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DOC = "Instead of supplying namespace, sharedAccessKey, sharedAccessName ... etc, you can just supply the connection string for your eventHub. The connection string for EventHubs already include all the necessary information to connection to your EventHub. To learn on how to generate the connection string, take a look at this documentation: https://docs.microsoft.com/en-us/azure/event-hubs/event-hubs-g [...]
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_CONF = "camel.component.azure-eventhubs.sharedAccessKey";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DOC = "The generated value for the SharedAccessName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_CONF = "camel.component.azure-eventhubs.sharedAccessName";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DOC = "The name you chose for your EventHubs SAS keys";
+    public static final String CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DEFAULT = null;
+
+    public CamelAzureeventhubsSourceConnectorConfig(
+            ConfigDef config,
+            Map<String, String> parsedConfig) {
+        super(config, parsedConfig);
+    }
+
+    public CamelAzureeventhubsSourceConnectorConfig(
+            Map<String, String> parsedConfig) {
+        this(conf(), parsedConfig);
+    }
+
+    public static ConfigDef conf() {
+        ConfigDef conf = new ConfigDef(CamelSourceConnectorConfig.conf());
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_PATH_NAMESPACE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_PATH_NAMESPACE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_PATH_NAMESPACE_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_PATH_EVENT_HUB_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_RETRY_OPTIONS_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AMQP_TRANSPORT_TYPE_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCOUNT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCOUNT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_ACCOUNT_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_CONTAINER_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_CONTAINER_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_CONTAINER_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CHECKPOINT_STORE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CHECKPOINT_STORE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CHECKPOINT_STORE_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONSUMER_GROUP_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONSUMER_GROUP_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONSUMER_GROUP_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EVENT_POSITION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EVENT_POSITION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EVENT_POSITION_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_PREFETCH_COUNT_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_PREFETCH_COUNT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_PREFETCH_COUNT_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCEPTION_HANDLER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCEPTION_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCEPTION_HANDLER_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCHANGE_PATTERN_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCHANGE_PATTERN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_EXCHANGE_PATTERN_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SYNCHRONOUS_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_CONNECTION_STRING_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_ENDPOINT_SHARED_ACCESS_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_RETRY_OPTIONS_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AMQP_TRANSPORT_TYPE_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONFIGURATION_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCOUNT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCOUNT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_ACCOUNT_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_CONTAINER_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_CONTAINER_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_CONTAINER_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BLOB_STORAGE_SHARED_KEY_CREDENTIAL_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CHECKPOINT_STORE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CHECKPOINT_STORE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CHECKPOINT_STORE_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONSUMER_GROUP_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONSUMER_GROUP_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONSUMER_GROUP_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_EVENT_POSITION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_EVENT_POSITION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_EVENT_POSITION_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_PREFETCH_COUNT_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_PREFETCH_COUNT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_PREFETCH_COUNT_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_CONNECTION_STRING_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZUREEVENTHUBS_COMPONENT_SHARED_ACCESS_NAME_DOC);
+        return conf;
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceTask.java b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceTask.java
new file mode 100644
index 0000000..888720d
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azureeventhubs/CamelAzureeventhubsSourceTask.java
@@ -0,0 +1,39 @@
+/*
+ * 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.kafkaconnector.azureeventhubs;
+
+import java.util.HashMap;
+import java.util.Map;
+import javax.annotation.Generated;
+import org.apache.camel.kafkaconnector.CamelSourceConnectorConfig;
+import org.apache.camel.kafkaconnector.CamelSourceTask;
+
+@Generated("This class has been generated by camel-kafka-connector-generator-maven-plugin, remove this annotation to prevent it from being generated.")
+public class CamelAzureeventhubsSourceTask extends CamelSourceTask {
+
+    @Override
+    protected CamelSourceConnectorConfig getCamelSourceConnectorConfig(
+            Map<String, String> props) {
+        return new CamelAzureeventhubsSourceConnectorConfig(props);
+    }
+    @Override
+    protected Map<String, String> getDefaultConfig() {
+        return new HashMap<String, String>() {{
+            put(CamelSourceConnectorConfig.CAMEL_SOURCE_COMPONENT_CONF, "azure-eventhubs");
+        }};
+    }
+}
\ No newline at end of file
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/resources/META-INF/LICENSE.txt b/connectors/camel-azure-eventhubs-kafka-connector/src/main/resources/META-INF/LICENSE.txt
new file mode 100644
index 0000000..6b0b127
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/resources/META-INF/LICENSE.txt
@@ -0,0 +1,203 @@
+
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+   END OF TERMS AND CONDITIONS
+
+   APPENDIX: How to apply the Apache License to your work.
+
+      To apply the Apache License to your work, attach the following
+      boilerplate notice, with the fields enclosed by brackets "[]"
+      replaced with your own identifying information. (Don't include
+      the brackets!)  The text should be enclosed in the appropriate
+      comment syntax for the file format. We also recommend that a
+      file or class name and description of purpose be included on the
+      same "printed page" as the copyright notice for easier
+      identification within third-party archives.
+
+   Copyright [yyyy] [name of copyright owner]
+
+   Licensed 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.
+
diff --git a/connectors/camel-azure-eventhubs-kafka-connector/src/main/resources/META-INF/NOTICE.txt b/connectors/camel-azure-eventhubs-kafka-connector/src/main/resources/META-INF/NOTICE.txt
new file mode 100644
index 0000000..2e215bf
--- /dev/null
+++ b/connectors/camel-azure-eventhubs-kafka-connector/src/main/resources/META-INF/NOTICE.txt
@@ -0,0 +1,11 @@
+   =========================================================================
+   ==  NOTICE file corresponding to the section 4 d of                    ==
+   ==  the Apache License, Version 2.0,                                   ==
+   ==  in this case for the Apache Camel distribution.                    ==
+   =========================================================================
+
+   This product includes software developed by
+   The Apache Software Foundation (http://www.apache.org/).
+
+   Please read the different LICENSE files present in the licenses directory of
+   this distribution.
diff --git a/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-sink-connector.adoc b/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-sink-connector.adoc
index 66baf67..b86ba85 100644
--- a/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-sink-connector.adoc
+++ b/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-azure-storage-blob-kafka-connector as sink make sure to use the
 ----
 
 
-The camel-azure-storage-blob sink connector supports 33 options, which are listed below.
+The camel-azure-storage-blob sink connector supports 55 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-azure-storage-blob sink connector supports 33 options, which are liste
 | Name | Description | Default | Priority
 | *camel.sink.path.accountName* | Azure account name to be used for authentication with azure blob services | null | MEDIUM
 | *camel.sink.path.containerName* | The blob container name | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.blobName* | The blob name, required for consumer. However on producer, is only required for the operations on the blob level | null | MEDIUM
 | *camel.sink.endpoint.blobOffset* | Set the blob offset for the upload or download operations, default is 0 | 0L | MEDIUM
 | *camel.sink.endpoint.blobServiceClient* | Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContainerClient(String), and operations on a blob are [...]
@@ -32,14 +33,25 @@ The camel-azure-storage-blob sink connector supports 33 options, which are liste
 | *camel.sink.endpoint.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
 | *camel.sink.endpoint.dataCount* | How many bytes to include in the range. Must be greater than or equal to 0 if specified. | null | MEDIUM
 | *camel.sink.endpoint.fileDir* | The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer | null | MEDIUM
+| *camel.sink.endpoint.maxResultsPerPage* | Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items. | null | MEDIUM
 | *camel.sink.endpoint.maxRetryRequests* | Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body. | 0 | MEDIUM
+| *camel.sink.endpoint.prefix* | Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs. | null | MEDIUM
 | *camel.sink.endpoint.serviceClient* | Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContainerClient(String), and operations on a blob are ava [...]
+| *camel.sink.endpoint.timeout* | An optional timeout value beyond which a RuntimeException will be raised. | null | MEDIUM
+| *camel.sink.endpoint.blobSequenceNumber* | A user-controlled value that you can use to track requests. The value of the sequence number must be between 0 and 263 - 1.The default value is 0. | "0" | MEDIUM
+| *camel.sink.endpoint.blockListType* | Specifies which type of blocks to return. One of: [committed] [uncommitted] [all] | "COMMITTED" | MEDIUM
 | *camel.sink.endpoint.closeStreamAfterWrite* | Close the stream after write or keep it open, default is true | true | MEDIUM
+| *camel.sink.endpoint.commitBlockListLater* | When is set to true, the staged blocks will not be committed directly. | true | MEDIUM
+| *camel.sink.endpoint.createAppendBlob* | When is set to true, the append blocks will be created when committing append blocks. | true | MEDIUM
+| *camel.sink.endpoint.createPageBlob* | When is set to true, the page blob will be created when uploading page blob. | true | MEDIUM
+| *camel.sink.endpoint.downloadLinkExpiration* | Override the default expiration (millis) of URL download link. | null | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.operation* | The blob operation that can be used with this component on the producer One of: [listBlobContainers] [createBlobContainer] [deleteBlobContainer] [listBlobs] [getBlob] [deleteBlob] [downloadBlobToFile] [downloadLink] [uploadBlockBlob] [stageBlockBlobList] [commitBlobBlockList] [getBlobBlockList] [createAppendBlob] [commitAppendBlob] [createPageBlob] [uploadPageBlob] [resizePageBlob] [clearPageBlob] [getPageBlobRanges] | "listBlobContainers" | MEDIUM
+| *camel.sink.endpoint.pageBlobSize* | Specifies the maximum size for the page blob, up to 8 TB. The page blob size must be aligned to a 512-byte boundary. | "512" | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.accessKey* | Access key for the associated azure account name to be used for authentication with azure blob services | null | MEDIUM
+| *camel.component.azure-storage-blob.autoDiscover Client* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.azure-storage-blob.blobName* | The blob name, required for consumer. However on producer, is only required for the operations on the blob level | null | MEDIUM
 | *camel.component.azure-storage-blob.blobOffset* | Set the blob offset for the upload or download operations, default is 0 | 0L | MEDIUM
 | *camel.component.azure-storage-blob.blobType* | The blob type in order to initiate the appropriate settings for each blob type One of: [blockblob] [appendblob] [pageblob] | "blockblob" | MEDIUM
@@ -48,14 +60,22 @@ The camel-azure-storage-blob sink connector supports 33 options, which are liste
 | *camel.component.azure-storage-blob.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
 | *camel.component.azure-storage-blob.dataCount* | How many bytes to include in the range. Must be greater than or equal to 0 if specified. | null | MEDIUM
 | *camel.component.azure-storage-blob.fileDir* | The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer | null | MEDIUM
+| *camel.component.azure-storage-blob.maxResultsPer Page* | Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items. | null | MEDIUM
 | *camel.component.azure-storage-blob.maxRetry Requests* | Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body. | 0 | MEDIUM
+| *camel.component.azure-storage-blob.prefix* | Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs. | null | MEDIUM
 | *camel.component.azure-storage-blob.serviceClient* | Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContainerClient(String), and operations on [...]
+| *camel.component.azure-storage-blob.timeout* | An optional timeout value beyond which a RuntimeException will be raised. | null | MEDIUM
+| *camel.component.azure-storage-blob.blobSequence Number* | A user-controlled value that you can use to track requests. The value of the sequence number must be between 0 and 263 - 1.The default value is 0. | "0" | MEDIUM
+| *camel.component.azure-storage-blob.blockListType* | Specifies which type of blocks to return. One of: [committed] [uncommitted] [all] | "COMMITTED" | MEDIUM
 | *camel.component.azure-storage-blob.closeStream AfterWrite* | Close the stream after write or keep it open, default is true | true | MEDIUM
+| *camel.component.azure-storage-blob.commitBlockList Later* | When is set to true, the staged blocks will not be committed directly. | true | MEDIUM
+| *camel.component.azure-storage-blob.createAppend Blob* | When is set to true, the append blocks will be created when committing append blocks. | true | MEDIUM
+| *camel.component.azure-storage-blob.createPageBlob* | When is set to true, the page blob will be created when uploading page blob. | true | MEDIUM
+| *camel.component.azure-storage-blob.downloadLink Expiration* | Override the default expiration (millis) of URL download link. | null | MEDIUM
 | *camel.component.azure-storage-blob.lazyStart Producer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is pr [...]
 | *camel.component.azure-storage-blob.operation* | The blob operation that can be used with this component on the producer One of: [listBlobContainers] [createBlobContainer] [deleteBlobContainer] [listBlobs] [getBlob] [deleteBlob] [downloadBlobToFile] [downloadLink] [uploadBlockBlob] [stageBlockBlobList] [commitBlobBlockList] [getBlobBlockList] [createAppendBlob] [commitAppendBlob] [createPageBlob] [uploadPageBlob] [resizePageBlob] [clearPageBlob] [getPageBlobRanges] | "listBlobContainer [...]
+| *camel.component.azure-storage-blob.pageBlobSize* | Specifies the maximum size for the page blob, up to 8 TB. The page blob size must be aligned to a 512-byte boundary. | "512" | MEDIUM
 | *camel.component.azure-storage-blob.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.azure-storage-blob.accessKey* | Access key for the associated azure account name to be used for authentication with azure blob services | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-source-connector.adoc b/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-source-connector.adoc
index ca57ddf..c55a017 100644
--- a/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-source-connector.adoc
+++ b/connectors/camel-azure-storage-blob-kafka-connector/src/main/docs/camel-azure-storage-blob-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-azure-storage-blob-kafka-connector as source make sure to use t
 ----
 
 
-The camel-azure-storage-blob source connector supports 31 options, which are listed below.
+The camel-azure-storage-blob source connector supports 39 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-azure-storage-blob source connector supports 31 options, which are lis
 | Name | Description | Default | Priority
 | *camel.source.path.accountName* | Azure account name to be used for authentication with azure blob services | null | MEDIUM
 | *camel.source.path.containerName* | The blob container name | null | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.source.endpoint.blobName* | The blob name, required for consumer. However on producer, is only required for the operations on the blob level | null | MEDIUM
 | *camel.source.endpoint.blobOffset* | Set the blob offset for the upload or download operations, default is 0 | 0L | MEDIUM
 | *camel.source.endpoint.blobServiceClient* | Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContainerClient(String), and operations on a blob a [...]
@@ -32,14 +33,18 @@ The camel-azure-storage-blob source connector supports 31 options, which are lis
 | *camel.source.endpoint.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
 | *camel.source.endpoint.dataCount* | How many bytes to include in the range. Must be greater than or equal to 0 if specified. | null | MEDIUM
 | *camel.source.endpoint.fileDir* | The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer | null | MEDIUM
+| *camel.source.endpoint.maxResultsPerPage* | Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items. | null | MEDIUM
 | *camel.source.endpoint.maxRetryRequests* | Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body. | 0 | MEDIUM
+| *camel.source.endpoint.prefix* | Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs. | null | MEDIUM
 | *camel.source.endpoint.serviceClient* | Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContainerClient(String), and operations on a blob are a [...]
+| *camel.source.endpoint.timeout* | An optional timeout value beyond which a RuntimeException will be raised. | null | MEDIUM
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.exceptionHandler* | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored. | null | MEDIUM
 | *camel.source.endpoint.exchangePattern* | Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut] | null | MEDIUM
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.source.endpoint.accessKey* | Access key for the associated azure account name to be used for authentication with azure blob services | null | MEDIUM
+| *camel.component.azure-storage-blob.autoDiscover Client* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.azure-storage-blob.blobName* | The blob name, required for consumer. However on producer, is only required for the operations on the blob level | null | MEDIUM
 | *camel.component.azure-storage-blob.blobOffset* | Set the blob offset for the upload or download operations, default is 0 | 0L | MEDIUM
 | *camel.component.azure-storage-blob.blobType* | The blob type in order to initiate the appropriate settings for each blob type One of: [blockblob] [appendblob] [pageblob] | "blockblob" | MEDIUM
@@ -48,12 +53,13 @@ The camel-azure-storage-blob source connector supports 31 options, which are lis
 | *camel.component.azure-storage-blob.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
 | *camel.component.azure-storage-blob.dataCount* | How many bytes to include in the range. Must be greater than or equal to 0 if specified. | null | MEDIUM
 | *camel.component.azure-storage-blob.fileDir* | The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer | null | MEDIUM
+| *camel.component.azure-storage-blob.maxResultsPer Page* | Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items. | null | MEDIUM
 | *camel.component.azure-storage-blob.maxRetry Requests* | Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body. | 0 | MEDIUM
+| *camel.component.azure-storage-blob.prefix* | Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs. | null | MEDIUM
 | *camel.component.azure-storage-blob.serviceClient* | Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContainerClient(String), and operations on [...]
+| *camel.component.azure-storage-blob.timeout* | An optional timeout value beyond which a RuntimeException will be raised. | null | MEDIUM
 | *camel.component.azure-storage-blob.bridgeError Handler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.azure-storage-blob.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.azure-storage-blob.accessKey* | Access key for the associated azure account name to be used for authentication with azure blob services | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSinkConnectorConfig.java b/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSinkConnectorConfig.java
index 7166175..f4e8c9f 100644
--- a/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSinkConnectorConfig.java
+++ b/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSinkConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAzurestorageblobSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_CONF = "camel.sink.path.containerName";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DOC = "The blob container name";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_CONF = "camel.sink.endpoint.blobName";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DOC = "The blob name, required for consumer. However on producer, is only required for the operations on the blob level";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DEFAULT = null;
@@ -56,21 +59,51 @@ public class CamelAzurestorageblobSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_CONF = "camel.sink.endpoint.fileDir";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DOC = "The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_CONF = "camel.sink.endpoint.maxResultsPerPage";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DOC = "Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_CONF = "camel.sink.endpoint.maxRetryRequests";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DOC = "Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body.";
     public static final Integer CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DEFAULT = 0;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PREFIX_CONF = "camel.sink.endpoint.prefix";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DOC = "Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_CONF = "camel.sink.endpoint.serviceClient";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DOC = "Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContain [...]
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_CONF = "camel.sink.endpoint.timeout";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DOC = "An optional timeout value beyond which a RuntimeException will be raised.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SEQUENCE_NUMBER_CONF = "camel.sink.endpoint.blobSequenceNumber";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SEQUENCE_NUMBER_DOC = "A user-controlled value that you can use to track requests. The value of the sequence number must be between 0 and 263 - 1.The default value is 0.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SEQUENCE_NUMBER_DEFAULT = "0";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOCK_LIST_TYPE_CONF = "camel.sink.endpoint.blockListType";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOCK_LIST_TYPE_DOC = "Specifies which type of blocks to return. One of: [committed] [uncommitted] [all]";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOCK_LIST_TYPE_DEFAULT = "COMMITTED";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CLOSE_STREAM_AFTER_WRITE_CONF = "camel.sink.endpoint.closeStreamAfterWrite";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CLOSE_STREAM_AFTER_WRITE_DOC = "Close the stream after write or keep it open, default is true";
     public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CLOSE_STREAM_AFTER_WRITE_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_COMMIT_BLOCK_LIST_LATER_CONF = "camel.sink.endpoint.commitBlockListLater";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_COMMIT_BLOCK_LIST_LATER_DOC = "When is set to true, the staged blocks will not be committed directly.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_COMMIT_BLOCK_LIST_LATER_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_APPEND_BLOB_CONF = "camel.sink.endpoint.createAppendBlob";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_APPEND_BLOB_DOC = "When is set to true, the append blocks will be created when committing append blocks.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_APPEND_BLOB_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_PAGE_BLOB_CONF = "camel.sink.endpoint.createPageBlob";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_PAGE_BLOB_DOC = "When is set to true, the page blob will be created when uploading page blob.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_PAGE_BLOB_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DOWNLOAD_LINK_EXPIRATION_CONF = "camel.sink.endpoint.downloadLinkExpiration";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DOWNLOAD_LINK_EXPIRATION_DOC = "Override the default expiration (millis) of URL download link.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DOWNLOAD_LINK_EXPIRATION_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Bewar [...]
     public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_OPERATION_CONF = "camel.sink.endpoint.operation";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_OPERATION_DOC = "The blob operation that can be used with this component on the producer One of: [listBlobContainers] [createBlobContainer] [deleteBlobContainer] [listBlobs] [getBlob] [deleteBlob] [downloadBlobToFile] [downloadLink] [uploadBlockBlob] [stageBlockBlobList] [commitBlobBlockList] [getBlobBlockList] [createAppendBlob] [commitAppendBlob] [createPageBlob] [uploadPageBlob] [resizePageBlob] [clearPageBlob] [getPa [...]
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_OPERATION_DEFAULT = "listBlobContainers";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PAGE_BLOB_SIZE_CONF = "camel.sink.endpoint.pageBlobSize";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PAGE_BLOB_SIZE_DOC = "Specifies the maximum size for the page blob, up to 8 TB. The page blob size must be aligned to a 512-byte boundary.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PAGE_BLOB_SIZE_DEFAULT = "512";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -80,6 +113,9 @@ public class CamelAzurestorageblobSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_CONF = "camel.sink.endpoint.accessKey";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DOC = "Access key for the associated azure account name to be used for authentication with azure blob services";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.azure-storage-blob.autoDiscoverClient";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_CONF = "camel.component.azure-storage-blob.blobName";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DOC = "The blob name, required for consumer. However on producer, is only required for the operations on the blob level";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DEFAULT = null;
@@ -104,21 +140,51 @@ public class CamelAzurestorageblobSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_CONF = "camel.component.azure-storage-blob.fileDir";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DOC = "The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_CONF = "camel.component.azure-storage-blob.maxResultsPerPage";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DOC = "Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_CONF = "camel.component.azure-storage-blob.maxRetryRequests";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DOC = "Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body.";
     public static final Integer CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DEFAULT = 0;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PREFIX_CONF = "camel.component.azure-storage-blob.prefix";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PREFIX_DOC = "Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PREFIX_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_CONF = "camel.component.azure-storage-blob.serviceClient";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DOC = "Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobContai [...]
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_CONF = "camel.component.azure-storage-blob.timeout";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DOC = "An optional timeout value beyond which a RuntimeException will be raised.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_SEQUENCE_NUMBER_CONF = "camel.component.azure-storage-blob.blobSequenceNumber";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_SEQUENCE_NUMBER_DOC = "A user-controlled value that you can use to track requests. The value of the sequence number must be between 0 and 263 - 1.The default value is 0.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_SEQUENCE_NUMBER_DEFAULT = "0";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOCK_LIST_TYPE_CONF = "camel.component.azure-storage-blob.blockListType";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOCK_LIST_TYPE_DOC = "Specifies which type of blocks to return. One of: [committed] [uncommitted] [all]";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOCK_LIST_TYPE_DEFAULT = "COMMITTED";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CLOSE_STREAM_AFTER_WRITE_CONF = "camel.component.azure-storage-blob.closeStreamAfterWrite";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CLOSE_STREAM_AFTER_WRITE_DOC = "Close the stream after write or keep it open, default is true";
     public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CLOSE_STREAM_AFTER_WRITE_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_COMMIT_BLOCK_LIST_LATER_CONF = "camel.component.azure-storage-blob.commitBlockListLater";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_COMMIT_BLOCK_LIST_LATER_DOC = "When is set to true, the staged blocks will not be committed directly.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_COMMIT_BLOCK_LIST_LATER_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_APPEND_BLOB_CONF = "camel.component.azure-storage-blob.createAppendBlob";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_APPEND_BLOB_DOC = "When is set to true, the append blocks will be created when committing append blocks.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_APPEND_BLOB_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_PAGE_BLOB_CONF = "camel.component.azure-storage-blob.createPageBlob";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_PAGE_BLOB_DOC = "When is set to true, the page blob will be created when uploading page blob.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_PAGE_BLOB_DEFAULT = true;
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DOWNLOAD_LINK_EXPIRATION_CONF = "camel.component.azure-storage-blob.downloadLinkExpiration";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DOWNLOAD_LINK_EXPIRATION_DOC = "Override the default expiration (millis) of URL download link.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DOWNLOAD_LINK_EXPIRATION_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.azure-storage-blob.lazyStartProducer";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Bewa [...]
     public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_OPERATION_CONF = "camel.component.azure-storage-blob.operation";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_OPERATION_DOC = "The blob operation that can be used with this component on the producer One of: [listBlobContainers] [createBlobContainer] [deleteBlobContainer] [listBlobs] [getBlob] [deleteBlob] [downloadBlobToFile] [downloadLink] [uploadBlockBlob] [stageBlockBlobList] [commitBlobBlockList] [getBlobBlockList] [createAppendBlob] [commitAppendBlob] [createPageBlob] [uploadPageBlob] [resizePageBlob] [clearPageBlob] [getP [...]
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_OPERATION_DEFAULT = "listBlobContainers";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PAGE_BLOB_SIZE_CONF = "camel.component.azure-storage-blob.pageBlobSize";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PAGE_BLOB_SIZE_DOC = "Specifies the maximum size for the page blob, up to 8 TB. The page blob size must be aligned to a 512-byte boundary.";
+    public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PAGE_BLOB_SIZE_DEFAULT = "512";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.azure-storage-blob.basicPropertyBinding";
     public static final String CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -141,6 +207,7 @@ public class CamelAzurestorageblobSinkConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_PATH_ACCOUNT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_PATH_ACCOUNT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_PATH_ACCOUNT_NAME_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_OFFSET_CONF, ConfigDef.Type.LONG, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_OFFSET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_OFFSET_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SERVICE_CLIENT_DOC);
@@ -149,14 +216,25 @@ public class CamelAzurestorageblobSinkConnectorConfig
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREDENTIALS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREDENTIALS_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DATA_COUNT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DATA_COUNT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DATA_COUNT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_CONF, ConfigDef.Type.INT, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SEQUENCE_NUMBER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SEQUENCE_NUMBER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOB_SEQUENCE_NUMBER_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOCK_LIST_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOCK_LIST_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BLOCK_LIST_TYPE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CLOSE_STREAM_AFTER_WRITE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CLOSE_STREAM_AFTER_WRITE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CLOSE_STREAM_AFTER_WRITE_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_COMMIT_BLOCK_LIST_LATER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_COMMIT_BLOCK_LIST_LATER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_COMMIT_BLOCK_LIST_LATER_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_APPEND_BLOB_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_APPEND_BLOB_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_APPEND_BLOB_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_PAGE_BLOB_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_PAGE_BLOB_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_CREATE_PAGE_BLOB_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DOWNLOAD_LINK_EXPIRATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DOWNLOAD_LINK_EXPIRATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_DOWNLOAD_LINK_EXPIRATION_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_OPERATION_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PAGE_BLOB_SIZE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PAGE_BLOB_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_PAGE_BLOB_SIZE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_OFFSET_CONF, ConfigDef.Type.LONG, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_OFFSET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_OFFSET_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_TYPE_DOC);
@@ -165,11 +243,21 @@ public class CamelAzurestorageblobSinkConnectorConfig
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREDENTIALS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREDENTIALS_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DATA_COUNT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DATA_COUNT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DATA_COUNT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_CONF, ConfigDef.Type.INT, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PREFIX_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_SEQUENCE_NUMBER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_SEQUENCE_NUMBER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOB_SEQUENCE_NUMBER_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOCK_LIST_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOCK_LIST_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BLOCK_LIST_TYPE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CLOSE_STREAM_AFTER_WRITE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CLOSE_STREAM_AFTER_WRITE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CLOSE_STREAM_AFTER_WRITE_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_COMMIT_BLOCK_LIST_LATER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_COMMIT_BLOCK_LIST_LATER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_COMMIT_BLOCK_LIST_LATER_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_APPEND_BLOB_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_APPEND_BLOB_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_APPEND_BLOB_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_PAGE_BLOB_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_PAGE_BLOB_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_CREATE_PAGE_BLOB_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DOWNLOAD_LINK_EXPIRATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DOWNLOAD_LINK_EXPIRATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_DOWNLOAD_LINK_EXPIRATION_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_OPERATION_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PAGE_BLOB_SIZE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PAGE_BLOB_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_PAGE_BLOB_SIZE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEBLOB_COMPONENT_ACCESS_KEY_DOC);
         return conf;
diff --git a/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSourceConnectorConfig.java b/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSourceConnectorConfig.java
index a72c093..fae5fe9 100644
--- a/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSourceConnectorConfig.java
+++ b/connectors/camel-azure-storage-blob-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestorageblob/CamelAzurestorageblobSourceConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAzurestorageblobSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_CONF = "camel.source.path.containerName";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DOC = "The blob container name";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_CONF = "camel.source.endpoint.blobName";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DOC = "The blob name, required for consumer. However on producer, is only required for the operations on the blob level";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DEFAULT = null;
@@ -56,12 +59,21 @@ public class CamelAzurestorageblobSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_CONF = "camel.source.endpoint.fileDir";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DOC = "The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_CONF = "camel.source.endpoint.maxResultsPerPage";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DOC = "Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_CONF = "camel.source.endpoint.maxRetryRequests";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DOC = "Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body.";
     public static final Integer CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DEFAULT = 0;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_PREFIX_CONF = "camel.source.endpoint.prefix";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DOC = "Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_CONF = "camel.source.endpoint.serviceClient";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DOC = "Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobConta [...]
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_CONF = "camel.source.endpoint.timeout";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DOC = "An optional timeout value beyond which a RuntimeException will be raised.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF = "camel.source.endpoint.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR leve [...]
     public static final Boolean CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
@@ -80,6 +92,9 @@ public class CamelAzurestorageblobSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_CONF = "camel.source.endpoint.accessKey";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DOC = "Access key for the associated azure account name to be used for authentication with azure blob services";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.azure-storage-blob.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_CONF = "camel.component.azure-storage-blob.blobName";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DOC = "The blob name, required for consumer. However on producer, is only required for the operations on the blob level";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DEFAULT = null;
@@ -104,12 +119,21 @@ public class CamelAzurestorageblobSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_CONF = "camel.component.azure-storage-blob.fileDir";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DOC = "The file directory where the downloaded blobs will be saved to, this can be used in both, producer and consumer";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_CONF = "camel.component.azure-storage-blob.maxResultsPerPage";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DOC = "Specifies the maximum number of blobs to return, including all BlobPrefix elements. If the request does not specify maxResultsPerPage or specifies a value greater than 5,000, the server will return up to 5,000 items.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_CONF = "camel.component.azure-storage-blob.maxRetryRequests";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DOC = "Specifies the maximum number of additional HTTP Get requests that will be made while reading the data from a response body.";
     public static final Integer CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DEFAULT = 0;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_PREFIX_CONF = "camel.component.azure-storage-blob.prefix";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_PREFIX_DOC = "Filters the results to return only blobs whose names begin with the specified prefix. May be null to return all blobs.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_PREFIX_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_CONF = "camel.component.azure-storage-blob.serviceClient";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DOC = "Client to a storage account. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. It may also be used to construct URLs to blobs and containers. This client contains operations on a service account. Operations on a container are available on BlobContainerClient through getBlobCont [...]
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_CONF = "camel.component.azure-storage-blob.timeout";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DOC = "An optional timeout value beyond which a RuntimeException will be raised.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.azure-storage-blob.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR lev [...]
     public static final Boolean CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
@@ -135,6 +159,7 @@ public class CamelAzurestorageblobSourceConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSourceConnectorConfig.conf());
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_ACCOUNT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_ACCOUNT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_ACCOUNT_NAME_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_PATH_CONTAINER_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_NAME_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_OFFSET_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_OFFSET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_OFFSET_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BLOB_SERVICE_CLIENT_DOC);
@@ -143,14 +168,18 @@ public class CamelAzurestorageblobSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_CREDENTIALS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_CREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_CREDENTIALS_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_DATA_COUNT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_DATA_COUNT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_DATA_COUNT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_FILE_DIR_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RESULTS_PER_PAGE_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_MAX_RETRY_REQUESTS_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_PREFIX_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SERVICE_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_TIMEOUT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_EXCEPTION_HANDLER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_EXCEPTION_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_EXCEPTION_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_EXCHANGE_PATTERN_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_EXCHANGE_PATTERN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_EXCHANGE_PATTERN_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_ENDPOINT_ACCESS_KEY_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_NAME_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_OFFSET_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_OFFSET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_OFFSET_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_TYPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_TYPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BLOB_TYPE_DOC);
@@ -159,8 +188,11 @@ public class CamelAzurestorageblobSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_CREDENTIALS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_CREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_CREDENTIALS_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_DATA_COUNT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_DATA_COUNT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_DATA_COUNT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_FILE_DIR_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RESULTS_PER_PAGE_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_MAX_RETRY_REQUESTS_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_PREFIX_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_SERVICE_CLIENT_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_TIMEOUT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEBLOB_COMPONENT_ACCESS_KEY_DOC);
diff --git a/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-sink-connector.adoc b/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-sink-connector.adoc
index 23f16dc..55726ad 100644
--- a/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-sink-connector.adoc
+++ b/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-azure-storage-queue-kafka-connector as sink make sure to use th
 ----
 
 
-The camel-azure-storage-queue sink connector supports 24 options, which are listed below.
+The camel-azure-storage-queue sink connector supports 32 options, which are listed below.
 
 
 
@@ -24,29 +24,35 @@ The camel-azure-storage-queue sink connector supports 24 options, which are list
 | Name | Description | Default | Priority
 | *camel.sink.path.accountName* | Azure account name to be used for authentication with azure queue services | null | MEDIUM
 | *camel.sink.path.queueName* | The queue resource name | null | MEDIUM
+| *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.serviceClient* | Service client to a storage account to interact with the queue service. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. This client contains all the operations for interacting with a queue account in Azure Storage. Operations allowed by the client are creating, listing, and deleting queues, retrieving and updating properties of [...]
+| *camel.sink.endpoint.createQueue* | When is set to true, the queue will be automatically created when sending messages to the queue. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.operation* | Queue service operation hint to the producer One of: [listQueues] [createQueue] [deleteQueue] [clearQueue] [sendMessage] [deleteMessage] [receiveMessages] [peekMessages] [updateMessage] | null | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.maxMessages* | Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages. | "1" | MEDIUM
+| *camel.sink.endpoint.messageId* | The ID of the message to be deleted or updated. | null | MEDIUM
+| *camel.sink.endpoint.popReceipt* | Unique identifier that must match for the message to be deleted or updated. | null | MEDIUM
 | *camel.sink.endpoint.timeout* | An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown. | null | MEDIUM
 | *camel.sink.endpoint.timeToLive* | How long the message will stay alive in the queue. If unset the value will default to 7 days, if -1 is passed the message will not expire. The time to live must be -1 or any positive number. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are typesafe. | null [...]
 | *camel.sink.endpoint.visibilityTimeout* | The timeout period for how long the message is invisible in the queue. The timeout must be between 1 seconds and 7 days. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are typesafe. | null | MEDIUM
 | *camel.sink.endpoint.accessKey* | Access key for the associated azure account name to be used for authentication with azure queue services | null | MEDIUM
 | *camel.sink.endpoint.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
+| *camel.component.azure-storage-queue.autoDiscover Client* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.azure-storage-queue.configuration* | The component configurations | null | MEDIUM
 | *camel.component.azure-storage-queue.serviceClient* | Service client to a storage account to interact with the queue service. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. This client contains all the operations for interacting with a queue account in Azure Storage. Operations allowed by the client are creating, listing, and deleting queues, retrieving and updati [...]
+| *camel.component.azure-storage-queue.createQueue* | When is set to true, the queue will be automatically created when sending messages to the queue. | true | MEDIUM
 | *camel.component.azure-storage-queue.lazyStart Producer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is p [...]
 | *camel.component.azure-storage-queue.operation* | Queue service operation hint to the producer One of: [listQueues] [createQueue] [deleteQueue] [clearQueue] [sendMessage] [deleteMessage] [receiveMessages] [peekMessages] [updateMessage] | null | MEDIUM
 | *camel.component.azure-storage-queue.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.azure-storage-queue.maxMessages* | Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages. | "1" | MEDIUM
+| *camel.component.azure-storage-queue.messageId* | The ID of the message to be deleted or updated. | null | MEDIUM
+| *camel.component.azure-storage-queue.popReceipt* | Unique identifier that must match for the message to be deleted or updated. | null | MEDIUM
 | *camel.component.azure-storage-queue.timeout* | An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown. | null | MEDIUM
 | *camel.component.azure-storage-queue.timeToLive* | How long the message will stay alive in the queue. If unset the value will default to 7 days, if -1 is passed the message will not expire. The time to live must be -1 or any positive number. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are  [...]
 | *camel.component.azure-storage-queue.visibility Timeout* | The timeout period for how long the message is invisible in the queue. The timeout must be between 1 seconds and 7 days. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are typesafe. | null | MEDIUM
 | *camel.component.azure-storage-queue.accessKey* | Access key for the associated azure account name to be used for authentication with azure queue services | null | MEDIUM
 | *camel.component.azure-storage-queue.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-source-connector.adoc b/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-source-connector.adoc
index 6e3610b..0c76daa 100644
--- a/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-source-connector.adoc
+++ b/connectors/camel-azure-storage-queue-kafka-connector/src/main/docs/camel-azure-storage-queue-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-azure-storage-queue-kafka-connector as source make sure to use
 ----
 
 
-The camel-azure-storage-queue source connector supports 24 options, which are listed below.
+The camel-azure-storage-queue source connector supports 30 options, which are listed below.
 
 
 
@@ -24,6 +24,7 @@ The camel-azure-storage-queue source connector supports 24 options, which are li
 | Name | Description | Default | Priority
 | *camel.source.path.accountName* | Azure account name to be used for authentication with azure queue services | null | MEDIUM
 | *camel.source.path.queueName* | The queue resource name | null | MEDIUM
+| *camel.source.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.source.endpoint.serviceClient* | Service client to a storage account to interact with the queue service. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. This client contains all the operations for interacting with a queue account in Azure Storage. Operations allowed by the client are creating, listing, and deleting queues, retrieving and updating properties  [...]
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.exceptionHandler* | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored. | null | MEDIUM
@@ -31,22 +32,25 @@ The camel-azure-storage-queue source connector supports 24 options, which are li
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.source.endpoint.maxMessages* | Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages. | "1" | MEDIUM
+| *camel.source.endpoint.messageId* | The ID of the message to be deleted or updated. | null | MEDIUM
+| *camel.source.endpoint.popReceipt* | Unique identifier that must match for the message to be deleted or updated. | null | MEDIUM
 | *camel.source.endpoint.timeout* | An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown. | null | MEDIUM
 | *camel.source.endpoint.timeToLive* | How long the message will stay alive in the queue. If unset the value will default to 7 days, if -1 is passed the message will not expire. The time to live must be -1 or any positive number. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are typesafe. | nu [...]
 | *camel.source.endpoint.visibilityTimeout* | The timeout period for how long the message is invisible in the queue. The timeout must be between 1 seconds and 7 days. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are typesafe. | null | MEDIUM
 | *camel.source.endpoint.accessKey* | Access key for the associated azure account name to be used for authentication with azure queue services | null | MEDIUM
 | *camel.source.endpoint.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
+| *camel.component.azure-storage-queue.autoDiscover Client* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.azure-storage-queue.configuration* | The component configurations | null | MEDIUM
 | *camel.component.azure-storage-queue.serviceClient* | Service client to a storage account to interact with the queue service. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. This client contains all the operations for interacting with a queue account in Azure Storage. Operations allowed by the client are creating, listing, and deleting queues, retrieving and updati [...]
 | *camel.component.azure-storage-queue.bridgeError Handler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.azure-storage-queue.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.azure-storage-queue.maxMessages* | Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages. | "1" | MEDIUM
+| *camel.component.azure-storage-queue.messageId* | The ID of the message to be deleted or updated. | null | MEDIUM
+| *camel.component.azure-storage-queue.popReceipt* | Unique identifier that must match for the message to be deleted or updated. | null | MEDIUM
 | *camel.component.azure-storage-queue.timeout* | An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown. | null | MEDIUM
 | *camel.component.azure-storage-queue.timeToLive* | How long the message will stay alive in the queue. If unset the value will default to 7 days, if -1 is passed the message will not expire. The time to live must be -1 or any positive number. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are  [...]
 | *camel.component.azure-storage-queue.visibility Timeout* | The timeout period for how long the message is invisible in the queue. The timeout must be between 1 seconds and 7 days. The format should be in this form: PnDTnHnMn.nS., e.g: PT20.345S -- parses as 20.345 seconds, P2D -- parses as 2 days However, in case you are using EndpointDsl/ComponentDsl, you can do something like Duration.ofSeconds() since these Java APIs are typesafe. | null | MEDIUM
 | *camel.component.azure-storage-queue.accessKey* | Access key for the associated azure account name to be used for authentication with azure queue services | null | MEDIUM
 | *camel.component.azure-storage-queue.credentials* | StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSinkConnectorConfig.java b/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSinkConnectorConfig.java
index 31d9e92..dee3ee6 100644
--- a/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSinkConnectorConfig.java
+++ b/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSinkConnectorConfig.java
@@ -32,9 +32,15 @@ public class CamelAzurestoragequeueSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_CONF = "camel.sink.path.queueName";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DOC = "The queue resource name";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.sink.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_CONF = "camel.sink.endpoint.serviceClient";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DOC = "Service client to a storage account to interact with the queue service. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. This client contains all the operations for interacting with a queue account in Azure Storage. Operations allowed by the client are creating, listing, and del [...]
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREATE_QUEUE_CONF = "camel.sink.endpoint.createQueue";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREATE_QUEUE_DOC = "When is set to true, the queue will be automatically created when sending messages to the queue.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREATE_QUEUE_DEFAULT = true;
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_LAZY_START_PRODUCER_CONF = "camel.sink.endpoint.lazyStartProducer";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Bewa [...]
     public static final Boolean CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -50,6 +56,12 @@ public class CamelAzurestoragequeueSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_CONF = "camel.sink.endpoint.maxMessages";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DOC = "Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages.";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DEFAULT = "1";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_CONF = "camel.sink.endpoint.messageId";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DOC = "The ID of the message to be deleted or updated.";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_CONF = "camel.sink.endpoint.popReceipt";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DOC = "Unique identifier that must match for the message to be deleted or updated.";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_CONF = "camel.sink.endpoint.timeout";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DOC = "An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown.";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DEFAULT = null;
@@ -65,12 +77,18 @@ public class CamelAzurestoragequeueSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_CONF = "camel.sink.endpoint.credentials";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DOC = "StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.azure-storage-queue.autoDiscoverClient";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_CONF = "camel.component.azure-storage-queue.configuration";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DOC = "The component configurations";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_CONF = "camel.component.azure-storage-queue.serviceClient";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_DOC = "Service client to a storage account to interact with the queue service. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. This client contains all the operations for interacting with a queue account in Azure Storage. Operations allowed by the client are creating, listing, and de [...]
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CREATE_QUEUE_CONF = "camel.component.azure-storage-queue.createQueue";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CREATE_QUEUE_DOC = "When is set to true, the queue will be automatically created when sending messages to the queue.";
+    public static final Boolean CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CREATE_QUEUE_DEFAULT = true;
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.azure-storage-queue.lazyStartProducer";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Bew [...]
     public static final Boolean CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -83,6 +101,12 @@ public class CamelAzurestoragequeueSinkConnectorConfig
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_CONF = "camel.component.azure-storage-queue.maxMessages";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DOC = "Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages.";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DEFAULT = "1";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_CONF = "camel.component.azure-storage-queue.messageId";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DOC = "The ID of the message to be deleted or updated.";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DEFAULT = null;
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_CONF = "camel.component.azure-storage-queue.popReceipt";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DOC = "Unique identifier that must match for the message to be deleted or updated.";
+    public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DEFAULT = null;
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_CONF = "camel.component.azure-storage-queue.timeout";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DOC = "An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown.";
     public static final String CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DEFAULT = null;
@@ -114,23 +138,31 @@ public class CamelAzurestoragequeueSinkConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSinkConnectorConfig.conf());
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_PATH_ACCOUNT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_PATH_ACCOUNT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_PATH_ACCOUNT_NAME_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREATE_QUEUE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIME_TO_LIVE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIME_TO_LIVE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_TIME_TO_LIVE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_VISIBILITY_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_VISIBILITY_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_VISIBILITY_TIMEOUT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CREATE_QUEUE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CREATE_QUEUE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_CREATE_QUEUE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_OPERATION_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DOC);
+        conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIME_TO_LIVE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIME_TO_LIVE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_TIME_TO_LIVE_DOC);
         conf.define(CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_VISIBILITY_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_VISIBILITY_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AZURESTORAGEQUEUE_COMPONENT_VISIBILITY_TIMEOUT_DOC);
diff --git a/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSourceConnectorConfig.java b/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSourceConnectorConfig.java
index bb7424a..6558e60 100644
--- a/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSourceConnectorConfig.java
+++ b/connectors/camel-azure-storage-queue-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/azurestoragequeue/CamelAzurestoragequeueSourceConnectorConfig.java
@@ -32,6 +32,9 @@ public class CamelAzurestoragequeueSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_CONF = "camel.source.path.queueName";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DOC = "The queue resource name";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF = "camel.source.endpoint.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_CONF = "camel.source.endpoint.serviceClient";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DOC = "Service client to a storage account to interact with the queue service. This client does not hold any state about a particular storage account but is instead a convenient way of sending off appropriate requests to the resource on the service. This client contains all the operations for interacting with a queue account in Azure Storage. Operations allowed by the client are creating, listing, and d [...]
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DEFAULT = null;
@@ -53,6 +56,12 @@ public class CamelAzurestoragequeueSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_CONF = "camel.source.endpoint.maxMessages";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DOC = "Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages.";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DEFAULT = "1";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_CONF = "camel.source.endpoint.messageId";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DOC = "The ID of the message to be deleted or updated.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_CONF = "camel.source.endpoint.popReceipt";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DOC = "Unique identifier that must match for the message to be deleted or updated.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_CONF = "camel.source.endpoint.timeout";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DOC = "An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown.";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DEFAULT = null;
@@ -68,6 +77,9 @@ public class CamelAzurestoragequeueSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_CONF = "camel.source.endpoint.credentials";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DOC = "StorageSharedKeyCredential can be injected to create the azure client, this holds the important authentication information";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF = "camel.component.azure-storage-queue.autoDiscoverClient";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC = "Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking.";
+    public static final Boolean CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT = true;
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_CONF = "camel.component.azure-storage-queue.configuration";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DOC = "The component configurations";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DEFAULT = null;
@@ -83,6 +95,12 @@ public class CamelAzurestoragequeueSourceConnectorConfig
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_CONF = "camel.component.azure-storage-queue.maxMessages";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DOC = "Maximum number of messages to get, if there are less messages exist in the queue than requested all the messages will be returned. If left empty only 1 message will be retrieved, the allowed range is 1 to 32 messages.";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DEFAULT = "1";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_CONF = "camel.component.azure-storage-queue.messageId";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DOC = "The ID of the message to be deleted or updated.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_CONF = "camel.component.azure-storage-queue.popReceipt";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DOC = "Unique identifier that must match for the message to be deleted or updated.";
+    public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DEFAULT = null;
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_CONF = "camel.component.azure-storage-queue.timeout";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DOC = "An optional timeout applied to the operation. If a response is not returned before the timeout concludes a RuntimeException will be thrown.";
     public static final String CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DEFAULT = null;
@@ -114,6 +132,7 @@ public class CamelAzurestoragequeueSourceConnectorConfig
         ConfigDef conf = new ConfigDef(CamelSourceConnectorConfig.conf());
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_ACCOUNT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_ACCOUNT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_ACCOUNT_NAME_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_PATH_QUEUE_NAME_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SERVICE_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_EXCEPTION_HANDLER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_EXCEPTION_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_EXCEPTION_HANDLER_DOC);
@@ -121,16 +140,21 @@ public class CamelAzurestoragequeueSourceConnectorConfig
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MAX_MESSAGES_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_MESSAGE_ID_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_POP_RECEIPT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIMEOUT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIME_TO_LIVE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIME_TO_LIVE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_TIME_TO_LIVE_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_VISIBILITY_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_VISIBILITY_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_VISIBILITY_TIMEOUT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_ACCESS_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_ACCESS_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_ACCESS_KEY_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_ENDPOINT_CREDENTIALS_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_AUTO_DISCOVER_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_CONFIGURATION_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_SERVICE_CLIENT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MAX_MESSAGES_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_MESSAGE_ID_DOC);
+        conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_POP_RECEIPT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIMEOUT_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIME_TO_LIVE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIME_TO_LIVE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_TIME_TO_LIVE_DOC);
         conf.define(CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_VISIBILITY_TIMEOUT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_VISIBILITY_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AZURESTORAGEQUEUE_COMPONENT_VISIBILITY_TIMEOUT_DOC);
diff --git a/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-sink-connector.adoc b/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-sink-connector.adoc
index ba6f5b5..5737085 100644
--- a/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-sink-connector.adoc
+++ b/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-sink-connector.adoc
@@ -30,8 +30,8 @@ The camel-beanstalk sink connector supports 11 options, which are listed below.
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.component.beanstalk.connectionSettings Factory* | Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings) | null | MEDIUM
 | *camel.component.beanstalk.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed th [...]
 | *camel.component.beanstalk.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.beanstalk.connectionSettings Factory* | Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings) | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-source-connector.adoc b/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-source-connector.adoc
index 74bea8f..206cbc5 100644
--- a/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-source-connector.adoc
+++ b/connectors/camel-beanstalk-kafka-connector/src/main/docs/camel-beanstalk-kafka-source-connector.adoc
@@ -46,13 +46,13 @@ The camel-beanstalk source connector supports 32 options, which are listed below
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
 | *camel.source.endpoint.useFixedDelay* | Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details. | true | MEDIUM
-| *camel.component.beanstalk.connectionSettings Factory* | Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings) | null | MEDIUM
 | *camel.component.beanstalk.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.beanstalk.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.beanstalk.connectionSettings Factory* | Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings) | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSinkConnectorConfig.java b/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSinkConnectorConfig.java
index cbe6a62..39a4744 100644
--- a/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSinkConnectorConfig.java
+++ b/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSinkConnectorConfig.java
@@ -50,15 +50,15 @@ public class CamelBeanstalkSinkConnectorConfig
     public static final String CAMEL_SINK_BEANSTALK_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
     public static final String CAMEL_SINK_BEANSTALK_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SINK_BEANSTALK_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
-    public static final String CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF = "camel.component.beanstalk.connectionSettingsFactory";
-    public static final String CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC = "Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings)";
-    public static final String CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT = null;
     public static final String CAMEL_SINK_BEANSTALK_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.beanstalk.lazyStartProducer";
     public static final String CAMEL_SINK_BEANSTALK_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that [...]
     public static final Boolean CAMEL_SINK_BEANSTALK_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.beanstalk.basicPropertyBinding";
     public static final String CAMEL_SINK_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF = "camel.component.beanstalk.connectionSettingsFactory";
+    public static final String CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC = "Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings)";
+    public static final String CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT = null;
 
     public CamelBeanstalkSinkConnectorConfig(
             ConfigDef config,
@@ -80,9 +80,9 @@ public class CamelBeanstalkSinkConnectorConfig
         conf.define(CAMEL_SINK_BEANSTALK_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_BEANSTALK_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_BEANSTALK_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_BEANSTALK_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_BEANSTALK_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_BEANSTALK_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_BEANSTALK_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_BEANSTALK_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_BEANSTALK_ENDPOINT_SYNCHRONOUS_DOC);
-        conf.define(CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC);
         conf.define(CAMEL_SINK_BEANSTALK_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_BEANSTALK_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_BEANSTALK_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSourceConnectorConfig.java b/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSourceConnectorConfig.java
index b69ea71..7e1e20f 100644
--- a/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSourceConnectorConfig.java
+++ b/connectors/camel-beanstalk-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/beanstalk/CamelBeanstalkSourceConnectorConfig.java
@@ -99,7 +99,7 @@ public class CamelBeanstalkSourceConnectorConfig
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -113,15 +113,15 @@ public class CamelBeanstalkSourceConnectorConfig
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_USE_FIXED_DELAY_CONF = "camel.source.endpoint.useFixedDelay";
     public static final String CAMEL_SOURCE_BEANSTALK_ENDPOINT_USE_FIXED_DELAY_DOC = "Controls if fixed delay or fixed rate is used. See ScheduledExecutorService in JDK for details.";
     public static final Boolean CAMEL_SOURCE_BEANSTALK_ENDPOINT_USE_FIXED_DELAY_DEFAULT = true;
-    public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF = "camel.component.beanstalk.connectionSettingsFactory";
-    public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC = "Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings)";
-    public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT = null;
     public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.beanstalk.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and  [...]
     public static final Boolean CAMEL_SOURCE_BEANSTALK_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
     public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.beanstalk.basicPropertyBinding";
     public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF = "camel.component.beanstalk.connectionSettingsFactory";
+    public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC = "Custom ConnectionSettingsFactory. Specify which ConnectionSettingsFactory to use to make connections to Beanstalkd. Especially useful for unit testing without beanstalkd daemon (you can mock ConnectionSettings)";
+    public static final String CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT = null;
 
     public CamelBeanstalkSourceConnectorConfig(
             ConfigDef config,
@@ -164,9 +164,9 @@ public class CamelBeanstalkSourceConnectorConfig
         conf.define(CAMEL_SOURCE_BEANSTALK_ENDPOINT_START_SCHEDULER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_BEANSTALK_ENDPOINT_START_SCHEDULER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_BEANSTALK_ENDPOINT_START_SCHEDULER_DOC);
         conf.define(CAMEL_SOURCE_BEANSTALK_ENDPOINT_TIME_UNIT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_BEANSTALK_ENDPOINT_TIME_UNIT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_BEANSTALK_ENDPOINT_TIME_UNIT_DOC);
         conf.define(CAMEL_SOURCE_BEANSTALK_ENDPOINT_USE_FIXED_DELAY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_BEANSTALK_ENDPOINT_USE_FIXED_DELAY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_BEANSTALK_ENDPOINT_USE_FIXED_DELAY_DOC);
-        conf.define(CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC);
         conf.define(CAMEL_SOURCE_BEANSTALK_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_BEANSTALK_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_BEANSTALK_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_BEANSTALK_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_BEANSTALK_COMPONENT_CONNECTION_SETTINGS_FACTORY_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-box-kafka-connector/src/main/docs/camel-box-kafka-source-connector.adoc b/connectors/camel-box-kafka-connector/src/main/docs/camel-box-kafka-source-connector.adoc
index 72db40b..fbea165 100644
--- a/connectors/camel-box-kafka-connector/src/main/docs/camel-box-kafka-source-connector.adoc
+++ b/connectors/camel-box-kafka-connector/src/main/docs/camel-box-kafka-source-connector.adoc
@@ -46,7 +46,7 @@ The camel-box source connector supports 57 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-box-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/box/CamelBoxSourceConnectorConfig.java b/connectors/camel-box-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/box/CamelBoxSourceConnectorConfig.java
index c7facda..cbe1774 100644
--- a/connectors/camel-box-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/box/CamelBoxSourceConnectorConfig.java
+++ b/connectors/camel-box-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/box/CamelBoxSourceConnectorConfig.java
@@ -97,7 +97,7 @@ public class CamelBoxSourceConnectorConfig extends CamelSourceConnectorConfig {
     public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_BOX_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-sink-connector.adoc b/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-sink-connector.adoc
index a457c3e..fdb71bb 100644
--- a/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-sink-connector.adoc
+++ b/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-sink-connector.adoc
@@ -31,7 +31,7 @@ The camel-braintree sink connector supports 20 options, which are listed below.
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.httpReadTimeout* | Set read timeout for http calls. | null | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.sink.endpoint.httpLogLevel* | Set logging level for http calls, see java.util.logging.Level | null | MEDIUM
+| *camel.sink.endpoint.httpLogLevel* | Set logging level for http calls, see java.util.logging.Level One of: [OFF] [SEVERE] [WARNING] [INFO] [CONFIG] [FINE] [FINER] [FINEST] [ALL] | null | MEDIUM
 | *camel.sink.endpoint.httpLogName* | Set log category to use to log http calls. | "Braintree" | MEDIUM
 | *camel.sink.endpoint.logHandlerEnabled* | Sets whether to enable the BraintreeLogHandler. It may be desirable to set this to 'false' where an existing JUL - SLF4J logger bridge is on the classpath. This option can also be configured globally on the BraintreeComponent. | true | MEDIUM
 | *camel.sink.endpoint.proxyHost* | The proxy host | null | MEDIUM
diff --git a/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-source-connector.adoc b/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-source-connector.adoc
index 8dd8bdc..a9622ae 100644
--- a/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-source-connector.adoc
+++ b/connectors/camel-braintree-kafka-connector/src/main/docs/camel-braintree-kafka-source-connector.adoc
@@ -35,7 +35,7 @@ The camel-braintree source connector supports 38 options, which are listed below
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.source.endpoint.httpReadTimeout* | Set read timeout for http calls. | null | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.source.endpoint.httpLogLevel* | Set logging level for http calls, see java.util.logging.Level | null | MEDIUM
+| *camel.source.endpoint.httpLogLevel* | Set logging level for http calls, see java.util.logging.Level One of: [OFF] [SEVERE] [WARNING] [INFO] [CONFIG] [FINE] [FINER] [FINEST] [ALL] | null | MEDIUM
 | *camel.source.endpoint.httpLogName* | Set log category to use to log http calls. | "Braintree" | MEDIUM
 | *camel.source.endpoint.logHandlerEnabled* | Sets whether to enable the BraintreeLogHandler. It may be desirable to set this to 'false' where an existing JUL - SLF4J logger bridge is on the classpath. This option can also be configured globally on the BraintreeComponent. | true | MEDIUM
 | *camel.source.endpoint.proxyHost* | The proxy host | null | MEDIUM
@@ -49,7 +49,7 @@ The camel-braintree source connector supports 38 options, which are listed below
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSinkConnectorConfig.java b/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSinkConnectorConfig.java
index 2157fd8..fd22dc5 100644
--- a/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSinkConnectorConfig.java
+++ b/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSinkConnectorConfig.java
@@ -54,7 +54,7 @@ public class CamelBraintreeSinkConnectorConfig
     public static final String CAMEL_SINK_BRAINTREE_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SINK_BRAINTREE_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
     public static final String CAMEL_SINK_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_CONF = "camel.sink.endpoint.httpLogLevel";
-    public static final String CAMEL_SINK_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_DOC = "Set logging level for http calls, see java.util.logging.Level";
+    public static final String CAMEL_SINK_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_DOC = "Set logging level for http calls, see java.util.logging.Level One of: [OFF] [SEVERE] [WARNING] [INFO] [CONFIG] [FINE] [FINER] [FINEST] [ALL]";
     public static final String CAMEL_SINK_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_DEFAULT = null;
     public static final String CAMEL_SINK_BRAINTREE_ENDPOINT_HTTP_LOG_NAME_CONF = "camel.sink.endpoint.httpLogName";
     public static final String CAMEL_SINK_BRAINTREE_ENDPOINT_HTTP_LOG_NAME_DOC = "Set log category to use to log http calls.";
diff --git a/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSourceConnectorConfig.java b/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSourceConnectorConfig.java
index b342328..ba2521c 100644
--- a/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSourceConnectorConfig.java
+++ b/connectors/camel-braintree-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/braintree/CamelBraintreeSourceConnectorConfig.java
@@ -66,7 +66,7 @@ public class CamelBraintreeSourceConnectorConfig
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SOURCE_BRAINTREE_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_CONF = "camel.source.endpoint.httpLogLevel";
-    public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_DOC = "Set logging level for http calls, see java.util.logging.Level";
+    public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_DOC = "Set logging level for http calls, see java.util.logging.Level One of: [OFF] [SEVERE] [WARNING] [INFO] [CONFIG] [FINE] [FINER] [FINEST] [ALL]";
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_HTTP_LOG_LEVEL_DEFAULT = null;
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_HTTP_LOG_NAME_CONF = "camel.source.endpoint.httpLogName";
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_HTTP_LOG_NAME_DOC = "Set log category to use to log http calls.";
@@ -108,7 +108,7 @@ public class CamelBraintreeSourceConnectorConfig
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_BRAINTREE_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-sink-connector.adoc b/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-sink-connector.adoc
index 561f8c5..815c8b9 100644
--- a/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-sink-connector.adoc
+++ b/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-sink-connector.adoc
@@ -34,8 +34,8 @@ The camel-cmis sink connector supports 15 options, which are listed below.
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.sink.endpoint.password* | Password for the cmis repository | null | MEDIUM
 | *camel.sink.endpoint.username* | Username for the cmis repository | null | MEDIUM
-| *camel.component.cmis.sessionFacadeFactory* | To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances | null | MEDIUM
 | *camel.component.cmis.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cr [...]
 | *camel.component.cmis.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.cmis.sessionFacadeFactory* | To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-source-connector.adoc b/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-source-connector.adoc
index 514199e..cd4efa0 100644
--- a/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-source-connector.adoc
+++ b/connectors/camel-cmis-kafka-connector/src/main/docs/camel-cmis-kafka-source-connector.adoc
@@ -36,8 +36,8 @@ The camel-cmis source connector supports 17 options, which are listed below.
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.source.endpoint.password* | Password for the cmis repository | null | MEDIUM
 | *camel.source.endpoint.username* | Username for the cmis repository | null | MEDIUM
-| *camel.component.cmis.sessionFacadeFactory* | To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances | null | MEDIUM
 | *camel.component.cmis.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.cmis.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.cmis.sessionFacadeFactory* | To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSinkConnectorConfig.java b/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSinkConnectorConfig.java
index 92b1698..5024814 100644
--- a/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSinkConnectorConfig.java
+++ b/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSinkConnectorConfig.java
@@ -60,15 +60,15 @@ public class CamelCmisSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_CMIS_ENDPOINT_USERNAME_CONF = "camel.sink.endpoint.username";
     public static final String CAMEL_SINK_CMIS_ENDPOINT_USERNAME_DOC = "Username for the cmis repository";
     public static final String CAMEL_SINK_CMIS_ENDPOINT_USERNAME_DEFAULT = null;
-    public static final String CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF = "camel.component.cmis.sessionFacadeFactory";
-    public static final String CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC = "To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances";
-    public static final String CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT = null;
     public static final String CAMEL_SINK_CMIS_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.cmis.lazyStartProducer";
     public static final String CAMEL_SINK_CMIS_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when [...]
     public static final Boolean CAMEL_SINK_CMIS_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.cmis.basicPropertyBinding";
     public static final String CAMEL_SINK_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF = "camel.component.cmis.sessionFacadeFactory";
+    public static final String CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC = "To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances";
+    public static final String CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT = null;
 
     public CamelCmisSinkConnectorConfig(
             ConfigDef config,
@@ -94,9 +94,9 @@ public class CamelCmisSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_CMIS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_CMIS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CMIS_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_CMIS_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CMIS_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CMIS_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SINK_CMIS_ENDPOINT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CMIS_ENDPOINT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CMIS_ENDPOINT_USERNAME_DOC);
-        conf.define(CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC);
         conf.define(CAMEL_SINK_CMIS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_CMIS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CMIS_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSourceConnectorConfig.java b/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSourceConnectorConfig.java
index 43dff71..ec4dc3c 100644
--- a/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSourceConnectorConfig.java
+++ b/connectors/camel-cmis-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cmis/CamelCmisSourceConnectorConfig.java
@@ -68,15 +68,15 @@ public class CamelCmisSourceConnectorConfig
     public static final String CAMEL_SOURCE_CMIS_ENDPOINT_USERNAME_CONF = "camel.source.endpoint.username";
     public static final String CAMEL_SOURCE_CMIS_ENDPOINT_USERNAME_DOC = "Username for the cmis repository";
     public static final String CAMEL_SOURCE_CMIS_ENDPOINT_USERNAME_DEFAULT = null;
-    public static final String CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF = "camel.component.cmis.sessionFacadeFactory";
-    public static final String CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC = "To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances";
-    public static final String CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT = null;
     public static final String CAMEL_SOURCE_CMIS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.cmis.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_CMIS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
     public static final Boolean CAMEL_SOURCE_CMIS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
     public static final String CAMEL_SOURCE_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.cmis.basicPropertyBinding";
     public static final String CAMEL_SOURCE_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF = "camel.component.cmis.sessionFacadeFactory";
+    public static final String CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC = "To use a custom CMISSessionFacadeFactory to create the CMISSessionFacade instances";
+    public static final String CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT = null;
 
     public CamelCmisSourceConnectorConfig(
             ConfigDef config,
@@ -104,9 +104,9 @@ public class CamelCmisSourceConnectorConfig
         conf.define(CAMEL_SOURCE_CMIS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_CMIS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CMIS_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SOURCE_CMIS_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CMIS_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CMIS_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SOURCE_CMIS_ENDPOINT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CMIS_ENDPOINT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CMIS_ENDPOINT_USERNAME_DOC);
-        conf.define(CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC);
         conf.define(CAMEL_SOURCE_CMIS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_CMIS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CMIS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CMIS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CMIS_COMPONENT_SESSION_FACADE_FACTORY_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-sink-connector.adoc b/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-sink-connector.adoc
index 6348c6b..959e3ce 100644
--- a/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-sink-connector.adoc
+++ b/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-couchbase-kafka-connector as sink make sure to use the followin
 ----
 
 
-The camel-couchbase sink connector supports 28 options, which are listed below.
+The camel-couchbase sink connector supports 23 options, which are listed below.
 
 
 
@@ -26,7 +26,9 @@ The camel-couchbase sink connector supports 28 options, which are listed below.
 | *camel.sink.path.hostname* | The hostname to use | null | HIGH
 | *camel.sink.path.port* | The port number to use | 8091 | MEDIUM
 | *camel.sink.endpoint.bucket* | The bucket to use | null | MEDIUM
+| *camel.sink.endpoint.collection* | The collection to use | null | MEDIUM
 | *camel.sink.endpoint.key* | The key to use | null | MEDIUM
+| *camel.sink.endpoint.scope* | The scope to use | null | MEDIUM
 | *camel.sink.endpoint.autoStartIdForInserts* | Define if we want an autostart Id when we are doing an insert operation | false | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.operation* | The operation to do | "CCB_PUT" | MEDIUM
@@ -37,15 +39,8 @@ The camel-couchbase sink connector supports 28 options, which are listed below.
 | *camel.sink.endpoint.startingIdForInsertsFrom* | Define the starting Id where we are doing an insert operation | null | MEDIUM
 | *camel.sink.endpoint.additionalHosts* | The additional hosts | null | MEDIUM
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
-| *camel.sink.endpoint.maxReconnectDelay* | Define the max delay during a reconnection | 30000L | MEDIUM
-| *camel.sink.endpoint.obsPollInterval* | Define the observation polling interval | 400L | MEDIUM
-| *camel.sink.endpoint.obsTimeout* | Define the observation timeout | -1L | MEDIUM
-| *camel.sink.endpoint.opQueueMaxBlockTime* | Define the max time an operation can be in queue blocked | 10000L | MEDIUM
-| *camel.sink.endpoint.opTimeOut* | Define the operation timeout | 2500L | MEDIUM
-| *camel.sink.endpoint.readBufferSize* | Define the buffer size | 16384 | MEDIUM
-| *camel.sink.endpoint.shouldOptimize* | Define if we want to use optimization or not where possible | false | MEDIUM
+| *camel.sink.endpoint.queryTimeout* | Define the operation timeout in milliseconds | 2500L | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.sink.endpoint.timeoutExceptionThreshold* | Define the threshold for throwing a timeout Exception | 998 | MEDIUM
 | *camel.sink.endpoint.password* | The password to use | null | MEDIUM
 | *camel.sink.endpoint.username* | The username to use | null | MEDIUM
 | *camel.component.couchbase.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed th [...]
diff --git a/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-source-connector.adoc b/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-source-connector.adoc
index 58516f5..3c8f66f 100644
--- a/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-source-connector.adoc
+++ b/connectors/camel-couchbase-kafka-connector/src/main/docs/camel-couchbase-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-couchbase-kafka-connector as source make sure to use the follow
 ----
 
 
-The camel-couchbase source connector supports 47 options, which are listed below.
+The camel-couchbase source connector supports 42 options, which are listed below.
 
 
 
@@ -26,7 +26,9 @@ The camel-couchbase source connector supports 47 options, which are listed below
 | *camel.source.path.hostname* | The hostname to use | null | HIGH
 | *camel.source.path.port* | The port number to use | 8091 | MEDIUM
 | *camel.source.endpoint.bucket* | The bucket to use | null | MEDIUM
+| *camel.source.endpoint.collection* | The collection to use | null | MEDIUM
 | *camel.source.endpoint.key* | The key to use | null | MEDIUM
+| *camel.source.endpoint.scope* | The scope to use | null | MEDIUM
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.consumerProcessedStrategy* | Define the consumer Processed strategy to use | "none" | MEDIUM
 | *camel.source.endpoint.descending* | Define if this operation is descending or not | false | MEDIUM
@@ -42,15 +44,8 @@ The camel-couchbase source connector supports 47 options, which are listed below
 | *camel.source.endpoint.pollStrategy* | A pluggable org.apache.camel.PollingConsumerPollingStrategy allowing you to provide your custom implementation to control error handling usually occurred during the poll operation before an Exchange have been created and being routed in Camel. | null | MEDIUM
 | *camel.source.endpoint.additionalHosts* | The additional hosts | null | MEDIUM
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
-| *camel.source.endpoint.maxReconnectDelay* | Define the max delay during a reconnection | 30000L | MEDIUM
-| *camel.source.endpoint.obsPollInterval* | Define the observation polling interval | 400L | MEDIUM
-| *camel.source.endpoint.obsTimeout* | Define the observation timeout | -1L | MEDIUM
-| *camel.source.endpoint.opQueueMaxBlockTime* | Define the max time an operation can be in queue blocked | 10000L | MEDIUM
-| *camel.source.endpoint.opTimeOut* | Define the operation timeout | 2500L | MEDIUM
-| *camel.source.endpoint.readBufferSize* | Define the buffer size | 16384 | MEDIUM
-| *camel.source.endpoint.shouldOptimize* | Define if we want to use optimization or not where possible | false | MEDIUM
+| *camel.source.endpoint.queryTimeout* | Define the operation timeout in milliseconds | 2500L | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.source.endpoint.timeoutExceptionThreshold* | Define the threshold for throwing a timeout Exception | 998 | MEDIUM
 | *camel.source.endpoint.backoffErrorThreshold* | The number of subsequent error polls (failed due some error) that should happen before the backoffMultipler should kick-in. | null | MEDIUM
 | *camel.source.endpoint.backoffIdleThreshold* | The number of subsequent idle polls that should happen before the backoffMultipler should kick-in. | null | MEDIUM
 | *camel.source.endpoint.backoffMultiplier* | To let the scheduled polling consumer backoff if there has been a number of subsequent idles/errors in a row. The multiplier is then the number of polls that will be skipped before the next actual attempt is happening again. When this option is in use then backoffIdleThreshold and/or backoffErrorThreshold must also be configured. | null | MEDIUM
@@ -60,7 +55,7 @@ The camel-couchbase source connector supports 47 options, which are listed below
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSinkConnectorConfig.java b/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSinkConnectorConfig.java
index 512a197..92ea3ed 100644
--- a/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSinkConnectorConfig.java
+++ b/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSinkConnectorConfig.java
@@ -38,9 +38,15 @@ public class CamelCouchbaseSinkConnectorConfig
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_BUCKET_CONF = "camel.sink.endpoint.bucket";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_BUCKET_DOC = "The bucket to use";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_BUCKET_DEFAULT = null;
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_COLLECTION_CONF = "camel.sink.endpoint.collection";
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_COLLECTION_DOC = "The collection to use";
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_COLLECTION_DEFAULT = null;
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_KEY_CONF = "camel.sink.endpoint.key";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_KEY_DOC = "The key to use";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_KEY_DEFAULT = null;
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_SCOPE_CONF = "camel.sink.endpoint.scope";
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_SCOPE_DOC = "The scope to use";
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_SCOPE_DEFAULT = null;
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_AUTO_START_ID_FOR_INSERTS_CONF = "camel.sink.endpoint.autoStartIdForInserts";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_AUTO_START_ID_FOR_INSERTS_DOC = "Define if we want an autostart Id when we are doing an insert operation";
     public static final Boolean CAMEL_SINK_COUCHBASE_ENDPOINT_AUTO_START_ID_FOR_INSERTS_DEFAULT = false;
@@ -71,33 +77,12 @@ public class CamelCouchbaseSinkConnectorConfig
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.sink.endpoint.basicPropertyBinding";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_CONF = "camel.sink.endpoint.maxReconnectDelay";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DOC = "Define the max delay during a reconnection";
-    public static final Long CAMEL_SINK_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DEFAULT = 30000L;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_CONF = "camel.sink.endpoint.obsPollInterval";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DOC = "Define the observation polling interval";
-    public static final Long CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DEFAULT = 400L;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_TIMEOUT_CONF = "camel.sink.endpoint.obsTimeout";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DOC = "Define the observation timeout";
-    public static final Long CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DEFAULT = -1L;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_CONF = "camel.sink.endpoint.opQueueMaxBlockTime";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DOC = "Define the max time an operation can be in queue blocked";
-    public static final Long CAMEL_SINK_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DEFAULT = 10000L;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OP_TIME_OUT_CONF = "camel.sink.endpoint.opTimeOut";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_OP_TIME_OUT_DOC = "Define the operation timeout";
-    public static final Long CAMEL_SINK_COUCHBASE_ENDPOINT_OP_TIME_OUT_DEFAULT = 2500L;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_CONF = "camel.sink.endpoint.readBufferSize";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DOC = "Define the buffer size";
-    public static final Integer CAMEL_SINK_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DEFAULT = 16384;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_CONF = "camel.sink.endpoint.shouldOptimize";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DOC = "Define if we want to use optimization or not where possible";
-    public static final Boolean CAMEL_SINK_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DEFAULT = false;
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_CONF = "camel.sink.endpoint.queryTimeout";
+    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DOC = "Define the operation timeout in milliseconds";
+    public static final Long CAMEL_SINK_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DEFAULT = 2500L;
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SINK_COUCHBASE_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_CONF = "camel.sink.endpoint.timeoutExceptionThreshold";
-    public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DOC = "Define the threshold for throwing a timeout Exception";
-    public static final Integer CAMEL_SINK_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DEFAULT = 998;
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_PASSWORD_CONF = "camel.sink.endpoint.password";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_PASSWORD_DOC = "The password to use";
     public static final String CAMEL_SINK_COUCHBASE_ENDPOINT_PASSWORD_DEFAULT = null;
@@ -127,7 +112,9 @@ public class CamelCouchbaseSinkConnectorConfig
         conf.define(CAMEL_SINK_COUCHBASE_PATH_HOSTNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_PATH_HOSTNAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SINK_COUCHBASE_PATH_HOSTNAME_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_PATH_PORT_CONF, ConfigDef.Type.INT, CAMEL_SINK_COUCHBASE_PATH_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_PATH_PORT_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_BUCKET_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_BUCKET_DOC);
+        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_COLLECTION_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_KEY_DOC);
+        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_SCOPE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_SCOPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_SCOPE_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_AUTO_START_ID_FOR_INSERTS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_COUCHBASE_ENDPOINT_AUTO_START_ID_FOR_INSERTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_AUTO_START_ID_FOR_INSERTS_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_COUCHBASE_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_OPERATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_OPERATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_OPERATION_DOC);
@@ -138,15 +125,8 @@ public class CamelCouchbaseSinkConnectorConfig
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_STARTING_ID_FOR_INSERTS_FROM_CONF, ConfigDef.Type.LONG, CAMEL_SINK_COUCHBASE_ENDPOINT_STARTING_ID_FOR_INSERTS_FROM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_STARTING_ID_FOR_INSERTS_FROM_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_ADDITIONAL_HOSTS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_ADDITIONAL_HOSTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_ADDITIONAL_HOSTS_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_CONF, ConfigDef.Type.LONG, CAMEL_SINK_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_CONF, ConfigDef.Type.LONG, CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_TIMEOUT_CONF, ConfigDef.Type.LONG, CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_CONF, ConfigDef.Type.LONG, CAMEL_SINK_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_OP_TIME_OUT_CONF, ConfigDef.Type.LONG, CAMEL_SINK_COUCHBASE_ENDPOINT_OP_TIME_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_OP_TIME_OUT_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SINK_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DOC);
+        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_CONF, ConfigDef.Type.LONG, CAMEL_SINK_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_COUCHBASE_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_SYNCHRONOUS_DOC);
-        conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_CONF, ConfigDef.Type.INT, CAMEL_SINK_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_ENDPOINT_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_COUCHBASE_ENDPOINT_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_ENDPOINT_USERNAME_DOC);
         conf.define(CAMEL_SINK_COUCHBASE_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_COUCHBASE_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_COUCHBASE_COMPONENT_LAZY_START_PRODUCER_DOC);
diff --git a/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSourceConnectorConfig.java b/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSourceConnectorConfig.java
index ef078f1..ef51ce5 100644
--- a/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSourceConnectorConfig.java
+++ b/connectors/camel-couchbase-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/couchbase/CamelCouchbaseSourceConnectorConfig.java
@@ -38,9 +38,15 @@ public class CamelCouchbaseSourceConnectorConfig
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BUCKET_CONF = "camel.source.endpoint.bucket";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BUCKET_DOC = "The bucket to use";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BUCKET_DEFAULT = null;
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_COLLECTION_CONF = "camel.source.endpoint.collection";
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_COLLECTION_DOC = "The collection to use";
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_COLLECTION_DEFAULT = null;
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_KEY_CONF = "camel.source.endpoint.key";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_KEY_DOC = "The key to use";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_KEY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCOPE_CONF = "camel.source.endpoint.scope";
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCOPE_DOC = "The scope to use";
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCOPE_DEFAULT = null;
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF = "camel.source.endpoint.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and i [...]
     public static final Boolean CAMEL_SOURCE_COUCHBASE_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
@@ -86,33 +92,12 @@ public class CamelCouchbaseSourceConnectorConfig
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF = "camel.source.endpoint.basicPropertyBinding";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC = "Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT = false;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_CONF = "camel.source.endpoint.maxReconnectDelay";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DOC = "Define the max delay during a reconnection";
-    public static final Long CAMEL_SOURCE_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DEFAULT = 30000L;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_CONF = "camel.source.endpoint.obsPollInterval";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DOC = "Define the observation polling interval";
-    public static final Long CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DEFAULT = 400L;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_TIMEOUT_CONF = "camel.source.endpoint.obsTimeout";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DOC = "Define the observation timeout";
-    public static final Long CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DEFAULT = -1L;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_CONF = "camel.source.endpoint.opQueueMaxBlockTime";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DOC = "Define the max time an operation can be in queue blocked";
-    public static final Long CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DEFAULT = 10000L;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_TIME_OUT_CONF = "camel.source.endpoint.opTimeOut";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_TIME_OUT_DOC = "Define the operation timeout";
-    public static final Long CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_TIME_OUT_DEFAULT = 2500L;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_CONF = "camel.source.endpoint.readBufferSize";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DOC = "Define the buffer size";
-    public static final Integer CAMEL_SOURCE_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DEFAULT = 16384;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_CONF = "camel.source.endpoint.shouldOptimize";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DOC = "Define if we want to use optimization or not where possible";
-    public static final Boolean CAMEL_SOURCE_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DEFAULT = false;
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_CONF = "camel.source.endpoint.queryTimeout";
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DOC = "Define the operation timeout in milliseconds";
+    public static final Long CAMEL_SOURCE_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DEFAULT = 2500L;
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SYNCHRONOUS_CONF = "camel.source.endpoint.synchronous";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SOURCE_COUCHBASE_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_CONF = "camel.source.endpoint.timeoutExceptionThreshold";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DOC = "Define the threshold for throwing a timeout Exception";
-    public static final Integer CAMEL_SOURCE_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DEFAULT = 998;
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_ERROR_THRESHOLD_CONF = "camel.source.endpoint.backoffErrorThreshold";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_ERROR_THRESHOLD_DOC = "The number of subsequent error polls (failed due some error) that should happen before the backoffMultipler should kick-in.";
     public static final Integer CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_ERROR_THRESHOLD_DEFAULT = null;
@@ -141,7 +126,7 @@ public class CamelCouchbaseSourceConnectorConfig
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -184,7 +169,9 @@ public class CamelCouchbaseSourceConnectorConfig
         conf.define(CAMEL_SOURCE_COUCHBASE_PATH_HOSTNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_PATH_HOSTNAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_COUCHBASE_PATH_HOSTNAME_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_PATH_PORT_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_COUCHBASE_PATH_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_PATH_PORT_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_BUCKET_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BUCKET_DOC);
+        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_COLLECTION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_ENDPOINT_COLLECTION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_COLLECTION_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_KEY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_ENDPOINT_KEY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_KEY_DOC);
+        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCOPE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCOPE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_SCOPE_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_CONSUMER_PROCESSED_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_ENDPOINT_CONSUMER_PROCESSED_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_CONSUMER_PROCESSED_STRATEGY_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_DESCENDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_COUCHBASE_ENDPOINT_DESCENDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_DESCENDING_DOC);
@@ -200,15 +187,8 @@ public class CamelCouchbaseSourceConnectorConfig
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_POLL_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_ENDPOINT_POLL_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_POLL_STRATEGY_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_ADDITIONAL_HOSTS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_COUCHBASE_ENDPOINT_ADDITIONAL_HOSTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_ADDITIONAL_HOSTS_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_MAX_RECONNECT_DELAY_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_POLL_INTERVAL_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_TIMEOUT_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OBS_TIMEOUT_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_QUEUE_MAX_BLOCK_TIME_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_TIME_OUT_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_TIME_OUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_OP_TIME_OUT_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_READ_BUFFER_SIZE_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_SHOULD_OPTIMIZE_DOC);
+        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_QUERY_TIMEOUT_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_COUCHBASE_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_SYNCHRONOUS_DOC);
-        conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_TIMEOUT_EXCEPTION_THRESHOLD_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_ERROR_THRESHOLD_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_ERROR_THRESHOLD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_ERROR_THRESHOLD_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_IDLE_THRESHOLD_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_IDLE_THRESHOLD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_IDLE_THRESHOLD_DOC);
         conf.define(CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_MULTIPLIER_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_MULTIPLIER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_COUCHBASE_ENDPOINT_BACKOFF_MULTIPLIER_DOC);
diff --git a/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-sink-connector.adoc b/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-sink-connector.adoc
index c4e2d44..5928661 100644
--- a/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-sink-connector.adoc
+++ b/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-sink-connector.adoc
@@ -26,11 +26,11 @@ The camel-cql sink connector supports 19 options, which are listed below.
 | *camel.sink.path.hosts* | Hostname(s) cassansdra server(s). Multiple hosts can be separated by comma. | null | MEDIUM
 | *camel.sink.path.port* | Port number of cassansdra server(s) | null | MEDIUM
 | *camel.sink.path.keyspace* | Keyspace to use | null | MEDIUM
-| *camel.sink.endpoint.cluster* | To use the Cluster instance (you would normally not use this option) | null | MEDIUM
 | *camel.sink.endpoint.clusterName* | Cluster name | null | MEDIUM
-| *camel.sink.endpoint.consistencyLevel* | Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL] [LOCAL_ONE] | null | MEDIUM
+| *camel.sink.endpoint.consistencyLevel* | Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_ONE] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL] | null | MEDIUM
 | *camel.sink.endpoint.cql* | CQL query to perform. Can be overridden with the message header with key CamelCqlQuery. | null | MEDIUM
-| *camel.sink.endpoint.loadBalancingPolicy* | To use a specific LoadBalancingPolicy | null | MEDIUM
+| *camel.sink.endpoint.datacenter* | Datacenter to use | "datacenter1" | MEDIUM
+| *camel.sink.endpoint.loadBalancingPolicyClass* | To use a specific LoadBalancingPolicyClass | null | MEDIUM
 | *camel.sink.endpoint.password* | Password for session authentication | null | MEDIUM
 | *camel.sink.endpoint.prepareStatements* | Whether to use PreparedStatements or regular Statements | true | MEDIUM
 | *camel.sink.endpoint.resultSetConversionStrategy* | To use a custom class that implements logic for converting ResultSet into message body ALL, ONE, LIMIT_10, LIMIT_100... | null | MEDIUM
diff --git a/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-source-connector.adoc b/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-source-connector.adoc
index 2343e0c..1dde014 100644
--- a/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-source-connector.adoc
+++ b/connectors/camel-cql-kafka-connector/src/main/docs/camel-cql-kafka-source-connector.adoc
@@ -26,11 +26,11 @@ The camel-cql source connector supports 37 options, which are listed below.
 | *camel.source.path.hosts* | Hostname(s) cassansdra server(s). Multiple hosts can be separated by comma. | null | MEDIUM
 | *camel.source.path.port* | Port number of cassansdra server(s) | null | MEDIUM
 | *camel.source.path.keyspace* | Keyspace to use | null | MEDIUM
-| *camel.source.endpoint.cluster* | To use the Cluster instance (you would normally not use this option) | null | MEDIUM
 | *camel.source.endpoint.clusterName* | Cluster name | null | MEDIUM
-| *camel.source.endpoint.consistencyLevel* | Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL] [LOCAL_ONE] | null | MEDIUM
+| *camel.source.endpoint.consistencyLevel* | Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_ONE] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL] | null | MEDIUM
 | *camel.source.endpoint.cql* | CQL query to perform. Can be overridden with the message header with key CamelCqlQuery. | null | MEDIUM
-| *camel.source.endpoint.loadBalancingPolicy* | To use a specific LoadBalancingPolicy | null | MEDIUM
+| *camel.source.endpoint.datacenter* | Datacenter to use | "datacenter1" | MEDIUM
+| *camel.source.endpoint.loadBalancingPolicyClass* | To use a specific LoadBalancingPolicyClass | null | MEDIUM
 | *camel.source.endpoint.password* | Password for session authentication | null | MEDIUM
 | *camel.source.endpoint.prepareStatements* | Whether to use PreparedStatements or regular Statements | true | MEDIUM
 | *camel.source.endpoint.resultSetConversionStrategy* | To use a custom class that implements logic for converting ResultSet into message body ALL, ONE, LIMIT_10, LIMIT_100... | null | MEDIUM
@@ -52,7 +52,7 @@ The camel-cql source connector supports 37 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSinkConnectorConfig.java b/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSinkConnectorConfig.java
index bf90648..5eca0bc 100644
--- a/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSinkConnectorConfig.java
+++ b/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSinkConnectorConfig.java
@@ -36,21 +36,21 @@ public class CamelCqlSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_CQL_PATH_KEYSPACE_CONF = "camel.sink.path.keyspace";
     public static final String CAMEL_SINK_CQL_PATH_KEYSPACE_DOC = "Keyspace to use";
     public static final String CAMEL_SINK_CQL_PATH_KEYSPACE_DEFAULT = null;
-    public static final String CAMEL_SINK_CQL_ENDPOINT_CLUSTER_CONF = "camel.sink.endpoint.cluster";
-    public static final String CAMEL_SINK_CQL_ENDPOINT_CLUSTER_DOC = "To use the Cluster instance (you would normally not use this option)";
-    public static final String CAMEL_SINK_CQL_ENDPOINT_CLUSTER_DEFAULT = null;
     public static final String CAMEL_SINK_CQL_ENDPOINT_CLUSTER_NAME_CONF = "camel.sink.endpoint.clusterName";
     public static final String CAMEL_SINK_CQL_ENDPOINT_CLUSTER_NAME_DOC = "Cluster name";
     public static final String CAMEL_SINK_CQL_ENDPOINT_CLUSTER_NAME_DEFAULT = null;
     public static final String CAMEL_SINK_CQL_ENDPOINT_CONSISTENCY_LEVEL_CONF = "camel.sink.endpoint.consistencyLevel";
-    public static final String CAMEL_SINK_CQL_ENDPOINT_CONSISTENCY_LEVEL_DOC = "Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL] [LOCAL_ONE]";
+    public static final String CAMEL_SINK_CQL_ENDPOINT_CONSISTENCY_LEVEL_DOC = "Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_ONE] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL]";
     public static final String CAMEL_SINK_CQL_ENDPOINT_CONSISTENCY_LEVEL_DEFAULT = null;
     public static final String CAMEL_SINK_CQL_ENDPOINT_CQL_CONF = "camel.sink.endpoint.cql";
     public static final String CAMEL_SINK_CQL_ENDPOINT_CQL_DOC = "CQL query to perform. Can be overridden with the message header with key CamelCqlQuery.";
     public static final String CAMEL_SINK_CQL_ENDPOINT_CQL_DEFAULT = null;
-    public static final String CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CONF = "camel.sink.endpoint.loadBalancingPolicy";
-    public static final String CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DOC = "To use a specific LoadBalancingPolicy";
-    public static final String CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DEFAULT = null;
+    public static final String CAMEL_SINK_CQL_ENDPOINT_DATACENTER_CONF = "camel.sink.endpoint.datacenter";
+    public static final String CAMEL_SINK_CQL_ENDPOINT_DATACENTER_DOC = "Datacenter to use";
+    public static final String CAMEL_SINK_CQL_ENDPOINT_DATACENTER_DEFAULT = "datacenter1";
+    public static final String CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_CONF = "camel.sink.endpoint.loadBalancingPolicyClass";
+    public static final String CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DOC = "To use a specific LoadBalancingPolicyClass";
+    public static final String CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DEFAULT = null;
     public static final String CAMEL_SINK_CQL_ENDPOINT_PASSWORD_CONF = "camel.sink.endpoint.password";
     public static final String CAMEL_SINK_CQL_ENDPOINT_PASSWORD_DOC = "Password for session authentication";
     public static final String CAMEL_SINK_CQL_ENDPOINT_PASSWORD_DEFAULT = null;
@@ -98,11 +98,11 @@ public class CamelCqlSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_CQL_PATH_HOSTS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_PATH_HOSTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_PATH_HOSTS_DOC);
         conf.define(CAMEL_SINK_CQL_PATH_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_PATH_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_PATH_PORT_DOC);
         conf.define(CAMEL_SINK_CQL_PATH_KEYSPACE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_PATH_KEYSPACE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_PATH_KEYSPACE_DOC);
-        conf.define(CAMEL_SINK_CQL_ENDPOINT_CLUSTER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_CLUSTER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_CLUSTER_DOC);
         conf.define(CAMEL_SINK_CQL_ENDPOINT_CLUSTER_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_CLUSTER_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_CLUSTER_NAME_DOC);
         conf.define(CAMEL_SINK_CQL_ENDPOINT_CONSISTENCY_LEVEL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_CONSISTENCY_LEVEL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_CONSISTENCY_LEVEL_DOC);
         conf.define(CAMEL_SINK_CQL_ENDPOINT_CQL_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_CQL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_CQL_DOC);
-        conf.define(CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DOC);
+        conf.define(CAMEL_SINK_CQL_ENDPOINT_DATACENTER_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_DATACENTER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_DATACENTER_DOC);
+        conf.define(CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DOC);
         conf.define(CAMEL_SINK_CQL_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SINK_CQL_ENDPOINT_PREPARE_STATEMENTS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_CQL_ENDPOINT_PREPARE_STATEMENTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_PREPARE_STATEMENTS_DOC);
         conf.define(CAMEL_SINK_CQL_ENDPOINT_RESULT_SET_CONVERSION_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_CQL_ENDPOINT_RESULT_SET_CONVERSION_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_CQL_ENDPOINT_RESULT_SET_CONVERSION_STRATEGY_DOC);
diff --git a/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSourceConnectorConfig.java b/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSourceConnectorConfig.java
index fc4a42b..cf61818 100644
--- a/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSourceConnectorConfig.java
+++ b/connectors/camel-cql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/cql/CamelCqlSourceConnectorConfig.java
@@ -36,21 +36,21 @@ public class CamelCqlSourceConnectorConfig extends CamelSourceConnectorConfig {
     public static final String CAMEL_SOURCE_CQL_PATH_KEYSPACE_CONF = "camel.source.path.keyspace";
     public static final String CAMEL_SOURCE_CQL_PATH_KEYSPACE_DOC = "Keyspace to use";
     public static final String CAMEL_SOURCE_CQL_PATH_KEYSPACE_DEFAULT = null;
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_CONF = "camel.source.endpoint.cluster";
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_DOC = "To use the Cluster instance (you would normally not use this option)";
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_DEFAULT = null;
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_NAME_CONF = "camel.source.endpoint.clusterName";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_NAME_DOC = "Cluster name";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_NAME_DEFAULT = null;
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CONSISTENCY_LEVEL_CONF = "camel.source.endpoint.consistencyLevel";
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_CONSISTENCY_LEVEL_DOC = "Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL] [LOCAL_ONE]";
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_CONSISTENCY_LEVEL_DOC = "Consistency level to use One of: [ANY] [ONE] [TWO] [THREE] [QUORUM] [ALL] [LOCAL_ONE] [LOCAL_QUORUM] [EACH_QUORUM] [SERIAL] [LOCAL_SERIAL]";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CONSISTENCY_LEVEL_DEFAULT = null;
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CQL_CONF = "camel.source.endpoint.cql";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CQL_DOC = "CQL query to perform. Can be overridden with the message header with key CamelCqlQuery.";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_CQL_DEFAULT = null;
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CONF = "camel.source.endpoint.loadBalancingPolicy";
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DOC = "To use a specific LoadBalancingPolicy";
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DEFAULT = null;
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_DATACENTER_CONF = "camel.source.endpoint.datacenter";
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_DATACENTER_DOC = "Datacenter to use";
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_DATACENTER_DEFAULT = "datacenter1";
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_CONF = "camel.source.endpoint.loadBalancingPolicyClass";
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DOC = "To use a specific LoadBalancingPolicyClass";
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DEFAULT = null;
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_PASSWORD_CONF = "camel.source.endpoint.password";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_PASSWORD_DOC = "Password for session authentication";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_PASSWORD_DEFAULT = null;
@@ -115,7 +115,7 @@ public class CamelCqlSourceConnectorConfig extends CamelSourceConnectorConfig {
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_CQL_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -152,11 +152,11 @@ public class CamelCqlSourceConnectorConfig extends CamelSourceConnectorConfig {
         conf.define(CAMEL_SOURCE_CQL_PATH_HOSTS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_PATH_HOSTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_PATH_HOSTS_DOC);
         conf.define(CAMEL_SOURCE_CQL_PATH_PORT_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_PATH_PORT_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_PATH_PORT_DOC);
         conf.define(CAMEL_SOURCE_CQL_PATH_KEYSPACE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_PATH_KEYSPACE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_PATH_KEYSPACE_DOC);
-        conf.define(CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_DOC);
         conf.define(CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_CLUSTER_NAME_DOC);
         conf.define(CAMEL_SOURCE_CQL_ENDPOINT_CONSISTENCY_LEVEL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_CONSISTENCY_LEVEL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_CONSISTENCY_LEVEL_DOC);
         conf.define(CAMEL_SOURCE_CQL_ENDPOINT_CQL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_CQL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_CQL_DOC);
-        conf.define(CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_DOC);
+        conf.define(CAMEL_SOURCE_CQL_ENDPOINT_DATACENTER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_DATACENTER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_DATACENTER_DOC);
+        conf.define(CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_LOAD_BALANCING_POLICY_CLASS_DOC);
         conf.define(CAMEL_SOURCE_CQL_ENDPOINT_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_PASSWORD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_PASSWORD_DOC);
         conf.define(CAMEL_SOURCE_CQL_ENDPOINT_PREPARE_STATEMENTS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_CQL_ENDPOINT_PREPARE_STATEMENTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_PREPARE_STATEMENTS_DOC);
         conf.define(CAMEL_SOURCE_CQL_ENDPOINT_RESULT_SET_CONVERSION_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_CQL_ENDPOINT_RESULT_SET_CONVERSION_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_CQL_ENDPOINT_RESULT_SET_CONVERSION_STRATEGY_DOC);
diff --git a/connectors/camel-debezium-mongodb-kafka-connector/src/main/docs/camel-debezium-mongodb-kafka-source-connector.adoc b/connectors/camel-debezium-mongodb-kafka-connector/src/main/docs/camel-debezium-mongodb-kafka-source-connector.adoc
index 2a1077d..eb9cf60 100644
--- a/connectors/camel-debezium-mongodb-kafka-connector/src/main/docs/camel-debezium-mongodb-kafka-source-connector.adoc
+++ b/connectors/camel-debezium-mongodb-kafka-connector/src/main/docs/camel-debezium-mongodb-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-debezium-mongodb-kafka-connector as source make sure to use the
 ----
 
 
-The camel-debezium-mongodb source connector supports 89 options, which are listed below.
+The camel-debezium-mongodb source connector supports 101 options, which are listed below.
 
 
 
@@ -44,9 +44,11 @@ The camel-debezium-mongodb source connector supports 89 options, which are liste
 | *camel.source.endpoint.connectBackoffInitialDelayMs* | The initial delay when trying to reconnect to a primary after a connection cannot be made or when no primary is available. Defaults to 1 second (1000 ms). | 1000L | MEDIUM
 | *camel.source.endpoint.connectBackoffMaxDelayMs* | The maximum delay when trying to reconnect to a primary after a connection cannot be made or when no primary is available. Defaults to 120 second (120,000 ms). | 120000L | MEDIUM
 | *camel.source.endpoint.connectMaxAttempts* | Maximum number of failed connection attempts to a replica set primary before an exception occurs and task is aborted. Defaults to 16, which with the defaults for 'connect.backoff.initial.delay.ms' and 'connect.backoff.max.delay.ms' results in just over 20 minutes of attempts before failing. | 16 | MEDIUM
+| *camel.source.endpoint.converters* | Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.' | null | MEDIUM
 | *camel.source.endpoint.databaseBlacklist* | The databases for which changes are to be excluded | null | MEDIUM
 | *camel.source.endpoint.databaseHistoryFileFilename* | The path to the file that will be used to record the database history | null | MEDIUM
 | *camel.source.endpoint.databaseWhitelist* | The databases for which changes are to be captured | null | MEDIUM
+| *camel.source.endpoint.eventProcessingFailure HandlingMode* | Specify how failures during processing of events (i.e. when encountering a corrupted event) should be handled, including:'fail' (the default) an exception indicating the problematic event and its position is raised, causing the connector to be stopped; 'warn' the problematic event and its position will be logged and the event will be skipped;'ignore' the problematic event will be skipped. | "fail" | MEDIUM
 | *camel.source.endpoint.fieldBlacklist* | Description is not available here, please check Debezium website for corresponding key 'field.blacklist' description. | null | MEDIUM
 | *camel.source.endpoint.fieldRenames* | Description is not available here, please check Debezium website for corresponding key 'field.renames' description. | null | MEDIUM
 | *camel.source.endpoint.heartbeatIntervalMs* | Length of an interval in milli-seconds in in which the connector periodically sends heartbeat messages to a heartbeat topic. Use 0 to disable heartbeat messages. Disabled by default. | 0 | MEDIUM
@@ -54,14 +56,18 @@ The camel-debezium-mongodb source connector supports 89 options, which are liste
 | *camel.source.endpoint.initialSyncMaxThreads* | Maximum number of threads used to perform an initial sync of the collections in a replica set. Defaults to 1. | 1 | MEDIUM
 | *camel.source.endpoint.maxBatchSize* | Maximum size of each batch of source records. Defaults to 2048. | 2048 | MEDIUM
 | *camel.source.endpoint.maxQueueSize* | Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size. | 8192 | MEDIUM
+| *camel.source.endpoint.mongodbAuthsource* | Database containing user credentials. | "admin" | MEDIUM
 | *camel.source.endpoint.mongodbHosts* | The hostname and port pairs (in the form 'host' or 'host:port') of the MongoDB server(s) in the replica set. | null | MEDIUM
 | *camel.source.endpoint.mongodbMembersAutoDiscover* | Specifies whether the addresses in 'hosts' are seeds that should be used to discover all members of the cluster or replica set ('true'), or whether the address(es) in 'hosts' should be used as is ('false'). The default is 'true'. | true | MEDIUM
 | *camel.source.endpoint.mongodbName* | Unique name that identifies the MongoDB replica set or cluster and all recorded offsets, andthat is used as a prefix for all schemas and topics. Each distinct MongoDB installation should have a separate namespace and monitored by at most one Debezium connector. | null | HIGH
 | *camel.source.endpoint.mongodbPassword* | Password to be used when connecting to MongoDB, if necessary. | null | HIGH
+| *camel.source.endpoint.mongodbPollIntervalSec* | Frequency in seconds to look for new, removed, or changed replica sets. Defaults to 30 seconds. | 30 | MEDIUM
 | *camel.source.endpoint.mongodbSslEnabled* | Should connector use SSL to connect to MongoDB instances | false | MEDIUM
 | *camel.source.endpoint.mongodbSslInvalidHostname Allowed* | Whether invalid host names are allowed when using SSL. If true the connection will not prevent man-in-the-middle attacks | false | MEDIUM
 | *camel.source.endpoint.mongodbUser* | Database user for connecting to MongoDB, if necessary. | null | MEDIUM
 | *camel.source.endpoint.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
+| *camel.source.endpoint.provideTransactionMetadata* | Enables transaction metadata extraction together with event counting | false | MEDIUM
+| *camel.source.endpoint.sanitizeFieldNames* | Whether field names will be sanitized to Avro naming conventions | false | MEDIUM
 | *camel.source.endpoint.skippedOperations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.source.endpoint.snapshotDelayMs* | The number of milliseconds to delay before a snapshot will begin. | 0L | MEDIUM
 | *camel.source.endpoint.snapshotFetchSize* | The maximum number of records that should be loaded into memory while performing a snapshot | null | MEDIUM
@@ -87,9 +93,11 @@ The camel-debezium-mongodb source connector supports 89 options, which are liste
 | *camel.component.debezium-mongodb.connectBackoff InitialDelayMs* | The initial delay when trying to reconnect to a primary after a connection cannot be made or when no primary is available. Defaults to 1 second (1000 ms). | 1000L | MEDIUM
 | *camel.component.debezium-mongodb.connectBackoffMax DelayMs* | The maximum delay when trying to reconnect to a primary after a connection cannot be made or when no primary is available. Defaults to 120 second (120,000 ms). | 120000L | MEDIUM
 | *camel.component.debezium-mongodb.connectMax Attempts* | Maximum number of failed connection attempts to a replica set primary before an exception occurs and task is aborted. Defaults to 16, which with the defaults for 'connect.backoff.initial.delay.ms' and 'connect.backoff.max.delay.ms' results in just over 20 minutes of attempts before failing. | 16 | MEDIUM
+| *camel.component.debezium-mongodb.converters* | Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.' | null | MEDIUM
 | *camel.component.debezium-mongodb.databaseBlacklist* | The databases for which changes are to be excluded | null | MEDIUM
 | *camel.component.debezium-mongodb.databaseHistory FileFilename* | The path to the file that will be used to record the database history | null | MEDIUM
 | *camel.component.debezium-mongodb.databaseWhitelist* | The databases for which changes are to be captured | null | MEDIUM
+| *camel.component.debezium-mongodb.eventProcessing FailureHandlingMode* | Specify how failures during processing of events (i.e. when encountering a corrupted event) should be handled, including:'fail' (the default) an exception indicating the problematic event and its position is raised, causing the connector to be stopped; 'warn' the problematic event and its position will be logged and the event will be skipped;'ignore' the problematic event will be skipped. | "fail" | MEDIUM
 | *camel.component.debezium-mongodb.fieldBlacklist* | Description is not available here, please check Debezium website for corresponding key 'field.blacklist' description. | null | MEDIUM
 | *camel.component.debezium-mongodb.fieldRenames* | Description is not available here, please check Debezium website for corresponding key 'field.renames' description. | null | MEDIUM
 | *camel.component.debezium-mongodb.heartbeatInterval Ms* | Length of an interval in milli-seconds in in which the connector periodically sends heartbeat messages to a heartbeat topic. Use 0 to disable heartbeat messages. Disabled by default. | 0 | MEDIUM
@@ -97,14 +105,18 @@ The camel-debezium-mongodb source connector supports 89 options, which are liste
 | *camel.component.debezium-mongodb.initialSyncMax Threads* | Maximum number of threads used to perform an initial sync of the collections in a replica set. Defaults to 1. | 1 | MEDIUM
 | *camel.component.debezium-mongodb.maxBatchSize* | Maximum size of each batch of source records. Defaults to 2048. | 2048 | MEDIUM
 | *camel.component.debezium-mongodb.maxQueueSize* | Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size. | 8192 | MEDIUM
+| *camel.component.debezium-mongodb.mongodbAuthsource* | Database containing user credentials. | "admin" | MEDIUM
 | *camel.component.debezium-mongodb.mongodbHosts* | The hostname and port pairs (in the form 'host' or 'host:port') of the MongoDB server(s) in the replica set. | null | MEDIUM
 | *camel.component.debezium-mongodb.mongodbMembers AutoDiscover* | Specifies whether the addresses in 'hosts' are seeds that should be used to discover all members of the cluster or replica set ('true'), or whether the address(es) in 'hosts' should be used as is ('false'). The default is 'true'. | true | MEDIUM
 | *camel.component.debezium-mongodb.mongodbName* | Unique name that identifies the MongoDB replica set or cluster and all recorded offsets, andthat is used as a prefix for all schemas and topics. Each distinct MongoDB installation should have a separate namespace and monitored by at most one Debezium connector. | null | HIGH
 | *camel.component.debezium-mongodb.mongodbPassword* | Password to be used when connecting to MongoDB, if necessary. | null | HIGH
+| *camel.component.debezium-mongodb.mongodbPoll IntervalSec* | Frequency in seconds to look for new, removed, or changed replica sets. Defaults to 30 seconds. | 30 | MEDIUM
 | *camel.component.debezium-mongodb.mongodbSslEnabled* | Should connector use SSL to connect to MongoDB instances | false | MEDIUM
 | *camel.component.debezium-mongodb.mongodbSslInvalid HostnameAllowed* | Whether invalid host names are allowed when using SSL. If true the connection will not prevent man-in-the-middle attacks | false | MEDIUM
 | *camel.component.debezium-mongodb.mongodbUser* | Database user for connecting to MongoDB, if necessary. | null | MEDIUM
 | *camel.component.debezium-mongodb.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
+| *camel.component.debezium-mongodb.provide TransactionMetadata* | Enables transaction metadata extraction together with event counting | false | MEDIUM
+| *camel.component.debezium-mongodb.sanitizeField Names* | Whether field names will be sanitized to Avro naming conventions | false | MEDIUM
 | *camel.component.debezium-mongodb.skippedOperations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.component.debezium-mongodb.snapshotDelayMs* | The number of milliseconds to delay before a snapshot will begin. | 0L | MEDIUM
 | *camel.component.debezium-mongodb.snapshotFetchSize* | The maximum number of records that should be loaded into memory while performing a snapshot | null | MEDIUM
diff --git a/connectors/camel-debezium-mongodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummongodb/CamelDebeziummongodbSourceConnectorConfig.java b/connectors/camel-debezium-mongodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummongodb/CamelDebeziummongodbSourceConnectorConfig.java
index bbde7d0..8c206fd 100644
--- a/connectors/camel-debezium-mongodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummongodb/CamelDebeziummongodbSourceConnectorConfig.java
+++ b/connectors/camel-debezium-mongodb-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummongodb/CamelDebeziummongodbSourceConnectorConfig.java
@@ -92,6 +92,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_MAX_ATTEMPTS_CONF = "camel.source.endpoint.connectMaxAttempts";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_MAX_ATTEMPTS_DOC = "Maximum number of failed connection attempts to a replica set primary before an exception occurs and task is aborted. Defaults to 16, which with the defaults for 'connect.backoff.initial.delay.ms' and 'connect.backoff.max.delay.ms' results in just over 20 minutes of attempts before failing.";
     public static final Integer CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_MAX_ATTEMPTS_DEFAULT = 16;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONVERTERS_CONF = "camel.source.endpoint.converters";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONVERTERS_DOC = "Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.'";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONVERTERS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_BLACKLIST_CONF = "camel.source.endpoint.databaseBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_BLACKLIST_DOC = "The databases for which changes are to be excluded";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_BLACKLIST_DEFAULT = null;
@@ -101,6 +104,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_WHITELIST_CONF = "camel.source.endpoint.databaseWhitelist";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_WHITELIST_DOC = "The databases for which changes are to be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_CONF = "camel.source.endpoint.eventProcessingFailureHandlingMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DOC = "Specify how failures during processing of events (i.e. when encountering a corrupted event) should be handled, including:'fail' (the default) an exception indicating the problematic event and its position is raised, causing the connector to be stopped; 'warn' the problematic event and its position will be logged and the event will be skipped;'ignore' the problematic event wi [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DEFAULT = "fail";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_BLACKLIST_CONF = "camel.source.endpoint.fieldBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'field.blacklist' description.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_BLACKLIST_DEFAULT = null;
@@ -122,6 +128,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_QUEUE_SIZE_CONF = "camel.source.endpoint.maxQueueSize";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_QUEUE_SIZE_DOC = "Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size.";
     public static final Integer CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_QUEUE_SIZE_DEFAULT = 8192;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_AUTHSOURCE_CONF = "camel.source.endpoint.mongodbAuthsource";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_AUTHSOURCE_DOC = "Database containing user credentials.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_AUTHSOURCE_DEFAULT = "admin";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_HOSTS_CONF = "camel.source.endpoint.mongodbHosts";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_HOSTS_DOC = "The hostname and port pairs (in the form 'host' or 'host:port') of the MongoDB server(s) in the replica set.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_HOSTS_DEFAULT = null;
@@ -134,6 +143,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_PASSWORD_CONF = "camel.source.endpoint.mongodbPassword";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_PASSWORD_DOC = "Password to be used when connecting to MongoDB, if necessary.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_PASSWORD_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_POLL_INTERVAL_SEC_CONF = "camel.source.endpoint.mongodbPollIntervalSec";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_POLL_INTERVAL_SEC_DOC = "Frequency in seconds to look for new, removed, or changed replica sets. Defaults to 30 seconds.";
+    public static final Integer CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_POLL_INTERVAL_SEC_DEFAULT = 30;
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_ENABLED_CONF = "camel.source.endpoint.mongodbSslEnabled";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_ENABLED_DOC = "Should connector use SSL to connect to MongoDB instances";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_ENABLED_DEFAULT = false;
@@ -146,6 +158,12 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_POLL_INTERVAL_MS_CONF = "camel.source.endpoint.pollIntervalMs";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_POLL_INTERVAL_MS_DOC = "Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms.";
     public static final Long CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_POLL_INTERVAL_MS_DEFAULT = 500L;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_PROVIDE_TRANSACTION_METADATA_CONF = "camel.source.endpoint.provideTransactionMetadata";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DOC = "Enables transaction metadata extraction together with event counting";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SANITIZE_FIELD_NAMES_CONF = "camel.source.endpoint.sanitizeFieldNames";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SANITIZE_FIELD_NAMES_DOC = "Whether field names will be sanitized to Avro naming conventions";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SANITIZE_FIELD_NAMES_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SKIPPED_OPERATIONS_CONF = "camel.source.endpoint.skippedOperations";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT = null;
@@ -221,6 +239,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_MAX_ATTEMPTS_CONF = "camel.component.debezium-mongodb.connectMaxAttempts";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_MAX_ATTEMPTS_DOC = "Maximum number of failed connection attempts to a replica set primary before an exception occurs and task is aborted. Defaults to 16, which with the defaults for 'connect.backoff.initial.delay.ms' and 'connect.backoff.max.delay.ms' results in just over 20 minutes of attempts before failing.";
     public static final Integer CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_MAX_ATTEMPTS_DEFAULT = 16;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONVERTERS_CONF = "camel.component.debezium-mongodb.converters";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONVERTERS_DOC = "Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.'";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONVERTERS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_BLACKLIST_CONF = "camel.component.debezium-mongodb.databaseBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_BLACKLIST_DOC = "The databases for which changes are to be excluded";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_BLACKLIST_DEFAULT = null;
@@ -230,6 +251,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_WHITELIST_CONF = "camel.component.debezium-mongodb.databaseWhitelist";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_WHITELIST_DOC = "The databases for which changes are to be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_CONF = "camel.component.debezium-mongodb.eventProcessingFailureHandlingMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DOC = "Specify how failures during processing of events (i.e. when encountering a corrupted event) should be handled, including:'fail' (the default) an exception indicating the problematic event and its position is raised, causing the connector to be stopped; 'warn' the problematic event and its position will be logged and the event will be skipped;'ignore' the problematic event w [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DEFAULT = "fail";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_BLACKLIST_CONF = "camel.component.debezium-mongodb.fieldBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'field.blacklist' description.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_BLACKLIST_DEFAULT = null;
@@ -251,6 +275,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_QUEUE_SIZE_CONF = "camel.component.debezium-mongodb.maxQueueSize";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_QUEUE_SIZE_DOC = "Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size.";
     public static final Integer CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_QUEUE_SIZE_DEFAULT = 8192;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_AUTHSOURCE_CONF = "camel.component.debezium-mongodb.mongodbAuthsource";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_AUTHSOURCE_DOC = "Database containing user credentials.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_AUTHSOURCE_DEFAULT = "admin";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_HOSTS_CONF = "camel.component.debezium-mongodb.mongodbHosts";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_HOSTS_DOC = "The hostname and port pairs (in the form 'host' or 'host:port') of the MongoDB server(s) in the replica set.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_HOSTS_DEFAULT = null;
@@ -263,6 +290,9 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_PASSWORD_CONF = "camel.component.debezium-mongodb.mongodbPassword";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_PASSWORD_DOC = "Password to be used when connecting to MongoDB, if necessary.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_PASSWORD_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_POLL_INTERVAL_SEC_CONF = "camel.component.debezium-mongodb.mongodbPollIntervalSec";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_POLL_INTERVAL_SEC_DOC = "Frequency in seconds to look for new, removed, or changed replica sets. Defaults to 30 seconds.";
+    public static final Integer CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_POLL_INTERVAL_SEC_DEFAULT = 30;
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_ENABLED_CONF = "camel.component.debezium-mongodb.mongodbSslEnabled";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_ENABLED_DOC = "Should connector use SSL to connect to MongoDB instances";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_ENABLED_DEFAULT = false;
@@ -275,6 +305,12 @@ public class CamelDebeziummongodbSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_POLL_INTERVAL_MS_CONF = "camel.component.debezium-mongodb.pollIntervalMs";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_POLL_INTERVAL_MS_DOC = "Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms.";
     public static final Long CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_POLL_INTERVAL_MS_DEFAULT = 500L;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_PROVIDE_TRANSACTION_METADATA_CONF = "camel.component.debezium-mongodb.provideTransactionMetadata";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_PROVIDE_TRANSACTION_METADATA_DOC = "Enables transaction metadata extraction together with event counting";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_PROVIDE_TRANSACTION_METADATA_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SANITIZE_FIELD_NAMES_CONF = "camel.component.debezium-mongodb.sanitizeFieldNames";
+    public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SANITIZE_FIELD_NAMES_DOC = "Whether field names will be sanitized to Avro naming conventions";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SANITIZE_FIELD_NAMES_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SKIPPED_OPERATIONS_CONF = "camel.component.debezium-mongodb.skippedOperations";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
     public static final String CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SKIPPED_OPERATIONS_DEFAULT = null;
@@ -329,9 +365,11 @@ public class CamelDebeziummongodbSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_BACKOFF_INITIAL_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_BACKOFF_INITIAL_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_BACKOFF_INITIAL_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_BACKOFF_MAX_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_BACKOFF_MAX_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_BACKOFF_MAX_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_MAX_ATTEMPTS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_MAX_ATTEMPTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONNECT_MAX_ATTEMPTS_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONVERTERS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONVERTERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_CONVERTERS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_DATABASE_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_RENAMES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_RENAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_FIELD_RENAMES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_HEARTBEAT_INTERVAL_MS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_HEARTBEAT_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_HEARTBEAT_INTERVAL_MS_DOC);
@@ -339,14 +377,18 @@ public class CamelDebeziummongodbSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_INITIAL_SYNC_MAX_THREADS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_INITIAL_SYNC_MAX_THREADS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_INITIAL_SYNC_MAX_THREADS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_BATCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_BATCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_BATCH_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_QUEUE_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_QUEUE_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MAX_QUEUE_SIZE_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_AUTHSOURCE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_AUTHSOURCE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_AUTHSOURCE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_HOSTS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_HOSTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_HOSTS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_MEMBERS_AUTO_DISCOVER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_MEMBERS_AUTO_DISCOVER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_MEMBERS_AUTO_DISCOVER_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_NAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_PASSWORD_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_PASSWORD_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_POLL_INTERVAL_SEC_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_POLL_INTERVAL_SEC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_POLL_INTERVAL_SEC_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_ENABLED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_ENABLED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_ENABLED_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_INVALID_HOSTNAME_ALLOWED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_INVALID_HOSTNAME_ALLOWED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_SSL_INVALID_HOSTNAME_ALLOWED_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_USER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_USER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_MONGODB_USER_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_POLL_INTERVAL_MS_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_PROVIDE_TRANSACTION_METADATA_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SANITIZE_FIELD_NAMES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SANITIZE_FIELD_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SANITIZE_FIELD_NAMES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SNAPSHOT_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SNAPSHOT_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SNAPSHOT_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SNAPSHOT_FETCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SNAPSHOT_FETCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_ENDPOINT_SNAPSHOT_FETCH_SIZE_DOC);
@@ -372,9 +414,11 @@ public class CamelDebeziummongodbSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_BACKOFF_INITIAL_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_BACKOFF_INITIAL_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_BACKOFF_INITIAL_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_BACKOFF_MAX_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_BACKOFF_MAX_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_BACKOFF_MAX_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_MAX_ATTEMPTS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_MAX_ATTEMPTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONNECT_MAX_ATTEMPTS_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONVERTERS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONVERTERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_CONVERTERS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_DATABASE_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_RENAMES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_RENAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_FIELD_RENAMES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_HEARTBEAT_INTERVAL_MS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_HEARTBEAT_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_HEARTBEAT_INTERVAL_MS_DOC);
@@ -382,14 +426,18 @@ public class CamelDebeziummongodbSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_INITIAL_SYNC_MAX_THREADS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_INITIAL_SYNC_MAX_THREADS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_INITIAL_SYNC_MAX_THREADS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_BATCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_BATCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_BATCH_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_QUEUE_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_QUEUE_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MAX_QUEUE_SIZE_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_AUTHSOURCE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_AUTHSOURCE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_AUTHSOURCE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_HOSTS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_HOSTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_HOSTS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_MEMBERS_AUTO_DISCOVER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_MEMBERS_AUTO_DISCOVER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_MEMBERS_AUTO_DISCOVER_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_NAME_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_NAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_PASSWORD_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_PASSWORD_DEFAULT, ConfigDef.Importance.HIGH, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_PASSWORD_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_POLL_INTERVAL_SEC_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_POLL_INTERVAL_SEC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_POLL_INTERVAL_SEC_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_ENABLED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_ENABLED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_ENABLED_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_INVALID_HOSTNAME_ALLOWED_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_INVALID_HOSTNAME_ALLOWED_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_SSL_INVALID_HOSTNAME_ALLOWED_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_USER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_USER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_MONGODB_USER_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_POLL_INTERVAL_MS_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_PROVIDE_TRANSACTION_METADATA_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_PROVIDE_TRANSACTION_METADATA_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_PROVIDE_TRANSACTION_METADATA_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SANITIZE_FIELD_NAMES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SANITIZE_FIELD_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SANITIZE_FIELD_NAMES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SNAPSHOT_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SNAPSHOT_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SNAPSHOT_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SNAPSHOT_FETCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SNAPSHOT_FETCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMONGODB_COMPONENT_SNAPSHOT_FETCH_SIZE_DOC);
diff --git a/connectors/camel-debezium-mysql-kafka-connector/src/main/docs/camel-debezium-mysql-kafka-source-connector.adoc b/connectors/camel-debezium-mysql-kafka-connector/src/main/docs/camel-debezium-mysql-kafka-source-connector.adoc
index 717ae96..3b6d50a 100644
--- a/connectors/camel-debezium-mysql-kafka-connector/src/main/docs/camel-debezium-mysql-kafka-source-connector.adoc
+++ b/connectors/camel-debezium-mysql-kafka-connector/src/main/docs/camel-debezium-mysql-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-debezium-mysql-kafka-connector as source make sure to use the f
 ----
 
 
-The camel-debezium-mysql source connector supports 149 options, which are listed below.
+The camel-debezium-mysql source connector supports 153 options, which are listed below.
 
 
 
@@ -40,8 +40,9 @@ The camel-debezium-mysql source connector supports 149 options, which are listed
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.source.endpoint.bigintUnsignedHandlingMode* | Specify how BIGINT UNSIGNED columns should be represented in change events, including:'precise' uses java.math.BigDecimal to represent values, which are encoded in the change events using a binary representation and Kafka Connect's 'org.apache.kafka.connect.data.Decimal' type; 'long' (the default) represents values using Java's 'long', which may not offer the precision but will be far easier to use in consumers. | "long" | MEDIUM
+| *camel.source.endpoint.binaryHandlingMode* | Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string | "bytes" | MEDIUM
 | *camel.source.endpoint.binlogBufferSize* | The size of a look-ahead buffer used by the binlog reader to decide whether the transaction in progress is going to be committed or rolled back. Use 0 to disable look-ahead buffering. Defaults to 0 (i.e. buffering is disabled). | 0 | MEDIUM
-| *camel.source.endpoint.columnBlacklist* | Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description. | null | MEDIUM
+| *camel.source.endpoint.columnBlacklist* | Regular expressions matching columns to exclude from change events | null | MEDIUM
 | *camel.source.endpoint.connectKeepAlive* | Whether a separate thread should be used to ensure the connection is kept alive. | true | MEDIUM
 | *camel.source.endpoint.connectKeepAliveIntervalMs* | Interval in milliseconds to wait for connection checking if keep alive thread is used. | 60000L | MEDIUM
 | *camel.source.endpoint.connectTimeoutMs* | Maximum time in milliseconds to wait after trying to connect to the database before timing out. | 30000 | MEDIUM
@@ -80,16 +81,17 @@ The camel-debezium-mysql source connector supports 149 options, which are listed
 | *camel.source.endpoint.heartbeatIntervalMs* | Length of an interval in milli-seconds in in which the connector periodically sends heartbeat messages to a heartbeat topic. Use 0 to disable heartbeat messages. Disabled by default. | 0 | MEDIUM
 | *camel.source.endpoint.heartbeatTopicsPrefix* | The prefix that is used to name heartbeat topics.Defaults to __debezium-heartbeat. | "__debezium-heartbeat" | MEDIUM
 | *camel.source.endpoint.includeQuery* | Whether the connector should include the original SQL query that generated the change event. Note: This option requires MySQL be configured with the binlog_rows_query_log_events option set to ON. Query will not be present for events generated from snapshot. WARNING: Enabling this option may expose tables or fields explicitly blacklisted or masked by including the original SQL statement in the change event. For this reason the default value is 'fal [...]
-| *camel.source.endpoint.includeSchemaChanges* | Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value includes the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history. | true | MEDIUM
+| *camel.source.endpoint.includeSchemaChanges* | Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history. | true | MEDIUM
 | *camel.source.endpoint.inconsistentSchemaHandling Mode* | Specify how binlog events that belong to a table missing from internal schema representation (i.e. internal representation is not consistent with database) should be handled, including:'fail' (the default) an exception indicating the problematic event and its binlog position is raised, causing the connector to be stopped; 'warn' the problematic event and its binlog position will be logged and the event will be skipped;'skip' the [...]
 | *camel.source.endpoint.maxBatchSize* | Maximum size of each batch of source records. Defaults to 2048. | 2048 | MEDIUM
 | *camel.source.endpoint.maxQueueSize* | Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size. | 8192 | MEDIUM
 | *camel.source.endpoint.messageKeyColumns* | A semicolon-separated list of expressions that match fully-qualified tables and column(s) to be used as message key. Each expression must match the pattern ':',where the table names could be defined as (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on the specific connector,and the key columns are a comma-separated list of columns representing the custom key. For any table without an explicit key configuration the table's primary [...]
 | *camel.source.endpoint.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
+| *camel.source.endpoint.skippedOperations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.source.endpoint.snapshotDelayMs* | The number of milliseconds to delay before a snapshot will begin. | 0L | MEDIUM
 | *camel.source.endpoint.snapshotFetchSize* | The maximum number of records that should be loaded into memory while performing a snapshot | null | MEDIUM
 | *camel.source.endpoint.snapshotLockingMode* | Controls how long the connector holds onto the global read lock while it is performing a snapshot. The default is 'minimal', which means the connector holds the global read lock (and thus prevents any updates) for just the initial portion of the snapshot while the database schemas and other metadata are being read. The remaining work in a snapshot involves selecting all rows from each table, and this can be done using the snapshot process'  [...]
-| *camel.source.endpoint.snapshotMode* | The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical server name; 'initial_only' same as 'initial' except the connector should stop after completing the snapshot and before it would normally read t [...]
+| *camel.source.endpoint.snapshotMode* | The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'schema_only' to only take a snapshot of the schema (table structures) but no actual data; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical server name; 'initial_only' same as 'initial' except  [...]
 | *camel.source.endpoint.snapshotNewTables* | BETA FEATURE: On connector restart, the connector will check if there have been any new tables added to the configuration, and snapshot them. There is presently only two options:'off': Default behavior. Do not snapshot new tables.'parallel': The snapshot of the new tables will occur in parallel to the continued binlog reading of the old tables. When the snapshot completes, an independent binlog reader will begin reading the events for the new [...]
 | *camel.source.endpoint.snapshotSelectStatement Overrides* | This property contains a comma-separated list of fully-qualified tables (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on thespecific connectors . Select statements for the individual tables are specified in further configuration properties, one for each table, identified by the id 'snapshot.select.statement.overrides.DB_NAME.TABLE_NAME' or 'snapshot.select.statement.overrides.SCHEMA_NAME.TABLE_NAME', respectively [...]
 | *camel.source.endpoint.sourceStructVersion* | A version of the format of the publicly visible source part in the message | "v2" | MEDIUM
@@ -113,8 +115,9 @@ The camel-debezium-mysql source connector supports 149 options, which are listed
 | *camel.component.debezium-mysql.offsetStorageTopic* | The name of the Kafka topic where offsets are to be stored. Required when offset.storage is set to the KafkaOffsetBackingStore. | null | MEDIUM
 | *camel.component.debezium-mysql.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.component.debezium-mysql.bigintUnsigned HandlingMode* | Specify how BIGINT UNSIGNED columns should be represented in change events, including:'precise' uses java.math.BigDecimal to represent values, which are encoded in the change events using a binary representation and Kafka Connect's 'org.apache.kafka.connect.data.Decimal' type; 'long' (the default) represents values using Java's 'long', which may not offer the precision but will be far easier to use in consumers. | "long" | MEDIUM
+| *camel.component.debezium-mysql.binaryHandlingMode* | Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string | "bytes" | MEDIUM
 | *camel.component.debezium-mysql.binlogBufferSize* | The size of a look-ahead buffer used by the binlog reader to decide whether the transaction in progress is going to be committed or rolled back. Use 0 to disable look-ahead buffering. Defaults to 0 (i.e. buffering is disabled). | 0 | MEDIUM
-| *camel.component.debezium-mysql.columnBlacklist* | Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description. | null | MEDIUM
+| *camel.component.debezium-mysql.columnBlacklist* | Regular expressions matching columns to exclude from change events | null | MEDIUM
 | *camel.component.debezium-mysql.connectKeepAlive* | Whether a separate thread should be used to ensure the connection is kept alive. | true | MEDIUM
 | *camel.component.debezium-mysql.connectKeepAlive IntervalMs* | Interval in milliseconds to wait for connection checking if keep alive thread is used. | 60000L | MEDIUM
 | *camel.component.debezium-mysql.connectTimeoutMs* | Maximum time in milliseconds to wait after trying to connect to the database before timing out. | 30000 | MEDIUM
@@ -153,16 +156,17 @@ The camel-debezium-mysql source connector supports 149 options, which are listed
 | *camel.component.debezium-mysql.heartbeatIntervalMs* | Length of an interval in milli-seconds in in which the connector periodically sends heartbeat messages to a heartbeat topic. Use 0 to disable heartbeat messages. Disabled by default. | 0 | MEDIUM
 | *camel.component.debezium-mysql.heartbeatTopics Prefix* | The prefix that is used to name heartbeat topics.Defaults to __debezium-heartbeat. | "__debezium-heartbeat" | MEDIUM
 | *camel.component.debezium-mysql.includeQuery* | Whether the connector should include the original SQL query that generated the change event. Note: This option requires MySQL be configured with the binlog_rows_query_log_events option set to ON. Query will not be present for events generated from snapshot. WARNING: Enabling this option may expose tables or fields explicitly blacklisted or masked by including the original SQL statement in the change event. For this reason the default valu [...]
-| *camel.component.debezium-mysql.includeSchema Changes* | Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value includes the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history. | true | MEDIUM
+| *camel.component.debezium-mysql.includeSchema Changes* | Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history. | true | MEDIUM
 | *camel.component.debezium-mysql.inconsistentSchema HandlingMode* | Specify how binlog events that belong to a table missing from internal schema representation (i.e. internal representation is not consistent with database) should be handled, including:'fail' (the default) an exception indicating the problematic event and its binlog position is raised, causing the connector to be stopped; 'warn' the problematic event and its binlog position will be logged and the event will be skipped;' [...]
 | *camel.component.debezium-mysql.maxBatchSize* | Maximum size of each batch of source records. Defaults to 2048. | 2048 | MEDIUM
 | *camel.component.debezium-mysql.maxQueueSize* | Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size. | 8192 | MEDIUM
 | *camel.component.debezium-mysql.messageKeyColumns* | A semicolon-separated list of expressions that match fully-qualified tables and column(s) to be used as message key. Each expression must match the pattern ':',where the table names could be defined as (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on the specific connector,and the key columns are a comma-separated list of columns representing the custom key. For any table without an explicit key configuration the table' [...]
 | *camel.component.debezium-mysql.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
+| *camel.component.debezium-mysql.skippedOperations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.component.debezium-mysql.snapshotDelayMs* | The number of milliseconds to delay before a snapshot will begin. | 0L | MEDIUM
 | *camel.component.debezium-mysql.snapshotFetchSize* | The maximum number of records that should be loaded into memory while performing a snapshot | null | MEDIUM
 | *camel.component.debezium-mysql.snapshotLockingMode* | Controls how long the connector holds onto the global read lock while it is performing a snapshot. The default is 'minimal', which means the connector holds the global read lock (and thus prevents any updates) for just the initial portion of the snapshot while the database schemas and other metadata are being read. The remaining work in a snapshot involves selecting all rows from each table, and this can be done using the snapshot  [...]
-| *camel.component.debezium-mysql.snapshotMode* | The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical server name; 'initial_only' same as 'initial' except the connector should stop after completing the snapshot and before it would normal [...]
+| *camel.component.debezium-mysql.snapshotMode* | The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'schema_only' to only take a snapshot of the schema (table structures) but no actual data; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical server name; 'initial_only' same as 'initial [...]
 | *camel.component.debezium-mysql.snapshotNewTables* | BETA FEATURE: On connector restart, the connector will check if there have been any new tables added to the configuration, and snapshot them. There is presently only two options:'off': Default behavior. Do not snapshot new tables.'parallel': The snapshot of the new tables will occur in parallel to the continued binlog reading of the old tables. When the snapshot completes, an independent binlog reader will begin reading the events fo [...]
 | *camel.component.debezium-mysql.snapshotSelect StatementOverrides* | This property contains a comma-separated list of fully-qualified tables (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on thespecific connectors . Select statements for the individual tables are specified in further configuration properties, one for each table, identified by the id 'snapshot.select.statement.overrides.DB_NAME.TABLE_NAME' or 'snapshot.select.statement.overrides.SCHEMA_NAME.TABLE_NAME', res [...]
 | *camel.component.debezium-mysql.sourceStructVersion* | A version of the format of the publicly visible source part in the message | "v2" | MEDIUM
diff --git a/connectors/camel-debezium-mysql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummysql/CamelDebeziummysqlSourceConnectorConfig.java b/connectors/camel-debezium-mysql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummysql/CamelDebeziummysqlSourceConnectorConfig.java
index 42e8a2a..dad5e9c 100644
--- a/connectors/camel-debezium-mysql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummysql/CamelDebeziummysqlSourceConnectorConfig.java
+++ b/connectors/camel-debezium-mysql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziummysql/CamelDebeziummysqlSourceConnectorConfig.java
@@ -80,11 +80,14 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BIGINT_UNSIGNED_HANDLING_MODE_CONF = "camel.source.endpoint.bigintUnsignedHandlingMode";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BIGINT_UNSIGNED_HANDLING_MODE_DOC = "Specify how BIGINT UNSIGNED columns should be represented in change events, including:'precise' uses java.math.BigDecimal to represent values, which are encoded in the change events using a binary representation and Kafka Connect's 'org.apache.kafka.connect.data.Decimal' type; 'long' (the default) represents values using Java's 'long', which may not offer the precision but will be far  [...]
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BIGINT_UNSIGNED_HANDLING_MODE_DEFAULT = "long";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINARY_HANDLING_MODE_CONF = "camel.source.endpoint.binaryHandlingMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINARY_HANDLING_MODE_DOC = "Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINARY_HANDLING_MODE_DEFAULT = "bytes";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINLOG_BUFFER_SIZE_CONF = "camel.source.endpoint.binlogBufferSize";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINLOG_BUFFER_SIZE_DOC = "The size of a look-ahead buffer used by the binlog reader to decide whether the transaction in progress is going to be committed or rolled back. Use 0 to disable look-ahead buffering. Defaults to 0 (i.e. buffering is disabled).";
     public static final Integer CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINLOG_BUFFER_SIZE_DEFAULT = 0;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_COLUMN_BLACKLIST_CONF = "camel.source.endpoint.columnBlacklist";
-    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_COLUMN_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_COLUMN_BLACKLIST_DOC = "Regular expressions matching columns to exclude from change events";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_COLUMN_BLACKLIST_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_CONNECT_KEEP_ALIVE_CONF = "camel.source.endpoint.connectKeepAlive";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_CONNECT_KEEP_ALIVE_DOC = "Whether a separate thread should be used to ensure the connection is kept alive.";
@@ -201,7 +204,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCLUDE_QUERY_DOC = "Whether the connector should include the original SQL query that generated the change event. Note: This option requires MySQL be configured with the binlog_rows_query_log_events option set to ON. Query will not be present for events generated from snapshot. WARNING: Enabling this option may expose tables or fields explicitly blacklisted or masked by including the original SQL statement in the change e [...]
     public static final Boolean CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCLUDE_QUERY_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCLUDE_SCHEMA_CHANGES_CONF = "camel.source.endpoint.includeSchemaChanges";
-    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCLUDE_SCHEMA_CHANGES_DOC = "Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value includes the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCLUDE_SCHEMA_CHANGES_DOC = "Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally records dat [...]
     public static final Boolean CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCLUDE_SCHEMA_CHANGES_DEFAULT = true;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCONSISTENT_SCHEMA_HANDLING_MODE_CONF = "camel.source.endpoint.inconsistentSchemaHandlingMode";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_INCONSISTENT_SCHEMA_HANDLING_MODE_DOC = "Specify how binlog events that belong to a table missing from internal schema representation (i.e. internal representation is not consistent with database) should be handled, including:'fail' (the default) an exception indicating the problematic event and its binlog position is raised, causing the connector to be stopped; 'warn' the problematic event and its binlog position will be [...]
@@ -218,6 +221,9 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_POLL_INTERVAL_MS_CONF = "camel.source.endpoint.pollIntervalMs";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_POLL_INTERVAL_MS_DOC = "Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms.";
     public static final Long CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_POLL_INTERVAL_MS_DEFAULT = 500L;
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SKIPPED_OPERATIONS_CONF = "camel.source.endpoint.skippedOperations";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_DELAY_MS_CONF = "camel.source.endpoint.snapshotDelayMs";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_DELAY_MS_DOC = "The number of milliseconds to delay before a snapshot will begin.";
     public static final Long CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_DELAY_MS_DEFAULT = 0L;
@@ -228,7 +234,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_LOCKING_MODE_DOC = "Controls how long the connector holds onto the global read lock while it is performing a snapshot. The default is 'minimal', which means the connector holds the global read lock (and thus prevents any updates) for just the initial portion of the snapshot while the database schemas and other metadata are being read. The remaining work in a snapshot involves selecting all rows from each table, a [...]
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_LOCKING_MODE_DEFAULT = "minimal";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_MODE_CONF = "camel.source.endpoint.snapshotMode";
-    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_MODE_DOC = "The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical server name; 'initial_only' same as 'initial' except the connector should stop after completing t [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_MODE_DOC = "The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'schema_only' to only take a snapshot of the schema (table structures) but no actual data; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical server [...]
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_MODE_DEFAULT = "initial";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_NEW_TABLES_CONF = "camel.source.endpoint.snapshotNewTables";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_NEW_TABLES_DOC = "BETA FEATURE: On connector restart, the connector will check if there have been any new tables added to the configuration, and snapshot them. There is presently only two options:'off': Default behavior. Do not snapshot new tables.'parallel': The snapshot of the new tables will occur in parallel to the continued binlog reading of the old tables. When the snapshot completes, an independent binlog  [...]
@@ -299,11 +305,14 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BIGINT_UNSIGNED_HANDLING_MODE_CONF = "camel.component.debezium-mysql.bigintUnsignedHandlingMode";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BIGINT_UNSIGNED_HANDLING_MODE_DOC = "Specify how BIGINT UNSIGNED columns should be represented in change events, including:'precise' uses java.math.BigDecimal to represent values, which are encoded in the change events using a binary representation and Kafka Connect's 'org.apache.kafka.connect.data.Decimal' type; 'long' (the default) represents values using Java's 'long', which may not offer the precision but will be far [...]
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BIGINT_UNSIGNED_HANDLING_MODE_DEFAULT = "long";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINARY_HANDLING_MODE_CONF = "camel.component.debezium-mysql.binaryHandlingMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINARY_HANDLING_MODE_DOC = "Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINARY_HANDLING_MODE_DEFAULT = "bytes";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINLOG_BUFFER_SIZE_CONF = "camel.component.debezium-mysql.binlogBufferSize";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINLOG_BUFFER_SIZE_DOC = "The size of a look-ahead buffer used by the binlog reader to decide whether the transaction in progress is going to be committed or rolled back. Use 0 to disable look-ahead buffering. Defaults to 0 (i.e. buffering is disabled).";
     public static final Integer CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINLOG_BUFFER_SIZE_DEFAULT = 0;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_COLUMN_BLACKLIST_CONF = "camel.component.debezium-mysql.columnBlacklist";
-    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_COLUMN_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_COLUMN_BLACKLIST_DOC = "Regular expressions matching columns to exclude from change events";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_COLUMN_BLACKLIST_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_CONNECT_KEEP_ALIVE_CONF = "camel.component.debezium-mysql.connectKeepAlive";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_CONNECT_KEEP_ALIVE_DOC = "Whether a separate thread should be used to ensure the connection is kept alive.";
@@ -420,7 +429,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCLUDE_QUERY_DOC = "Whether the connector should include the original SQL query that generated the change event. Note: This option requires MySQL be configured with the binlog_rows_query_log_events option set to ON. Query will not be present for events generated from snapshot. WARNING: Enabling this option may expose tables or fields explicitly blacklisted or masked by including the original SQL statement in the change  [...]
     public static final Boolean CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCLUDE_QUERY_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCLUDE_SCHEMA_CHANGES_CONF = "camel.component.debezium-mysql.includeSchemaChanges";
-    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCLUDE_SCHEMA_CHANGES_DOC = "Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value includes the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCLUDE_SCHEMA_CHANGES_DOC = "Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally records da [...]
     public static final Boolean CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCLUDE_SCHEMA_CHANGES_DEFAULT = true;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCONSISTENT_SCHEMA_HANDLING_MODE_CONF = "camel.component.debezium-mysql.inconsistentSchemaHandlingMode";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_INCONSISTENT_SCHEMA_HANDLING_MODE_DOC = "Specify how binlog events that belong to a table missing from internal schema representation (i.e. internal representation is not consistent with database) should be handled, including:'fail' (the default) an exception indicating the problematic event and its binlog position is raised, causing the connector to be stopped; 'warn' the problematic event and its binlog position will b [...]
@@ -437,6 +446,9 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_POLL_INTERVAL_MS_CONF = "camel.component.debezium-mysql.pollIntervalMs";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_POLL_INTERVAL_MS_DOC = "Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms.";
     public static final Long CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_POLL_INTERVAL_MS_DEFAULT = 500L;
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SKIPPED_OPERATIONS_CONF = "camel.component.debezium-mysql.skippedOperations";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SKIPPED_OPERATIONS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_DELAY_MS_CONF = "camel.component.debezium-mysql.snapshotDelayMs";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_DELAY_MS_DOC = "The number of milliseconds to delay before a snapshot will begin.";
     public static final Long CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_DELAY_MS_DEFAULT = 0L;
@@ -447,7 +459,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_LOCKING_MODE_DOC = "Controls how long the connector holds onto the global read lock while it is performing a snapshot. The default is 'minimal', which means the connector holds the global read lock (and thus prevents any updates) for just the initial portion of the snapshot while the database schemas and other metadata are being read. The remaining work in a snapshot involves selecting all rows from each table,  [...]
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_LOCKING_MODE_DEFAULT = "minimal";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_MODE_CONF = "camel.component.debezium-mysql.snapshotMode";
-    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_MODE_DOC = "The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical server name; 'initial_only' same as 'initial' except the connector should stop after completing  [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_MODE_DOC = "The criteria for running a snapshot upon startup of the connector. Options include: 'when_needed' to specify that the connector run a snapshot upon startup whenever it deems it necessary; 'schema_only' to only take a snapshot of the schema (table structures) but no actual data; 'initial' (the default) to specify the connector can run a snapshot only when no offsets are available for the logical serve [...]
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_MODE_DEFAULT = "initial";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_NEW_TABLES_CONF = "camel.component.debezium-mysql.snapshotNewTables";
     public static final String CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_NEW_TABLES_DOC = "BETA FEATURE: On connector restart, the connector will check if there have been any new tables added to the configuration, and snapshot them. There is presently only two options:'off': Default behavior. Do not snapshot new tables.'parallel': The snapshot of the new tables will occur in parallel to the continued binlog reading of the old tables. When the snapshot completes, an independent binlog [...]
@@ -505,6 +517,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BIGINT_UNSIGNED_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BIGINT_UNSIGNED_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BIGINT_UNSIGNED_HANDLING_MODE_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINARY_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINARY_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINARY_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINLOG_BUFFER_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINLOG_BUFFER_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_BINLOG_BUFFER_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_COLUMN_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_COLUMN_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_COLUMN_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_CONNECT_KEEP_ALIVE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_CONNECT_KEEP_ALIVE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_CONNECT_KEEP_ALIVE_DOC);
@@ -551,6 +564,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_MAX_QUEUE_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_MAX_QUEUE_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_MAX_QUEUE_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_MESSAGE_KEY_COLUMNS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_MESSAGE_KEY_COLUMNS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_MESSAGE_KEY_COLUMNS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_POLL_INTERVAL_MS_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_FETCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_FETCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_FETCH_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_LOCKING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_LOCKING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_ENDPOINT_SNAPSHOT_LOCKING_MODE_DOC);
@@ -578,6 +592,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_OFFSET_STORAGE_TOPIC_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_OFFSET_STORAGE_TOPIC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_OFFSET_STORAGE_TOPIC_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BIGINT_UNSIGNED_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BIGINT_UNSIGNED_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BIGINT_UNSIGNED_HANDLING_MODE_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINARY_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINARY_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINARY_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINLOG_BUFFER_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINLOG_BUFFER_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_BINLOG_BUFFER_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_COLUMN_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_COLUMN_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_COLUMN_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_CONNECT_KEEP_ALIVE_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_CONNECT_KEEP_ALIVE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_CONNECT_KEEP_ALIVE_DOC);
@@ -624,6 +639,7 @@ public class CamelDebeziummysqlSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_MAX_QUEUE_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_MAX_QUEUE_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_MAX_QUEUE_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_MESSAGE_KEY_COLUMNS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_MESSAGE_KEY_COLUMNS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_MESSAGE_KEY_COLUMNS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_POLL_INTERVAL_MS_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_FETCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_FETCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_FETCH_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_LOCKING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_LOCKING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMMYSQL_COMPONENT_SNAPSHOT_LOCKING_MODE_DOC);
diff --git a/connectors/camel-debezium-postgres-kafka-connector/src/main/docs/camel-debezium-postgres-kafka-source-connector.adoc b/connectors/camel-debezium-postgres-kafka-connector/src/main/docs/camel-debezium-postgres-kafka-source-connector.adoc
index 98b173e..72e9a28 100644
--- a/connectors/camel-debezium-postgres-kafka-connector/src/main/docs/camel-debezium-postgres-kafka-source-connector.adoc
+++ b/connectors/camel-debezium-postgres-kafka-connector/src/main/docs/camel-debezium-postgres-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-debezium-postgres-kafka-connector as source make sure to use th
 ----
 
 
-The camel-debezium-postgres source connector supports 137 options, which are listed below.
+The camel-debezium-postgres source connector supports 151 options, which are listed below.
 
 
 
@@ -39,7 +39,10 @@ The camel-debezium-postgres source connector supports 137 options, which are lis
 | *camel.source.endpoint.exchangePattern* | Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut] | null | MEDIUM
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.source.endpoint.columnBlacklist* | Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description. | null | MEDIUM
+| *camel.source.endpoint.binaryHandlingMode* | Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string | "bytes" | MEDIUM
+| *camel.source.endpoint.columnBlacklist* | Regular expressions matching columns to exclude from change events | null | MEDIUM
+| *camel.source.endpoint.columnWhitelist* | Regular expressions matching columns to include in change events | null | MEDIUM
+| *camel.source.endpoint.converters* | Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.' | null | MEDIUM
 | *camel.source.endpoint.databaseDbname* | The name of the database the connector should be monitoring | null | MEDIUM
 | *camel.source.endpoint.databaseHistoryFileFilename* | The path to the file that will be used to record the database history | null | MEDIUM
 | *camel.source.endpoint.databaseHostname* | Resolvable hostname or IP address of the Postgres database server. | null | MEDIUM
@@ -69,10 +72,13 @@ The camel-debezium-postgres source connector supports 137 options, which are lis
 | *camel.source.endpoint.pluginName* | The name of the Postgres logical decoding plugin installed on the server. Supported values are 'decoderbufs' and 'wal2json'. Defaults to 'decoderbufs'. | "decoderbufs" | MEDIUM
 | *camel.source.endpoint.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
 | *camel.source.endpoint.provideTransactionMetadata* | Enables transaction metadata extraction together with event counting | false | MEDIUM
+| *camel.source.endpoint.publicationAutocreateMode* | Applies only when streaming changes using pgoutput.Determine how creation of a publication should work, the default is all_tables.DISABLED - The connector will not attempt to create a publication at all. The expectation is that the user has created the publication up-front. If the publication isn't found to exist upon startup, the connector will throw an exception and stop.ALL_TABLES - If no publication exists, the connector will crea [...]
 | *camel.source.endpoint.publicationName* | The name of the Postgres 10 publication used for streaming changes from a plugin.Defaults to 'dbz_publication' | "dbz_publication" | MEDIUM
+| *camel.source.endpoint.sanitizeFieldNames* | Whether field names will be sanitized to Avro naming conventions | false | MEDIUM
 | *camel.source.endpoint.schemaBlacklist* | The schemas for which events must not be captured | null | MEDIUM
 | *camel.source.endpoint.schemaRefreshMode* | Specify the conditions that trigger a refresh of the in-memory schema for a table. 'columns_diff' (the default) is the safest mode, ensuring the in-memory schema stays in-sync with the database table's schema at all times. 'columns_diff_exclude_unchanged_toast' instructs the connector to refresh the in-memory schema cache if there is a discrepancy between it and the schema derived from the incoming message, unless unchanged TOASTable data ful [...]
 | *camel.source.endpoint.schemaWhitelist* | The schemas for which events should be captured | null | MEDIUM
+| *camel.source.endpoint.skippedOperations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.source.endpoint.slotDropOnStop* | Whether or not to drop the logical replication slot when the connector finishes orderlyBy default the replication is kept so that on restart progress can resume from the last recorded location | false | MEDIUM
 | *camel.source.endpoint.slotMaxRetries* | How many times to retry connecting to a replication slot when an attempt fails. | 6 | MEDIUM
 | *camel.source.endpoint.slotName* | The name of the Postgres logical decoding slot created for streaming changes from a plugin.Defaults to 'debezium | "debezium" | MEDIUM
@@ -87,6 +93,7 @@ The camel-debezium-postgres source connector supports 137 options, which are lis
 | *camel.source.endpoint.sourceStructVersion* | A version of the format of the publicly visible source part in the message | "v2" | MEDIUM
 | *camel.source.endpoint.statusUpdateIntervalMs* | Frequency in milliseconds for sending replication connection status updates to the server. Defaults to 10 seconds (10000 ms). | 10000 | MEDIUM
 | *camel.source.endpoint.tableBlacklist* | Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description. | null | MEDIUM
+| *camel.source.endpoint.tableIgnoreBuiltin* | Flag specifying whether built-in tables should be ignored. | true | MEDIUM
 | *camel.source.endpoint.tableWhitelist* | The tables for which changes are to be captured | null | MEDIUM
 | *camel.source.endpoint.timePrecisionMode* | Time, date, and timestamps can be represented with different kinds of precisions, including:'adaptive' (the default) bases the precision of time, date, and timestamp values on the database column's precision; 'adaptive_time_microseconds' like 'adaptive' mode, but TIME fields always use microseconds precision;'connect' always represents time, date, and timestamp values using Kafka Connect's built-in representations for Time, Date, and Timestam [...]
 | *camel.source.endpoint.toastedValuePlaceholder* | Specify the constant that will be provided by Debezium to indicate that the original value is a toasted value not provided by the database.If starts with 'hex:' prefix it is expected that the rest of the string repesents hexadecimally encoded octets. | "__debezium_unavailable_value" | MEDIUM
@@ -106,7 +113,10 @@ The camel-debezium-postgres source connector supports 137 options, which are lis
 | *camel.component.debezium-postgres.offsetStorage ReplicationFactor* | Replication factor used when creating the offset storage topic. Required when offset.storage is set to the KafkaOffsetBackingStore | null | MEDIUM
 | *camel.component.debezium-postgres.offsetStorage Topic* | The name of the Kafka topic where offsets are to be stored. Required when offset.storage is set to the KafkaOffsetBackingStore. | null | MEDIUM
 | *camel.component.debezium-postgres.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
-| *camel.component.debezium-postgres.columnBlacklist* | Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description. | null | MEDIUM
+| *camel.component.debezium-postgres.binaryHandling Mode* | Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string | "bytes" | MEDIUM
+| *camel.component.debezium-postgres.columnBlacklist* | Regular expressions matching columns to exclude from change events | null | MEDIUM
+| *camel.component.debezium-postgres.columnWhitelist* | Regular expressions matching columns to include in change events | null | MEDIUM
+| *camel.component.debezium-postgres.converters* | Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.' | null | MEDIUM
 | *camel.component.debezium-postgres.databaseDbname* | The name of the database the connector should be monitoring | null | MEDIUM
 | *camel.component.debezium-postgres.databaseHistory FileFilename* | The path to the file that will be used to record the database history | null | MEDIUM
 | *camel.component.debezium-postgres.databaseHostname* | Resolvable hostname or IP address of the Postgres database server. | null | MEDIUM
@@ -136,10 +146,13 @@ The camel-debezium-postgres source connector supports 137 options, which are lis
 | *camel.component.debezium-postgres.pluginName* | The name of the Postgres logical decoding plugin installed on the server. Supported values are 'decoderbufs' and 'wal2json'. Defaults to 'decoderbufs'. | "decoderbufs" | MEDIUM
 | *camel.component.debezium-postgres.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
 | *camel.component.debezium-postgres.provide TransactionMetadata* | Enables transaction metadata extraction together with event counting | false | MEDIUM
+| *camel.component.debezium-postgres.publication AutocreateMode* | Applies only when streaming changes using pgoutput.Determine how creation of a publication should work, the default is all_tables.DISABLED - The connector will not attempt to create a publication at all. The expectation is that the user has created the publication up-front. If the publication isn't found to exist upon startup, the connector will throw an exception and stop.ALL_TABLES - If no publication exists, the connec [...]
 | *camel.component.debezium-postgres.publicationName* | The name of the Postgres 10 publication used for streaming changes from a plugin.Defaults to 'dbz_publication' | "dbz_publication" | MEDIUM
+| *camel.component.debezium-postgres.sanitizeField Names* | Whether field names will be sanitized to Avro naming conventions | false | MEDIUM
 | *camel.component.debezium-postgres.schemaBlacklist* | The schemas for which events must not be captured | null | MEDIUM
 | *camel.component.debezium-postgres.schemaRefresh Mode* | Specify the conditions that trigger a refresh of the in-memory schema for a table. 'columns_diff' (the default) is the safest mode, ensuring the in-memory schema stays in-sync with the database table's schema at all times. 'columns_diff_exclude_unchanged_toast' instructs the connector to refresh the in-memory schema cache if there is a discrepancy between it and the schema derived from the incoming message, unless unchanged TOAST [...]
 | *camel.component.debezium-postgres.schemaWhitelist* | The schemas for which events should be captured | null | MEDIUM
+| *camel.component.debezium-postgres.skipped Operations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.component.debezium-postgres.slotDropOnStop* | Whether or not to drop the logical replication slot when the connector finishes orderlyBy default the replication is kept so that on restart progress can resume from the last recorded location | false | MEDIUM
 | *camel.component.debezium-postgres.slotMaxRetries* | How many times to retry connecting to a replication slot when an attempt fails. | 6 | MEDIUM
 | *camel.component.debezium-postgres.slotName* | The name of the Postgres logical decoding slot created for streaming changes from a plugin.Defaults to 'debezium | "debezium" | MEDIUM
@@ -154,6 +167,7 @@ The camel-debezium-postgres source connector supports 137 options, which are lis
 | *camel.component.debezium-postgres.sourceStruct Version* | A version of the format of the publicly visible source part in the message | "v2" | MEDIUM
 | *camel.component.debezium-postgres.statusUpdate IntervalMs* | Frequency in milliseconds for sending replication connection status updates to the server. Defaults to 10 seconds (10000 ms). | 10000 | MEDIUM
 | *camel.component.debezium-postgres.tableBlacklist* | Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description. | null | MEDIUM
+| *camel.component.debezium-postgres.tableIgnore Builtin* | Flag specifying whether built-in tables should be ignored. | true | MEDIUM
 | *camel.component.debezium-postgres.tableWhitelist* | The tables for which changes are to be captured | null | MEDIUM
 | *camel.component.debezium-postgres.timePrecision Mode* | Time, date, and timestamps can be represented with different kinds of precisions, including:'adaptive' (the default) bases the precision of time, date, and timestamp values on the database column's precision; 'adaptive_time_microseconds' like 'adaptive' mode, but TIME fields always use microseconds precision;'connect' always represents time, date, and timestamp values using Kafka Connect's built-in representations for Time, Date, [...]
 | *camel.component.debezium-postgres.toastedValue Placeholder* | Specify the constant that will be provided by Debezium to indicate that the original value is a toasted value not provided by the database.If starts with 'hex:' prefix it is expected that the rest of the string repesents hexadecimally encoded octets. | "__debezium_unavailable_value" | MEDIUM
diff --git a/connectors/camel-debezium-postgres-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumpostgres/CamelDebeziumpostgresSourceConnectorConfig.java b/connectors/camel-debezium-postgres-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumpostgres/CamelDebeziumpostgresSourceConnectorConfig.java
index d9ec83e..c718138 100644
--- a/connectors/camel-debezium-postgres-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumpostgres/CamelDebeziumpostgresSourceConnectorConfig.java
+++ b/connectors/camel-debezium-postgres-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumpostgres/CamelDebeziumpostgresSourceConnectorConfig.java
@@ -77,9 +77,18 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SYNCHRONOUS_CONF = "camel.source.endpoint.synchronous";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BINARY_HANDLING_MODE_CONF = "camel.source.endpoint.binaryHandlingMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BINARY_HANDLING_MODE_DOC = "Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BINARY_HANDLING_MODE_DEFAULT = "bytes";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_BLACKLIST_CONF = "camel.source.endpoint.columnBlacklist";
-    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description.";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_BLACKLIST_DOC = "Regular expressions matching columns to exclude from change events";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_BLACKLIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_WHITELIST_CONF = "camel.source.endpoint.columnWhitelist";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_WHITELIST_DOC = "Regular expressions matching columns to include in change events";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_CONVERTERS_CONF = "camel.source.endpoint.converters";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_CONVERTERS_DOC = "Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.'";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_CONVERTERS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_DBNAME_CONF = "camel.source.endpoint.databaseDbname";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_DBNAME_DOC = "The name of the database the connector should be monitoring";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_DBNAME_DEFAULT = null;
@@ -167,9 +176,15 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PROVIDE_TRANSACTION_METADATA_CONF = "camel.source.endpoint.provideTransactionMetadata";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DOC = "Enables transaction metadata extraction together with event counting";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_AUTOCREATE_MODE_CONF = "camel.source.endpoint.publicationAutocreateMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_AUTOCREATE_MODE_DOC = "Applies only when streaming changes using pgoutput.Determine how creation of a publication should work, the default is all_tables.DISABLED - The connector will not attempt to create a publication at all. The expectation is that the user has created the publication up-front. If the publication isn't found to exist upon startup, the connector will throw an exception and stop.ALL_TABLES  [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_AUTOCREATE_MODE_DEFAULT = "all_tables";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_NAME_CONF = "camel.source.endpoint.publicationName";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_NAME_DOC = "The name of the Postgres 10 publication used for streaming changes from a plugin.Defaults to 'dbz_publication'";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_NAME_DEFAULT = "dbz_publication";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SANITIZE_FIELD_NAMES_CONF = "camel.source.endpoint.sanitizeFieldNames";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SANITIZE_FIELD_NAMES_DOC = "Whether field names will be sanitized to Avro naming conventions";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SANITIZE_FIELD_NAMES_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_BLACKLIST_CONF = "camel.source.endpoint.schemaBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_BLACKLIST_DOC = "The schemas for which events must not be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_BLACKLIST_DEFAULT = null;
@@ -179,6 +194,9 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_WHITELIST_CONF = "camel.source.endpoint.schemaWhitelist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_WHITELIST_DOC = "The schemas for which events should be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SKIPPED_OPERATIONS_CONF = "camel.source.endpoint.skippedOperations";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_DROP_ON_STOP_CONF = "camel.source.endpoint.slotDropOnStop";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_DROP_ON_STOP_DOC = "Whether or not to drop the logical replication slot when the connector finishes orderlyBy default the replication is kept so that on restart progress can resume from the last recorded location";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_DROP_ON_STOP_DEFAULT = false;
@@ -221,6 +239,9 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_BLACKLIST_CONF = "camel.source.endpoint.tableBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description.";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_BLACKLIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_IGNORE_BUILTIN_CONF = "camel.source.endpoint.tableIgnoreBuiltin";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_IGNORE_BUILTIN_DOC = "Flag specifying whether built-in tables should be ignored.";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_IGNORE_BUILTIN_DEFAULT = true;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_WHITELIST_CONF = "camel.source.endpoint.tableWhitelist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_WHITELIST_DOC = "The tables for which changes are to be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_WHITELIST_DEFAULT = null;
@@ -278,9 +299,18 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.debezium-postgres.basicPropertyBinding";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BINARY_HANDLING_MODE_CONF = "camel.component.debezium-postgres.binaryHandlingMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BINARY_HANDLING_MODE_DOC = "Specify how binary (blob, binary, etc.) columns should be represented in change events, including:'bytes' represents binary data as byte array (default)'base64' represents binary data as base64-encoded string'hex' represents binary data as hex-encoded (base16) string";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BINARY_HANDLING_MODE_DEFAULT = "bytes";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_BLACKLIST_CONF = "camel.component.debezium-postgres.columnBlacklist";
-    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description.";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_BLACKLIST_DOC = "Regular expressions matching columns to exclude from change events";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_BLACKLIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_WHITELIST_CONF = "camel.component.debezium-postgres.columnWhitelist";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_WHITELIST_DOC = "Regular expressions matching columns to include in change events";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_CONVERTERS_CONF = "camel.component.debezium-postgres.converters";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_CONVERTERS_DOC = "Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.'";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_CONVERTERS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_DBNAME_CONF = "camel.component.debezium-postgres.databaseDbname";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_DBNAME_DOC = "The name of the database the connector should be monitoring";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_DBNAME_DEFAULT = null;
@@ -368,9 +398,15 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PROVIDE_TRANSACTION_METADATA_CONF = "camel.component.debezium-postgres.provideTransactionMetadata";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PROVIDE_TRANSACTION_METADATA_DOC = "Enables transaction metadata extraction together with event counting";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PROVIDE_TRANSACTION_METADATA_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_AUTOCREATE_MODE_CONF = "camel.component.debezium-postgres.publicationAutocreateMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_AUTOCREATE_MODE_DOC = "Applies only when streaming changes using pgoutput.Determine how creation of a publication should work, the default is all_tables.DISABLED - The connector will not attempt to create a publication at all. The expectation is that the user has created the publication up-front. If the publication isn't found to exist upon startup, the connector will throw an exception and stop.ALL_TABLES [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_AUTOCREATE_MODE_DEFAULT = "all_tables";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_NAME_CONF = "camel.component.debezium-postgres.publicationName";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_NAME_DOC = "The name of the Postgres 10 publication used for streaming changes from a plugin.Defaults to 'dbz_publication'";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_NAME_DEFAULT = "dbz_publication";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SANITIZE_FIELD_NAMES_CONF = "camel.component.debezium-postgres.sanitizeFieldNames";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SANITIZE_FIELD_NAMES_DOC = "Whether field names will be sanitized to Avro naming conventions";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SANITIZE_FIELD_NAMES_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_BLACKLIST_CONF = "camel.component.debezium-postgres.schemaBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_BLACKLIST_DOC = "The schemas for which events must not be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_BLACKLIST_DEFAULT = null;
@@ -380,6 +416,9 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_WHITELIST_CONF = "camel.component.debezium-postgres.schemaWhitelist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_WHITELIST_DOC = "The schemas for which events should be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SKIPPED_OPERATIONS_CONF = "camel.component.debezium-postgres.skippedOperations";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SKIPPED_OPERATIONS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_DROP_ON_STOP_CONF = "camel.component.debezium-postgres.slotDropOnStop";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_DROP_ON_STOP_DOC = "Whether or not to drop the logical replication slot when the connector finishes orderlyBy default the replication is kept so that on restart progress can resume from the last recorded location";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_DROP_ON_STOP_DEFAULT = false;
@@ -422,6 +461,9 @@ public class CamelDebeziumpostgresSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_BLACKLIST_CONF = "camel.component.debezium-postgres.tableBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description.";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_BLACKLIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_IGNORE_BUILTIN_CONF = "camel.component.debezium-postgres.tableIgnoreBuiltin";
+    public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_IGNORE_BUILTIN_DOC = "Flag specifying whether built-in tables should be ignored.";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_IGNORE_BUILTIN_DEFAULT = true;
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_WHITELIST_CONF = "camel.component.debezium-postgres.tableWhitelist";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_WHITELIST_DOC = "The tables for which changes are to be captured";
     public static final String CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_WHITELIST_DEFAULT = null;
@@ -468,7 +510,10 @@ public class CamelDebeziumpostgresSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_EXCHANGE_PATTERN_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_EXCHANGE_PATTERN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_EXCHANGE_PATTERN_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SYNCHRONOUS_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BINARY_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BINARY_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_BINARY_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_BLACKLIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_COLUMN_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_CONVERTERS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_CONVERTERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_CONVERTERS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_DBNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_DBNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_DBNAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_HOSTNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_HOSTNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_DATABASE_HOSTNAME_DOC);
@@ -498,10 +543,13 @@ public class CamelDebeziumpostgresSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PLUGIN_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PLUGIN_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PLUGIN_NAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_POLL_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PROVIDE_TRANSACTION_METADATA_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_AUTOCREATE_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_AUTOCREATE_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_AUTOCREATE_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_PUBLICATION_NAME_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SANITIZE_FIELD_NAMES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SANITIZE_FIELD_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SANITIZE_FIELD_NAMES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_REFRESH_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_REFRESH_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_REFRESH_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SCHEMA_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_DROP_ON_STOP_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_DROP_ON_STOP_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_DROP_ON_STOP_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_MAX_RETRIES_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_MAX_RETRIES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_MAX_RETRIES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SLOT_NAME_DOC);
@@ -516,6 +564,7 @@ public class CamelDebeziumpostgresSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SOURCE_STRUCT_VERSION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SOURCE_STRUCT_VERSION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_SOURCE_STRUCT_VERSION_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_STATUS_UPDATE_INTERVAL_MS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_STATUS_UPDATE_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_STATUS_UPDATE_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_BLACKLIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_IGNORE_BUILTIN_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_IGNORE_BUILTIN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_IGNORE_BUILTIN_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TABLE_WHITELIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TIME_PRECISION_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TIME_PRECISION_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TIME_PRECISION_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TOASTED_VALUE_PLACEHOLDER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TOASTED_VALUE_PLACEHOLDER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_ENDPOINT_TOASTED_VALUE_PLACEHOLDER_DOC);
@@ -535,7 +584,10 @@ public class CamelDebeziumpostgresSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_OFFSET_STORAGE_REPLICATION_FACTOR_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_OFFSET_STORAGE_REPLICATION_FACTOR_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_OFFSET_STORAGE_REPLICATION_FACTOR_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_OFFSET_STORAGE_TOPIC_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_OFFSET_STORAGE_TOPIC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_OFFSET_STORAGE_TOPIC_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BINARY_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BINARY_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_BINARY_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_BLACKLIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_COLUMN_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_CONVERTERS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_CONVERTERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_CONVERTERS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_DBNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_DBNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_DBNAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_HOSTNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_HOSTNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_DATABASE_HOSTNAME_DOC);
@@ -565,10 +617,13 @@ public class CamelDebeziumpostgresSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PLUGIN_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PLUGIN_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PLUGIN_NAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_POLL_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PROVIDE_TRANSACTION_METADATA_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PROVIDE_TRANSACTION_METADATA_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PROVIDE_TRANSACTION_METADATA_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_AUTOCREATE_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_AUTOCREATE_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_AUTOCREATE_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_PUBLICATION_NAME_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SANITIZE_FIELD_NAMES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SANITIZE_FIELD_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SANITIZE_FIELD_NAMES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_REFRESH_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_REFRESH_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_REFRESH_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SCHEMA_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_DROP_ON_STOP_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_DROP_ON_STOP_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_DROP_ON_STOP_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_MAX_RETRIES_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_MAX_RETRIES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_MAX_RETRIES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SLOT_NAME_DOC);
@@ -583,6 +638,7 @@ public class CamelDebeziumpostgresSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SOURCE_STRUCT_VERSION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SOURCE_STRUCT_VERSION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_SOURCE_STRUCT_VERSION_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_STATUS_UPDATE_INTERVAL_MS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_STATUS_UPDATE_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_STATUS_UPDATE_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_BLACKLIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_IGNORE_BUILTIN_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_IGNORE_BUILTIN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_IGNORE_BUILTIN_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TABLE_WHITELIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TIME_PRECISION_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TIME_PRECISION_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TIME_PRECISION_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TOASTED_VALUE_PLACEHOLDER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TOASTED_VALUE_PLACEHOLDER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMPOSTGRES_COMPONENT_TOASTED_VALUE_PLACEHOLDER_DOC);
diff --git a/connectors/camel-debezium-sqlserver-kafka-connector/src/main/docs/camel-debezium-sqlserver-kafka-source-connector.adoc b/connectors/camel-debezium-sqlserver-kafka-connector/src/main/docs/camel-debezium-sqlserver-kafka-source-connector.adoc
index b8bfdb3..cdae86d 100644
--- a/connectors/camel-debezium-sqlserver-kafka-connector/src/main/docs/camel-debezium-sqlserver-kafka-source-connector.adoc
+++ b/connectors/camel-debezium-sqlserver-kafka-connector/src/main/docs/camel-debezium-sqlserver-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-debezium-sqlserver-kafka-connector as source make sure to use t
 ----
 
 
-The camel-debezium-sqlserver source connector supports 99 options, which are listed below.
+The camel-debezium-sqlserver source connector supports 113 options, which are listed below.
 
 
 
@@ -39,7 +39,9 @@ The camel-debezium-sqlserver source connector supports 99 options, which are lis
 | *camel.source.endpoint.exchangePattern* | Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut] | null | MEDIUM
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.source.endpoint.columnBlacklist* | Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description. | null | MEDIUM
+| *camel.source.endpoint.columnBlacklist* | Regular expressions matching columns to exclude from change events | null | MEDIUM
+| *camel.source.endpoint.columnWhitelist* | Regular expressions matching columns to include in change events | null | MEDIUM
+| *camel.source.endpoint.converters* | Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.' | null | MEDIUM
 | *camel.source.endpoint.databaseDbname* | The name of the database the connector should be monitoring. When working with a multi-tenant set-up, must be set to the CDB name. | null | MEDIUM
 | *camel.source.endpoint.databaseHistory* | The name of the DatabaseHistory class that should be used to store and recover database schema changes. The configuration properties for the history are prefixed with the 'database.history.' string. | "io.debezium.relational.history.FileDatabaseHistory" | MEDIUM
 | *camel.source.endpoint.databaseHistoryFileFilename* | The path to the file that will be used to record the database history | null | MEDIUM
@@ -57,17 +59,22 @@ The camel-debezium-sqlserver source connector supports 99 options, which are lis
 | *camel.source.endpoint.eventProcessingFailure HandlingMode* | Specify how failures during processing of events (i.e. when encountering a corrupted event) should be handled, including:'fail' (the default) an exception indicating the problematic event and its position is raised, causing the connector to be stopped; 'warn' the problematic event and its position will be logged and the event will be skipped;'ignore' the problematic event will be skipped. | "fail" | MEDIUM
 | *camel.source.endpoint.heartbeatIntervalMs* | Length of an interval in milli-seconds in in which the connector periodically sends heartbeat messages to a heartbeat topic. Use 0 to disable heartbeat messages. Disabled by default. | 0 | MEDIUM
 | *camel.source.endpoint.heartbeatTopicsPrefix* | The prefix that is used to name heartbeat topics.Defaults to __debezium-heartbeat. | "__debezium-heartbeat" | MEDIUM
+| *camel.source.endpoint.includeSchemaChanges* | Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history. | true | MEDIUM
 | *camel.source.endpoint.maxBatchSize* | Maximum size of each batch of source records. Defaults to 2048. | 2048 | MEDIUM
 | *camel.source.endpoint.maxQueueSize* | Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size. | 8192 | MEDIUM
 | *camel.source.endpoint.messageKeyColumns* | A semicolon-separated list of expressions that match fully-qualified tables and column(s) to be used as message key. Each expression must match the pattern ':',where the table names could be defined as (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on the specific connector,and the key columns are a comma-separated list of columns representing the custom key. For any table without an explicit key configuration the table's primary [...]
 | *camel.source.endpoint.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
 | *camel.source.endpoint.provideTransactionMetadata* | Enables transaction metadata extraction together with event counting | false | MEDIUM
+| *camel.source.endpoint.sanitizeFieldNames* | Whether field names will be sanitized to Avro naming conventions | false | MEDIUM
+| *camel.source.endpoint.skippedOperations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.source.endpoint.snapshotDelayMs* | The number of milliseconds to delay before a snapshot will begin. | 0L | MEDIUM
 | *camel.source.endpoint.snapshotFetchSize* | The maximum number of records that should be loaded into memory while performing a snapshot | null | MEDIUM
+| *camel.source.endpoint.snapshotIsolationMode* | Controls which transaction isolation level is used and how long the connector locks the monitored tables. The default is 'repeatable_read', which means that repeatable read isolation level is used. In addition, exclusive locks are taken only during schema snapshot. Using a value of 'exclusive' ensures that the connector holds the exclusive lock (and thus prevents any reads and updates) for all monitored tables during the entire snapshot d [...]
 | *camel.source.endpoint.snapshotLockTimeoutMs* | The maximum number of millis to wait for table locks at the beginning of a snapshot. If locks cannot be acquired in this time frame, the snapshot will be aborted. Defaults to 10 seconds | 10000L | MEDIUM
 | *camel.source.endpoint.snapshotMode* | The criteria for running a snapshot upon startup of the connector. Options include: 'initial' (the default) to specify the connector should run a snapshot only when no offsets are available for the logical server name; 'schema_only' to specify the connector should run a snapshot of the schema when no offsets are available for the logical server name. | "initial" | MEDIUM
 | *camel.source.endpoint.snapshotSelectStatement Overrides* | This property contains a comma-separated list of fully-qualified tables (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on thespecific connectors . Select statements for the individual tables are specified in further configuration properties, one for each table, identified by the id 'snapshot.select.statement.overrides.DB_NAME.TABLE_NAME' or 'snapshot.select.statement.overrides.SCHEMA_NAME.TABLE_NAME', respectively [...]
 | *camel.source.endpoint.sourceStructVersion* | A version of the format of the publicly visible source part in the message | "v2" | MEDIUM
+| *camel.source.endpoint.sourceTimestampMode* | Configures the criteria of the attached timestamp within the source record (ts_ms).Options include:'commit', (default) the source timestamp is set to the instant where the record was committed in the database'processing', the source timestamp is set to the instant where the record was processed by Debezium. | "commit" | MEDIUM
 | *camel.source.endpoint.tableBlacklist* | Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description. | null | MEDIUM
 | *camel.source.endpoint.tableIgnoreBuiltin* | Flag specifying whether built-in tables should be ignored. | true | MEDIUM
 | *camel.source.endpoint.tableWhitelist* | The tables for which changes are to be captured | null | MEDIUM
@@ -87,7 +94,9 @@ The camel-debezium-sqlserver source connector supports 99 options, which are lis
 | *camel.component.debezium-sqlserver.offsetStorage ReplicationFactor* | Replication factor used when creating the offset storage topic. Required when offset.storage is set to the KafkaOffsetBackingStore | null | MEDIUM
 | *camel.component.debezium-sqlserver.offsetStorage Topic* | The name of the Kafka topic where offsets are to be stored. Required when offset.storage is set to the KafkaOffsetBackingStore. | null | MEDIUM
 | *camel.component.debezium-sqlserver.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
-| *camel.component.debezium-sqlserver.columnBlacklist* | Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description. | null | MEDIUM
+| *camel.component.debezium-sqlserver.columnBlacklist* | Regular expressions matching columns to exclude from change events | null | MEDIUM
+| *camel.component.debezium-sqlserver.columnWhitelist* | Regular expressions matching columns to include in change events | null | MEDIUM
+| *camel.component.debezium-sqlserver.converters* | Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.' | null | MEDIUM
 | *camel.component.debezium-sqlserver.databaseDbname* | The name of the database the connector should be monitoring. When working with a multi-tenant set-up, must be set to the CDB name. | null | MEDIUM
 | *camel.component.debezium-sqlserver.databaseHistory* | The name of the DatabaseHistory class that should be used to store and recover database schema changes. The configuration properties for the history are prefixed with the 'database.history.' string. | "io.debezium.relational.history.FileDatabaseHistory" | MEDIUM
 | *camel.component.debezium-sqlserver.databaseHistory FileFilename* | The path to the file that will be used to record the database history | null | MEDIUM
@@ -105,17 +114,22 @@ The camel-debezium-sqlserver source connector supports 99 options, which are lis
 | *camel.component.debezium-sqlserver.eventProcessing FailureHandlingMode* | Specify how failures during processing of events (i.e. when encountering a corrupted event) should be handled, including:'fail' (the default) an exception indicating the problematic event and its position is raised, causing the connector to be stopped; 'warn' the problematic event and its position will be logged and the event will be skipped;'ignore' the problematic event will be skipped. | "fail" | MEDIUM
 | *camel.component.debezium-sqlserver.heartbeat IntervalMs* | Length of an interval in milli-seconds in in which the connector periodically sends heartbeat messages to a heartbeat topic. Use 0 to disable heartbeat messages. Disabled by default. | 0 | MEDIUM
 | *camel.component.debezium-sqlserver.heartbeatTopics Prefix* | The prefix that is used to name heartbeat topics.Defaults to __debezium-heartbeat. | "__debezium-heartbeat" | MEDIUM
+| *camel.component.debezium-sqlserver.includeSchema Changes* | Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally records database history. | true | MEDIUM
 | *camel.component.debezium-sqlserver.maxBatchSize* | Maximum size of each batch of source records. Defaults to 2048. | 2048 | MEDIUM
 | *camel.component.debezium-sqlserver.maxQueueSize* | Maximum size of the queue for change events read from the database log but not yet recorded or forwarded. Defaults to 8192, and should always be larger than the maximum batch size. | 8192 | MEDIUM
 | *camel.component.debezium-sqlserver.messageKey Columns* | A semicolon-separated list of expressions that match fully-qualified tables and column(s) to be used as message key. Each expression must match the pattern ':',where the table names could be defined as (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on the specific connector,and the key columns are a comma-separated list of columns representing the custom key. For any table without an explicit key configuration the t [...]
 | *camel.component.debezium-sqlserver.pollIntervalMs* | Frequency in milliseconds to wait for new change events to appear after receiving no events. Defaults to 500ms. | 500L | MEDIUM
 | *camel.component.debezium-sqlserver.provide TransactionMetadata* | Enables transaction metadata extraction together with event counting | false | MEDIUM
+| *camel.component.debezium-sqlserver.sanitizeField Names* | Whether field names will be sanitized to Avro naming conventions | false | MEDIUM
+| *camel.component.debezium-sqlserver.skipped Operations* | The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped. | null | MEDIUM
 | *camel.component.debezium-sqlserver.snapshotDelayMs* | The number of milliseconds to delay before a snapshot will begin. | 0L | MEDIUM
 | *camel.component.debezium-sqlserver.snapshotFetch Size* | The maximum number of records that should be loaded into memory while performing a snapshot | null | MEDIUM
+| *camel.component.debezium-sqlserver.snapshot IsolationMode* | Controls which transaction isolation level is used and how long the connector locks the monitored tables. The default is 'repeatable_read', which means that repeatable read isolation level is used. In addition, exclusive locks are taken only during schema snapshot. Using a value of 'exclusive' ensures that the connector holds the exclusive lock (and thus prevents any reads and updates) for all monitored tables during the ent [...]
 | *camel.component.debezium-sqlserver.snapshotLock TimeoutMs* | The maximum number of millis to wait for table locks at the beginning of a snapshot. If locks cannot be acquired in this time frame, the snapshot will be aborted. Defaults to 10 seconds | 10000L | MEDIUM
 | *camel.component.debezium-sqlserver.snapshotMode* | The criteria for running a snapshot upon startup of the connector. Options include: 'initial' (the default) to specify the connector should run a snapshot only when no offsets are available for the logical server name; 'schema_only' to specify the connector should run a snapshot of the schema when no offsets are available for the logical server name. | "initial" | MEDIUM
 | *camel.component.debezium-sqlserver.snapshotSelect StatementOverrides* | This property contains a comma-separated list of fully-qualified tables (DB_NAME.TABLE_NAME) or (SCHEMA_NAME.TABLE_NAME), depending on thespecific connectors . Select statements for the individual tables are specified in further configuration properties, one for each table, identified by the id 'snapshot.select.statement.overrides.DB_NAME.TABLE_NAME' or 'snapshot.select.statement.overrides.SCHEMA_NAME.TABLE_NAME', [...]
 | *camel.component.debezium-sqlserver.sourceStruct Version* | A version of the format of the publicly visible source part in the message | "v2" | MEDIUM
+| *camel.component.debezium-sqlserver.sourceTimestamp Mode* | Configures the criteria of the attached timestamp within the source record (ts_ms).Options include:'commit', (default) the source timestamp is set to the instant where the record was committed in the database'processing', the source timestamp is set to the instant where the record was processed by Debezium. | "commit" | MEDIUM
 | *camel.component.debezium-sqlserver.tableBlacklist* | Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description. | null | MEDIUM
 | *camel.component.debezium-sqlserver.tableIgnore Builtin* | Flag specifying whether built-in tables should be ignored. | true | MEDIUM
 | *camel.component.debezium-sqlserver.tableWhitelist* | The tables for which changes are to be captured | null | MEDIUM
diff --git a/connectors/camel-debezium-sqlserver-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumsqlserver/CamelDebeziumsqlserverSourceConnectorConfig.java b/connectors/camel-debezium-sqlserver-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumsqlserver/CamelDebeziumsqlserverSourceConnectorConfig.java
index b26a472..852d4d3 100644
--- a/connectors/camel-debezium-sqlserver-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumsqlserver/CamelDebeziumsqlserverSourceConnectorConfig.java
+++ b/connectors/camel-debezium-sqlserver-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/debeziumsqlserver/CamelDebeziumsqlserverSourceConnectorConfig.java
@@ -78,8 +78,14 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_BLACKLIST_CONF = "camel.source.endpoint.columnBlacklist";
-    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description.";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_BLACKLIST_DOC = "Regular expressions matching columns to exclude from change events";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_BLACKLIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_WHITELIST_CONF = "camel.source.endpoint.columnWhitelist";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_WHITELIST_DOC = "Regular expressions matching columns to include in change events";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_CONVERTERS_CONF = "camel.source.endpoint.converters";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_CONVERTERS_DOC = "Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.'";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_CONVERTERS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_DBNAME_CONF = "camel.source.endpoint.databaseDbname";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_DBNAME_DOC = "The name of the database the connector should be monitoring. When working with a multi-tenant set-up, must be set to the CDB name.";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_DBNAME_DEFAULT = null;
@@ -131,6 +137,9 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_TOPICS_PREFIX_CONF = "camel.source.endpoint.heartbeatTopicsPrefix";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_TOPICS_PREFIX_DOC = "The prefix that is used to name heartbeat topics.Defaults to __debezium-heartbeat.";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_TOPICS_PREFIX_DEFAULT = "__debezium-heartbeat";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_INCLUDE_SCHEMA_CHANGES_CONF = "camel.source.endpoint.includeSchemaChanges";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_INCLUDE_SCHEMA_CHANGES_DOC = "Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally records [...]
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_INCLUDE_SCHEMA_CHANGES_DEFAULT = true;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_BATCH_SIZE_CONF = "camel.source.endpoint.maxBatchSize";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_BATCH_SIZE_DOC = "Maximum size of each batch of source records. Defaults to 2048.";
     public static final Integer CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_BATCH_SIZE_DEFAULT = 2048;
@@ -146,12 +155,21 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_PROVIDE_TRANSACTION_METADATA_CONF = "camel.source.endpoint.provideTransactionMetadata";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DOC = "Enables transaction metadata extraction together with event counting";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SANITIZE_FIELD_NAMES_CONF = "camel.source.endpoint.sanitizeFieldNames";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SANITIZE_FIELD_NAMES_DOC = "Whether field names will be sanitized to Avro naming conventions";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SANITIZE_FIELD_NAMES_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SKIPPED_OPERATIONS_CONF = "camel.source.endpoint.skippedOperations";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_DELAY_MS_CONF = "camel.source.endpoint.snapshotDelayMs";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_DELAY_MS_DOC = "The number of milliseconds to delay before a snapshot will begin.";
     public static final Long CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_DELAY_MS_DEFAULT = 0L;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_FETCH_SIZE_CONF = "camel.source.endpoint.snapshotFetchSize";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_FETCH_SIZE_DOC = "The maximum number of records that should be loaded into memory while performing a snapshot";
     public static final Integer CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_FETCH_SIZE_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_ISOLATION_MODE_CONF = "camel.source.endpoint.snapshotIsolationMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_ISOLATION_MODE_DOC = "Controls which transaction isolation level is used and how long the connector locks the monitored tables. The default is 'repeatable_read', which means that repeatable read isolation level is used. In addition, exclusive locks are taken only during schema snapshot. Using a value of 'exclusive' ensures that the connector holds the exclusive lock (and thus prevents any reads and updates) f [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_ISOLATION_MODE_DEFAULT = "repeatable_read";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_LOCK_TIMEOUT_MS_CONF = "camel.source.endpoint.snapshotLockTimeoutMs";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_LOCK_TIMEOUT_MS_DOC = "The maximum number of millis to wait for table locks at the beginning of a snapshot. If locks cannot be acquired in this time frame, the snapshot will be aborted. Defaults to 10 seconds";
     public static final Long CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_LOCK_TIMEOUT_MS_DEFAULT = 10000L;
@@ -164,6 +182,9 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_STRUCT_VERSION_CONF = "camel.source.endpoint.sourceStructVersion";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_STRUCT_VERSION_DOC = "A version of the format of the publicly visible source part in the message";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_STRUCT_VERSION_DEFAULT = "v2";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_TIMESTAMP_MODE_CONF = "camel.source.endpoint.sourceTimestampMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_TIMESTAMP_MODE_DOC = "Configures the criteria of the attached timestamp within the source record (ts_ms).Options include:'commit', (default) the source timestamp is set to the instant where the record was committed in the database'processing', the source timestamp is set to the instant where the record was processed by Debezium.";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_TIMESTAMP_MODE_DEFAULT = "commit";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_BLACKLIST_CONF = "camel.source.endpoint.tableBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description.";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_BLACKLIST_DEFAULT = null;
@@ -222,8 +243,14 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_BLACKLIST_CONF = "camel.component.debezium-sqlserver.columnBlacklist";
-    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'column.blacklist' description.";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_BLACKLIST_DOC = "Regular expressions matching columns to exclude from change events";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_BLACKLIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_WHITELIST_CONF = "camel.component.debezium-sqlserver.columnWhitelist";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_WHITELIST_DOC = "Regular expressions matching columns to include in change events";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_WHITELIST_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_CONVERTERS_CONF = "camel.component.debezium-sqlserver.converters";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_CONVERTERS_DOC = "Optional list of custom converters that would be used instead of default ones. The converters are defined using '.type' config option and configured using options '.'";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_CONVERTERS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_DBNAME_CONF = "camel.component.debezium-sqlserver.databaseDbname";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_DBNAME_DOC = "The name of the database the connector should be monitoring. When working with a multi-tenant set-up, must be set to the CDB name.";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_DBNAME_DEFAULT = null;
@@ -275,6 +302,9 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_TOPICS_PREFIX_CONF = "camel.component.debezium-sqlserver.heartbeatTopicsPrefix";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_TOPICS_PREFIX_DOC = "The prefix that is used to name heartbeat topics.Defaults to __debezium-heartbeat.";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_TOPICS_PREFIX_DEFAULT = "__debezium-heartbeat";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_INCLUDE_SCHEMA_CHANGES_CONF = "camel.component.debezium-sqlserver.includeSchemaChanges";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_INCLUDE_SCHEMA_CHANGES_DOC = "Whether the connector should publish changes in the database schema to a Kafka topic with the same name as the database server ID. Each schema change will be recorded using a key that contains the database name and whose value include logical description of the new schema and optionally the DDL statement(s).The default is 'true'. This is independent of how the connector internally record [...]
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_INCLUDE_SCHEMA_CHANGES_DEFAULT = true;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_BATCH_SIZE_CONF = "camel.component.debezium-sqlserver.maxBatchSize";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_BATCH_SIZE_DOC = "Maximum size of each batch of source records. Defaults to 2048.";
     public static final Integer CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_BATCH_SIZE_DEFAULT = 2048;
@@ -290,12 +320,21 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_PROVIDE_TRANSACTION_METADATA_CONF = "camel.component.debezium-sqlserver.provideTransactionMetadata";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_PROVIDE_TRANSACTION_METADATA_DOC = "Enables transaction metadata extraction together with event counting";
     public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_PROVIDE_TRANSACTION_METADATA_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SANITIZE_FIELD_NAMES_CONF = "camel.component.debezium-sqlserver.sanitizeFieldNames";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SANITIZE_FIELD_NAMES_DOC = "Whether field names will be sanitized to Avro naming conventions";
+    public static final Boolean CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SANITIZE_FIELD_NAMES_DEFAULT = false;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SKIPPED_OPERATIONS_CONF = "camel.component.debezium-sqlserver.skippedOperations";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SKIPPED_OPERATIONS_DOC = "The comma-separated list of operations to skip during streaming, defined as: 'i' for inserts; 'u' for updates; 'd' for deletes. By default, no operations will be skipped.";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SKIPPED_OPERATIONS_DEFAULT = null;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_DELAY_MS_CONF = "camel.component.debezium-sqlserver.snapshotDelayMs";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_DELAY_MS_DOC = "The number of milliseconds to delay before a snapshot will begin.";
     public static final Long CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_DELAY_MS_DEFAULT = 0L;
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_FETCH_SIZE_CONF = "camel.component.debezium-sqlserver.snapshotFetchSize";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_FETCH_SIZE_DOC = "The maximum number of records that should be loaded into memory while performing a snapshot";
     public static final Integer CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_FETCH_SIZE_DEFAULT = null;
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_ISOLATION_MODE_CONF = "camel.component.debezium-sqlserver.snapshotIsolationMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_ISOLATION_MODE_DOC = "Controls which transaction isolation level is used and how long the connector locks the monitored tables. The default is 'repeatable_read', which means that repeatable read isolation level is used. In addition, exclusive locks are taken only during schema snapshot. Using a value of 'exclusive' ensures that the connector holds the exclusive lock (and thus prevents any reads and updates)  [...]
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_ISOLATION_MODE_DEFAULT = "repeatable_read";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_LOCK_TIMEOUT_MS_CONF = "camel.component.debezium-sqlserver.snapshotLockTimeoutMs";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_LOCK_TIMEOUT_MS_DOC = "The maximum number of millis to wait for table locks at the beginning of a snapshot. If locks cannot be acquired in this time frame, the snapshot will be aborted. Defaults to 10 seconds";
     public static final Long CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_LOCK_TIMEOUT_MS_DEFAULT = 10000L;
@@ -308,6 +347,9 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_STRUCT_VERSION_CONF = "camel.component.debezium-sqlserver.sourceStructVersion";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_STRUCT_VERSION_DOC = "A version of the format of the publicly visible source part in the message";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_STRUCT_VERSION_DEFAULT = "v2";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_TIMESTAMP_MODE_CONF = "camel.component.debezium-sqlserver.sourceTimestampMode";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_TIMESTAMP_MODE_DOC = "Configures the criteria of the attached timestamp within the source record (ts_ms).Options include:'commit', (default) the source timestamp is set to the instant where the record was committed in the database'processing', the source timestamp is set to the instant where the record was processed by Debezium.";
+    public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_TIMESTAMP_MODE_DEFAULT = "commit";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_BLACKLIST_CONF = "camel.component.debezium-sqlserver.tableBlacklist";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_BLACKLIST_DOC = "Description is not available here, please check Debezium website for corresponding key 'table.blacklist' description.";
     public static final String CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_BLACKLIST_DEFAULT = null;
@@ -355,6 +397,8 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_BLACKLIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_COLUMN_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_CONVERTERS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_CONVERTERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_CONVERTERS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_DBNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_DBNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_DBNAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_HISTORY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_HISTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_HISTORY_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_DATABASE_HISTORY_FILE_FILENAME_DOC);
@@ -372,17 +416,22 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_INTERVAL_MS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_TOPICS_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_TOPICS_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_HEARTBEAT_TOPICS_PREFIX_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_INCLUDE_SCHEMA_CHANGES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_INCLUDE_SCHEMA_CHANGES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_INCLUDE_SCHEMA_CHANGES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_BATCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_BATCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_BATCH_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_QUEUE_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_QUEUE_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MAX_QUEUE_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MESSAGE_KEY_COLUMNS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MESSAGE_KEY_COLUMNS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_MESSAGE_KEY_COLUMNS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_POLL_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_PROVIDE_TRANSACTION_METADATA_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_PROVIDE_TRANSACTION_METADATA_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SANITIZE_FIELD_NAMES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SANITIZE_FIELD_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SANITIZE_FIELD_NAMES_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_FETCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_FETCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_FETCH_SIZE_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_ISOLATION_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_ISOLATION_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_ISOLATION_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_LOCK_TIMEOUT_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_LOCK_TIMEOUT_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_LOCK_TIMEOUT_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_SELECT_STATEMENT_OVERRIDES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_SELECT_STATEMENT_OVERRIDES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SNAPSHOT_SELECT_STATEMENT_OVERRIDES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_STRUCT_VERSION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_STRUCT_VERSION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_STRUCT_VERSION_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_TIMESTAMP_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_TIMESTAMP_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_SOURCE_TIMESTAMP_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_IGNORE_BUILTIN_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_IGNORE_BUILTIN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_IGNORE_BUILTIN_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_ENDPOINT_TABLE_WHITELIST_DOC);
@@ -403,6 +452,8 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_OFFSET_STORAGE_TOPIC_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_OFFSET_STORAGE_TOPIC_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_OFFSET_STORAGE_TOPIC_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_BLACKLIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_COLUMN_WHITELIST_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_CONVERTERS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_CONVERTERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_CONVERTERS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_DBNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_DBNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_DBNAME_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_HISTORY_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_HISTORY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_HISTORY_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_DATABASE_HISTORY_FILE_FILENAME_DOC);
@@ -420,17 +471,22 @@ public class CamelDebeziumsqlserverSourceConnectorConfig
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_EVENT_PROCESSING_FAILURE_HANDLING_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_INTERVAL_MS_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_TOPICS_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_TOPICS_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_HEARTBEAT_TOPICS_PREFIX_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_INCLUDE_SCHEMA_CHANGES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_INCLUDE_SCHEMA_CHANGES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_INCLUDE_SCHEMA_CHANGES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_BATCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_BATCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_BATCH_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_QUEUE_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_QUEUE_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MAX_QUEUE_SIZE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MESSAGE_KEY_COLUMNS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MESSAGE_KEY_COLUMNS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_MESSAGE_KEY_COLUMNS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_POLL_INTERVAL_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_POLL_INTERVAL_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_POLL_INTERVAL_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_PROVIDE_TRANSACTION_METADATA_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_PROVIDE_TRANSACTION_METADATA_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_PROVIDE_TRANSACTION_METADATA_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SANITIZE_FIELD_NAMES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SANITIZE_FIELD_NAMES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SANITIZE_FIELD_NAMES_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SKIPPED_OPERATIONS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SKIPPED_OPERATIONS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SKIPPED_OPERATIONS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_DELAY_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_DELAY_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_DELAY_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_FETCH_SIZE_CONF, ConfigDef.Type.INT, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_FETCH_SIZE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_FETCH_SIZE_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_ISOLATION_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_ISOLATION_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_ISOLATION_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_LOCK_TIMEOUT_MS_CONF, ConfigDef.Type.LONG, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_LOCK_TIMEOUT_MS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_LOCK_TIMEOUT_MS_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_SELECT_STATEMENT_OVERRIDES_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_SELECT_STATEMENT_OVERRIDES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SNAPSHOT_SELECT_STATEMENT_OVERRIDES_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_STRUCT_VERSION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_STRUCT_VERSION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_STRUCT_VERSION_DOC);
+        conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_TIMESTAMP_MODE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_TIMESTAMP_MODE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_SOURCE_TIMESTAMP_MODE_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_BLACKLIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_BLACKLIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_BLACKLIST_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_IGNORE_BUILTIN_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_IGNORE_BUILTIN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_IGNORE_BUILTIN_DOC);
         conf.define(CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_WHITELIST_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_WHITELIST_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_DEBEZIUMSQLSERVER_COMPONENT_TABLE_WHITELIST_DOC);
diff --git a/connectors/camel-elsql-kafka-connector/src/main/docs/camel-elsql-kafka-source-connector.adoc b/connectors/camel-elsql-kafka-connector/src/main/docs/camel-elsql-kafka-source-connector.adoc
index a72296a..3de6bfe 100644
--- a/connectors/camel-elsql-kafka-connector/src/main/docs/camel-elsql-kafka-source-connector.adoc
+++ b/connectors/camel-elsql-kafka-connector/src/main/docs/camel-elsql-kafka-source-connector.adoc
@@ -65,7 +65,7 @@ The camel-elsql source connector supports 54 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-elsql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/elsql/CamelElsqlSourceConnectorConfig.java b/connectors/camel-elsql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/elsql/CamelElsqlSourceConnectorConfig.java
index e80b875..5e752da 100644
--- a/connectors/camel-elsql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/elsql/CamelElsqlSourceConnectorConfig.java
+++ b/connectors/camel-elsql-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/elsql/CamelElsqlSourceConnectorConfig.java
@@ -156,7 +156,7 @@ public class CamelElsqlSourceConnectorConfig
     public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_ELSQL_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-etcd-stats-kafka-connector/src/main/docs/camel-etcd-stats-kafka-source-connector.adoc b/connectors/camel-etcd-stats-kafka-connector/src/main/docs/camel-etcd-stats-kafka-source-connector.adoc
index a618d9b..fcf3e11 100644
--- a/connectors/camel-etcd-stats-kafka-connector/src/main/docs/camel-etcd-stats-kafka-source-connector.adoc
+++ b/connectors/camel-etcd-stats-kafka-connector/src/main/docs/camel-etcd-stats-kafka-source-connector.adoc
@@ -45,7 +45,7 @@ The camel-etcd-stats source connector supports 44 options, which are listed belo
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-etcd-stats-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/etcdstats/CamelEtcdstatsSourceConnectorConfig.java b/connectors/camel-etcd-stats-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/etcdstats/CamelEtcdstatsSourceConnectorConfig.java
index de03f96..2bcd531 100644
--- a/connectors/camel-etcd-stats-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/etcdstats/CamelEtcdstatsSourceConnectorConfig.java
+++ b/connectors/camel-etcd-stats-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/etcdstats/CamelEtcdstatsSourceConnectorConfig.java
@@ -96,7 +96,7 @@ public class CamelEtcdstatsSourceConnectorConfig
     public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_ETCDSTATS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-fhir-kafka-connector/src/main/docs/camel-fhir-kafka-source-connector.adoc b/connectors/camel-fhir-kafka-connector/src/main/docs/camel-fhir-kafka-source-connector.adoc
index 8fa1f70..a8cdf94 100644
--- a/connectors/camel-fhir-kafka-connector/src/main/docs/camel-fhir-kafka-source-connector.adoc
+++ b/connectors/camel-fhir-kafka-connector/src/main/docs/camel-fhir-kafka-source-connector.adoc
@@ -61,7 +61,7 @@ The camel-fhir source connector supports 73 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-fhir-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/fhir/CamelFhirSourceConnectorConfig.java b/connectors/camel-fhir-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/fhir/CamelFhirSourceConnectorConfig.java
index 4b4332f..07a9145 100644
--- a/connectors/camel-fhir-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/fhir/CamelFhirSourceConnectorConfig.java
+++ b/connectors/camel-fhir-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/fhir/CamelFhirSourceConnectorConfig.java
@@ -144,7 +144,7 @@ public class CamelFhirSourceConnectorConfig
     public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_FHIR_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc b/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc
index f6d7cc8..d08c5ea 100644
--- a/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc
+++ b/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc
@@ -92,7 +92,7 @@ The camel-file source connector supports 80 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/CamelFileSourceConnectorConfig.java b/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/CamelFileSourceConnectorConfig.java
index a804f97..9f20ce9 100644
--- a/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/CamelFileSourceConnectorConfig.java
+++ b/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/CamelFileSourceConnectorConfig.java
@@ -237,7 +237,7 @@ public class CamelFileSourceConnectorConfig
     public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_FILE_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-flatpack-kafka-connector/src/main/docs/camel-flatpack-kafka-source-connector.adoc b/connectors/camel-flatpack-kafka-connector/src/main/docs/camel-flatpack-kafka-source-connector.adoc
index 2a64615..4f78bf4 100644
--- a/connectors/camel-flatpack-kafka-connector/src/main/docs/camel-flatpack-kafka-source-connector.adoc
+++ b/connectors/camel-flatpack-kafka-connector/src/main/docs/camel-flatpack-kafka-source-connector.adoc
@@ -46,7 +46,7 @@ The camel-flatpack source connector supports 31 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-flatpack-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flatpack/CamelFlatpackSourceConnectorConfig.java b/connectors/camel-flatpack-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flatpack/CamelFlatpackSourceConnectorConfig.java
index baa7b53..9cee8f0 100644
--- a/connectors/camel-flatpack-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flatpack/CamelFlatpackSourceConnectorConfig.java
+++ b/connectors/camel-flatpack-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flatpack/CamelFlatpackSourceConnectorConfig.java
@@ -99,7 +99,7 @@ public class CamelFlatpackSourceConnectorConfig
     public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_FLATPACK_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-flink-kafka-connector/src/main/docs/camel-flink-kafka-sink-connector.adoc b/connectors/camel-flink-kafka-connector/src/main/docs/camel-flink-kafka-sink-connector.adoc
index 9f5bbbc..5efa297 100644
--- a/connectors/camel-flink-kafka-connector/src/main/docs/camel-flink-kafka-sink-connector.adoc
+++ b/connectors/camel-flink-kafka-connector/src/main/docs/camel-flink-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-flink-kafka-connector as sink make sure to use the following Ma
 ----
 
 
-The camel-flink sink connector supports 15 options, which are listed below.
+The camel-flink sink connector supports 14 options, which are listed below.
 
 
 
@@ -31,7 +31,6 @@ The camel-flink sink connector supports 15 options, which are listed below.
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
-| *camel.component.flink.dataSet* | DataSet to compute against. | null | MEDIUM
 | *camel.component.flink.dataSetCallback* | Function performing action against a DataSet. | null | MEDIUM
 | *camel.component.flink.dataStream* | DataStream to compute against. | null | MEDIUM
 | *camel.component.flink.dataStreamCallback* | Function performing action against a DataStream. | null | MEDIUM
diff --git a/connectors/camel-flink-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flink/CamelFlinkSinkConnectorConfig.java b/connectors/camel-flink-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flink/CamelFlinkSinkConnectorConfig.java
index 4b911e3..39d745f 100644
--- a/connectors/camel-flink-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flink/CamelFlinkSinkConnectorConfig.java
+++ b/connectors/camel-flink-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/flink/CamelFlinkSinkConnectorConfig.java
@@ -51,9 +51,6 @@ public class CamelFlinkSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_FLINK_ENDPOINT_SYNCHRONOUS_CONF = "camel.sink.endpoint.synchronous";
     public static final String CAMEL_SINK_FLINK_ENDPOINT_SYNCHRONOUS_DOC = "Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported).";
     public static final Boolean CAMEL_SINK_FLINK_ENDPOINT_SYNCHRONOUS_DEFAULT = false;
-    public static final String CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CONF = "camel.component.flink.dataSet";
-    public static final String CAMEL_SINK_FLINK_COMPONENT_DATA_SET_DOC = "DataSet to compute against.";
-    public static final String CAMEL_SINK_FLINK_COMPONENT_DATA_SET_DEFAULT = null;
     public static final String CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CALLBACK_CONF = "camel.component.flink.dataSetCallback";
     public static final String CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CALLBACK_DOC = "Function performing action against a DataSet.";
     public static final String CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CALLBACK_DEFAULT = null;
@@ -91,7 +88,6 @@ public class CamelFlinkSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_FLINK_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_FLINK_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_FLINK_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_FLINK_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_FLINK_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_FLINK_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_FLINK_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_FLINK_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_FLINK_ENDPOINT_SYNCHRONOUS_DOC);
-        conf.define(CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CONF, ConfigDef.Type.STRING, CAMEL_SINK_FLINK_COMPONENT_DATA_SET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_FLINK_COMPONENT_DATA_SET_DOC);
         conf.define(CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CALLBACK_CONF, ConfigDef.Type.STRING, CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CALLBACK_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_FLINK_COMPONENT_DATA_SET_CALLBACK_DOC);
         conf.define(CAMEL_SINK_FLINK_COMPONENT_DATA_STREAM_CONF, ConfigDef.Type.STRING, CAMEL_SINK_FLINK_COMPONENT_DATA_STREAM_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_FLINK_COMPONENT_DATA_STREAM_DOC);
         conf.define(CAMEL_SINK_FLINK_COMPONENT_DATA_STREAM_CALLBACK_CONF, ConfigDef.Type.STRING, CAMEL_SINK_FLINK_COMPONENT_DATA_STREAM_CALLBACK_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_FLINK_COMPONENT_DATA_STREAM_CALLBACK_DOC);
diff --git a/connectors/camel-ftp-kafka-connector/src/main/docs/camel-ftp-kafka-source-connector.adoc b/connectors/camel-ftp-kafka-connector/src/main/docs/camel-ftp-kafka-source-connector.adoc
index 0deb2a1..5598f03 100644
--- a/connectors/camel-ftp-kafka-connector/src/main/docs/camel-ftp-kafka-source-connector.adoc
+++ b/connectors/camel-ftp-kafka-connector/src/main/docs/camel-ftp-kafka-source-connector.adoc
@@ -110,7 +110,7 @@ The camel-ftp source connector supports 101 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-ftp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftp/CamelFtpSourceConnectorConfig.java b/connectors/camel-ftp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftp/CamelFtpSourceConnectorConfig.java
index 49998ff..8a9ac8d 100644
--- a/connectors/camel-ftp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftp/CamelFtpSourceConnectorConfig.java
+++ b/connectors/camel-ftp-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftp/CamelFtpSourceConnectorConfig.java
@@ -289,7 +289,7 @@ public class CamelFtpSourceConnectorConfig extends CamelSourceConnectorConfig {
     public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_FTP_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-ftps-kafka-connector/src/main/docs/camel-ftps-kafka-source-connector.adoc b/connectors/camel-ftps-kafka-connector/src/main/docs/camel-ftps-kafka-source-connector.adoc
index 5b3d716..8a5440c 100644
--- a/connectors/camel-ftps-kafka-connector/src/main/docs/camel-ftps-kafka-source-connector.adoc
+++ b/connectors/camel-ftps-kafka-connector/src/main/docs/camel-ftps-kafka-source-connector.adoc
@@ -110,7 +110,7 @@ The camel-ftps source connector supports 110 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-ftps-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftps/CamelFtpsSourceConnectorConfig.java b/connectors/camel-ftps-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftps/CamelFtpsSourceConnectorConfig.java
index 616168f..273be35 100644
--- a/connectors/camel-ftps-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftps/CamelFtpsSourceConnectorConfig.java
+++ b/connectors/camel-ftps-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ftps/CamelFtpsSourceConnectorConfig.java
@@ -291,7 +291,7 @@ public class CamelFtpsSourceConnectorConfig
     public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_FTPS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-google-calendar-kafka-connector/src/main/docs/camel-google-calendar-kafka-source-connector.adoc b/connectors/camel-google-calendar-kafka-connector/src/main/docs/camel-google-calendar-kafka-source-connector.adoc
index 42f5458..8a0041c 100644
--- a/connectors/camel-google-calendar-kafka-connector/src/main/docs/camel-google-calendar-kafka-source-connector.adoc
+++ b/connectors/camel-google-calendar-kafka-connector/src/main/docs/camel-google-calendar-kafka-source-connector.adoc
@@ -47,7 +47,7 @@ The camel-google-calendar source connector supports 46 options, which are listed
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-google-calendar-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendar/CamelGooglecalendarSourceConnectorConfig.java b/connectors/camel-google-calendar-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendar/CamelGooglecalendarSourceConnectorConfig.java
index 39a49bd..fe93326 100644
--- a/connectors/camel-google-calendar-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendar/CamelGooglecalendarSourceConnectorConfig.java
+++ b/connectors/camel-google-calendar-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendar/CamelGooglecalendarSourceConnectorConfig.java
@@ -102,7 +102,7 @@ public class CamelGooglecalendarSourceConnectorConfig
     public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_GOOGLECALENDAR_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-google-calendar-stream-kafka-connector/src/main/docs/camel-google-calendar-stream-kafka-source-connector.adoc b/connectors/camel-google-calendar-stream-kafka-connector/src/main/docs/camel-google-calendar-stream-kafka-source-connector.adoc
index 8c459a6..6d574f0 100644
--- a/connectors/camel-google-calendar-stream-kafka-connector/src/main/docs/camel-google-calendar-stream-kafka-source-connector.adoc
+++ b/connectors/camel-google-calendar-stream-kafka-connector/src/main/docs/camel-google-calendar-stream-kafka-source-connector.adoc
@@ -50,7 +50,7 @@ The camel-google-calendar-stream source connector supports 48 options, which are
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-google-calendar-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendarstream/CamelGooglecalendarstreamSourceConnectorConfig.java b/connectors/camel-google-calendar-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendarstream/CamelGooglecalendarstreamSourceConnectorConfig.java
index 1d36bd5..6447557 100644
--- a/connectors/camel-google-calendar-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendarstream/CamelGooglecalendarstreamSourceConnectorConfig.java
+++ b/connectors/camel-google-calendar-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlecalendarstream/CamelGooglecalendarstreamSourceConnectorConfig.java
@@ -111,7 +111,7 @@ public class CamelGooglecalendarstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_GOOGLECALENDARSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-google-drive-kafka-connector/src/main/docs/camel-google-drive-kafka-source-connector.adoc b/connectors/camel-google-drive-kafka-connector/src/main/docs/camel-google-drive-kafka-source-connector.adoc
index 034ff6c..6eca74c 100644
--- a/connectors/camel-google-drive-kafka-connector/src/main/docs/camel-google-drive-kafka-source-connector.adoc
+++ b/connectors/camel-google-drive-kafka-connector/src/main/docs/camel-google-drive-kafka-source-connector.adoc
@@ -45,7 +45,7 @@ The camel-google-drive source connector supports 41 options, which are listed be
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-google-drive-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googledrive/CamelGoogledriveSourceConnectorConfig.java b/connectors/camel-google-drive-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googledrive/CamelGoogledriveSourceConnectorConfig.java
index 7aaf8f0..8db904b 100644
--- a/connectors/camel-google-drive-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googledrive/CamelGoogledriveSourceConnectorConfig.java
+++ b/connectors/camel-google-drive-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googledrive/CamelGoogledriveSourceConnectorConfig.java
@@ -96,7 +96,7 @@ public class CamelGoogledriveSourceConnectorConfig
     public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_GOOGLEDRIVE_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-google-mail-kafka-connector/src/main/docs/camel-google-mail-kafka-source-connector.adoc b/connectors/camel-google-mail-kafka-connector/src/main/docs/camel-google-mail-kafka-source-connector.adoc
index 6f55379..291f5fd 100644
--- a/connectors/camel-google-mail-kafka-connector/src/main/docs/camel-google-mail-kafka-source-connector.adoc
+++ b/connectors/camel-google-mail-kafka-connector/src/main/docs/camel-google-mail-kafka-source-connector.adoc
@@ -43,7 +43,7 @@ The camel-google-mail source connector supports 38 options, which are listed bel
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-google-mail-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemail/CamelGooglemailSourceConnectorConfig.java b/connectors/camel-google-mail-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemail/CamelGooglemailSourceConnectorConfig.java
index 820c79f..71237eb 100644
--- a/connectors/camel-google-mail-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemail/CamelGooglemailSourceConnectorConfig.java
+++ b/connectors/camel-google-mail-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemail/CamelGooglemailSourceConnectorConfig.java
@@ -90,7 +90,7 @@ public class CamelGooglemailSourceConnectorConfig
     public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_GOOGLEMAIL_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-google-mail-stream-kafka-connector/src/main/docs/camel-google-mail-stream-kafka-source-connector.adoc b/connectors/camel-google-mail-stream-kafka-connector/src/main/docs/camel-google-mail-stream-kafka-source-connector.adoc
index aef18bc..626ced6 100644
--- a/connectors/camel-google-mail-stream-kafka-connector/src/main/docs/camel-google-mail-stream-kafka-source-connector.adoc
+++ b/connectors/camel-google-mail-stream-kafka-connector/src/main/docs/camel-google-mail-stream-kafka-source-connector.adoc
@@ -48,7 +48,7 @@ The camel-google-mail-stream source connector supports 44 options, which are lis
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-google-mail-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemailstream/CamelGooglemailstreamSourceConnectorConfig.java b/connectors/camel-google-mail-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemailstream/CamelGooglemailstreamSourceConnectorConfig.java
index 2e5cabb..9d30b69 100644
--- a/connectors/camel-google-mail-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemailstream/CamelGooglemailstreamSourceConnectorConfig.java
+++ b/connectors/camel-google-mail-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlemailstream/CamelGooglemailstreamSourceConnectorConfig.java
@@ -105,7 +105,7 @@ public class CamelGooglemailstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_GOOGLEMAILSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-google-sheets-kafka-connector/src/main/docs/camel-google-sheets-kafka-source-connector.adoc b/connectors/camel-google-sheets-kafka-connector/src/main/docs/camel-google-sheets-kafka-source-connector.adoc
index 65337bb..210b563 100644
--- a/connectors/camel-google-sheets-kafka-connector/src/main/docs/camel-google-sheets-kafka-source-connector.adoc
+++ b/connectors/camel-google-sheets-kafka-connector/src/main/docs/camel-google-sheets-kafka-source-connector.adoc
@@ -43,7 +43,7 @@ The camel-google-sheets source connector supports 38 options, which are listed b
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-google-sheets-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheets/CamelGooglesheetsSourceConnectorConfig.java b/connectors/camel-google-sheets-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheets/CamelGooglesheetsSourceConnectorConfig.java
index 23a6960..9dd35a7 100644
--- a/connectors/camel-google-sheets-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheets/CamelGooglesheetsSourceConnectorConfig.java
+++ b/connectors/camel-google-sheets-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheets/CamelGooglesheetsSourceConnectorConfig.java
@@ -90,7 +90,7 @@ public class CamelGooglesheetsSourceConnectorConfig
     public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_GOOGLESHEETS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-google-sheets-stream-kafka-connector/src/main/docs/camel-google-sheets-stream-kafka-source-connector.adoc b/connectors/camel-google-sheets-stream-kafka-connector/src/main/docs/camel-google-sheets-stream-kafka-source-connector.adoc
index dbde947..4da28a8 100644
--- a/connectors/camel-google-sheets-stream-kafka-connector/src/main/docs/camel-google-sheets-stream-kafka-source-connector.adoc
+++ b/connectors/camel-google-sheets-stream-kafka-connector/src/main/docs/camel-google-sheets-stream-kafka-source-connector.adoc
@@ -52,7 +52,7 @@ The camel-google-sheets-stream source connector supports 52 options, which are l
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-google-sheets-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheetsstream/CamelGooglesheetsstreamSourceConnectorConfig.java b/connectors/camel-google-sheets-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheetsstream/CamelGooglesheetsstreamSourceConnectorConfig.java
index ba73644..363ec19 100644
--- a/connectors/camel-google-sheets-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheetsstream/CamelGooglesheetsstreamSourceConnectorConfig.java
+++ b/connectors/camel-google-sheets-stream-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/googlesheetsstream/CamelGooglesheetsstreamSourceConnectorConfig.java
@@ -117,7 +117,7 @@ public class CamelGooglesheetsstreamSourceConnectorConfig
     public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_GOOGLESHEETSSTREAM_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-sink-connector.adoc b/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-sink-connector.adoc
index 40a3193..1abb772 100644
--- a/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-sink-connector.adoc
+++ b/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-sink-connector.adoc
@@ -15,7 +15,7 @@ When using camel-guava-eventbus-kafka-connector as sink make sure to use the fol
 ----
 
 
-The camel-guava-eventbus sink connector supports 10 options, which are listed below.
+The camel-guava-eventbus sink connector supports 9 options, which are listed below.
 
 
 
@@ -29,7 +29,6 @@ The camel-guava-eventbus sink connector supports 10 options, which are listed be
 | *camel.sink.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.sink.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.component.guava-eventbus.eventBus* | To use the given Guava EventBus instance | null | MEDIUM
-| *camel.component.guava-eventbus.listenerInterface* | The interface with method(s) marked with the Subscribe annotation. Dynamic proxy will be created over the interface so it could be registered as the EventBus listener. Particularly useful when creating multi-event listeners and for handling DeadEvent properly. This option cannot be used together with eventClass option. | null | MEDIUM
 | *camel.component.guava-eventbus.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is process [...]
 | *camel.component.guava-eventbus.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 |===
diff --git a/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-source-connector.adoc b/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-source-connector.adoc
index 4415b88..23ac995 100644
--- a/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-source-connector.adoc
+++ b/connectors/camel-guava-eventbus-kafka-connector/src/main/docs/camel-guava-eventbus-kafka-source-connector.adoc
@@ -31,8 +31,8 @@ The camel-guava-eventbus source connector supports 12 options, which are listed
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 | *camel.source.endpoint.synchronous* | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | MEDIUM
 | *camel.component.guava-eventbus.eventBus* | To use the given Guava EventBus instance | null | MEDIUM
-| *camel.component.guava-eventbus.listenerInterface* | The interface with method(s) marked with the Subscribe annotation. Dynamic proxy will be created over the interface so it could be registered as the EventBus listener. Particularly useful when creating multi-event listeners and for handling DeadEvent properly. This option cannot be used together with eventClass option. | null | MEDIUM
 | *camel.component.guava-eventbus.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
+| *camel.component.guava-eventbus.listenerInterface* | The interface with method(s) marked with the Subscribe annotation. Dynamic proxy will be created over the interface so it could be registered as the EventBus listener. Particularly useful when creating multi-event listeners and for handling DeadEvent properly. This option cannot be used together with eventClass option. | null | MEDIUM
 | *camel.component.guava-eventbus.basicProperty Binding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSinkConnectorConfig.java b/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSinkConnectorConfig.java
index db04e8c..421dc5b 100644
--- a/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSinkConnectorConfig.java
+++ b/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSinkConnectorConfig.java
@@ -47,9 +47,6 @@ public class CamelGuavaeventbusSinkConnectorConfig
     public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_CONF = "camel.component.guava-eventbus.eventBus";
     public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DOC = "To use the given Guava EventBus instance";
     public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DEFAULT = null;
-    public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_CONF = "camel.component.guava-eventbus.listenerInterface";
-    public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DOC = "The interface with method(s) marked with the Subscribe annotation. Dynamic proxy will be created over the interface so it could be registered as the EventBus listener. Particularly useful when creating multi-event listeners and for handling DeadEvent properly. This option cannot be used together with eventClass option.";
-    public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DEFAULT = null;
     public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.guava-eventbus.lazyStartProducer";
     public static final String CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware  [...]
     public static final Boolean CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
@@ -77,7 +74,6 @@ public class CamelGuavaeventbusSinkConnectorConfig
         conf.define(CAMEL_SINK_GUAVAEVENTBUS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_GUAVAEVENTBUS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_GUAVAEVENTBUS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SINK_GUAVAEVENTBUS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_GUAVAEVENTBUS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_GUAVAEVENTBUS_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DOC);
-        conf.define(CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DOC);
         conf.define(CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         return conf;
diff --git a/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSourceConnectorConfig.java b/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSourceConnectorConfig.java
index 3b11f46..67f7455 100644
--- a/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSourceConnectorConfig.java
+++ b/connectors/camel-guava-eventbus-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/guavaeventbus/CamelGuavaeventbusSourceConnectorConfig.java
@@ -53,12 +53,12 @@ public class CamelGuavaeventbusSourceConnectorConfig
     public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_CONF = "camel.component.guava-eventbus.eventBus";
     public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DOC = "To use the given Guava EventBus instance";
     public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DEFAULT = null;
-    public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_CONF = "camel.component.guava-eventbus.listenerInterface";
-    public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DOC = "The interface with method(s) marked with the Subscribe annotation. Dynamic proxy will be created over the interface so it could be registered as the EventBus listener. Particularly useful when creating multi-event listeners and for handling DeadEvent properly. This option cannot be used together with eventClass option.";
-    public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.guava-eventbus.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level  [...]
     public static final Boolean CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
+    public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_CONF = "camel.component.guava-eventbus.listenerInterface";
+    public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DOC = "The interface with method(s) marked with the Subscribe annotation. Dynamic proxy will be created over the interface so it could be registered as the EventBus listener. Particularly useful when creating multi-event listeners and for handling DeadEvent properly. This option cannot be used together with eventClass option.";
+    public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DEFAULT = null;
     public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.guava-eventbus.basicPropertyBinding";
     public static final String CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
@@ -85,8 +85,8 @@ public class CamelGuavaeventbusSourceConnectorConfig
         conf.define(CAMEL_SOURCE_GUAVAEVENTBUS_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_GUAVAEVENTBUS_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_GUAVAEVENTBUS_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
         conf.define(CAMEL_SOURCE_GUAVAEVENTBUS_ENDPOINT_SYNCHRONOUS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_GUAVAEVENTBUS_ENDPOINT_SYNCHRONOUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_GUAVAEVENTBUS_ENDPOINT_SYNCHRONOUS_DOC);
         conf.define(CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_EVENT_BUS_DOC);
-        conf.define(CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DOC);
         conf.define(CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
+        conf.define(CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_LISTENER_INTERFACE_DOC);
         conf.define(CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_GUAVAEVENTBUS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
         return conf;
     }
diff --git a/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-sink-connector.adoc b/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-sink-connector.adoc
index 9332cab..39a11d9 100644
--- a/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-sink-connector.adoc
+++ b/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-sink-connector.adoc
@@ -50,9 +50,9 @@ The camel-hdfs sink connector supports 32 options, which are listed below.
 | *camel.sink.endpoint.kerberosConfigFileLocation* | The location of the kerb5.conf file (\https://web.mit.edu/kerberos/krb5-1.12/doc/admin/conf_files/krb5_conf.html) | null | MEDIUM
 | *camel.sink.endpoint.kerberosKeytabLocation* | The location of the keytab file used to authenticate with the kerberos nodes (contains pairs of kerberos principals and encrypted keys (which are derived from the Kerberos password)) | null | MEDIUM
 | *camel.sink.endpoint.kerberosUsername* | The username used to authenticate with the kerberos nodes | null | MEDIUM
-| *camel.component.hdfs.jAASConfiguration* | To use the given configuration for security with JAAS. | null | MEDIUM
-| *camel.component.hdfs.kerberosConfigFile* | To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter | null | MEDIUM
 | *camel.component.hdfs.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cr [...]
 | *camel.component.hdfs.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.hdfs.jAASConfiguration* | To use the given configuration for security with JAAS. | null | MEDIUM
+| *camel.component.hdfs.kerberosConfigFile* | To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-source-connector.adoc b/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-source-connector.adoc
index 186907c..7f7ce1c 100644
--- a/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-source-connector.adoc
+++ b/connectors/camel-hdfs-kafka-connector/src/main/docs/camel-hdfs-kafka-source-connector.adoc
@@ -61,7 +61,7 @@ The camel-hdfs source connector supports 51 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
@@ -69,9 +69,9 @@ The camel-hdfs source connector supports 51 options, which are listed below.
 | *camel.source.endpoint.kerberosConfigFileLocation* | The location of the kerb5.conf file (\https://web.mit.edu/kerberos/krb5-1.12/doc/admin/conf_files/krb5_conf.html) | null | MEDIUM
 | *camel.source.endpoint.kerberosKeytabLocation* | The location of the keytab file used to authenticate with the kerberos nodes (contains pairs of kerberos principals and encrypted keys (which are derived from the Kerberos password)) | null | MEDIUM
 | *camel.source.endpoint.kerberosUsername* | The username used to authenticate with the kerberos nodes | null | MEDIUM
-| *camel.component.hdfs.jAASConfiguration* | To use the given configuration for security with JAAS. | null | MEDIUM
-| *camel.component.hdfs.kerberosConfigFile* | To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter | null | MEDIUM
 | *camel.component.hdfs.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.component.hdfs.basicPropertyBinding* | Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
+| *camel.component.hdfs.jAASConfiguration* | To use the given configuration for security with JAAS. | null | MEDIUM
+| *camel.component.hdfs.kerberosConfigFile* | To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter | null | MEDIUM
 |===
 // kafka-connector options: END
diff --git a/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSinkConnectorConfig.java b/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSinkConnectorConfig.java
index f008d80..a5edd27 100644
--- a/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSinkConnectorConfig.java
+++ b/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSinkConnectorConfig.java
@@ -108,18 +108,18 @@ public class CamelHdfsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_USERNAME_CONF = "camel.sink.endpoint.kerberosUsername";
     public static final String CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_USERNAME_DOC = "The username used to authenticate with the kerberos nodes";
     public static final String CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_USERNAME_DEFAULT = null;
-    public static final String CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_CONF = "camel.component.hdfs.jAASConfiguration";
-    public static final String CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DOC = "To use the given configuration for security with JAAS.";
-    public static final String CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT = null;
-    public static final String CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF = "camel.component.hdfs.kerberosConfigFile";
-    public static final String CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC = "To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter";
-    public static final String CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT = null;
     public static final String CAMEL_SINK_HDFS_COMPONENT_LAZY_START_PRODUCER_CONF = "camel.component.hdfs.lazyStartProducer";
     public static final String CAMEL_SINK_HDFS_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when [...]
     public static final Boolean CAMEL_SINK_HDFS_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.hdfs.basicPropertyBinding";
     public static final String CAMEL_SINK_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SINK_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_CONF = "camel.component.hdfs.jAASConfiguration";
+    public static final String CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DOC = "To use the given configuration for security with JAAS.";
+    public static final String CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT = null;
+    public static final String CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF = "camel.component.hdfs.kerberosConfigFile";
+    public static final String CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC = "To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter";
+    public static final String CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT = null;
 
     public CamelHdfsSinkConnectorConfig(
             ConfigDef config,
@@ -161,10 +161,10 @@ public class CamelHdfsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_CONFIG_FILE_LOCATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_CONFIG_FILE_LOCATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_CONFIG_FILE_LOCATION_DOC);
         conf.define(CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_KEYTAB_LOCATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_KEYTAB_LOCATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_KEYTAB_LOCATION_DOC);
         conf.define(CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_ENDPOINT_KERBEROS_USERNAME_DOC);
-        conf.define(CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DOC);
-        conf.define(CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC);
         conf.define(CAMEL_SINK_HDFS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_HDFS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_COMPONENT_JAASCONFIGURATION_DOC);
+        conf.define(CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF, ConfigDef.Type.STRING, CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSourceConnectorConfig.java b/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSourceConnectorConfig.java
index 1581b57..3fbbbb4 100644
--- a/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSourceConnectorConfig.java
+++ b/connectors/camel-hdfs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hdfs/CamelHdfsSourceConnectorConfig.java
@@ -144,7 +144,7 @@ public class CamelHdfsSourceConnectorConfig
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
@@ -167,18 +167,18 @@ public class CamelHdfsSourceConnectorConfig
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_USERNAME_CONF = "camel.source.endpoint.kerberosUsername";
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_USERNAME_DOC = "The username used to authenticate with the kerberos nodes";
     public static final String CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_USERNAME_DEFAULT = null;
-    public static final String CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_CONF = "camel.component.hdfs.jAASConfiguration";
-    public static final String CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DOC = "To use the given configuration for security with JAAS.";
-    public static final String CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT = null;
-    public static final String CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF = "camel.component.hdfs.kerberosConfigFile";
-    public static final String CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC = "To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter";
-    public static final String CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT = null;
     public static final String CAMEL_SOURCE_HDFS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF = "camel.component.hdfs.bridgeErrorHandler";
     public static final String CAMEL_SOURCE_HDFS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC = "Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
     public static final Boolean CAMEL_SOURCE_HDFS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT = false;
     public static final String CAMEL_SOURCE_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_CONF = "camel.component.hdfs.basicPropertyBinding";
     public static final String CAMEL_SOURCE_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DOC = "Whether the component should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities";
     public static final Boolean CAMEL_SOURCE_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT = false;
+    public static final String CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_CONF = "camel.component.hdfs.jAASConfiguration";
+    public static final String CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DOC = "To use the given configuration for security with JAAS.";
+    public static final String CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT = null;
+    public static final String CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF = "camel.component.hdfs.kerberosConfigFile";
+    public static final String CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC = "To use kerberos authentication, set the value of the 'java.security.krb5.conf' environment variable to an existing file. If the environment variable is already set, warn if different than the specified parameter";
+    public static final String CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT = null;
 
     public CamelHdfsSourceConnectorConfig(
             ConfigDef config,
@@ -239,10 +239,10 @@ public class CamelHdfsSourceConnectorConfig
         conf.define(CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_CONFIG_FILE_LOCATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_CONFIG_FILE_LOCATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_CONFIG_FILE_LOCATION_DOC);
         conf.define(CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_KEYTAB_LOCATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_KEYTAB_LOCATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_KEYTAB_LOCATION_DOC);
         conf.define(CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_USERNAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_USERNAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_ENDPOINT_KERBEROS_USERNAME_DOC);
-        conf.define(CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DOC);
-        conf.define(CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC);
         conf.define(CAMEL_SOURCE_HDFS_COMPONENT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_HDFS_COMPONENT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_COMPONENT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_COMPONENT_BASIC_PROPERTY_BINDING_DOC);
+        conf.define(CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_COMPONENT_JAASCONFIGURATION_DOC);
+        conf.define(CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_HDFS_COMPONENT_KERBEROS_CONFIG_FILE_DOC);
         return conf;
     }
 }
\ No newline at end of file
diff --git a/connectors/camel-hipchat-kafka-connector/src/main/docs/camel-hipchat-kafka-source-connector.adoc b/connectors/camel-hipchat-kafka-connector/src/main/docs/camel-hipchat-kafka-source-connector.adoc
index 3d801f7..d685e4a 100644
--- a/connectors/camel-hipchat-kafka-connector/src/main/docs/camel-hipchat-kafka-source-connector.adoc
+++ b/connectors/camel-hipchat-kafka-connector/src/main/docs/camel-hipchat-kafka-source-connector.adoc
@@ -44,7 +44,7 @@ The camel-hipchat source connector supports 29 options, which are listed below.
 | *camel.source.endpoint.repeatCount* | Specifies a maximum limit of number of fires. So if you set it to 1, the scheduler will only fire once. If you set it to 5, it will only fire five times. A value of zero or negative means fire forever. | 0L | MEDIUM
 | *camel.source.endpoint.runLoggingLevel* | The consumer logs a start/complete log line when it polls. This option allows you to configure the logging level for that. One of: [TRACE] [DEBUG] [INFO] [WARN] [ERROR] [OFF] | "TRACE" | MEDIUM
 | *camel.source.endpoint.scheduledExecutorService* | Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool. | null | MEDIUM
-| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz] | "none" | MEDIUM
+| *camel.source.endpoint.scheduler* | To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler | "none" | MEDIUM
 | *camel.source.endpoint.schedulerProperties* | To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler. | null | MEDIUM
 | *camel.source.endpoint.startScheduler* | Whether the scheduler should be auto started. | true | MEDIUM
 | *camel.source.endpoint.timeUnit* | Time unit for initialDelay and delay options. One of: [NANOSECONDS] [MICROSECONDS] [MILLISECONDS] [SECONDS] [MINUTES] [HOURS] [DAYS] | "MILLISECONDS" | MEDIUM
diff --git a/connectors/camel-hipchat-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hipchat/CamelHipchatSourceConnectorConfig.java b/connectors/camel-hipchat-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hipchat/CamelHipchatSourceConnectorConfig.java
index ee19db8..1c207ba 100644
--- a/connectors/camel-hipchat-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hipchat/CamelHipchatSourceConnectorConfig.java
+++ b/connectors/camel-hipchat-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/hipchat/CamelHipchatSourceConnectorConfig.java
@@ -93,7 +93,7 @@ public class CamelHipchatSourceConnectorConfig
     public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DOC = "Allows for configuring a custom/shared thread pool to use for the consumer. By default each consumer has its own single threaded thread pool.";
     public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULED_EXECUTOR_SERVICE_DEFAULT = null;
     public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULER_CONF = "camel.source.endpoint.scheduler";
-    public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component One of: [none] [spring] [quartz]";
+    public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULER_DOC = "To use a cron scheduler from either camel-spring or camel-quartz component. Use value spring or quartz for built in scheduler";
     public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULER_DEFAULT = "none";
     public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULER_PROPERTIES_CONF = "camel.source.endpoint.schedulerProperties";
     public static final String CAMEL_SOURCE_HIPCHAT_ENDPOINT_SCHEDULER_PROPERTIES_DOC = "To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.";
diff --git a/connectors/camel-http-kafka-connector/src/main/docs/camel-http-kafka-sink-connector.adoc b/connectors/camel-http-kafka-connector/src/main/docs/camel-http-kafka-sink-connector.adoc
index 7d32208..3948708 100644
--- a/connectors/camel-http-kafka-connector/src/main/docs/camel-http-kafka-sink-connector.adoc
+++ b/connectors/camel-http-kafka-connector/src/main/docs/camel-http-kafka-sink-connector.adoc
... 13873 lines suppressed ...


[camel-kafka-connector] 04/07: Fix cassandra for camel 3.5

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

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

commit 054de9d177413d7267f5f774d60b772c8e94b4e0
Author: Otavio Rodolfo Piske <op...@redhat.com>
AuthorDate: Tue Aug 25 09:49:41 2020 +0200

    Fix cassandra for camel 3.5
    
    Adjusts the client code to use the newer Cassandra client version from
    camel-cassandraql
---
 .../cassandra/clients/CassandraClient.java         | 18 ++++-----
 .../cassandra/clients/dao/TestDataDao.java         | 43 ++++++++++++++--------
 .../dao/TestResultSetConversionStrategy.java       |  4 +-
 .../cassandra/sink/CamelSinkCassandraITCase.java   |  6 ++-
 .../source/CamelSourceCassandraITCase.java         |  8 +++-
 5 files changed, 49 insertions(+), 30 deletions(-)

diff --git a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/CassandraClient.java b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/CassandraClient.java
index 2c26f24..b8b1704 100644
--- a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/CassandraClient.java
+++ b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/CassandraClient.java
@@ -17,24 +17,24 @@
 
 package org.apache.camel.kafkaconnector.cassandra.clients;
 
-import com.datastax.driver.core.Cluster;
-import com.datastax.driver.core.Session;
+import java.net.InetSocketAddress;
+
+import com.datastax.oss.driver.api.core.CqlSession;
 import org.apache.camel.kafkaconnector.cassandra.clients.dao.TestDataDao;
 
 /**
  * A simple client for Cassandra for testing purposes
  */
 public class CassandraClient {
-    private Cluster cluster;
-    private Session session;
+    private CqlSession session;
 
     public CassandraClient(String host, int port) {
-        cluster = Cluster.builder()
-                .addContactPoint(host)
-                .withPort(port)
-                .build();
+        InetSocketAddress socketAddress = new InetSocketAddress(host, port);
 
-        session = cluster.connect();
+        session = CqlSession.builder()
+                .addContactPoint(socketAddress)
+                .withLocalDatacenter("datacenter1")
+                .build();
     }
 
 
diff --git a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestDataDao.java b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestDataDao.java
index 4fcde37..ea8de7a 100644
--- a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestDataDao.java
+++ b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestDataDao.java
@@ -23,11 +23,11 @@ import java.util.List;
 import java.util.Map;
 import java.util.function.Consumer;
 
-import com.datastax.driver.core.DataType;
-import com.datastax.driver.core.ResultSet;
-import com.datastax.driver.core.Row;
-import com.datastax.driver.core.Session;
-import com.datastax.driver.core.schemabuilder.SchemaBuilder;
+import com.datastax.oss.driver.api.core.CqlSession;
+import com.datastax.oss.driver.api.core.cql.ResultSet;
+import com.datastax.oss.driver.api.core.cql.Row;
+import com.datastax.oss.driver.api.core.type.DataTypes;
+import com.datastax.oss.driver.api.querybuilder.SchemaBuilder;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -38,9 +38,9 @@ public class TestDataDao {
     private static final Logger LOG = LoggerFactory.getLogger(TestDataDao.class);
 
 
-    private final Session session;
+    private final CqlSession session;
 
-    public TestDataDao(Session session) {
+    public TestDataDao(CqlSession session) {
         this.session = session;
     }
 
@@ -52,12 +52,16 @@ public class TestDataDao {
 
         String statement = SchemaBuilder.createKeyspace(KEY_SPACE)
                 .ifNotExists()
-                .with()
-                .replication(replication).getQueryString();
+                .withReplicationOptions(replication)
+                .asCql();
 
         LOG.info("Executing {}", statement);
 
-        session.execute(statement);
+        ResultSet rs = session.execute(statement);
+
+        if (!rs.wasApplied()) {
+            LOG.warn("The create key space statement did not execute");
+        }
     }
 
     public void useKeySpace() {
@@ -69,22 +73,29 @@ public class TestDataDao {
 
     public void createTable() {
         String statement = SchemaBuilder.createTable(TABLE_NAME)
-                .addPartitionKey("id", DataType.timeuuid())
-                .addClusteringColumn("text", DataType.text())
-                .getQueryString();
+                .withPartitionKey("id", DataTypes.TIMEUUID)
+                .withClusteringColumn("text", DataTypes.TEXT)
+                .asCql();
+
 
         LOG.info("Executing create table {}", statement);
 
-        session.execute(statement);
+        ResultSet rs = session.execute(statement);
+        if (!rs.wasApplied()) {
+            LOG.warn("The create table statement did not execute");
+        }
     }
 
     public void dropTable() {
         String statement = SchemaBuilder.dropTable(TABLE_NAME)
-                .getQueryString();
+                .asCql();
 
         LOG.info("Executing drop table {}", statement);
 
-        session.execute(statement);
+        ResultSet rs = session.execute(statement);
+        if (!rs.wasApplied()) {
+            LOG.warn("The drop table statement did not execute");
+        }
     }
 
     public boolean hasEnoughData(long expected) {
diff --git a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestResultSetConversionStrategy.java b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestResultSetConversionStrategy.java
index 84f57a2..63febeb 100644
--- a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestResultSetConversionStrategy.java
+++ b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/clients/dao/TestResultSetConversionStrategy.java
@@ -21,8 +21,8 @@ import java.util.ArrayList;
 import java.util.Iterator;
 import java.util.List;
 
-import com.datastax.driver.core.ResultSet;
-import com.datastax.driver.core.Row;
+import com.datastax.oss.driver.api.core.cql.ResultSet;
+import com.datastax.oss.driver.api.core.cql.Row;
 import org.apache.camel.component.cassandra.ResultSetConversionStrategy;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
diff --git a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/sink/CamelSinkCassandraITCase.java b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/sink/CamelSinkCassandraITCase.java
index 0cdf1b6..c583d71 100644
--- a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/sink/CamelSinkCassandraITCase.java
+++ b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/sink/CamelSinkCassandraITCase.java
@@ -77,7 +77,11 @@ public class CamelSinkCassandraITCase extends AbstractKafkaTest {
         cassandraClient = cassandraService.getClient();
 
         if (testDataDao != null) {
-            testDataDao.dropTable();
+            try {
+                testDataDao.dropTable();
+            } catch (Exception e) {
+                LOG.warn("Unable to drop the table: {}", e.getMessage(), e);
+            }
         }
     }
 
diff --git a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/source/CamelSourceCassandraITCase.java b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/source/CamelSourceCassandraITCase.java
index 707f923..25ef1ee 100644
--- a/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/source/CamelSourceCassandraITCase.java
+++ b/tests/itests-cassandra/src/test/java/org/apache/camel/kafkaconnector/cassandra/source/CamelSourceCassandraITCase.java
@@ -19,7 +19,7 @@ package org.apache.camel.kafkaconnector.cassandra.source;
 
 import java.util.concurrent.ExecutionException;
 
-import com.datastax.driver.core.Row;
+import com.datastax.oss.driver.api.core.cql.Row;
 import org.apache.camel.kafkaconnector.cassandra.clients.CassandraClient;
 import org.apache.camel.kafkaconnector.cassandra.clients.dao.TestDataDao;
 import org.apache.camel.kafkaconnector.cassandra.clients.dao.TestResultSetConversionStrategy;
@@ -78,7 +78,11 @@ public class CamelSourceCassandraITCase extends AbstractKafkaTest {
         cassandraClient = cassandraService.getClient();
 
         if (testDataDao != null) {
-            testDataDao.dropTable();
+            try {
+                testDataDao.dropTable();
+            } catch (Exception e) {
+                LOG.warn("Unable to drop the table: {}", e.getMessage(), e);
+            }
         }
     }
 


[camel-kafka-connector] 06/07: [create-pull-request] automated change

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

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

commit ed40b7930d2e920554f57088ae63cb2586d1b6d5
Author: github-actions[bot] <41...@users.noreply.github.com>
AuthorDate: Fri Aug 28 03:50:35 2020 +0000

    [create-pull-request] automated change
---
 .../src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc          | 6 ++----
 .../src/main/docs/examples/CamelAws2stsSinkConnector.properties     | 4 ++--
 .../kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java     | 4 ++--
 .../ROOT/pages/connectors/camel-aws2-sts-kafka-sink-connector.adoc  | 6 ++----
 4 files changed, 8 insertions(+), 12 deletions(-)

diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc
index 204c475..59de716 100644
--- a/connectors/camel-aws2-sts-kafka-connector/src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/camel-aws2-sts-kafka-sink-connector.adoc
@@ -25,7 +25,7 @@ The camel-aws2-sts sink connector supports 29 options, which are listed below.
 | *camel.sink.path.label* | Logical name | null | HIGH
 | *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
-| *camel.sink.endpoint.operation* | The operation to perform One of: [assumeRole] [getSessionToken] | "assumeRole" | HIGH
+| *camel.sink.endpoint.operation* | The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken] | "assumeRole" | HIGH
 | *camel.sink.endpoint.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the STS client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the STS client | null | MEDIUM
@@ -40,7 +40,7 @@ The camel-aws2-sts sink connector supports 29 options, which are listed below.
 | *camel.component.aws2-sts.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-sts.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-sts.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
-| *camel.component.aws2-sts.operation* | The operation to perform One of: [assumeRole] [getSessionToken] | "assumeRole" | HIGH
+| *camel.component.aws2-sts.operation* | The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken] | "assumeRole" | HIGH
 | *camel.component.aws2-sts.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.component.aws2-sts.proxyHost* | To define a proxy host when instantiating the STS client | null | MEDIUM
 | *camel.component.aws2-sts.proxyPort* | To define a proxy port when instantiating the STS client | null | MEDIUM
@@ -52,6 +52,4 @@ The camel-aws2-sts sink connector supports 29 options, which are listed below.
 | *camel.component.aws2-sts.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-sts.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 |===
-
-
 // kafka-connector options: END
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/docs/examples/CamelAws2stsSinkConnector.properties b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/examples/CamelAws2stsSinkConnector.properties
index 3954446..b1e982f 100644
--- a/connectors/camel-aws2-sts-kafka-connector/src/main/docs/examples/CamelAws2stsSinkConnector.properties
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/docs/examples/CamelAws2stsSinkConnector.properties
@@ -28,9 +28,9 @@ topics=
 
 # mandatory properties (for a complete properties list see the connector documentation):
 
-# The operation to perform One of: [assumeRole] [getSessionToken]
+# The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken]
 camel.component.aws2-sts.operation=
-# The operation to perform One of: [assumeRole] [getSessionToken]
+# The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken]
 camel.sink.endpoint.operation=
 # Logical name
 camel.sink.path.label=
diff --git a/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java
index 66ef528..0aaddad 100644
--- a/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java
+++ b/connectors/camel-aws2-sts-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sts/CamelAws2stsSinkConnectorConfig.java
@@ -34,7 +34,7 @@ public class CamelAws2stsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that wh [...]
     public static final Boolean CAMEL_SINK_AWS2STS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_CONF = "camel.sink.endpoint.operation";
-    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_DOC = "The operation to perform One of: [assumeRole] [getSessionToken]";
+    public static final String CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_DOC = "The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken]";
     public static final String CAMEL_SINK_AWS2STS_ENDPOINT_OPERATION_DEFAULT = "assumeRole";
     public static final String CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_CONF = "camel.sink.endpoint.pojoRequest";
     public static final String CAMEL_SINK_AWS2STS_ENDPOINT_POJO_REQUEST_DOC = "If we want to use a POJO request as body or not";
@@ -79,7 +79,7 @@ public class CamelAws2stsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_DOC = "Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that w [...]
     public static final Boolean CAMEL_SINK_AWS2STS_COMPONENT_LAZY_START_PRODUCER_DEFAULT = false;
     public static final String CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_CONF = "camel.component.aws2-sts.operation";
-    public static final String CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_DOC = "The operation to perform One of: [assumeRole] [getSessionToken]";
+    public static final String CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_DOC = "The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken]";
     public static final String CAMEL_SINK_AWS2STS_COMPONENT_OPERATION_DEFAULT = "assumeRole";
     public static final String CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_CONF = "camel.component.aws2-sts.pojoRequest";
     public static final String CAMEL_SINK_AWS2STS_COMPONENT_POJO_REQUEST_DOC = "If we want to use a POJO request as body or not";
diff --git a/docs/modules/ROOT/pages/connectors/camel-aws2-sts-kafka-sink-connector.adoc b/docs/modules/ROOT/pages/connectors/camel-aws2-sts-kafka-sink-connector.adoc
index 204c475..59de716 100644
--- a/docs/modules/ROOT/pages/connectors/camel-aws2-sts-kafka-sink-connector.adoc
+++ b/docs/modules/ROOT/pages/connectors/camel-aws2-sts-kafka-sink-connector.adoc
@@ -25,7 +25,7 @@ The camel-aws2-sts sink connector supports 29 options, which are listed below.
 | *camel.sink.path.label* | Logical name | null | HIGH
 | *camel.sink.endpoint.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
-| *camel.sink.endpoint.operation* | The operation to perform One of: [assumeRole] [getSessionToken] | "assumeRole" | HIGH
+| *camel.sink.endpoint.operation* | The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken] | "assumeRole" | HIGH
 | *camel.sink.endpoint.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.sink.endpoint.proxyHost* | To define a proxy host when instantiating the STS client | null | MEDIUM
 | *camel.sink.endpoint.proxyPort* | To define a proxy port when instantiating the STS client | null | MEDIUM
@@ -40,7 +40,7 @@ The camel-aws2-sts sink connector supports 29 options, which are listed below.
 | *camel.component.aws2-sts.autoDiscoverClient* | Setting the autoDiscoverClient mechanism, if true, the component will look for a client instance in the registry automatically otherwise it will skip that checking. | true | MEDIUM
 | *camel.component.aws2-sts.configuration* | Component configuration | null | MEDIUM
 | *camel.component.aws2-sts.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
-| *camel.component.aws2-sts.operation* | The operation to perform One of: [assumeRole] [getSessionToken] | "assumeRole" | HIGH
+| *camel.component.aws2-sts.operation* | The operation to perform One of: [assumeRole] [getSessionToken] [getFederationToken] | "assumeRole" | HIGH
 | *camel.component.aws2-sts.pojoRequest* | If we want to use a POJO request as body or not | false | MEDIUM
 | *camel.component.aws2-sts.proxyHost* | To define a proxy host when instantiating the STS client | null | MEDIUM
 | *camel.component.aws2-sts.proxyPort* | To define a proxy port when instantiating the STS client | null | MEDIUM
@@ -52,6 +52,4 @@ The camel-aws2-sts sink connector supports 29 options, which are listed below.
 | *camel.component.aws2-sts.accessKey* | Amazon AWS Access Key | null | MEDIUM
 | *camel.component.aws2-sts.secretKey* | Amazon AWS Secret Key | null | MEDIUM
 |===
-
-
 // kafka-connector options: END


[camel-kafka-connector] 01/07: Point to 3.5.0-SNAPSHOT

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

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

commit 895f7c155254841dc1cd93fead25a64c49dcb730
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Tue Aug 25 06:37:58 2020 +0200

    Point to 3.5.0-SNAPSHOT
---
 parent/pom.xml | 2 +-
 pom.xml        | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)

diff --git a/parent/pom.xml b/parent/pom.xml
index f485ca7..26a104a 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -28,7 +28,7 @@
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
 
         <kafka.version>2.5.0</kafka.version>
-        <camel.version>3.4.3</camel.version>
+        <camel.version>3.5.0-SNAPSHOT</camel.version>
         <version.java>1.8</version.java>
         <version.guava>20.0</version.guava>
         <version.javax.annotation-api>1.3.2</version.javax.annotation-api>
diff --git a/pom.xml b/pom.xml
index 78c98be..9148c02 100644
--- a/pom.xml
+++ b/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel</groupId>
         <artifactId>camel-dependencies</artifactId>
-        <version>3.4.3</version>
+        <version>3.5.0-SNAPSHOT</version>
     </parent>
 
     <groupId>org.apache.camel.kafkaconnector</groupId>


[camel-kafka-connector] 05/07: [create-pull-request] automated change

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

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

commit 34b44966292c04588cca1739bc8fdf0042244eef
Author: github-actions[bot] <41...@users.noreply.github.com>
AuthorDate: Thu Aug 27 03:48:53 2020 +0000

    [create-pull-request] automated change
---
 .../main/docs/camel-aws2-s3-kafka-source-connector.adoc  |  6 +++++-
 .../aws2s3/CamelAws2s3SourceConnectorConfig.java         | 16 ++++++++++++++++
 .../connectors/camel-aws2-s3-kafka-source-connector.adoc |  6 +++++-
 3 files changed, 26 insertions(+), 2 deletions(-)

diff --git a/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc b/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc
index ed7935d..579d343 100644
--- a/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc
+++ b/connectors/camel-aws2-s3-kafka-connector/src/main/docs/camel-aws2-s3-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-s3-kafka-connector as source make sure to use the followin
 ----
 
 
-The camel-aws2-s3 source connector supports 81 options, which are listed below.
+The camel-aws2-s3 source connector supports 85 options, which are listed below.
 
 
 
@@ -43,6 +43,8 @@ The camel-aws2-s3 source connector supports 81 options, which are listed below.
 | *camel.source.endpoint.deleteAfterRead* | Delete objects from S3 after they have been retrieved. The delete is only performed if the Exchange is committed. If a rollback occurs, the object is not deleted. If this option is false, then the same objects will be retrieve over and over again on the polls. Therefore you need to use the Idempotent Consumer EIP in the route to filter out duplicates. You can filter using the AWS2S3Constants#BUCKET_NAME and AWS2S3Constants#KEY headers, or only  [...]
 | *camel.source.endpoint.delimiter* | The delimiter which is used in the com.amazonaws.services.s3.model.ListObjectsRequest to only consume objects we are interested in. | null | MEDIUM
 | *camel.source.endpoint.destinationBucket* | Define the destination bucket where an object must be moved when moveAfterRead is set to true. | null | MEDIUM
+| *camel.source.endpoint.destinationBucketPrefix* | Define the destination bucket prefix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
+| *camel.source.endpoint.destinationBucketSuffix* | Define the destination bucket suffix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
 | *camel.source.endpoint.fileName* | To get the object from the bucket with the given file name | null | MEDIUM
 | *camel.source.endpoint.includeBody* | If it is true, the exchange body will be set to a stream to the contents of the file. If false, the headers will be set with the S3 object metadata, but the body will be null. This option is strongly related to autocloseBody option. In case of setting includeBody to true and autocloseBody to false, it will be up to the caller to close the S3Object stream. Setting autocloseBody to true, will close the S3Object stream automatically. | true | MEDIUM
 | *camel.source.endpoint.includeFolders* | If it is true, the folders/directories will be consumed. If it is false, they will be ignored, and Exchanges will not be created for those | true | MEDIUM
@@ -94,6 +96,8 @@ The camel-aws2-s3 source connector supports 81 options, which are listed below.
 | *camel.component.aws2-s3.deleteAfterRead* | Delete objects from S3 after they have been retrieved. The delete is only performed if the Exchange is committed. If a rollback occurs, the object is not deleted. If this option is false, then the same objects will be retrieve over and over again on the polls. Therefore you need to use the Idempotent Consumer EIP in the route to filter out duplicates. You can filter using the AWS2S3Constants#BUCKET_NAME and AWS2S3Constants#KEY headers, or onl [...]
 | *camel.component.aws2-s3.delimiter* | The delimiter which is used in the com.amazonaws.services.s3.model.ListObjectsRequest to only consume objects we are interested in. | null | MEDIUM
 | *camel.component.aws2-s3.destinationBucket* | Define the destination bucket where an object must be moved when moveAfterRead is set to true. | null | MEDIUM
+| *camel.component.aws2-s3.destinationBucketPrefix* | Define the destination bucket prefix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
+| *camel.component.aws2-s3.destinationBucketSuffix* | Define the destination bucket suffix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
 | *camel.component.aws2-s3.fileName* | To get the object from the bucket with the given file name | null | MEDIUM
 | *camel.component.aws2-s3.includeBody* | If it is true, the exchange body will be set to a stream to the contents of the file. If false, the headers will be set with the S3 object metadata, but the body will be null. This option is strongly related to autocloseBody option. In case of setting includeBody to true and autocloseBody to false, it will be up to the caller to close the S3Object stream. Setting autocloseBody to true, will close the S3Object stream automatically. | true | MEDIUM
 | *camel.component.aws2-s3.includeFolders* | If it is true, the folders/directories will be consumed. If it is false, they will be ignored, and Exchanges will not be created for those | true | MEDIUM
diff --git a/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java b/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java
index f2f9492..a1c9898 100644
--- a/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java
+++ b/connectors/camel-aws2-s3-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2s3/CamelAws2s3SourceConnectorConfig.java
@@ -89,6 +89,12 @@ public class CamelAws2s3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_CONF = "camel.source.endpoint.destinationBucket";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_DOC = "Define the destination bucket where an object must be moved when moveAfterRead is set to true.";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_PREFIX_CONF = "camel.source.endpoint.destinationBucketPrefix";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_PREFIX_DOC = "Define the destination bucket prefix to use when an object must be moved and moveAfterRead is set to true.";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_PREFIX_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_SUFFIX_CONF = "camel.source.endpoint.destinationBucketSuffix";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_SUFFIX_DOC = "Define the destination bucket suffix to use when an object must be moved and moveAfterRead is set to true.";
+    public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_SUFFIX_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_FILE_NAME_CONF = "camel.source.endpoint.fileName";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_FILE_NAME_DOC = "To get the object from the bucket with the given file name";
     public static final String CAMEL_SOURCE_AWS2S3_ENDPOINT_FILE_NAME_DEFAULT = null;
@@ -242,6 +248,12 @@ public class CamelAws2s3SourceConnectorConfig
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_CONF = "camel.component.aws2-s3.destinationBucket";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_DOC = "Define the destination bucket where an object must be moved when moveAfterRead is set to true.";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_PREFIX_CONF = "camel.component.aws2-s3.destinationBucketPrefix";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_PREFIX_DOC = "Define the destination bucket prefix to use when an object must be moved and moveAfterRead is set to true.";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_PREFIX_DEFAULT = null;
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_SUFFIX_CONF = "camel.component.aws2-s3.destinationBucketSuffix";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_SUFFIX_DOC = "Define the destination bucket suffix to use when an object must be moved and moveAfterRead is set to true.";
+    public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_SUFFIX_DEFAULT = null;
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_FILE_NAME_CONF = "camel.component.aws2-s3.fileName";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_FILE_NAME_DOC = "To get the object from the bucket with the given file name";
     public static final String CAMEL_SOURCE_AWS2S3_COMPONENT_FILE_NAME_DEFAULT = null;
@@ -303,6 +315,8 @@ public class CamelAws2s3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_DELETE_AFTER_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELETE_AFTER_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELETE_AFTER_READ_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_DELIMITER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELIMITER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_DELIMITER_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_PREFIX_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_SUFFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_SUFFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_DESTINATION_BUCKET_SUFFIX_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_FILE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_ENDPOINT_FILE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_FILE_NAME_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_INCLUDE_BODY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_INCLUDE_BODY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_INCLUDE_BODY_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_ENDPOINT_INCLUDE_FOLDERS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_ENDPOINT_INCLUDE_FOLDERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_ENDPOINT_INCLUDE_FOLDERS_DOC);
@@ -354,6 +368,8 @@ public class CamelAws2s3SourceConnectorConfig
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_DELETE_AFTER_READ_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_DELETE_AFTER_READ_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_DELETE_AFTER_READ_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_DELIMITER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_DELIMITER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_DELIMITER_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_PREFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_PREFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_PREFIX_DOC);
+        conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_SUFFIX_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_SUFFIX_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_DESTINATION_BUCKET_SUFFIX_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_FILE_NAME_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_AWS2S3_COMPONENT_FILE_NAME_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_FILE_NAME_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_INCLUDE_BODY_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_INCLUDE_BODY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_INCLUDE_BODY_DOC);
         conf.define(CAMEL_SOURCE_AWS2S3_COMPONENT_INCLUDE_FOLDERS_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_AWS2S3_COMPONENT_INCLUDE_FOLDERS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_AWS2S3_COMPONENT_INCLUDE_FOLDERS_DOC);
diff --git a/docs/modules/ROOT/pages/connectors/camel-aws2-s3-kafka-source-connector.adoc b/docs/modules/ROOT/pages/connectors/camel-aws2-s3-kafka-source-connector.adoc
index ed7935d..579d343 100644
--- a/docs/modules/ROOT/pages/connectors/camel-aws2-s3-kafka-source-connector.adoc
+++ b/docs/modules/ROOT/pages/connectors/camel-aws2-s3-kafka-source-connector.adoc
@@ -15,7 +15,7 @@ When using camel-aws2-s3-kafka-connector as source make sure to use the followin
 ----
 
 
-The camel-aws2-s3 source connector supports 81 options, which are listed below.
+The camel-aws2-s3 source connector supports 85 options, which are listed below.
 
 
 
@@ -43,6 +43,8 @@ The camel-aws2-s3 source connector supports 81 options, which are listed below.
 | *camel.source.endpoint.deleteAfterRead* | Delete objects from S3 after they have been retrieved. The delete is only performed if the Exchange is committed. If a rollback occurs, the object is not deleted. If this option is false, then the same objects will be retrieve over and over again on the polls. Therefore you need to use the Idempotent Consumer EIP in the route to filter out duplicates. You can filter using the AWS2S3Constants#BUCKET_NAME and AWS2S3Constants#KEY headers, or only  [...]
 | *camel.source.endpoint.delimiter* | The delimiter which is used in the com.amazonaws.services.s3.model.ListObjectsRequest to only consume objects we are interested in. | null | MEDIUM
 | *camel.source.endpoint.destinationBucket* | Define the destination bucket where an object must be moved when moveAfterRead is set to true. | null | MEDIUM
+| *camel.source.endpoint.destinationBucketPrefix* | Define the destination bucket prefix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
+| *camel.source.endpoint.destinationBucketSuffix* | Define the destination bucket suffix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
 | *camel.source.endpoint.fileName* | To get the object from the bucket with the given file name | null | MEDIUM
 | *camel.source.endpoint.includeBody* | If it is true, the exchange body will be set to a stream to the contents of the file. If false, the headers will be set with the S3 object metadata, but the body will be null. This option is strongly related to autocloseBody option. In case of setting includeBody to true and autocloseBody to false, it will be up to the caller to close the S3Object stream. Setting autocloseBody to true, will close the S3Object stream automatically. | true | MEDIUM
 | *camel.source.endpoint.includeFolders* | If it is true, the folders/directories will be consumed. If it is false, they will be ignored, and Exchanges will not be created for those | true | MEDIUM
@@ -94,6 +96,8 @@ The camel-aws2-s3 source connector supports 81 options, which are listed below.
 | *camel.component.aws2-s3.deleteAfterRead* | Delete objects from S3 after they have been retrieved. The delete is only performed if the Exchange is committed. If a rollback occurs, the object is not deleted. If this option is false, then the same objects will be retrieve over and over again on the polls. Therefore you need to use the Idempotent Consumer EIP in the route to filter out duplicates. You can filter using the AWS2S3Constants#BUCKET_NAME and AWS2S3Constants#KEY headers, or onl [...]
 | *camel.component.aws2-s3.delimiter* | The delimiter which is used in the com.amazonaws.services.s3.model.ListObjectsRequest to only consume objects we are interested in. | null | MEDIUM
 | *camel.component.aws2-s3.destinationBucket* | Define the destination bucket where an object must be moved when moveAfterRead is set to true. | null | MEDIUM
+| *camel.component.aws2-s3.destinationBucketPrefix* | Define the destination bucket prefix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
+| *camel.component.aws2-s3.destinationBucketSuffix* | Define the destination bucket suffix to use when an object must be moved and moveAfterRead is set to true. | null | MEDIUM
 | *camel.component.aws2-s3.fileName* | To get the object from the bucket with the given file name | null | MEDIUM
 | *camel.component.aws2-s3.includeBody* | If it is true, the exchange body will be set to a stream to the contents of the file. If false, the headers will be set with the S3 object metadata, but the body will be null. This option is strongly related to autocloseBody option. In case of setting includeBody to true and autocloseBody to false, it will be up to the caller to close the S3Object stream. Setting autocloseBody to true, will close the S3Object stream automatically. | true | MEDIUM
 | *camel.component.aws2-s3.includeFolders* | If it is true, the folders/directories will be consumed. If it is false, they will be ignored, and Exchanges will not be created for those | true | MEDIUM


[camel-kafka-connector] 02/07: Pointing the github actions to 3.5.0-SNAPSHOT

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

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

commit b87ab800d2f6ad4d32e8971f6a84fc494b896bc7
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Tue Aug 25 06:43:09 2020 +0200

    Pointing the github actions to 3.5.0-SNAPSHOT
---
 .github/workflows/master-pr-build.yml   | 2 +-
 .github/workflows/master-push-build.yml | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)

diff --git a/.github/workflows/master-pr-build.yml b/.github/workflows/master-pr-build.yml
index 928332a..ccb869d 100644
--- a/.github/workflows/master-pr-build.yml
+++ b/.github/workflows/master-pr-build.yml
@@ -20,7 +20,7 @@ name: master pr build
 on:
   pull_request:
     branches:
-      - master
+      - camel-master
 jobs:
   build:
     runs-on: ubuntu-latest
diff --git a/.github/workflows/master-push-build.yml b/.github/workflows/master-push-build.yml
index 035fff7..d181bee 100644
--- a/.github/workflows/master-push-build.yml
+++ b/.github/workflows/master-push-build.yml
@@ -20,7 +20,7 @@ name: master build
 on:
   push:
     branches:
-      - master
+      - camel-master
 jobs:
   build:
     runs-on: ubuntu-latest


[camel-kafka-connector] 07/07: [create-pull-request] automated change

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

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

commit ec5bec4d0defca680ee4e872736bbb7eee8452ae
Author: github-actions[bot] <41...@users.noreply.github.com>
AuthorDate: Sat Aug 29 03:52:20 2020 +0000

    [create-pull-request] automated change
---
 .../src/main/docs/camel-jira-kafka-sink-connector.adoc         |  2 +-
 .../src/main/docs/camel-jira-kafka-source-connector.adoc       |  6 ++++--
 .../src/main/docs/examples/CamelJiraSinkConnector.properties   |  2 +-
 .../src/main/docs/examples/CamelJiraSourceConnector.properties |  2 +-
 .../kafkaconnector/jira/CamelJiraSinkConnectorConfig.java      |  2 +-
 .../kafkaconnector/jira/CamelJiraSourceConnectorConfig.java    | 10 +++++++++-
 .../ROOT/pages/connectors/camel-jira-kafka-sink-connector.adoc |  2 +-
 .../pages/connectors/camel-jira-kafka-source-connector.adoc    |  6 ++++--
 8 files changed, 22 insertions(+), 10 deletions(-)

diff --git a/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-sink-connector.adoc b/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-sink-connector.adoc
index 5d399cb..94d4212 100644
--- a/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-sink-connector.adoc
+++ b/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-sink-connector.adoc
@@ -22,7 +22,7 @@ The camel-jira sink connector supports 23 options, which are listed below.
 [width="100%",cols="2,5,^1,2",options="header"]
 |===
 | Name | Description | Default | Priority
-| *camel.sink.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
+| *camel.sink.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
 | *camel.sink.endpoint.delay* | Time in milliseconds to elapse for the next poll. | "6000" | MEDIUM
 | *camel.sink.endpoint.jiraUrl* | The Jira server url, example: \http://my_jira.com:8081 | null | HIGH
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
diff --git a/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-source-connector.adoc b/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-source-connector.adoc
index 3cce7fc..4234e6d 100644
--- a/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-source-connector.adoc
+++ b/connectors/camel-jira-kafka-connector/src/main/docs/camel-jira-kafka-source-connector.adoc
@@ -15,19 +15,21 @@ When using camel-jira-kafka-connector as source make sure to use the following M
 ----
 
 
-The camel-jira source connector supports 27 options, which are listed below.
+The camel-jira source connector supports 29 options, which are listed below.
 
 
 
 [width="100%",cols="2,5,^1,2",options="header"]
 |===
 | Name | Description | Default | Priority
-| *camel.source.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
+| *camel.source.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
 | *camel.source.endpoint.delay* | Time in milliseconds to elapse for the next poll. | "6000" | MEDIUM
 | *camel.source.endpoint.jiraUrl* | The Jira server url, example: \http://my_jira.com:8081 | null | HIGH
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.jql* | JQL is the query language from JIRA which allows you to retrieve the data you want. For example jql=project=MyProject Where MyProject is the product key in Jira. It is important to use the RAW() and set the JQL inside it to prevent camel parsing it, example: RAW(project in (MYP, COM) AND resolution = Unresolved) | null | MEDIUM
 | *camel.source.endpoint.maxResults* | Max number of issues to search for | "50" | MEDIUM
+| *camel.source.endpoint.sendOnlyUpdatedField* | Indicator for sending only changed fields in exchange body or issue object. By default consumer sends only changed fields. | true | MEDIUM
+| *camel.source.endpoint.watchedFields* | Comma separated list of fields to watch for changes. Status,Priority are the defaults. | "Status,Priority" | MEDIUM
 | *camel.source.endpoint.exceptionHandler* | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored. | null | MEDIUM
 | *camel.source.endpoint.exchangePattern* | Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut] | null | MEDIUM
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM
diff --git a/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSinkConnector.properties b/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSinkConnector.properties
index 064ae0b..c3908b7 100644
--- a/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSinkConnector.properties
+++ b/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSinkConnector.properties
@@ -32,6 +32,6 @@ topics=
 camel.component.jira.jiraUrl=
 # The Jira server url, example: http://my_jira.com:8081
 camel.sink.endpoint.jiraUrl=
-# Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]
+# Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]
 camel.sink.path.type=
 
diff --git a/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSourceConnector.properties b/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSourceConnector.properties
index 1b9abd6..9273ad5 100644
--- a/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSourceConnector.properties
+++ b/connectors/camel-jira-kafka-connector/src/main/docs/examples/CamelJiraSourceConnector.properties
@@ -32,6 +32,6 @@ topics=
 camel.component.jira.jiraUrl=
 # The Jira server url, example: http://my_jira.com:8081
 camel.source.endpoint.jiraUrl=
-# Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]
+# Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]
 camel.source.path.type=
 
diff --git a/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSinkConnectorConfig.java b/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSinkConnectorConfig.java
index 85a5039..4cf3841 100644
--- a/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSinkConnectorConfig.java
+++ b/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSinkConnectorConfig.java
@@ -25,7 +25,7 @@ import org.apache.kafka.common.config.ConfigDef;
 public class CamelJiraSinkConnectorConfig extends CamelSinkConnectorConfig {
 
     public static final String CAMEL_SINK_JIRA_PATH_TYPE_CONF = "camel.sink.path.type";
-    public static final String CAMEL_SINK_JIRA_PATH_TYPE_DOC = "Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]";
+    public static final String CAMEL_SINK_JIRA_PATH_TYPE_DOC = "Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]";
     public static final String CAMEL_SINK_JIRA_PATH_TYPE_DEFAULT = null;
     public static final String CAMEL_SINK_JIRA_ENDPOINT_DELAY_CONF = "camel.sink.endpoint.delay";
     public static final String CAMEL_SINK_JIRA_ENDPOINT_DELAY_DOC = "Time in milliseconds to elapse for the next poll.";
diff --git a/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSourceConnectorConfig.java b/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSourceConnectorConfig.java
index 12bc5d7..ab5ec0f 100644
--- a/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSourceConnectorConfig.java
+++ b/connectors/camel-jira-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/jira/CamelJiraSourceConnectorConfig.java
@@ -27,7 +27,7 @@ public class CamelJiraSourceConnectorConfig
             CamelSourceConnectorConfig {
 
     public static final String CAMEL_SOURCE_JIRA_PATH_TYPE_CONF = "camel.source.path.type";
-    public static final String CAMEL_SOURCE_JIRA_PATH_TYPE_DOC = "Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]";
+    public static final String CAMEL_SOURCE_JIRA_PATH_TYPE_DOC = "Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS]";
     public static final String CAMEL_SOURCE_JIRA_PATH_TYPE_DEFAULT = null;
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_DELAY_CONF = "camel.source.endpoint.delay";
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_DELAY_DOC = "Time in milliseconds to elapse for the next poll.";
@@ -44,6 +44,12 @@ public class CamelJiraSourceConnectorConfig
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_MAX_RESULTS_CONF = "camel.source.endpoint.maxResults";
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_MAX_RESULTS_DOC = "Max number of issues to search for";
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_MAX_RESULTS_DEFAULT = "50";
+    public static final String CAMEL_SOURCE_JIRA_ENDPOINT_SEND_ONLY_UPDATED_FIELD_CONF = "camel.source.endpoint.sendOnlyUpdatedField";
+    public static final String CAMEL_SOURCE_JIRA_ENDPOINT_SEND_ONLY_UPDATED_FIELD_DOC = "Indicator for sending only changed fields in exchange body or issue object. By default consumer sends only changed fields.";
+    public static final Boolean CAMEL_SOURCE_JIRA_ENDPOINT_SEND_ONLY_UPDATED_FIELD_DEFAULT = true;
+    public static final String CAMEL_SOURCE_JIRA_ENDPOINT_WATCHED_FIELDS_CONF = "camel.source.endpoint.watchedFields";
+    public static final String CAMEL_SOURCE_JIRA_ENDPOINT_WATCHED_FIELDS_DOC = "Comma separated list of fields to watch for changes. Status,Priority are the defaults.";
+    public static final String CAMEL_SOURCE_JIRA_ENDPOINT_WATCHED_FIELDS_DEFAULT = "Status,Priority";
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_EXCEPTION_HANDLER_CONF = "camel.source.endpoint.exceptionHandler";
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_EXCEPTION_HANDLER_DOC = "To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored.";
     public static final String CAMEL_SOURCE_JIRA_ENDPOINT_EXCEPTION_HANDLER_DEFAULT = null;
@@ -126,6 +132,8 @@ public class CamelJiraSourceConnectorConfig
         conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_BRIDGE_ERROR_HANDLER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_JIRA_ENDPOINT_BRIDGE_ERROR_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_BRIDGE_ERROR_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_JQL_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_JIRA_ENDPOINT_JQL_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_JQL_DOC);
         conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_MAX_RESULTS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_JIRA_ENDPOINT_MAX_RESULTS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_MAX_RESULTS_DOC);
+        conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_SEND_ONLY_UPDATED_FIELD_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_JIRA_ENDPOINT_SEND_ONLY_UPDATED_FIELD_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_SEND_ONLY_UPDATED_FIELD_DOC);
+        conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_WATCHED_FIELDS_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_JIRA_ENDPOINT_WATCHED_FIELDS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_WATCHED_FIELDS_DOC);
         conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_EXCEPTION_HANDLER_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_JIRA_ENDPOINT_EXCEPTION_HANDLER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_EXCEPTION_HANDLER_DOC);
         conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_EXCHANGE_PATTERN_CONF, ConfigDef.Type.STRING, CAMEL_SOURCE_JIRA_ENDPOINT_EXCHANGE_PATTERN_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_EXCHANGE_PATTERN_DOC);
         conf.define(CAMEL_SOURCE_JIRA_ENDPOINT_BASIC_PROPERTY_BINDING_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SOURCE_JIRA_ENDPOINT_BASIC_PROPERTY_BINDING_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SOURCE_JIRA_ENDPOINT_BASIC_PROPERTY_BINDING_DOC);
diff --git a/docs/modules/ROOT/pages/connectors/camel-jira-kafka-sink-connector.adoc b/docs/modules/ROOT/pages/connectors/camel-jira-kafka-sink-connector.adoc
index 5d399cb..94d4212 100644
--- a/docs/modules/ROOT/pages/connectors/camel-jira-kafka-sink-connector.adoc
+++ b/docs/modules/ROOT/pages/connectors/camel-jira-kafka-sink-connector.adoc
@@ -22,7 +22,7 @@ The camel-jira sink connector supports 23 options, which are listed below.
 [width="100%",cols="2,5,^1,2",options="header"]
 |===
 | Name | Description | Default | Priority
-| *camel.sink.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
+| *camel.sink.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
 | *camel.sink.endpoint.delay* | Time in milliseconds to elapse for the next poll. | "6000" | MEDIUM
 | *camel.sink.endpoint.jiraUrl* | The Jira server url, example: \http://my_jira.com:8081 | null | HIGH
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
diff --git a/docs/modules/ROOT/pages/connectors/camel-jira-kafka-source-connector.adoc b/docs/modules/ROOT/pages/connectors/camel-jira-kafka-source-connector.adoc
index 3cce7fc..4234e6d 100644
--- a/docs/modules/ROOT/pages/connectors/camel-jira-kafka-source-connector.adoc
+++ b/docs/modules/ROOT/pages/connectors/camel-jira-kafka-source-connector.adoc
@@ -15,19 +15,21 @@ When using camel-jira-kafka-connector as source make sure to use the following M
 ----
 
 
-The camel-jira source connector supports 27 options, which are listed below.
+The camel-jira source connector supports 29 options, which are listed below.
 
 
 
 [width="100%",cols="2,5,^1,2",options="header"]
 |===
 | Name | Description | Default | Priority
-| *camel.source.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
+| *camel.source.path.type* | Operation to perform. Consumers: NewIssues, NewComments. Producers: AddIssue, AttachFile, DeleteIssue, TransitionIssue, UpdateIssue, Watchers. See this class javadoc description for more information. One of: [ADDCOMMENT] [ADDISSUE] [ATTACH] [DELETEISSUE] [NEWISSUES] [NEWCOMMENTS] [WATCHUPDATES] [UPDATEISSUE] [TRANSITIONISSUE] [WATCHERS] [ADDISSUELINK] [ADDWORKLOG] [FETCHISSUE] [FETCHCOMMENTS] | null | HIGH
 | *camel.source.endpoint.delay* | Time in milliseconds to elapse for the next poll. | "6000" | MEDIUM
 | *camel.source.endpoint.jiraUrl* | The Jira server url, example: \http://my_jira.com:8081 | null | HIGH
 | *camel.source.endpoint.bridgeErrorHandler* | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | MEDIUM
 | *camel.source.endpoint.jql* | JQL is the query language from JIRA which allows you to retrieve the data you want. For example jql=project=MyProject Where MyProject is the product key in Jira. It is important to use the RAW() and set the JQL inside it to prevent camel parsing it, example: RAW(project in (MYP, COM) AND resolution = Unresolved) | null | MEDIUM
 | *camel.source.endpoint.maxResults* | Max number of issues to search for | "50" | MEDIUM
+| *camel.source.endpoint.sendOnlyUpdatedField* | Indicator for sending only changed fields in exchange body or issue object. By default consumer sends only changed fields. | true | MEDIUM
+| *camel.source.endpoint.watchedFields* | Comma separated list of fields to watch for changes. Status,Priority are the defaults. | "Status,Priority" | MEDIUM
 | *camel.source.endpoint.exceptionHandler* | To let the consumer use a custom ExceptionHandler. Notice if the option bridgeErrorHandler is enabled then this option is not in use. By default the consumer will deal with exceptions, that will be logged at WARN or ERROR level and ignored. | null | MEDIUM
 | *camel.source.endpoint.exchangePattern* | Sets the exchange pattern when the consumer creates an exchange. One of: [InOnly] [InOut] [InOptionalOut] | null | MEDIUM
 | *camel.source.endpoint.basicPropertyBinding* | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | MEDIUM