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

[camel] branch master updated (dea324f -> c2062ad)

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

davsclaus pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/camel.git.


    from dea324f  Merge pull request #3659 from djencks/issue-14747-aggregate-eip-task-14754
     new 21d8ad3  CAMEL-14762: camel-core - Configurer to include API for method name and type
     new a92f87d  CAMEL-14762: camel-core - Configurer to include API for method name and type
     new 4b4a09f  CAMEL-14762: camel-core - Configurer to include API for method name and type
     new 1bdfcfe  Make camel-debezium generate boolean getter with isXXX name instead of getXXX
     new 81fb703  CAMEL-14762: camel-core - Configurer to include API for method name and type
     new 21eece5  CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
     new 7d1a25e  CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
     new f16ff39  Add first version
     new e6fad20  CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
     new 718801e  CAMEL-14762: camel-core - Configurer to include API for method name and type
     new 1387dee  CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
     new 94c9c3f  CAMEL-14762: Fixed CS
     new c2062ad  Lets use ENGLISH instead of US in lower case

The 13 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:
 .../activemq/ActiveMQComponentConfigurer.java      |  31 +-
 .../activemq/ActiveMQEndpointConfigurer.java       |   7 +-
 .../component/activemq/ActiveMQComponent.java      |  28 ++
 .../component/ahc/ws/WsComponentConfigurer.java    |  22 +-
 .../component/ahc/ws/WsEndpointConfigurer.java     |  34 +-
 .../component/ahc/AhcComponentConfigurer.java      |  44 ++-
 .../camel/component/ahc/AhcEndpointConfigurer.java |  62 +++-
 .../component/amqp/AMQPComponentConfigurer.java    |  22 +-
 .../component/amqp/AMQPEndpointConfigurer.java     |   7 +-
 .../apache/camel/component/amqp/AMQPComponent.java |   7 +
 .../component/apns/ApnsComponentConfigurer.java    |  31 +-
 .../component/apns/ApnsEndpointConfigurer.java     |  83 ++++-
 .../component/as2/AS2ComponentConfigurer.java      |  30 +-
 .../camel/component/as2/AS2EndpointConfigurer.java | 159 +++++++++-
 .../asterisk/AsteriskComponentConfigurer.java      |  28 +-
 .../asterisk/AsteriskEndpointConfigurer.java       |  44 ++-
 .../component/atmos/AtmosComponentConfigurer.java  |  39 ++-
 .../component/atmos/AtmosEndpointConfigurer.java   |  58 +++-
 .../websocket/WebsocketComponentConfigurer.java    |  22 +-
 .../websocket/WebsocketEndpointConfigurer.java     |  67 +++-
 .../component/atom/AtomComponentConfigurer.java    |  25 +-
 .../component/atom/AtomEndpointConfigurer.java     |  99 +++++-
 .../client/map/AtomixMapComponentConfigurer.java   |  67 +++-
 .../client/map/AtomixMapEndpointConfigurer.java    |  73 ++++-
 .../AtomixMessagingComponentConfigurer.java        |  72 ++++-
 .../AtomixMessagingEndpointConfigurer.java         |  78 ++++-
 .../AtomixMultiMapComponentConfigurer.java         |  64 +++-
 .../multimap/AtomixMultiMapEndpointConfigurer.java |  64 +++-
 .../queue/AtomixQueueComponentConfigurer.java      |  63 +++-
 .../queue/AtomixQueueEndpointConfigurer.java       |  69 +++-
 .../client/set/AtomixSetComponentConfigurer.java   |  65 +++-
 .../client/set/AtomixSetEndpointConfigurer.java    |  71 ++++-
 .../value/AtomixValueComponentConfigurer.java      |  65 +++-
 .../value/AtomixValueEndpointConfigurer.java       |  71 ++++-
 .../component/avro/AvroComponentConfigurer.java    |  47 ++-
 .../component/avro/AvroEndpointConfigurer.java     |  53 +++-
 .../component/aws/cw/CwComponentConfigurer.java    |  55 +++-
 .../component/aws/cw/CwEndpointConfigurer.java     |  55 +++-
 .../component/aws/ddb/DdbComponentConfigurer.java  |  64 +++-
 .../component/aws/ddb/DdbEndpointConfigurer.java   |  64 +++-
 .../ddbstream/DdbStreamComponentConfigurer.java    |  56 +++-
 .../aws/ddbstream/DdbStreamEndpointConfigurer.java | 107 ++++++-
 .../component/aws/ec2/EC2ComponentConfigurer.java  |  49 ++-
 .../component/aws/ec2/EC2EndpointConfigurer.java   |  49 ++-
 .../component/aws/ecs/ECSComponentConfigurer.java  |  49 ++-
 .../component/aws/ecs/ECSEndpointConfigurer.java   |  49 ++-
 .../component/aws/eks/EKSComponentConfigurer.java  |  49 ++-
 .../component/aws/eks/EKSEndpointConfigurer.java   |  49 ++-
 .../component/aws/iam/IAMComponentConfigurer.java  |  49 ++-
 .../component/aws/iam/IAMEndpointConfigurer.java   |  49 ++-
 .../KinesisFirehoseComponentConfigurer.java        |  47 ++-
 .../KinesisFirehoseEndpointConfigurer.java         |  47 ++-
 .../aws/kinesis/KinesisComponentConfigurer.java    |  65 +++-
 .../aws/kinesis/KinesisEndpointConfigurer.java     | 116 ++++++-
 .../component/aws/kms/KMSComponentConfigurer.java  |  49 ++-
 .../component/aws/kms/KMSEndpointConfigurer.java   |  49 ++-
 .../aws/lambda/LambdaComponentConfigurer.java      |  49 ++-
 .../aws/lambda/LambdaEndpointConfigurer.java       |  49 ++-
 .../component/aws/mq/MQComponentConfigurer.java    |  49 ++-
 .../component/aws/mq/MQEndpointConfigurer.java     |  49 ++-
 .../component/aws/msk/MSKComponentConfigurer.java  |  49 ++-
 .../component/aws/msk/MSKEndpointConfigurer.java   |  49 ++-
 .../component/aws/s3/S3ComponentConfigurer.java    | 127 +++++++-
 .../component/aws/s3/S3EndpointConfigurer.java     | 184 ++++++++++-
 .../component/aws/sdb/SdbComponentConfigurer.java  |  25 +-
 .../component/aws/sdb/SdbEndpointConfigurer.java   |  55 +++-
 .../component/aws/ses/SesComponentConfigurer.java  |  57 +++-
 .../component/aws/ses/SesEndpointConfigurer.java   |  57 +++-
 .../component/aws/sns/SnsComponentConfigurer.java  |  72 ++++-
 .../component/aws/sns/SnsEndpointConfigurer.java   |  75 ++++-
 .../component/aws/sqs/SqsComponentConfigurer.java  | 128 +++++++-
 .../component/aws/sqs/SqsEndpointConfigurer.java   | 185 ++++++++++-
 .../component/aws/swf/SWFComponentConfigurer.java  | 105 +++++-
 .../component/aws/swf/SWFEndpointConfigurer.java   | 111 ++++++-
 .../translate/TranslateComponentConfigurer.java    |  58 +++-
 .../aws/translate/TranslateEndpointConfigurer.java |  58 +++-
 .../component/aws2/cw/Cw2ComponentConfigurer.java  |  55 +++-
 .../component/aws2/cw/Cw2EndpointConfigurer.java   |  55 +++-
 .../aws2/ddb/Ddb2ComponentConfigurer.java          |  64 +++-
 .../component/aws2/ddb/Ddb2EndpointConfigurer.java |  64 +++-
 .../ddbstream/Ddb2StreamComponentConfigurer.java   |  56 +++-
 .../ddbstream/Ddb2StreamEndpointConfigurer.java    | 107 ++++++-
 .../aws2/ec2/AWS2EC2ComponentConfigurer.java       |  49 ++-
 .../aws2/ec2/AWS2EC2EndpointConfigurer.java        |  49 ++-
 .../aws2/ecs/ECS2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/ecs/ECS2EndpointConfigurer.java |  49 ++-
 .../aws2/eks/EKS2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/eks/EKS2EndpointConfigurer.java |  49 ++-
 .../aws2/iam/IAM2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/iam/IAM2EndpointConfigurer.java |  49 ++-
 .../KinesisFirehose2ComponentConfigurer.java       |  47 ++-
 .../KinesisFirehose2EndpointConfigurer.java        |  47 ++-
 .../aws2/kinesis/Kinesis2ComponentConfigurer.java  |  65 +++-
 .../aws2/kinesis/Kinesis2EndpointConfigurer.java   | 116 ++++++-
 .../aws2/kms/KMS2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/kms/KMS2EndpointConfigurer.java |  49 ++-
 .../aws2/lambda/Lambda2ComponentConfigurer.java    |  49 ++-
 .../aws2/lambda/Lambda2EndpointConfigurer.java     |  49 ++-
 .../component/aws2/mq/MQ2ComponentConfigurer.java  |  49 ++-
 .../component/aws2/mq/MQ2EndpointConfigurer.java   |  49 ++-
 .../aws2/msk/MSK2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/msk/MSK2EndpointConfigurer.java |  49 ++-
 .../aws2/s3/AWS2S3ComponentConfigurer.java         | 103 +++++-
 .../aws2/s3/AWS2S3EndpointConfigurer.java          | 160 +++++++++-
 .../aws2/ses/Ses2ComponentConfigurer.java          |  57 +++-
 .../component/aws2/ses/Ses2EndpointConfigurer.java |  57 +++-
 .../aws2/sns/Sns2ComponentConfigurer.java          |  69 +++-
 .../component/aws2/sns/Sns2EndpointConfigurer.java |  72 ++++-
 .../aws2/sqs/Sqs2ComponentConfigurer.java          | 128 +++++++-
 .../component/aws2/sqs/Sqs2EndpointConfigurer.java | 185 ++++++++++-
 .../translate/Translate2ComponentConfigurer.java   |  58 +++-
 .../translate/Translate2EndpointConfigurer.java    |  58 +++-
 .../azure/blob/BlobServiceComponentConfigurer.java |  79 ++++-
 .../azure/blob/BlobServiceEndpointConfigurer.java  |  85 ++++-
 .../queue/QueueServiceComponentConfigurer.java     |  52 ++-
 .../queue/QueueServiceEndpointConfigurer.java      |  58 +++-
 .../BeanValidatorComponentConfigurer.java          |  40 ++-
 .../validator/BeanValidatorEndpointConfigurer.java |  47 ++-
 .../component/bean/BeanComponentConfigurer.java    |  29 +-
 .../component/bean/BeanEndpointConfigurer.java     |  35 +-
 .../beanclass/ClassComponentConfigurer.java        |   7 +-
 .../beanclass/ClassEndpointConfigurer.java         |   7 +-
 .../beanstalk/BeanstalkComponentConfigurer.java    |  31 +-
 .../beanstalk/BeanstalkEndpointConfigurer.java     | 101 +++++-
 .../bonita/BonitaComponentConfigurer.java          |  25 +-
 .../component/bonita/BonitaEndpointConfigurer.java |  38 ++-
 .../component/box/BoxComponentConfigurer.java      |  75 ++++-
 .../camel/component/box/BoxEndpointConfigurer.java | 129 +++++++-
 .../braintree/BraintreeComponentConfigurer.java    |  30 +-
 .../braintree/BraintreeEndpointConfigurer.java     | 116 ++++++-
 .../browse/BrowseComponentConfigurer.java          |  28 +-
 .../component/browse/BrowseEndpointConfigurer.java |  36 ++-
 .../cache/CaffeineCacheComponentConfigurer.java    |  69 +++-
 .../cache/CaffeineCacheEndpointConfigurer.java     |  69 +++-
 .../load/CaffeineLoadCacheComponentConfigurer.java |  69 +++-
 .../load/CaffeineLoadCacheEndpointConfigurer.java  |  69 +++-
 .../cassandra/CassandraComponentConfigurer.java    |  28 +-
 .../cassandra/CassandraEndpointConfigurer.java     | 106 ++++++-
 .../chatscript/ChatScriptComponentConfigurer.java  |  25 +-
 .../chatscript/ChatScriptEndpointConfigurer.java   |  33 +-
 .../component/chunk/ChunkComponentConfigurer.java  |  25 +-
 .../component/chunk/ChunkEndpointConfigurer.java   |  43 ++-
 .../camel/component/cm/CMComponentConfigurer.java  |  25 +-
 .../camel/component/cm/CMEndpointConfigurer.java   |  39 ++-
 .../component/cmis/CMISComponentConfigurer.java    |  31 +-
 .../component/cmis/CMISEndpointConfigurer.java     |  60 +++-
 .../apache/camel/coap/CoAPComponentConfigurer.java |  28 +-
 .../apache/camel/coap/CoAPEndpointConfigurer.java  |  65 +++-
 .../cometd/CometdComponentConfigurer.java          |  48 ++-
 .../component/cometd/CometdEndpointConfigurer.java |  70 +++-
 .../consul/ConsulComponentConfigurer.java          |  89 +++++-
 .../component/consul/ConsulEndpointConfigurer.java |  92 +++++-
 .../controlbus/ControlBusComponentConfigurer.java  |  25 +-
 .../controlbus/ControlBusEndpointConfigurer.java   |  40 ++-
 .../component/corda/CordaComponentConfigurer.java  |  56 +++-
 .../component/corda/CordaEndpointConfigurer.java   |  62 +++-
 .../couchbase/CouchbaseComponentConfigurer.java    |  28 +-
 .../couchbase/CouchbaseEndpointConfigurer.java     | 157 ++++++++-
 .../couchdb/CouchDbComponentConfigurer.java        |  28 +-
 .../couchdb/CouchDbEndpointConfigurer.java         |  53 +++-
 .../component/cron/CronComponentConfigurer.java    |  28 +-
 .../component/cron/CronEndpointConfigurer.java     |  35 +-
 .../crypto/cms/CryptoCmsComponentConfigurer.java   |  31 +-
 .../crypto/cms/CryptoCmsEndpointConfigurer.java    |  66 +++-
 .../DigitalSignatureComponentConfigurer.java       |  75 ++++-
 .../crypto/DigitalSignatureEndpointConfigurer.java |  75 ++++-
 .../component/cxf/CxfComponentConfigurer.java      |  37 ++-
 .../camel/component/cxf/CxfEndpointConfigurer.java | 121 ++++++-
 .../cxf/jaxrs/CxfRsComponentConfigurer.java        |  34 +-
 .../cxf/jaxrs/CxfRsEndpointConfigurer.java         | 110 ++++++-
 .../apache/camel/component/cxf/CxfComponent.java   |   2 +-
 .../dataformat/DataFormatComponentConfigurer.java  |  25 +-
 .../dataformat/DataFormatEndpointConfigurer.java   |  27 +-
 .../dataset/DataSetComponentConfigurer.java        |  28 +-
 .../dataset/DataSetEndpointConfigurer.java         |  46 ++-
 .../dataset/DataSetTestComponentConfigurer.java    |  25 +-
 .../dataset/DataSetTestEndpointConfigurer.java     |  28 +-
 .../camel/maven/config/ConnectorConfigField.java   |  10 +-
 .../DebeziumMongodbComponentConfigurer.java        | 144 ++++++++-
 .../DebeziumMongodbEndpointConfigurer.java         | 150 ++++++++-
 ...goDbConnectorEmbeddedDebeziumConfiguration.java |   8 +-
 .../debezium/DebeziumMySqlComponentConfigurer.java | 234 +++++++++++++-
 .../debezium/DebeziumMySqlEndpointConfigurer.java  | 240 +++++++++++++-
 ...ySqlConnectorEmbeddedDebeziumConfiguration.java |  18 +-
 .../DebeziumPostgresComponentConfigurer.java       | 210 +++++++++++-
 .../DebeziumPostgresEndpointConfigurer.java        | 216 ++++++++++++-
 ...gresConnectorEmbeddedDebeziumConfiguration.java |   8 +-
 .../DebeziumSqlserverComponentConfigurer.java      | 156 ++++++++-
 .../DebeziumSqlserverEndpointConfigurer.java       | 162 +++++++++-
 ...rverConnectorEmbeddedDebeziumConfiguration.java |   4 +-
 .../DigitalOceanComponentConfigurer.java           |  25 +-
 .../DigitalOceanEndpointConfigurer.java            |  52 ++-
 .../direct/DirectComponentConfigurer.java          |  32 +-
 .../component/direct/DirectEndpointConfigurer.java |  43 ++-
 .../directvm/DirectVmComponentConfigurer.java      |  38 ++-
 .../directvm/DirectVmEndpointConfigurer.java       |  49 ++-
 .../disruptor/DisruptorComponentConfigurer.java    |  46 ++-
 .../disruptor/DisruptorEndpointConfigurer.java     |  58 +++-
 .../component/dns/DnsComponentConfigurer.java      |  25 +-
 .../camel/component/dns/DnsEndpointConfigurer.java |  27 +-
 .../docker/DockerComponentConfigurer.java          |  73 ++++-
 .../component/docker/DockerEndpointConfigurer.java |  79 ++++-
 .../component/dozer/DozerComponentConfigurer.java  |  25 +-
 .../component/dozer/DozerEndpointConfigurer.java   |  45 ++-
 .../component/drill/DrillComponentConfigurer.java  |  25 +-
 .../component/drill/DrillEndpointConfigurer.java   |  36 ++-
 .../dropbox/DropboxComponentConfigurer.java        |  28 +-
 .../dropbox/DropboxEndpointConfigurer.java         |  58 +++-
 .../ehcache/EhcacheComponentConfigurer.java        |  63 +++-
 .../ehcache/EhcacheEndpointConfigurer.java         |  71 ++++-
 .../ElasticsearchComponentConfigurer.java          |  55 +++-
 .../ElasticsearchEndpointConfigurer.java           |  71 ++++-
 .../elasticsearch/ElasticsearchConfiguration.java  |   4 +-
 .../elasticsearch/ElasticsearchProducer.java       |   4 +-
 .../component/elsql/ElsqlComponentConfigurer.java  |  40 ++-
 .../component/elsql/ElsqlEndpointConfigurer.java   | 160 +++++++++-
 .../elytron/ElytronComponentConfigurer.java        |  28 +-
 .../elytron/ElytronEndpointConfigurer.java         |   7 +-
 .../etcd/EtcdKeysComponentConfigurer.java          |  50 ++-
 .../component/etcd/EtcdKeysEndpointConfigurer.java |  47 ++-
 .../etcd/EtcdStatsComponentConfigurer.java         |  59 +++-
 .../etcd/EtcdStatsEndpointConfigurer.java          | 107 ++++++-
 .../etcd/EtcdWatchComponentConfigurer.java         |  53 +++-
 .../etcd/EtcdWatchEndpointConfigurer.java          |  56 +++-
 .../eventadmin/EventAdminComponentConfigurer.java  |  31 +-
 .../eventadmin/EventAdminEndpointConfigurer.java   |  38 ++-
 .../component/exec/ExecComponentConfigurer.java    |  25 +-
 .../component/exec/ExecEndpointConfigurer.java     |  48 ++-
 .../facebook/FacebookComponentConfigurer.java      | 111 ++++++-
 .../facebook/FacebookEndpointConfigurer.java       | 313 +++++++++++++++++-
 .../component/fhir/FhirComponentConfigurer.java    |  92 +++++-
 .../component/fhir/FhirEndpointConfigurer.java     | 146 ++++++++-
 .../file/watch/FileWatchComponentConfigurer.java   |  40 ++-
 .../file/watch/FileWatchEndpointConfigurer.java    |  58 +++-
 .../component/file/FileComponentConfigurer.java    |  28 +-
 .../component/file/FileEndpointConfigurer.java     | 278 +++++++++++++++-
 .../flatpack/FlatpackComponentConfigurer.java      |  28 +-
 .../flatpack/FlatpackEndpointConfigurer.java       |  98 +++++-
 .../component/flink/FlinkComponentConfigurer.java  |  37 ++-
 .../component/flink/FlinkEndpointConfigurer.java   |  41 ++-
 .../component/fop/FopComponentConfigurer.java      |  25 +-
 .../camel/component/fop/FopEndpointConfigurer.java |  33 +-
 .../freemarker/FreemarkerComponentConfigurer.java  |  27 +-
 .../freemarker/FreemarkerEndpointConfigurer.java   |  37 ++-
 .../file/remote/FtpComponentConfigurer.java        |  28 +-
 .../file/remote/FtpEndpointConfigurer.java         | 323 ++++++++++++++++++-
 .../file/remote/FtpsComponentConfigurer.java       |  22 +-
 .../file/remote/FtpsEndpointConfigurer.java        |  42 ++-
 .../file/remote/SftpComponentConfigurer.java       |  28 +-
 .../file/remote/SftpEndpointConfigurer.java        | 351 ++++++++++++++++++++-
 .../ganglia/GangliaComponentConfigurer.java        |  55 +++-
 .../ganglia/GangliaEndpointConfigurer.java         |  55 +++-
 .../geocoder/GeoCoderComponentConfigurer.java      |  25 +-
 .../geocoder/GeoCoderEndpointConfigurer.java       |  62 +++-
 .../component/git/GitComponentConfigurer.java      |  28 +-
 .../camel/component/git/GitEndpointConfigurer.java |  59 +++-
 .../github/GitHubComponentConfigurer.java          |  28 +-
 .../component/github/GitHubEndpointConfigurer.java |  56 +++-
 .../GoogleBigQueryComponentConfigurer.java         |  34 +-
 .../bigquery/GoogleBigQueryEndpointConfigurer.java |  33 +-
 .../sql/GoogleBigQuerySQLComponentConfigurer.java  |  31 +-
 .../sql/GoogleBigQuerySQLEndpointConfigurer.java   |  30 +-
 .../GoogleCalendarComponentConfigurer.java         |  58 +++-
 .../calendar/GoogleCalendarEndpointConfigurer.java | 109 ++++++-
 .../GoogleCalendarStreamComponentConfigurer.java   |  61 +++-
 .../GoogleCalendarStreamEndpointConfigurer.java    | 109 ++++++-
 .../drive/GoogleDriveComponentConfigurer.java      |  50 ++-
 .../drive/GoogleDriveEndpointConfigurer.java       | 104 +++++-
 .../google/mail/GoogleMailComponentConfigurer.java |  48 ++-
 .../google/mail/GoogleMailEndpointConfigurer.java  |  99 +++++-
 .../GoogleMailStreamComponentConfigurer.java       |  55 +++-
 .../stream/GoogleMailStreamEndpointConfigurer.java | 103 +++++-
 .../pubsub/GooglePubsubComponentConfigurer.java    |  39 ++-
 .../pubsub/GooglePubsubEndpointConfigurer.java     |  51 ++-
 .../google/pubsub/GooglePubsubConsumer.java        |   2 +-
 .../google/pubsub/GooglePubsubEndpoint.java        |   2 +-
 .../sheets/GoogleSheetsComponentConfigurer.java    |  48 ++-
 .../sheets/GoogleSheetsEndpointConfigurer.java     |  99 +++++-
 .../GoogleSheetsStreamComponentConfigurer.java     |  67 +++-
 .../GoogleSheetsStreamEndpointConfigurer.java      | 115 ++++++-
 .../component/gora/GoraComponentConfigurer.java    |  28 +-
 .../component/gora/GoraEndpointConfigurer.java     |  84 ++++-
 .../component/grape/GrapeComponentConfigurer.java  |  28 +-
 .../component/grape/GrapeEndpointConfigurer.java   |  27 +-
 .../graphql/GraphqlComponentConfigurer.java        |  25 +-
 .../graphql/GraphqlEndpointConfigurer.java         |  47 ++-
 .../camel/component/graphql/GraphqlEndpoint.java   |   2 +-
 .../component/grpc/GrpcComponentConfigurer.java    |  28 +-
 .../component/grpc/GrpcEndpointConfigurer.java     |  98 +++++-
 .../eventbus/GuavaEventBusComponentConfigurer.java |  34 +-
 .../eventbus/GuavaEventBusEndpointConfigurer.java  |  42 ++-
 .../HazelcastAtomicnumberComponentConfigurer.java  |  31 +-
 .../HazelcastAtomicnumberEndpointConfigurer.java   |  36 ++-
 .../HazelcastInstanceComponentConfigurer.java      |  31 +-
 .../HazelcastInstanceEndpointConfigurer.java       |  42 ++-
 .../list/HazelcastListComponentConfigurer.java     |  34 +-
 .../list/HazelcastListEndpointConfigurer.java      |  45 ++-
 .../map/HazelcastMapComponentConfigurer.java       |  34 +-
 .../map/HazelcastMapEndpointConfigurer.java        |  45 ++-
 .../HazelcastMultimapComponentConfigurer.java      |  34 +-
 .../HazelcastMultimapEndpointConfigurer.java       |  45 ++-
 .../queue/HazelcastQueueComponentConfigurer.java   |  34 +-
 .../queue/HazelcastQueueEndpointConfigurer.java    |  54 +++-
 .../HazelcastReplicatedmapComponentConfigurer.java |  34 +-
 .../HazelcastReplicatedmapEndpointConfigurer.java  |  45 ++-
 .../HazelcastRingbufferComponentConfigurer.java    |  31 +-
 .../HazelcastRingbufferEndpointConfigurer.java     |  36 ++-
 .../seda/HazelcastSedaComponentConfigurer.java     |  34 +-
 .../seda/HazelcastSedaEndpointConfigurer.java      |  59 +++-
 .../set/HazelcastSetComponentConfigurer.java       |  34 +-
 .../set/HazelcastSetEndpointConfigurer.java        |  45 ++-
 .../topic/HazelcastTopicComponentConfigurer.java   |  34 +-
 .../topic/HazelcastTopicEndpointConfigurer.java    |  47 ++-
 .../component/hbase/HBaseComponentConfigurer.java  |  33 +-
 .../component/hbase/HBaseEndpointConfigurer.java   |  69 +++-
 .../component/hdfs/HdfsComponentConfigurer.java    |  34 +-
 .../component/hdfs/HdfsEndpointConfigurer.java     | 151 ++++++++-
 .../apache/camel/component/hdfs/HdfsComponent.java |  10 +-
 .../hipchat/HipchatComponentConfigurer.java        |  28 +-
 .../hipchat/HipchatEndpointConfigurer.java         |  90 +++++-
 .../component/http/HttpComponentConfigurer.java    |  76 ++++-
 .../component/http/HttpEndpointConfigurer.java     | 173 +++++++++-
 .../iec60870/client/ClientComponentConfigurer.java |  31 +-
 .../iec60870/client/ClientEndpointConfigurer.java  |  81 ++++-
 .../iec60870/server/ServerComponentConfigurer.java |  31 +-
 .../iec60870/server/ServerEndpointConfigurer.java  |  84 ++++-
 .../infinispan/InfinispanComponentConfigurer.java  |  70 +++-
 .../infinispan/InfinispanEndpointConfigurer.java   |  76 ++++-
 .../influxdb/InfluxDbComponentConfigurer.java      |  25 +-
 .../influxdb/InfluxDbEndpointConfigurer.java       |  39 ++-
 .../component/iota/IOTAComponentConfigurer.java    |  25 +-
 .../component/iota/IOTAEndpointConfigurer.java     |  41 ++-
 .../component/ipfs/IPFSComponentConfigurer.java    |  31 +-
 .../component/ipfs/IPFSEndpointConfigurer.java     |  29 +-
 .../component/irc/IrcComponentConfigurer.java      |  31 +-
 .../camel/component/irc/IrcEndpointConfigurer.java |  97 +++++-
 .../ironmq/IronMQComponentConfigurer.java          |  28 +-
 .../component/ironmq/IronMQEndpointConfigurer.java | 110 ++++++-
 .../component/jbpm/JBPMComponentConfigurer.java    |  28 +-
 .../component/jbpm/JBPMEndpointConfigurer.java     | 103 +++++-
 .../jcache/JCacheComponentConfigurer.java          |  43 ++-
 .../component/jcache/JCacheEndpointConfigurer.java |  89 +++++-
 .../jclouds/JcloudsComponentConfigurer.java        |  34 +-
 .../jclouds/JcloudsEndpointConfigurer.java         |  64 +++-
 .../component/jcr/JcrComponentConfigurer.java      |  28 +-
 .../camel/component/jcr/JcrEndpointConfigurer.java |  62 +++-
 .../component/jdbc/JdbcComponentConfigurer.java    |  28 +-
 .../component/jdbc/JdbcEndpointConfigurer.java     |  61 +++-
 .../apache/camel/component/jdbc/JdbcComponent.java |   4 +
 .../camel/component/jetty/JettyHttpComponent.java  |   4 +
 .../jetty9/JettyHttpComponent9Configurer.java      | 114 ++++++-
 .../jetty9/JettyHttpEndpoint9Configurer.java       | 116 ++++++-
 .../raft/JGroupsRaftComponentConfigurer.java       |  40 ++-
 .../raft/JGroupsRaftEndpointConfigurer.java        |  39 ++-
 .../jgroups/JGroupsComponentConfigurer.java        |  36 ++-
 .../jgroups/JGroupsEndpointConfigurer.java         |  42 ++-
 .../validator/jing/JingComponentConfigurer.java    |  25 +-
 .../validator/jing/JingEndpointConfigurer.java     |  30 +-
 .../component/jira/JiraComponentConfigurer.java    |  51 ++-
 .../component/jira/JiraEndpointConfigurer.java     |  62 +++-
 .../component/jms/JmsComponentConfigurer.java      | 301 +++++++++++++++++-
 .../camel/component/jms/JmsEndpointConfigurer.java | 295 ++++++++++++++++-
 .../component/jmx/JMXComponentConfigurer.java      |  25 +-
 .../camel/component/jmx/JMXEndpointConfigurer.java | 105 +++++-
 .../component/jolt/JoltComponentConfigurer.java    |  27 +-
 .../component/jolt/JoltEndpointConfigurer.java     |  39 ++-
 .../component/jooq/JooqComponentConfigurer.java    |  40 ++-
 .../component/jooq/JooqEndpointConfigurer.java     |  91 +++++-
 .../component/jpa/JpaComponentConfigurer.java      |  40 ++-
 .../camel/component/jpa/JpaEndpointConfigurer.java | 149 ++++++++-
 .../component/scp/ScpComponentConfigurer.java      |  28 +-
 .../camel/component/scp/ScpEndpointConfigurer.java |  83 ++++-
 .../component/jslt/JsltComponentConfigurer.java    |  27 +-
 .../component/jslt/JsltEndpointConfigurer.java     |  33 +-
 .../JsonValidatorComponentConfigurer.java          |  25 +-
 .../JsonValidatorEndpointConfigurer.java           |  45 ++-
 .../component/jt400/Jt400ComponentConfigurer.java  |  31 +-
 .../component/jt400/Jt400EndpointConfigurer.java   | 110 ++++++-
 .../component/kafka/KafkaComponentConfigurer.java  | 302 +++++++++++++++++-
 .../component/kafka/KafkaEndpointConfigurer.java   | 302 +++++++++++++++++-
 .../KubernetesConfigMapsComponentConfigurer.java   |  25 +-
 .../KubernetesConfigMapsEndpointConfigurer.java    |  81 ++++-
 .../KubernetesDeploymentsComponentConfigurer.java  |  28 +-
 .../KubernetesDeploymentsEndpointConfigurer.java   | 104 +++++-
 .../hpa/KubernetesHPAComponentConfigurer.java      |  28 +-
 .../hpa/KubernetesHPAEndpointConfigurer.java       | 104 +++++-
 .../job/KubernetesJobComponentConfigurer.java      |  28 +-
 .../job/KubernetesJobEndpointConfigurer.java       | 104 +++++-
 .../KubernetesNamespacesComponentConfigurer.java   |  28 +-
 .../KubernetesNamespacesEndpointConfigurer.java    | 104 +++++-
 .../nodes/KubernetesNodesComponentConfigurer.java  |  28 +-
 .../nodes/KubernetesNodesEndpointConfigurer.java   | 104 +++++-
 ...rnetesPersistentVolumesComponentConfigurer.java |  25 +-
 ...ernetesPersistentVolumesEndpointConfigurer.java |  81 ++++-
 ...PersistentVolumesClaimsComponentConfigurer.java |  25 +-
 ...sPersistentVolumesClaimsEndpointConfigurer.java |  81 ++++-
 .../pods/KubernetesPodsComponentConfigurer.java    |  28 +-
 .../pods/KubernetesPodsEndpointConfigurer.java     | 104 +++++-
 ...sReplicationControllersComponentConfigurer.java |  28 +-
 ...esReplicationControllersEndpointConfigurer.java | 104 +++++-
 ...ubernetesResourcesQuotaComponentConfigurer.java |  25 +-
 ...KubernetesResourcesQuotaEndpointConfigurer.java |  81 ++++-
 .../KubernetesSecretsComponentConfigurer.java      |  25 +-
 .../KubernetesSecretsEndpointConfigurer.java       |  81 ++++-
 ...bernetesServiceAccountsComponentConfigurer.java |  25 +-
 ...ubernetesServiceAccountsEndpointConfigurer.java |  81 ++++-
 .../KubernetesServicesComponentConfigurer.java     |  28 +-
 .../KubernetesServicesEndpointConfigurer.java      | 104 +++++-
 .../OpenshiftBuildConfigsComponentConfigurer.java  |  25 +-
 .../OpenshiftBuildConfigsEndpointConfigurer.java   |  81 ++++-
 .../builds/OpenshiftBuildsComponentConfigurer.java |  25 +-
 .../builds/OpenshiftBuildsEndpointConfigurer.java  |  81 ++++-
 .../component/kudu/KuduComponentConfigurer.java    |  25 +-
 .../component/kudu/KuduEndpointConfigurer.java     |  29 +-
 .../language/LanguageComponentConfigurer.java      |  25 +-
 .../language/LanguageEndpointConfigurer.java       |  39 ++-
 .../component/ldap/LdapComponentConfigurer.java    |  25 +-
 .../component/ldap/LdapEndpointConfigurer.java     |  37 ++-
 .../component/ldif/LdifComponentConfigurer.java    |  25 +-
 .../component/ldif/LdifEndpointConfigurer.java     |  27 +-
 .../component/log/LogComponentConfigurer.java      |  28 +-
 .../camel/component/log/LogEndpointConfigurer.java |  98 +++++-
 .../lucene/LuceneComponentConfigurer.java          |  38 ++-
 .../component/lucene/LuceneEndpointConfigurer.java |  38 ++-
 .../lumberjack/LumberjackComponentConfigurer.java  |  31 +-
 .../lumberjack/LumberjackEndpointConfigurer.java   |  36 ++-
 .../component/mail/MailComponentConfigurer.java    | 129 +++++++-
 .../component/mail/MailEndpointConfigurer.java     | 200 +++++++++++-
 .../master/MasterComponentConfigurer.java          |  30 +-
 .../component/master/MasterEndpointConfigurer.java |  33 +-
 .../metrics/MetricsComponentConfigurer.java        |  28 +-
 .../metrics/MetricsEndpointConfigurer.java         |  39 ++-
 .../micrometer/MicrometerComponentConfigurer.java  |  28 +-
 .../micrometer/MicrometerEndpointConfigurer.java   |  35 +-
 .../MicroProfileMetricsComponentConfigurer.java    |  28 +-
 .../MicroProfileMetricsEndpointConfigurer.java     |  55 +++-
 .../milo/client/MiloClientComponentConfigurer.java |  87 ++++-
 .../milo/client/MiloClientEndpointConfigurer.java  | 103 +++++-
 .../milo/server/MiloServerComponentConfigurer.java |  88 +++++-
 .../milo/server/MiloServerEndpointConfigurer.java  |  36 ++-
 .../camel/component/milo/server/milo-server.json   |  10 +-
 .../src/main/docs/milo-server-component.adoc       |  10 +-
 .../component/milo/server/MiloServerComponent.java | 278 +++++++++-------
 .../component/milo/AbstractMiloServerTest.java     |   2 +-
 .../milo/MonitorItemMultiConnectionsCertTest.java  |   4 +-
 .../component/milo/server/ServerLocalTest.java     |   2 +-
 .../server/ServerSetCertificateManagerTest.java    |   4 +-
 .../milo/server/ServerSetSecurityPoliciesTest.java |   7 +-
 .../component/mina/MinaComponentConfigurer.java    |  95 +++++-
 .../component/mina/MinaEndpointConfigurer.java     |  98 +++++-
 .../component/mock/MockComponentConfigurer.java    |  25 +-
 .../component/mock/MockEndpointConfigurer.java     |  57 +++-
 .../mongodb/gridfs/GridFsComponentConfigurer.java  |  28 +-
 .../mongodb/gridfs/GridFsEndpointConfigurer.java   |  67 +++-
 .../mongodb/MongoDbComponentConfigurer.java        |  31 +-
 .../mongodb/MongoDbEndpointConfigurer.java         |  92 +++++-
 .../validator/msv/MsvComponentConfigurer.java      |  22 +-
 .../validator/msv/MsvEndpointConfigurer.java       |   7 +-
 .../mustache/MustacheComponentConfigurer.java      |  28 +-
 .../mustache/MustacheEndpointConfigurer.java       |  38 ++-
 .../component/mvel/MvelComponentConfigurer.java    |  25 +-
 .../component/mvel/MvelEndpointConfigurer.java     |  32 +-
 .../mybatis/MyBatisBeanComponentConfigurer.java    |  31 +-
 .../mybatis/MyBatisBeanEndpointConfigurer.java     |  36 ++-
 .../mybatis/MyBatisComponentConfigurer.java        |  34 +-
 .../mybatis/MyBatisEndpointConfigurer.java         | 110 ++++++-
 .../nagios/NagiosComponentConfigurer.java          |  36 ++-
 .../component/nagios/NagiosEndpointConfigurer.java |  39 ++-
 .../component/nats/NatsComponentConfigurer.java    |  33 +-
 .../component/nats/NatsEndpointConfigurer.java     |  96 +++++-
 .../netty/http/NettyHttpComponentConfigurer.java   |  28 +-
 .../netty/http/NettyHttpEndpointConfigurer.java    |  89 +++++-
 .../component/netty/NettyComponentConfigurer.java  | 221 ++++++++++++-
 .../component/netty/NettyEndpointConfigurer.java   | 218 ++++++++++++-
 .../nitrite/NitriteComponentConfigurer.java        |  28 +-
 .../nitrite/NitriteEndpointConfigurer.java         |  48 ++-
 .../component/nsq/NsqComponentConfigurer.java      |  33 +-
 .../camel/component/nsq/NsqEndpointConfigurer.java |  68 +++-
 .../olingo2/Olingo2ComponentConfigurer.java        |  65 +++-
 .../olingo2/Olingo2EndpointConfigurer.java         | 116 ++++++-
 .../olingo4/Olingo4ComponentConfigurer.java        |  65 +++-
 .../olingo4/Olingo4EndpointConfigurer.java         | 116 ++++++-
 .../cinder/CinderComponentConfigurer.java          |  25 +-
 .../openstack/cinder/CinderEndpointConfigurer.java |  44 ++-
 .../glance/GlanceComponentConfigurer.java          |  25 +-
 .../openstack/glance/GlanceEndpointConfigurer.java |  42 ++-
 .../keystone/KeystoneComponentConfigurer.java      |  25 +-
 .../keystone/KeystoneEndpointConfigurer.java       |  41 ++-
 .../neutron/NeutronComponentConfigurer.java        |  25 +-
 .../neutron/NeutronEndpointConfigurer.java         |  44 ++-
 .../openstack/nova/NovaComponentConfigurer.java    |  25 +-
 .../openstack/nova/NovaEndpointConfigurer.java     |  44 ++-
 .../openstack/swift/SwiftComponentConfigurer.java  |  25 +-
 .../openstack/swift/SwiftEndpointConfigurer.java   |  44 ++-
 .../OptaPlannerComponentConfigurer.java            |  28 +-
 .../optaplanner/OptaPlannerEndpointConfigurer.java |  44 ++-
 .../component/paho/PahoComponentConfigurer.java    | 106 ++++++-
 .../component/paho/PahoEndpointConfigurer.java     | 112 ++++++-
 .../paxlogging/PaxLoggingComponentConfigurer.java  |  28 +-
 .../paxlogging/PaxLoggingEndpointConfigurer.java   |  33 +-
 .../component/pdf/PdfComponentConfigurer.java      |  25 +-
 .../camel/component/pdf/PdfEndpointConfigurer.java |  50 ++-
 .../slot/PgReplicationSlotComponentConfigurer.java |  25 +-
 .../slot/PgReplicationSlotEndpointConfigurer.java  |  91 +++++-
 .../pgevent/PgEventComponentConfigurer.java        |  28 +-
 .../pgevent/PgEventEndpointConfigurer.java         |  42 ++-
 components/camel-platform-http-vertx/pom.xml       |   5 +
 .../http/PlatformHttpComponentConfigurer.java      |  27 +-
 .../http/PlatformHttpEndpointConfigurer.java       |  52 ++-
 .../platform/http/PlatformHttpEndpoint.java        |   2 +-
 .../printer/PrinterComponentConfigurer.java        |  25 +-
 .../printer/PrinterEndpointConfigurer.java         |  53 +++-
 .../pubnub/PubNubComponentConfigurer.java          |  28 +-
 .../component/pubnub/PubNubEndpointConfigurer.java |  62 +++-
 .../pulsar/PulsarComponentConfigurer.java          | 117 ++++++-
 .../component/pulsar/PulsarEndpointConfigurer.java | 114 ++++++-
 .../quartz/QuartzComponentConfigurer.java          |  56 +++-
 .../component/quartz/QuartzEndpointConfigurer.java |  76 ++++-
 .../camel/component/quartz/QuartzComponent.java    |   8 +-
 .../quickfixj/QuickfixjComponentConfigurer.java    |  40 ++-
 .../quickfixj/QuickfixjEndpointConfigurer.java     |  42 ++-
 .../component/quickfixj/QuickfixjComponent.java    |  12 +
 .../rabbitmq/RabbitMQComponentConfigurer.java      | 166 +++++++++-
 .../rabbitmq/RabbitMQEndpointConfigurer.java       | 194 +++++++++++-
 .../ReactiveStreamsComponentConfigurer.java        |  46 ++-
 .../streams/ReactiveStreamsEndpointConfigurer.java |  54 +++-
 .../component/ref/RefComponentConfigurer.java      |  28 +-
 .../camel/component/ref/RefEndpointConfigurer.java |  36 ++-
 .../openapi/RestOpenApiComponentConfigurer.java    |  46 ++-
 .../openapi/RestOpenApiEndpointConfigurer.java     |  39 ++-
 .../swagger/RestSwaggerComponentConfigurer.java    |  46 ++-
 .../swagger/RestSwaggerEndpointConfigurer.java     |  42 ++-
 .../component/rest/RestApiComponentConfigurer.java |  25 +-
 .../component/rest/RestApiEndpointConfigurer.java  |  39 ++-
 .../component/rest/RestComponentConfigurer.java    |  42 ++-
 .../component/rest/RestEndpointConfigurer.java     |  68 +++-
 .../RobotFrameworkComponentConfigurer.java         | 149 ++++++++-
 .../RobotFrameworkEndpointConfigurer.java          | 203 +++++++++++-
 .../component/rss/RssComponentConfigurer.java      |  25 +-
 .../camel/component/rss/RssEndpointConfigurer.java |  99 +++++-
 .../component/saga/SagaComponentConfigurer.java    |  25 +-
 .../component/saga/SagaEndpointConfigurer.java     |  27 +-
 .../salesforce/SalesforceComponentConfigurer.java  | 237 +++++++++++++-
 .../salesforce/SalesforceEndpointConfigurer.java   | 151 ++++++++-
 .../camel/component/salesforce/salesforce.json     |   4 +-
 .../src/main/docs/salesforce-component.adoc        |   4 +-
 .../component/salesforce/SalesforceComponent.java  |  20 +-
 .../salesforce/HttpProxyIntegrationTest.java       |   2 +-
 .../netweaver/NetWeaverComponentConfigurer.java    |  25 +-
 .../sap/netweaver/NetWeaverEndpointConfigurer.java |  39 ++-
 .../xquery/XQueryComponentConfigurer.java          |  36 ++-
 .../component/xquery/XQueryEndpointConfigurer.java | 114 ++++++-
 .../scheduler/SchedulerComponentConfigurer.java    |  28 +-
 .../scheduler/SchedulerEndpointConfigurer.java     |  81 ++++-
 .../schematron/SchematronComponentConfigurer.java  |  25 +-
 .../schematron/SchematronEndpointConfigurer.java   |  34 +-
 .../component/seda/SedaComponentConfigurer.java    |  46 ++-
 .../component/seda/SedaEndpointConfigurer.java     |  75 ++++-
 .../service/ServiceComponentConfigurer.java        |  30 +-
 .../service/ServiceEndpointConfigurer.java         |  33 +-
 .../servicenow/ServiceNowComponentConfigurer.java  | 152 ++++++++-
 .../servicenow/ServiceNowEndpointConfigurer.java   | 146 ++++++++-
 .../servlet/ServletComponentConfigurer.java        |  49 ++-
 .../servlet/ServletEndpointConfigurer.java         |  88 +++++-
 .../component/sip/SipComponentConfigurer.java      |  28 +-
 .../camel/component/sip/SipEndpointConfigurer.java | 154 ++++++++-
 .../component/sjms/SjmsComponentConfigurer.java    |  76 ++++-
 .../component/sjms/SjmsEndpointConfigurer.java     | 129 +++++++-
 .../sjms/batch/SjmsBatchComponentConfigurer.java   |  37 ++-
 .../sjms/batch/SjmsBatchEndpointConfigurer.java    |  90 +++++-
 .../component/sjms2/Sjms2ComponentConfigurer.java  |   7 +-
 .../component/sjms2/Sjms2EndpointConfigurer.java   |  26 +-
 .../component/slack/SlackComponentConfigurer.java  |  31 +-
 .../component/slack/SlackEndpointConfigurer.java   | 100 +++++-
 .../component/smpp/SmppComponentConfigurer.java    | 129 +++++++-
 .../component/smpp/SmppEndpointConfigurer.java     | 135 +++++++-
 .../component/snmp/SnmpComponentConfigurer.java    |  28 +-
 .../component/snmp/SnmpEndpointConfigurer.java     | 124 +++++++-
 .../component/solr/SolrComponentConfigurer.java    |  25 +-
 .../component/solr/SolrEndpointConfigurer.java     |  66 +++-
 .../component/SoroushBotComponentConfigurer.java   |  31 +-
 .../component/SoroushBotEndpointConfigurer.java    |  84 ++++-
 .../sparkrest/SparkRestComponentConfigurer.java    |  72 ++++-
 .../sparkrest/SparkRestEndpointConfigurer.java     |  53 +++-
 .../component/spark/SparkComponentConfigurer.java  |  30 +-
 .../component/spark/SparkEndpointConfigurer.java   |  40 ++-
 .../splunk/SplunkComponentConfigurer.java          |  31 +-
 .../component/splunk/SplunkEndpointConfigurer.java | 137 +++++++-
 .../batch/SpringBatchComponentConfigurer.java      |  31 +-
 .../batch/SpringBatchEndpointConfigurer.java       |  36 ++-
 .../SpringIntegrationComponentConfigurer.java      |  28 +-
 .../SpringIntegrationEndpointConfigurer.java       |  45 ++-
 .../springldap/SpringLdapComponentConfigurer.java  |  25 +-
 .../springldap/SpringLdapEndpointConfigurer.java   |  31 +-
 .../component/redis/RedisComponentConfigurer.java  |  28 +-
 .../component/redis/RedisEndpointConfigurer.java   |  51 ++-
 .../ws/SpringWebserviceComponentConfigurer.java    |  31 +-
 .../ws/SpringWebserviceEndpointConfigurer.java     |  86 ++++-
 .../component/event/EventComponentConfigurer.java  |  28 +-
 .../component/event/EventEndpointConfigurer.java   |  36 ++-
 .../component/sql/SqlComponentConfigurer.java      |  34 +-
 .../camel/component/sql/SqlEndpointConfigurer.java | 154 ++++++++-
 .../sql/stored/SqlStoredComponentConfigurer.java   |  28 +-
 .../sql/stored/SqlStoredEndpointConfigurer.java    |  42 ++-
 .../component/ssh/SshComponentConfigurer.java      |  66 +++-
 .../camel/component/ssh/SshEndpointConfigurer.java | 117 ++++++-
 .../component/stax/StAXComponentConfigurer.java    |  25 +-
 .../component/stax/StAXEndpointConfigurer.java     |  27 +-
 .../component/stomp/StompComponentConfigurer.java  |  53 +++-
 .../component/stomp/StompEndpointConfigurer.java   |  56 +++-
 .../stream/StreamComponentConfigurer.java          |  28 +-
 .../component/stream/StreamEndpointConfigurer.java |  78 ++++-
 .../StringTemplateComponentConfigurer.java         |  25 +-
 .../StringTemplateEndpointConfigurer.java          |  36 ++-
 .../component/stub/StubComponentConfigurer.java    |   7 +-
 .../component/stub/StubEndpointConfigurer.java     |   7 +-
 .../telegram/TelegramComponentConfigurer.java      |  39 ++-
 .../telegram/TelegramEndpointConfigurer.java       | 106 ++++++-
 .../thrift/ThriftComponentConfigurer.java          |  31 +-
 .../component/thrift/ThriftEndpointConfigurer.java |  59 +++-
 .../component/tika/TikaComponentConfigurer.java    |  25 +-
 .../component/tika/TikaEndpointConfigurer.java     |  39 ++-
 .../component/timer/TimerComponentConfigurer.java  |  25 +-
 .../component/timer/TimerEndpointConfigurer.java   |  54 +++-
 .../twilio/TwilioComponentConfigurer.java          |  40 ++-
 .../component/twilio/TwilioEndpointConfigurer.java |  84 ++++-
 .../TwitterDirectMessageComponentConfigurer.java   |  52 ++-
 .../TwitterDirectMessageEndpointConfigurer.java    | 140 +++++++-
 .../search/TwitterSearchComponentConfigurer.java   |  52 ++-
 .../search/TwitterSearchEndpointConfigurer.java    | 140 +++++++-
 .../TwitterTimelineComponentConfigurer.java        |  52 ++-
 .../TwitterTimelineEndpointConfigurer.java         | 142 ++++++++-
 .../undertow/UndertowComponentConfigurer.java      |  49 ++-
 .../undertow/UndertowEndpointConfigurer.java       | 106 ++++++-
 .../validator/ValidatorComponentConfigurer.java    |  28 +-
 .../validator/ValidatorEndpointConfigurer.java     |  54 +++-
 .../velocity/VelocityComponentConfigurer.java      |  28 +-
 .../velocity/VelocityEndpointConfigurer.java       |  38 ++-
 .../component/vertx/VertxComponentConfigurer.java  |  42 ++-
 .../component/vertx/VertxEndpointConfigurer.java   |  39 ++-
 .../camel/component/vm/VmComponentConfigurer.java  |   7 +-
 .../camel/component/vm/VmEndpointConfigurer.java   |   7 +-
 .../weather/WeatherComponentConfigurer.java        |  34 +-
 .../weather/WeatherEndpointConfigurer.java         | 147 ++++++++-
 .../component/web3j/Web3jComponentConfigurer.java  | 119 ++++++-
 .../component/web3j/Web3jEndpointConfigurer.java   | 125 +++++++-
 .../webhook/WebhookComponentConfigurer.java        |  42 ++-
 .../webhook/WebhookEndpointConfigurer.java         |  48 ++-
 .../websocket/jsr356/JSR356EndpointConfigurer.java |  39 ++-
 .../jsr356/JSR356WebSocketComponentConfigurer.java |  31 +-
 .../websocket/WebsocketComponentConfigurer.java    |  62 +++-
 .../websocket/WebsocketEndpointConfigurer.java     |  78 ++++-
 .../component/weka/WekaComponentConfigurer.java    |  25 +-
 .../component/weka/WekaEndpointConfigurer.java     |  47 ++-
 .../wordpress/WordpressComponentConfigurer.java    |  48 ++-
 .../wordpress/WordpressEndpointConfigurer.java     |  54 +++-
 .../workday/WorkdayComponentConfigurer.java        |  25 +-
 .../workday/WorkdayEndpointConfigurer.java         |  46 ++-
 .../xchange/XChangeComponentConfigurer.java        |  25 +-
 .../xchange/XChangeEndpointConfigurer.java         |  36 ++-
 .../camel/component/xj/XJComponentConfigurer.java  |   7 +-
 .../camel/component/xj/XJEndpointConfigurer.java   |  22 +-
 .../xmlsecurity/XmlSignerComponentConfigurer.java  | 105 +++++-
 .../xmlsecurity/XmlSignerEndpointConfigurer.java   | 104 +++++-
 .../XmlVerifierComponentConfigurer.java            |  76 ++++-
 .../xmlsecurity/XmlVerifierEndpointConfigurer.java |  75 ++++-
 .../component/xmpp/XmppComponentConfigurer.java    |  28 +-
 .../component/xmpp/XmppEndpointConfigurer.java     |  73 ++++-
 .../xslt/saxon/XsltSaxonComponentConfigurer.java   |  28 +-
 .../xslt/saxon/XsltSaxonEndpointConfigurer.java    |  28 +-
 .../component/xslt/XsltComponentConfigurer.java    |  40 ++-
 .../component/xslt/XsltEndpointConfigurer.java     |  62 +++-
 .../yammer/YammerComponentConfigurer.java          |  59 +++-
 .../component/yammer/YammerEndpointConfigurer.java | 108 ++++++-
 .../zendesk/ZendeskComponentConfigurer.java        |  32 +-
 .../zendesk/ZendeskEndpointConfigurer.java         |  96 +++++-
 .../zookeepermaster/MasterComponentConfigurer.java |  42 ++-
 .../zookeepermaster/MasterEndpointConfigurer.java  |  33 +-
 .../zookeeper/ZooKeeperComponentConfigurer.java    |  47 ++-
 .../zookeeper/ZooKeeperEndpointConfigurer.java     |  53 +++-
 .../org/apache/camel/spi/PropertyConfigurer.java   |   2 +
 ...nfigurer.java => PropertyConfigurerGetter.java} |  27 +-
 .../dsl/MiloServerComponentBuilderFactory.java     |  73 +++--
 .../dsl/SalesforceComponentBuilderFactory.java     |  38 +--
 .../camel/catalog/impl/AbstractCamelCatalog.java   |   6 +-
 .../PropertyBindingSupportConfigurerTest.java      |   2 +-
 .../org/apache/camel/main/BaseMainSupport.java     |  12 +-
 .../camel/support/PropertyBindingSupport.java      |  62 +++-
 .../java/org/apache/camel/util/StringHelper.java   |   2 +-
 .../modules/ROOT/pages/milo-server-component.adoc  |  10 +-
 .../modules/ROOT/pages/salesforce-component.adoc   |   4 +-
 .../camel/maven/packaging/MainConfigurerMojo.java  |  21 +-
 .../packaging/PropertyConfigurerGenerator.java     |  71 ++++-
 693 files changed, 39917 insertions(+), 947 deletions(-)
 copy core/camel-api/src/main/java/org/apache/camel/spi/{PropertyConfigurer.java => PropertyConfigurerGetter.java} (56%)


[camel] 03/13: CAMEL-14762: camel-core - Configurer to include API for method name and type

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

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

commit 4b4a09f981a48352d8801866119f517e90d0d8bb
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sat Mar 21 22:11:26 2020 +0100

    CAMEL-14762: camel-core - Configurer to include API for method name and type
---
 .../org/apache/camel/spi/PropertyConfigurer.java   |  2 +
 .../camel/support/PropertyBindingSupport.java      | 58 ++++++++++++++++++++--
 2 files changed, 56 insertions(+), 4 deletions(-)

diff --git a/core/camel-api/src/main/java/org/apache/camel/spi/PropertyConfigurer.java b/core/camel-api/src/main/java/org/apache/camel/spi/PropertyConfigurer.java
index 8e2c674..197bb1f 100644
--- a/core/camel-api/src/main/java/org/apache/camel/spi/PropertyConfigurer.java
+++ b/core/camel-api/src/main/java/org/apache/camel/spi/PropertyConfigurer.java
@@ -23,6 +23,8 @@ import org.apache.camel.CamelContext;
  * <p/>
  * This is used in Camel to have fast property configuration of Camel components & endpoints,
  * and for EIP patterns as well.
+ *
+ * @see PropertyConfigurerGetter
  */
 public interface PropertyConfigurer {
 
diff --git a/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java b/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java
index 5c60834..14d698c 100644
--- a/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java
+++ b/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java
@@ -30,9 +30,12 @@ import java.util.Map;
 import java.util.Set;
 
 import org.apache.camel.CamelContext;
+import org.apache.camel.Component;
 import org.apache.camel.ExtendedCamelContext;
 import org.apache.camel.PropertyBindingException;
 import org.apache.camel.spi.PropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.support.service.ServiceHelper;
 import org.apache.camel.util.StringHelper;
 import org.apache.camel.util.StringQuoteHelper;
 
@@ -338,11 +341,44 @@ public final class PropertyBindingSupport {
         return false;
     }
 
-    private static boolean doAutowireSingletonPropertiesFromRegistry(CamelContext camelContext, Object target, Set<Object> parents,
+    private static boolean doAutowireSingletonPropertiesFromRegistry(final CamelContext camelContext, Object target, Set<Object> parents,
                                                                      boolean bindNullOnly, boolean deepNesting, OnAutowiring callback) throws Exception {
 
+        // properties of all the current values from the target
         Map<String, Object> properties = new LinkedHashMap<>();
-        camelContext.adapt(ExtendedCamelContext.class).getBeanIntrospection().getProperties(target, properties, null);
+
+        // if there a configurer
+        PropertyConfigurer configurer = null;
+        PropertyConfigurerGetter getter = null;
+        if (target instanceof Component) {
+            // the component needs to be initialized to have the configurer ready
+            ServiceHelper.initService(target);
+            configurer = ((Component) target).getComponentPropertyConfigurer();
+        }
+        if (configurer == null) {
+            String name = target.getClass().getSimpleName();
+            if (target instanceof ExtendedCamelContext) {
+                // special for camel context itself as we have an extended configurer
+                name = "ExtendedCamelContext";
+            }
+            // see if there is a configurer for it
+            configurer = camelContext.adapt(ExtendedCamelContext.class).getConfigurerResolver().resolvePropertyConfigurer(name, camelContext);
+        }
+
+        // use configurer to get all the current options and its values
+        if (configurer instanceof PropertyConfigurerGetter) {
+            getter = (PropertyConfigurerGetter) configurer;
+            final PropertyConfigurerGetter lambdaGetter = getter;
+            final Object lambdaTarget = target;
+            // TODO: optimize to only load complex values as these are the only ones we
+            getter.getAllOptions(target).forEach((key, type) -> {
+                Object value = lambdaGetter.getOptionValue(lambdaTarget, key, true);
+                properties.put(key, value);
+            });
+        } else {
+            // okay use reflection based
+            camelContext.adapt(ExtendedCamelContext.class).getBeanIntrospection().getProperties(target, properties, null);
+        }
 
         boolean hit = false;
 
@@ -362,7 +398,14 @@ public final class PropertyBindingSupport {
                 continue;
             }
 
-            Class<?> type = getGetterType(camelContext, target, key, false);
+            Class<?> type;
+            if (getter != null) {
+                // use getter configurer to know the property class type
+                type = (Class<?>) getter.getAllOptions(target).get(key);
+            } else {
+                // okay fallback to use reflection based
+                type = getGetterType(camelContext, target, key, false);
+            }
             if (type != null && CamelContext.class.isAssignableFrom(type)) {
                 // the camel context is usually bound by other means so don't bind it to the target object
                 // and most important do not walk it down and re-configure it.
@@ -380,7 +423,14 @@ public final class PropertyBindingSupport {
                     if (lookup.size() == 1) {
                         value = lookup.iterator().next();
                         if (value != null) {
-                            hit |= camelContext.adapt(ExtendedCamelContext.class).getBeanIntrospection().setProperty(camelContext, target, key, value);
+                            if (configurer != null) {
+                                // favour using source code generated configurer
+                                hit = configurer.configure(camelContext, target, key, value, true);
+                            }
+                            if (!hit) {
+                                // fallback to use reflection based
+                                hit = camelContext.adapt(ExtendedCamelContext.class).getBeanIntrospection().setProperty(camelContext, target, key, value);
+                            }
                             if (hit && callback != null) {
                                 callback.onAutowire(target, key, type, value);
                             }


[camel] 09/13: CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs

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

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

commit e6fad20c3712f0ad9f748fe3a136f80ecc94208d
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 09:03:45 2020 +0100

    CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
---
 docs/components/modules/ROOT/pages/milo-server-component.adoc | 10 +++++-----
 docs/components/modules/ROOT/pages/salesforce-component.adoc  |  4 ++--
 2 files changed, 7 insertions(+), 7 deletions(-)

diff --git a/docs/components/modules/ROOT/pages/milo-server-component.adoc b/docs/components/modules/ROOT/pages/milo-server-component.adoc
index 1169e8b..871b874 100644
--- a/docs/components/modules/ROOT/pages/milo-server-component.adoc
+++ b/docs/components/modules/ROOT/pages/milo-server-component.adoc
@@ -41,18 +41,18 @@ The OPC UA Server component supports 20 options, which are listed below.
 | *applicationName* (common) | The application name |  | String
 | *applicationUri* (common) | The application URI |  | String
 | *bindAddresses* (common) | Set the addresses of the local addresses the server should bind to |  | String
-| *bindPort* (common) | The TCP port the server binds to |  | int
 | *buildInfo* (common) | Server build info |  | BuildInfo
+| *certificate* (common) | Server certificate |  | X509Certificate
 | *certificateManager* (common) | Server certificate manager |  | CertificateManager
-| *certificateValidator* (common) | Validator for client certificates |  | Supplier
-| *defaultCertificateValidator* (common) | Validator for client certificates using default file based approach |  | File
+| *certificateValidator* (common) | Validator for client certificates |  | CertificateValidator
+| *defaultCertificateValidator* (common) | Validator for client certificates using default file based approach |  | String
 | *enableAnonymousAuthentication* (common) | Enable anonymous authentication, disabled by default | false | boolean
 | *namespaceUri* (common) | The URI of the namespace, defaults to urn:org:apache:camel |  | String
 | *path* (common) | The path to be appended to the end of the endpoint url. (doesn't need to start with '/') |  | String
+| *port* (common) | The TCP port the server binds to |  | int
 | *productUri* (common) | The product URI |  | String
 | *securityPolicies* (common) | Security policies |  | Set
-| *securityPoliciesById* (common) | Security policies by URI or name |  | Collection
-| *serverCertificate* (common) | Server certificate |  | Result
+| *securityPoliciesById* (common) | Security policies by URI or name. Multiple policies can be separated by comma. |  | String
 | *userAuthenticationCredentials* (common) | Set user password combinations in the form of user1:pwd1,user2:pwd2 Usernames and passwords will be URL decoded |  | String
 | *usernameSecurityPolicyUri* (common) | Set the UserTokenPolicy used when. The value can be one of: None, Basic128Rsa15, Basic256, Basic256Sha256, Aes128_Sha256_RsaOaep, Aes256_Sha256_RsaPss |  | SecurityPolicy
 | *bridgeErrorHandler* (consumer) | 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 | boolean
diff --git a/docs/components/modules/ROOT/pages/salesforce-component.adoc b/docs/components/modules/ROOT/pages/salesforce-component.adoc
index 43b2931..098a5c6 100644
--- a/docs/components/modules/ROOT/pages/salesforce-component.adoc
+++ b/docs/components/modules/ROOT/pages/salesforce-component.adoc
@@ -711,17 +711,17 @@ The Salesforce component supports 72 options, which are listed below.
 | *httpProxyHost* (proxy) | Hostname of the HTTP proxy server to use. |  | String
 | *httpProxyIncludedAddresses* (proxy) | A list of addresses for which HTTP proxy server should be used. |  | Set
 | *httpProxyPort* (proxy) | Port number of the HTTP proxy server to use. |  | Integer
-| *isHttpProxySocks4* (proxy) | If set to true the configures the HTTP proxy to use as a SOCKS4 proxy. | false | boolean
+| *httpProxySocks4* (proxy) | If set to true the configures the HTTP proxy to use as a SOCKS4 proxy. | false | boolean
 | *authenticationType* (security) | Explicit authentication method to be used, one of USERNAME_PASSWORD, REFRESH_TOKEN or JWT. Salesforce component can auto-determine the authentication method to use from the properties set, set this property to eliminate any ambiguity. The value can be one of: USERNAME_PASSWORD, REFRESH_TOKEN, JWT |  | AuthenticationType
 | *clientId* (security) | *Required* OAuth Consumer Key of the connected app configured in the Salesforce instance setup. Typically a connected app needs to be configured but one can be provided by installing a package. |  | String
 | *clientSecret* (security) | OAuth Consumer Secret of the connected app configured in the Salesforce instance setup. |  | String
 | *httpProxyAuthUri* (security) | Used in authentication against the HTTP proxy server, needs to match the URI of the proxy server in order for the httpProxyUsername and httpProxyPassword to be used for authentication. |  | String
 | *httpProxyPassword* (security) | Password to use to authenticate against the HTTP proxy server. |  | String
 | *httpProxyRealm* (security) | Realm of the proxy server, used in preemptive Basic/Digest authentication methods against the HTTP proxy server. |  | String
+| *httpProxySecure* (security) | If set to false disables the use of TLS when accessing the HTTP proxy. | true | boolean
 | *httpProxyUseDigestAuth* (security) | If set to true Digest authentication will be used when authenticating to the HTTP proxy, otherwise Basic authorization method will be used | false | boolean
 | *httpProxyUsername* (security) | Username to use to authenticate against the HTTP proxy server. |  | String
 | *instanceUrl* (security) | URL of the Salesforce instance used after authentication, by default received from Salesforce on successful authentication |  | String
-| *isHttpProxySecure* (security) | If set to false disables the use of TLS when accessing the HTTP proxy. | true | boolean
 | *keystore* (security) | KeyStore parameters to use in OAuth JWT flow. The KeyStore should contain only one entry with private key and certificate. Salesforce does not verify the certificate chain, so this can easily be a selfsigned certificate. Make sure that you upload the certificate to the corresponding connected app. |  | KeyStoreParameters
 | *lazyLogin* (security) | If set to true prevents the component from authenticating to Salesforce with the start of the component. You would generally set this to the (default) false and authenticate early and be immediately aware of any authentication issues. | false | boolean
 | *loginConfig* (security) | All authentication configuration in one nested bean, all properties set there can be set directly on the component as well |  | SalesforceLoginConfig


[camel] 12/13: CAMEL-14762: Fixed CS

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

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

commit 94c9c3f65a5d4aa8fb03c1c954ba2cf3f65bf3c8
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 10:01:07 2020 +0100

    CAMEL-14762: Fixed CS
---
 .../camel/maven/packaging/MainConfigurerMojo.java   | 21 ++++++++++-----------
 1 file changed, 10 insertions(+), 11 deletions(-)

diff --git a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/MainConfigurerMojo.java b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/MainConfigurerMojo.java
index 0cc5d5a..42cfc82 100644
--- a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/MainConfigurerMojo.java
+++ b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/MainConfigurerMojo.java
@@ -39,6 +39,13 @@ import org.springframework.util.ReflectionUtils;
 @Mojo(name = "generate-main-configurer", threadSafe = true, defaultPhase = LifecyclePhase.PROCESS_CLASSES)
 public class MainConfigurerMojo extends AbstractGeneratorMojo {
 
+    private static final String[] CLASS_NAMES = new String[]{
+        "org.apache.camel.main.MainConfigurationProperties",
+        "org.apache.camel.main.HystrixConfigurationProperties",
+        "org.apache.camel.main.Resilience4jConfigurationProperties",
+        "org.apache.camel.main.RestConfigurationProperties",
+        "org.apache.camel.ExtendedCamelContext"};
+
     /**
      * The output directory for generated java source code
      */
@@ -50,18 +57,10 @@ public class MainConfigurerMojo extends AbstractGeneratorMojo {
 
     private DynamicClassLoader projectClassLoader;
 
-    private static final String[] CLASS_NAMES = new String[]{
-            "org.apache.camel.main.MainConfigurationProperties",
-            "org.apache.camel.main.HystrixConfigurationProperties",
-            "org.apache.camel.main.Resilience4jConfigurationProperties",
-            "org.apache.camel.main.RestConfigurationProperties",
-            "org.apache.camel.ExtendedCamelContext"};
-
     private static class Option extends BaseOptionModel {
-        // we just use name, type
-
 
         public Option(String name, Class type) {
+            // we just use name, type
             setName(name);
             setJavaType(type.getName());
         }
@@ -139,11 +138,11 @@ public class MainConfigurerMojo extends AbstractGeneratorMojo {
         }
     }
 
-    protected void generateMetaInfConfigurer(String fqn) {
+    private void generateMetaInfConfigurer(String fqn) {
         String name = fqn.substring(fqn.lastIndexOf('.') + 1);
         try (Writer w = new StringWriter()) {
             w.append("# " + GENERATED_MSG + "\n");
-            w.append("class=").append(fqn + "Configurer").append("\n");
+            w.append("class=").append(fqn).append("Configurer").append("\n");
             updateResource(resourcesOutputDir.toPath(), "META-INF/services/org/apache/camel/configurer/" + name, w.toString());
         } catch (IOException e) {
             throw new RuntimeException(e);


[camel] 11/13: CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs

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

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

commit 1387dee0d8926a41552f7e8ad6ad26a12187b3ce
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 09:57:28 2020 +0100

    CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
---
 .../org/apache/camel/component/milo/server/MiloServerComponent.java | 6 +++++-
 .../camel/component/milo/server/ServerSetSecurityPoliciesTest.java  | 5 -----
 2 files changed, 5 insertions(+), 6 deletions(-)

diff --git a/components/camel-milo/src/main/java/org/apache/camel/component/milo/server/MiloServerComponent.java b/components/camel-milo/src/main/java/org/apache/camel/component/milo/server/MiloServerComponent.java
index dc0f6be..e47f5db 100644
--- a/components/camel-milo/src/main/java/org/apache/camel/component/milo/server/MiloServerComponent.java
+++ b/components/camel-milo/src/main/java/org/apache/camel/component/milo/server/MiloServerComponent.java
@@ -131,6 +131,8 @@ public class MiloServerComponent extends DefaultComponent {
     private OpcUaServerConfig buildServerConfig() {
         OpcUaServerConfigBuilder serverConfig = this.opcServerConfig  != null ? this.opcServerConfig : createDefaultConfiguration();
 
+        this.securityPolicies = createSecurityPolicies();
+
         Map<String, String> userMap = createUserMap();
         if (!userMap.isEmpty() || enableAnonymousAuthentication != null) {
             // set identity validator
@@ -204,7 +206,7 @@ public class MiloServerComponent extends DefaultComponent {
     }
 
     private Set<EndpointConfiguration> createEndpointConfigurations(List<UserTokenPolicy> userTokenPolicies) {
-        return createEndpointConfigurations(userTokenPolicies, createSecurityPolicies());
+        return createEndpointConfigurations(userTokenPolicies, securityPolicies);
     }
 
     private Set<EndpointConfiguration> createEndpointConfigurations(List<UserTokenPolicy> userTokenPolicies, Set<SecurityPolicy> securityPolicies) {
@@ -491,6 +493,8 @@ public class MiloServerComponent extends DefaultComponent {
         } else {
             this.securityPolicies = EnumSet.copyOf(securityPolicies);
         }
+        // clear id as we set explicit these policies
+        this.securityPoliciesById = null;
     }
 
     /**
diff --git a/components/camel-milo/src/test/java/org/apache/camel/component/milo/server/ServerSetSecurityPoliciesTest.java b/components/camel-milo/src/test/java/org/apache/camel/component/milo/server/ServerSetSecurityPoliciesTest.java
index 5750890..d73f3fa 100644
--- a/components/camel-milo/src/test/java/org/apache/camel/component/milo/server/ServerSetSecurityPoliciesTest.java
+++ b/components/camel-milo/src/test/java/org/apache/camel/component/milo/server/ServerSetSecurityPoliciesTest.java
@@ -42,9 +42,4 @@ public class ServerSetSecurityPoliciesTest extends CamelTestSupport {
         component.setSecurityPoliciesById("None,http://opcfoundation.org/UA/SecurityPolicy#Basic256Sha256");
     }
 
-    @Test(expected = IllegalArgumentException.class)
-    public void testSetSecurityPolicies4() {
-        final MiloServerComponent component = new MiloServerComponent();
-        component.setSecurityPoliciesById("I just made that up");
-    }
 }


[camel] 13/13: Lets use ENGLISH instead of US in lower case

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

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

commit c2062ad3605e7b964956cea343824345922846da
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 10:06:22 2020 +0100

    Lets use ENGLISH instead of US in lower case
---
 .../org/apache/camel/catalog/impl/AbstractCamelCatalog.java  |  6 +++---
 .../camel/support/PropertyBindingSupportConfigurerTest.java  |  2 +-
 .../src/main/java/org/apache/camel/main/BaseMainSupport.java | 12 ++++++------
 .../src/main/java/org/apache/camel/util/StringHelper.java    |  2 +-
 4 files changed, 11 insertions(+), 11 deletions(-)

diff --git a/core/camel-core-catalog/src/main/java/org/apache/camel/catalog/impl/AbstractCamelCatalog.java b/core/camel-core-catalog/src/main/java/org/apache/camel/catalog/impl/AbstractCamelCatalog.java
index ed0ef67..3dab3f7 100644
--- a/core/camel-core-catalog/src/main/java/org/apache/camel/catalog/impl/AbstractCamelCatalog.java
+++ b/core/camel-core-catalog/src/main/java/org/apache/camel/catalog/impl/AbstractCamelCatalog.java
@@ -903,7 +903,7 @@ public abstract class AbstractCamelCatalog {
                 model.getOptions().forEach(o -> rows.put(o.getName(), o));
 
                 // lower case option and remove dash
-                String nOption = option.replace("-", "").toLowerCase(Locale.US);
+                String nOption = option.replace("-", "").toLowerCase(Locale.ENGLISH);
                 String suffix = null;
                 int posDot = nOption.indexOf('.');
                 int posBracket = nOption.indexOf('[');
@@ -937,7 +937,7 @@ public abstract class AbstractCamelCatalog {
                 model.getOptions().forEach(o -> rows.put(dashToCamelCase(o.getName()), o));
 
                 // lower case option and remove dash
-                String nOption = longKey.replace("-", "").toLowerCase(Locale.US);
+                String nOption = longKey.replace("-", "").toLowerCase(Locale.ENGLISH);
 
                 // look for suffix or array index after 2nd dot
                 int secondDot = nOption.indexOf('.', nOption.indexOf('.') + 1) + 1;
@@ -971,7 +971,7 @@ public abstract class AbstractCamelCatalog {
 
         // find option
         String rowKey = rows.keySet().stream()
-                .filter(n -> n.toLowerCase(Locale.US).equals(lookupKey)).findFirst().orElse(null);
+                .filter(n -> n.toLowerCase(Locale.ENGLISH).equals(lookupKey)).findFirst().orElse(null);
         if (rowKey == null) {
             // unknown option
             result.addUnknown(longKey);
diff --git a/core/camel-core/src/test/java/org/apache/camel/support/PropertyBindingSupportConfigurerTest.java b/core/camel-core/src/test/java/org/apache/camel/support/PropertyBindingSupportConfigurerTest.java
index de5cf00..431c6ce 100644
--- a/core/camel-core/src/test/java/org/apache/camel/support/PropertyBindingSupportConfigurerTest.java
+++ b/core/camel-core/src/test/java/org/apache/camel/support/PropertyBindingSupportConfigurerTest.java
@@ -205,7 +205,7 @@ public class PropertyBindingSupportConfigurerTest extends ContextTestSupport {
 
         @Override
         public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-            name = name.toLowerCase(Locale.US);
+            name = name.toLowerCase(Locale.ENGLISH);
             name = name.replaceAll("-", "");
             if (target instanceof Bar) {
                 Bar bar = (Bar) target;
diff --git a/core/camel-main/src/main/java/org/apache/camel/main/BaseMainSupport.java b/core/camel-main/src/main/java/org/apache/camel/main/BaseMainSupport.java
index fe1b829..2493155 100644
--- a/core/camel-main/src/main/java/org/apache/camel/main/BaseMainSupport.java
+++ b/core/camel-main/src/main/java/org/apache/camel/main/BaseMainSupport.java
@@ -110,7 +110,7 @@ public abstract class BaseMainSupport extends BaseService {
             System.getenv().forEach((k, v) -> {
                 k = k.toUpperCase(Locale.US);
                 if (k.startsWith(pk) || k.startsWith(pk2)) {
-                    String key = k.toLowerCase(Locale.US).replace('_', '.');
+                    String key = k.toLowerCase(Locale.ENGLISH).replace('_', '.');
                     answer.put(key, v);
                 }
             });
@@ -122,7 +122,7 @@ public abstract class BaseMainSupport extends BaseService {
     protected static String optionKey(String key) {
         // as we ignore case for property names we should use keys in same case and without dashes
         key = StringHelper.replaceAll(key, "-", "");
-        key = key.toLowerCase(Locale.US);
+        key = key.toLowerCase(Locale.ENGLISH);
         return key;
     }
 
@@ -574,7 +574,7 @@ public abstract class BaseMainSupport extends BaseService {
         if (mainConfigurationProperties.isAutoConfigurationLogSummary() && !autoConfiguredProperties.isEmpty()) {
             LOG.info("Auto-configuration summary:");
             autoConfiguredProperties.forEach((k, v) -> {
-                boolean sensitive = SENSITIVE_KEYS.contains(k.toLowerCase(Locale.US));
+                boolean sensitive = SENSITIVE_KEYS.contains(k.toLowerCase(Locale.ENGLISH));
                 if (sensitive) {
                     LOG.info("\t{}=xxxxxx", k);
                 } else {
@@ -1076,10 +1076,10 @@ public abstract class BaseMainSupport extends BaseService {
     protected void doAutowireWildcardProperties(String name, Component component) {
         Map<PropertyOptionKey, Map<String, Object>> properties = new LinkedHashMap<>();
         Map<String, String> autoConfiguredProperties = new LinkedHashMap<>();
-        String match = ("camel.component." + name).toLowerCase(Locale.US);
+        String match = ("camel.component." + name).toLowerCase(Locale.ENGLISH);
 
         for (String key : wildcardProperties.stringPropertyNames()) {
-            String mKey = key.substring(0, key.indexOf('*')).toLowerCase(Locale.US);
+            String mKey = key.substring(0, key.indexOf('*')).toLowerCase(Locale.ENGLISH);
             if (match.startsWith(mKey)) {
                 computeProperties("camel.component.", key, wildcardProperties, properties, s -> Collections.singleton(component));
             }
@@ -1100,7 +1100,7 @@ public abstract class BaseMainSupport extends BaseService {
             if (mainConfigurationProperties.isAutoConfigurationLogSummary() && !autoConfiguredProperties.isEmpty()) {
                 LOG.info("Auto-configuration component {} summary:", name);
                 autoConfiguredProperties.forEach((k, v) -> {
-                    boolean sensitive = SENSITIVE_KEYS.contains(k.toLowerCase(Locale.US));
+                    boolean sensitive = SENSITIVE_KEYS.contains(k.toLowerCase(Locale.ENGLISH));
                     if (sensitive) {
                         LOG.info("\t{}=xxxxxx", k);
                     } else {
diff --git a/core/camel-util/src/main/java/org/apache/camel/util/StringHelper.java b/core/camel-util/src/main/java/org/apache/camel/util/StringHelper.java
index fd6fe35..440a8c2 100644
--- a/core/camel-util/src/main/java/org/apache/camel/util/StringHelper.java
+++ b/core/camel-util/src/main/java/org/apache/camel/util/StringHelper.java
@@ -861,7 +861,7 @@ public final class StringHelper {
             prev = ch;
         }
         
-        return answer.toString().toLowerCase(Locale.US);
+        return answer.toString().toLowerCase(Locale.ENGLISH);
     }
 
 }


[camel] 08/13: Add first version

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

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

commit f16ff3939c6890b2c97489ab49b0043a5966c8af
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 09:02:32 2020 +0100

    Add first version
---
 components/camel-platform-http-vertx/pom.xml | 5 +++++
 1 file changed, 5 insertions(+)

diff --git a/components/camel-platform-http-vertx/pom.xml b/components/camel-platform-http-vertx/pom.xml
index b92e1f2..a6e4d1a 100644
--- a/components/camel-platform-http-vertx/pom.xml
+++ b/components/camel-platform-http-vertx/pom.xml
@@ -32,6 +32,11 @@
     <name>Camel :: Platform HTTP :: Vert.x</name>
     <description>Implementation of the Platform HTTP Engine based on Vert.x Web</description>
 
+    <properties>
+        <firstVersion>3.2.0</firstVersion>
+        <label>http</label>
+    </properties>
+
     <dependencies>
         <dependency>
             <groupId>org.apache.camel</groupId>


[camel] 02/13: CAMEL-14762: camel-core - Configurer to include API for method name and type

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

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

commit a92f87d8d085362a94665f3436e67bf573600f17
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sat Mar 21 21:14:41 2020 +0100

    CAMEL-14762: camel-core - Configurer to include API for method name and type
---
 ...nfigurer.java => PropertyConfigurerGetter.java} | 22 ++++++++--
 .../packaging/PropertyConfigurerGenerator.java     | 50 +++++++++++++++++++---
 2 files changed, 64 insertions(+), 8 deletions(-)

diff --git a/core/camel-api/src/main/java/org/apache/camel/spi/PropertyOptionsConfigurer.java b/core/camel-api/src/main/java/org/apache/camel/spi/PropertyConfigurerGetter.java
similarity index 55%
rename from core/camel-api/src/main/java/org/apache/camel/spi/PropertyOptionsConfigurer.java
rename to core/camel-api/src/main/java/org/apache/camel/spi/PropertyConfigurerGetter.java
index 9c7b3e9..c0d24f9 100644
--- a/core/camel-api/src/main/java/org/apache/camel/spi/PropertyOptionsConfigurer.java
+++ b/core/camel-api/src/main/java/org/apache/camel/spi/PropertyConfigurerGetter.java
@@ -21,14 +21,30 @@ import java.util.Map;
 /**
  * A marker interface to identify the object as being a configurer which can
  * provide details about the options the configurer supports.
+ * <p/>
+ * This is used in Camel to have fast property configuration of Camel components & endpoints,
+ * and for EIP patterns as well.
+ *
+ * @see PropertyConfigurer
  */
-public interface PropertyOptionsConfigurer {
+public interface PropertyConfigurerGetter {
 
     /**
      * Provides a map of which options the cofigurer supports and their class type.
      *
-     * @return options as map name -> class type.
+     * @param target  the target instance such as {@link org.apache.camel.Endpoint} or {@link org.apache.camel.Component}.
+     * @return configurable options from the target as a Map name -> class type.
+     */
+    Map<String, Object> getAllOptions(Object target);
+
+    /**
+     * Gets the property value
+     *
+     * @param target  the target instance such as {@link org.apache.camel.Endpoint} or {@link org.apache.camel.Component}.
+     * @param name          the property name
+     * @param ignoreCase    whether to ignore case for matching the property name
+     * @return the property value
      */
-    Map<String, Object> options();
+    Object getOptionValue(Object target, String name, boolean ignoreCase);
 
 }
diff --git a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
index 86229bf..5a26889 100644
--- a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
+++ b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
@@ -40,7 +40,7 @@ public final class PropertyConfigurerGenerator {
         w.write("\n");
         w.write("import org.apache.camel.CamelContext;\n");
         w.write("import org.apache.camel.spi.GeneratedPropertyConfigurer;\n");
-        w.write("import org.apache.camel.spi.PropertyOptionsConfigurer;\n");
+        w.write("import org.apache.camel.spi.PropertyConfigurerGetter;\n");
         w.write("import org.apache.camel.util.CaseInsensitiveMap;\n");
         w.write("import "  + pfqn + ";\n");
         w.write("\n");
@@ -48,7 +48,7 @@ public final class PropertyConfigurerGenerator {
         w.write(" * " + AbstractGeneratorMojo.GENERATED_MSG + "\n");
         w.write(" */\n");
         w.write("@SuppressWarnings(\"unchecked\")\n");
-        w.write("public class " + cn + " extends " + psn + " implements GeneratedPropertyConfigurer, PropertyOptionsConfigurer {\n");
+        w.write("public class " + cn + " extends " + psn + " implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {\n");
         w.write("\n");
         if (!options.isEmpty() || !hasSuper) {
 
@@ -88,12 +88,12 @@ public final class PropertyConfigurerGenerator {
             }
             w.write("    }\n");
 
-            // generate API that returns which
+            // generate API that returns all the options
             w.write("\n");
             w.write("    @Override\n");
-            w.write("    public Map<String, Object> options() {\n");
+            w.write("    public Map<String, Object> getAllOptions(Object target) {\n");
             if (hasSuper) {
-                w.write("        Map<String, Object> answer = super.options();\n");
+                w.write("        Map<String, Object> answer = super.getAllOptions(target);\n");
             } else {
                 w.write("        Map<String, Object> answer = new CaseInsensitiveMap();\n");
             }
@@ -110,6 +110,31 @@ public final class PropertyConfigurerGenerator {
                 w.write("        return answer;\n");
                 w.write("    }\n");
             }
+
+            // generate API for getting a property
+            w.write("\n");
+            w.write("    @Override\n");
+            w.write("    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {\n");
+            if (!options.isEmpty()) {
+                w.write("        " + en + " target = (" + en + ") obj;\n");
+                w.write("        switch (ignoreCase ? name.toLowerCase() : name) {\n");
+                for (BaseOptionModel option : options) {
+                    String getOrSet = option.getName();
+                    getOrSet = Character.toUpperCase(getOrSet.charAt(0)) + getOrSet.substring(1);
+                    String getterLambda = getterLambda(getOrSet, option.getJavaType(), option.getConfigurationField(), component);
+                    if (!option.getName().toLowerCase().equals(option.getName())) {
+                        w.write(String.format("        case \"%s\":\n", option.getName().toLowerCase()));
+                    }
+                    w.write(String.format("        case \"%s\": %s; return true;\n", option.getName(), getterLambda));
+                }
+                if (hasSuper) {
+                    w.write("        default: return super.getOptionValue(obj, name, ignoreCase);\n");
+                } else {
+                    w.write("        default: return null;\n");
+                }
+                w.write("        }\n");
+            }
+            w.write("    }\n");
         }
 
         w.write("}\n");
@@ -141,6 +166,21 @@ public final class PropertyConfigurerGenerator {
         return String.format("%s(property(camelContext, %s.class, value))", getOrSet, type);
     }
 
+    private static String getterLambda(String getOrSet, String type, String configurationField, boolean component) {
+        String prefix = "boolean".equals(type) ? "is" : "get";
+        if (configurationField != null) {
+            if (component) {
+                getOrSet = "getOrCreateConfiguration(target)." + prefix + getOrSet;
+            } else {
+                getOrSet = "target.get" + Character.toUpperCase(configurationField.charAt(0)) + configurationField.substring(1) + "()." + prefix + getOrSet;
+            }
+        } else {
+            getOrSet = "target." + prefix + getOrSet;
+        }
+
+        return getOrSet + "()";
+    }
+
     private static String createGetOrCreateConfiguration(String targetClass, String configurationClass, String configurationField) {
         String getter = "get" + Character.toUpperCase(configurationField.charAt(0)) + configurationField.substring(1);
         String setter = "set" + Character.toUpperCase(configurationField.charAt(0)) + configurationField.substring(1);


[camel] 07/13: CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs

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

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

commit 7d1a25eebbe01471bc17bb28ee95fbd48c80a501
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 08:28:44 2020 +0100

    CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
---
 .../activemq/ActiveMQComponentConfigurer.java      |   8 +-
 .../component/ahc/ws/WsComponentConfigurer.java    |   2 +-
 .../component/ahc/ws/WsEndpointConfigurer.java     |  10 +-
 .../component/ahc/AhcComponentConfigurer.java      |  18 +-
 .../camel/component/ahc/AhcEndpointConfigurer.java |  30 +--
 .../component/amqp/AMQPComponentConfigurer.java    |   2 +-
 .../component/apns/ApnsComponentConfigurer.java    |   8 +-
 .../component/apns/ApnsEndpointConfigurer.java     |  46 ++--
 .../component/as2/AS2ComponentConfigurer.java      |   8 +-
 .../camel/component/as2/AS2EndpointConfigurer.java |  98 ++++-----
 .../asterisk/AsteriskComponentConfigurer.java      |   6 +-
 .../asterisk/AsteriskEndpointConfigurer.java       |  20 +-
 .../component/atmos/AtmosComponentConfigurer.java  |  14 +-
 .../component/atmos/AtmosEndpointConfigurer.java   |  28 +--
 .../websocket/WebsocketComponentConfigurer.java    |   2 +-
 .../websocket/WebsocketEndpointConfigurer.java     |  32 +--
 .../component/atom/AtomComponentConfigurer.java    |   4 +-
 .../component/atom/AtomEndpointConfigurer.java     |  58 ++---
 .../client/map/AtomixMapComponentConfigurer.java   |  36 ++--
 .../client/map/AtomixMapEndpointConfigurer.java    |  40 ++--
 .../AtomixMessagingComponentConfigurer.java        |  38 ++--
 .../AtomixMessagingEndpointConfigurer.java         |  42 ++--
 .../AtomixMultiMapComponentConfigurer.java         |  34 +--
 .../multimap/AtomixMultiMapEndpointConfigurer.java |  34 +--
 .../queue/AtomixQueueComponentConfigurer.java      |  32 +--
 .../queue/AtomixQueueEndpointConfigurer.java       |  36 ++--
 .../client/set/AtomixSetComponentConfigurer.java   |  34 +--
 .../client/set/AtomixSetEndpointConfigurer.java    |  38 ++--
 .../value/AtomixValueComponentConfigurer.java      |  34 +--
 .../value/AtomixValueEndpointConfigurer.java       |  38 ++--
 .../component/avro/AvroComponentConfigurer.java    |  20 +-
 .../component/avro/AvroEndpointConfigurer.java     |  24 +--
 .../component/aws/cw/CwComponentConfigurer.java    |  28 +--
 .../component/aws/cw/CwEndpointConfigurer.java     |  28 +--
 .../component/aws/ddb/DdbComponentConfigurer.java  |  32 +--
 .../component/aws/ddb/DdbEndpointConfigurer.java   |  32 +--
 .../ddbstream/DdbStreamComponentConfigurer.java    |  26 +--
 .../aws/ddbstream/DdbStreamEndpointConfigurer.java |  62 +++---
 .../component/aws/ec2/EC2ComponentConfigurer.java  |  22 +-
 .../component/aws/ec2/EC2EndpointConfigurer.java   |  22 +-
 .../component/aws/ecs/ECSComponentConfigurer.java  |  22 +-
 .../component/aws/ecs/ECSEndpointConfigurer.java   |  22 +-
 .../component/aws/eks/EKSComponentConfigurer.java  |  22 +-
 .../component/aws/eks/EKSEndpointConfigurer.java   |  22 +-
 .../component/aws/iam/IAMComponentConfigurer.java  |  22 +-
 .../component/aws/iam/IAMEndpointConfigurer.java   |  22 +-
 .../KinesisFirehoseComponentConfigurer.java        |  20 +-
 .../KinesisFirehoseEndpointConfigurer.java         |  20 +-
 .../aws/kinesis/KinesisComponentConfigurer.java    |  32 +--
 .../aws/kinesis/KinesisEndpointConfigurer.java     |  68 +++---
 .../component/aws/kms/KMSComponentConfigurer.java  |  22 +-
 .../component/aws/kms/KMSEndpointConfigurer.java   |  22 +-
 .../aws/lambda/LambdaComponentConfigurer.java      |  22 +-
 .../aws/lambda/LambdaEndpointConfigurer.java       |  22 +-
 .../component/aws/mq/MQComponentConfigurer.java    |  22 +-
 .../component/aws/mq/MQEndpointConfigurer.java     |  22 +-
 .../component/aws/msk/MSKComponentConfigurer.java  |  22 +-
 .../component/aws/msk/MSKEndpointConfigurer.java   |  22 +-
 .../component/aws/s3/S3ComponentConfigurer.java    |  76 +++----
 .../component/aws/s3/S3EndpointConfigurer.java     | 116 +++++-----
 .../component/aws/sdb/SdbComponentConfigurer.java  |   4 +-
 .../component/aws/sdb/SdbEndpointConfigurer.java   |  26 +--
 .../component/aws/ses/SesComponentConfigurer.java  |  28 +--
 .../component/aws/ses/SesEndpointConfigurer.java   |  28 +--
 .../component/aws/sns/SnsComponentConfigurer.java  |  38 ++--
 .../component/aws/sns/SnsEndpointConfigurer.java   |  40 ++--
 .../component/aws/sqs/SqsComponentConfigurer.java  |  76 +++----
 .../component/aws/sqs/SqsEndpointConfigurer.java   | 116 +++++-----
 .../component/aws/swf/SWFComponentConfigurer.java  |  60 +++---
 .../component/aws/swf/SWFEndpointConfigurer.java   |  64 +++---
 .../translate/TranslateComponentConfigurer.java    |  28 +--
 .../aws/translate/TranslateEndpointConfigurer.java |  28 +--
 .../component/aws2/cw/Cw2ComponentConfigurer.java  |  28 +--
 .../component/aws2/cw/Cw2EndpointConfigurer.java   |  28 +--
 .../aws2/ddb/Ddb2ComponentConfigurer.java          |  32 +--
 .../component/aws2/ddb/Ddb2EndpointConfigurer.java |  32 +--
 .../ddbstream/Ddb2StreamComponentConfigurer.java   |  26 +--
 .../ddbstream/Ddb2StreamEndpointConfigurer.java    |  62 +++---
 .../aws2/ec2/AWS2EC2ComponentConfigurer.java       |  22 +-
 .../aws2/ec2/AWS2EC2EndpointConfigurer.java        |  22 +-
 .../aws2/ecs/ECS2ComponentConfigurer.java          |  22 +-
 .../component/aws2/ecs/ECS2EndpointConfigurer.java |  22 +-
 .../aws2/eks/EKS2ComponentConfigurer.java          |  22 +-
 .../component/aws2/eks/EKS2EndpointConfigurer.java |  22 +-
 .../aws2/iam/IAM2ComponentConfigurer.java          |  22 +-
 .../component/aws2/iam/IAM2EndpointConfigurer.java |  22 +-
 .../KinesisFirehose2ComponentConfigurer.java       |  20 +-
 .../KinesisFirehose2EndpointConfigurer.java        |  20 +-
 .../aws2/kinesis/Kinesis2ComponentConfigurer.java  |  32 +--
 .../aws2/kinesis/Kinesis2EndpointConfigurer.java   |  68 +++---
 .../aws2/kms/KMS2ComponentConfigurer.java          |  22 +-
 .../component/aws2/kms/KMS2EndpointConfigurer.java |  22 +-
 .../aws2/lambda/Lambda2ComponentConfigurer.java    |  22 +-
 .../aws2/lambda/Lambda2EndpointConfigurer.java     |  22 +-
 .../component/aws2/mq/MQ2ComponentConfigurer.java  |  22 +-
 .../component/aws2/mq/MQ2EndpointConfigurer.java   |  22 +-
 .../aws2/msk/MSK2ComponentConfigurer.java          |  22 +-
 .../component/aws2/msk/MSK2EndpointConfigurer.java |  22 +-
 .../aws2/s3/AWS2S3ComponentConfigurer.java         |  60 +++---
 .../aws2/s3/AWS2S3EndpointConfigurer.java          | 100 ++++-----
 .../aws2/ses/Ses2ComponentConfigurer.java          |  28 +--
 .../component/aws2/ses/Ses2EndpointConfigurer.java |  28 +--
 .../aws2/sns/Sns2ComponentConfigurer.java          |  36 ++--
 .../component/aws2/sns/Sns2EndpointConfigurer.java |  38 ++--
 .../aws2/sqs/Sqs2ComponentConfigurer.java          |  76 +++----
 .../component/aws2/sqs/Sqs2EndpointConfigurer.java | 116 +++++-----
 .../translate/Translate2ComponentConfigurer.java   |  28 +--
 .../translate/Translate2EndpointConfigurer.java    |  28 +--
 .../azure/blob/BlobServiceComponentConfigurer.java |  42 ++--
 .../azure/blob/BlobServiceEndpointConfigurer.java  |  46 ++--
 .../queue/QueueServiceComponentConfigurer.java     |  24 +--
 .../queue/QueueServiceEndpointConfigurer.java      |  28 +--
 .../BeanValidatorComponentConfigurer.java          |  14 +-
 .../validator/BeanValidatorEndpointConfigurer.java |  20 +-
 .../component/bean/BeanComponentConfigurer.java    |   8 +-
 .../component/bean/BeanEndpointConfigurer.java     |  14 +-
 .../beanstalk/BeanstalkComponentConfigurer.java    |   8 +-
 .../beanstalk/BeanstalkEndpointConfigurer.java     |  58 ++---
 .../bonita/BonitaComponentConfigurer.java          |   4 +-
 .../component/bonita/BonitaEndpointConfigurer.java |  16 +-
 .../component/box/BoxComponentConfigurer.java      |  38 ++--
 .../camel/component/box/BoxEndpointConfigurer.java |  76 +++----
 .../braintree/BraintreeComponentConfigurer.java    |   8 +-
 .../braintree/BraintreeEndpointConfigurer.java     |  68 +++---
 .../browse/BrowseComponentConfigurer.java          |   6 +-
 .../component/browse/BrowseEndpointConfigurer.java |  12 +-
 .../cache/CaffeineCacheComponentConfigurer.java    |  36 ++--
 .../cache/CaffeineCacheEndpointConfigurer.java     |  36 ++--
 .../load/CaffeineLoadCacheComponentConfigurer.java |  36 ++--
 .../load/CaffeineLoadCacheEndpointConfigurer.java  |  36 ++--
 .../cassandra/CassandraComponentConfigurer.java    |   6 +-
 .../cassandra/CassandraEndpointConfigurer.java     |  64 +++---
 .../chatscript/ChatScriptComponentConfigurer.java  |   4 +-
 .../chatscript/ChatScriptEndpointConfigurer.java   |  10 +-
 .../component/chunk/ChunkComponentConfigurer.java  |   4 +-
 .../component/chunk/ChunkEndpointConfigurer.java   |  18 +-
 .../camel/component/cm/CMComponentConfigurer.java  |   4 +-
 .../camel/component/cm/CMEndpointConfigurer.java   |  14 +-
 .../component/cmis/CMISComponentConfigurer.java    |   8 +-
 .../component/cmis/CMISEndpointConfigurer.java     |  30 +--
 .../apache/camel/coap/CoAPComponentConfigurer.java |   6 +-
 .../apache/camel/coap/CoAPEndpointConfigurer.java  |  32 +--
 .../cometd/CometdComponentConfigurer.java          |  20 +-
 .../component/cometd/CometdEndpointConfigurer.java |  36 ++--
 .../consul/ConsulComponentConfigurer.java          |  52 ++---
 .../component/consul/ConsulEndpointConfigurer.java |  54 ++---
 .../controlbus/ControlBusComponentConfigurer.java  |   4 +-
 .../controlbus/ControlBusEndpointConfigurer.java   |  16 +-
 .../component/corda/CordaComponentConfigurer.java  |  28 +--
 .../component/corda/CordaEndpointConfigurer.java   |  32 +--
 .../couchbase/CouchbaseComponentConfigurer.java    |   6 +-
 .../couchbase/CouchbaseEndpointConfigurer.java     | 100 ++++-----
 .../couchdb/CouchDbComponentConfigurer.java        |   6 +-
 .../couchdb/CouchDbEndpointConfigurer.java         |  28 +--
 .../component/cron/CronComponentConfigurer.java    |   6 +-
 .../component/cron/CronEndpointConfigurer.java     |  12 +-
 .../crypto/cms/CryptoCmsComponentConfigurer.java   |   8 +-
 .../crypto/cms/CryptoCmsEndpointConfigurer.java    |  34 +--
 .../DigitalSignatureComponentConfigurer.java       |  42 ++--
 .../crypto/DigitalSignatureEndpointConfigurer.java |  42 ++--
 .../component/cxf/CxfComponentConfigurer.java      |  12 +-
 .../camel/component/cxf/CxfEndpointConfigurer.java |  72 +++----
 .../cxf/jaxrs/CxfRsComponentConfigurer.java        |  10 +-
 .../cxf/jaxrs/CxfRsEndpointConfigurer.java         |  64 +++---
 .../dataformat/DataFormatComponentConfigurer.java  |   4 +-
 .../dataformat/DataFormatEndpointConfigurer.java   |   6 +-
 .../dataset/DataSetComponentConfigurer.java        |   6 +-
 .../dataset/DataSetEndpointConfigurer.java         |  18 +-
 .../dataset/DataSetTestComponentConfigurer.java    |   4 +-
 .../dataset/DataSetTestEndpointConfigurer.java     |   8 +-
 .../DebeziumMongodbComponentConfigurer.java        |  84 ++++----
 .../DebeziumMongodbEndpointConfigurer.java         |  88 ++++----
 .../debezium/DebeziumMySqlComponentConfigurer.java | 144 ++++++-------
 .../debezium/DebeziumMySqlEndpointConfigurer.java  | 148 ++++++-------
 .../DebeziumPostgresComponentConfigurer.java       | 128 +++++------
 .../DebeziumPostgresEndpointConfigurer.java        | 132 ++++++------
 .../DebeziumSqlserverComponentConfigurer.java      |  92 ++++----
 .../DebeziumSqlserverEndpointConfigurer.java       |  96 ++++-----
 .../DigitalOceanComponentConfigurer.java           |   4 +-
 .../DigitalOceanEndpointConfigurer.java            |  24 +--
 .../direct/DirectComponentConfigurer.java          |  10 +-
 .../component/direct/DirectEndpointConfigurer.java |  18 +-
 .../directvm/DirectVmComponentConfigurer.java      |  14 +-
 .../directvm/DirectVmEndpointConfigurer.java       |  22 +-
 .../disruptor/DisruptorComponentConfigurer.java    |  18 +-
 .../disruptor/DisruptorEndpointConfigurer.java     |  28 +--
 .../component/dns/DnsComponentConfigurer.java      |   4 +-
 .../camel/component/dns/DnsEndpointConfigurer.java |   6 +-
 .../docker/DockerComponentConfigurer.java          |  42 ++--
 .../component/docker/DockerEndpointConfigurer.java |  46 ++--
 .../component/dozer/DozerComponentConfigurer.java  |   4 +-
 .../component/dozer/DozerEndpointConfigurer.java   |  18 +-
 .../component/drill/DrillComponentConfigurer.java  |   4 +-
 .../component/drill/DrillEndpointConfigurer.java   |  14 +-
 .../dropbox/DropboxComponentConfigurer.java        |   6 +-
 .../dropbox/DropboxEndpointConfigurer.java         |  28 +--
 .../ehcache/EhcacheComponentConfigurer.java        |  32 +--
 .../ehcache/EhcacheEndpointConfigurer.java         |  38 ++--
 .../ElasticsearchComponentConfigurer.java          |  26 +--
 .../ElasticsearchEndpointConfigurer.java           |  38 ++--
 .../component/elsql/ElsqlComponentConfigurer.java  |  14 +-
 .../component/elsql/ElsqlEndpointConfigurer.java   | 100 ++++-----
 .../elytron/ElytronComponentConfigurer.java        |   6 +-
 .../etcd/EtcdKeysComponentConfigurer.java          |  24 +--
 .../component/etcd/EtcdKeysEndpointConfigurer.java |  22 +-
 .../etcd/EtcdStatsComponentConfigurer.java         |  30 +--
 .../etcd/EtcdStatsEndpointConfigurer.java          |  64 +++---
 .../etcd/EtcdWatchComponentConfigurer.java         |  26 +--
 .../etcd/EtcdWatchEndpointConfigurer.java          |  28 +--
 .../eventadmin/EventAdminComponentConfigurer.java  |   8 +-
 .../eventadmin/EventAdminEndpointConfigurer.java   |  14 +-
 .../component/exec/ExecComponentConfigurer.java    |   4 +-
 .../component/exec/ExecEndpointConfigurer.java     |  22 +-
 .../facebook/FacebookComponentConfigurer.java      |  62 +++---
 .../facebook/FacebookEndpointConfigurer.java       | 208 +++++++++---------
 .../component/fhir/FhirComponentConfigurer.java    |  54 ++---
 .../component/fhir/FhirEndpointConfigurer.java     |  92 ++++----
 .../file/watch/FileWatchComponentConfigurer.java   |  14 +-
 .../file/watch/FileWatchEndpointConfigurer.java    |  28 +--
 .../component/file/FileComponentConfigurer.java    |   6 +-
 .../component/file/FileEndpointConfigurer.java     | 184 ++++++++--------
 .../flatpack/FlatpackComponentConfigurer.java      |   6 +-
 .../flatpack/FlatpackEndpointConfigurer.java       |  56 ++---
 .../component/flink/FlinkComponentConfigurer.java  |  12 +-
 .../component/flink/FlinkEndpointConfigurer.java   |  16 +-
 .../component/fop/FopComponentConfigurer.java      |   4 +-
 .../camel/component/fop/FopEndpointConfigurer.java |  10 +-
 .../freemarker/FreemarkerComponentConfigurer.java  |   6 +-
 .../freemarker/FreemarkerEndpointConfigurer.java   |  14 +-
 .../file/remote/FtpComponentConfigurer.java        |   6 +-
 .../file/remote/FtpEndpointConfigurer.java         | 220 +++++++++----------
 .../file/remote/FtpsComponentConfigurer.java       |   2 +-
 .../file/remote/FtpsEndpointConfigurer.java        |  16 +-
 .../file/remote/SftpComponentConfigurer.java       |   6 +-
 .../file/remote/SftpEndpointConfigurer.java        | 240 ++++++++++-----------
 .../ganglia/GangliaComponentConfigurer.java        |  30 +--
 .../ganglia/GangliaEndpointConfigurer.java         |  30 +--
 .../geocoder/GeoCoderComponentConfigurer.java      |   4 +-
 .../geocoder/GeoCoderEndpointConfigurer.java       |  30 +--
 .../component/git/GitComponentConfigurer.java      |   6 +-
 .../camel/component/git/GitEndpointConfigurer.java |  30 +--
 .../github/GitHubComponentConfigurer.java          |   6 +-
 .../component/github/GitHubEndpointConfigurer.java |  28 +--
 .../GoogleBigQueryComponentConfigurer.java         |  10 +-
 .../bigquery/GoogleBigQueryEndpointConfigurer.java |  10 +-
 .../sql/GoogleBigQuerySQLComponentConfigurer.java  |   8 +-
 .../sql/GoogleBigQuerySQLEndpointConfigurer.java   |   8 +-
 .../GoogleCalendarComponentConfigurer.java         |  28 +--
 .../calendar/GoogleCalendarEndpointConfigurer.java |  64 +++---
 .../GoogleCalendarStreamComponentConfigurer.java   |  30 +--
 .../GoogleCalendarStreamEndpointConfigurer.java    |  64 +++---
 .../drive/GoogleDriveComponentConfigurer.java      |  22 +-
 .../drive/GoogleDriveEndpointConfigurer.java       |  60 +++---
 .../google/mail/GoogleMailComponentConfigurer.java |  20 +-
 .../google/mail/GoogleMailEndpointConfigurer.java  |  56 ++---
 .../GoogleMailStreamComponentConfigurer.java       |  26 +--
 .../stream/GoogleMailStreamEndpointConfigurer.java |  60 +++---
 .../pubsub/GooglePubsubComponentConfigurer.java    |  14 +-
 .../pubsub/GooglePubsubEndpointConfigurer.java     |  22 +-
 .../sheets/GoogleSheetsComponentConfigurer.java    |  20 +-
 .../sheets/GoogleSheetsEndpointConfigurer.java     |  56 ++---
 .../GoogleSheetsStreamComponentConfigurer.java     |  34 +--
 .../GoogleSheetsStreamEndpointConfigurer.java      |  68 +++---
 .../component/gora/GoraComponentConfigurer.java    |   6 +-
 .../component/gora/GoraEndpointConfigurer.java     |  46 ++--
 .../component/grape/GrapeComponentConfigurer.java  |   6 +-
 .../component/grape/GrapeEndpointConfigurer.java   |   6 +-
 .../graphql/GraphqlComponentConfigurer.java        |   4 +-
 .../graphql/GraphqlEndpointConfigurer.java         |  22 +-
 .../component/grpc/GrpcComponentConfigurer.java    |   6 +-
 .../component/grpc/GrpcEndpointConfigurer.java     |  54 ++---
 .../eventbus/GuavaEventBusComponentConfigurer.java |  10 +-
 .../eventbus/GuavaEventBusEndpointConfigurer.java  |  16 +-
 .../HazelcastAtomicnumberComponentConfigurer.java  |   8 +-
 .../HazelcastAtomicnumberEndpointConfigurer.java   |  12 +-
 .../HazelcastInstanceComponentConfigurer.java      |   8 +-
 .../HazelcastInstanceEndpointConfigurer.java       |  16 +-
 .../list/HazelcastListComponentConfigurer.java     |  10 +-
 .../list/HazelcastListEndpointConfigurer.java      |  18 +-
 .../map/HazelcastMapComponentConfigurer.java       |  10 +-
 .../map/HazelcastMapEndpointConfigurer.java        |  18 +-
 .../HazelcastMultimapComponentConfigurer.java      |  10 +-
 .../HazelcastMultimapEndpointConfigurer.java       |  18 +-
 .../queue/HazelcastQueueComponentConfigurer.java   |  10 +-
 .../queue/HazelcastQueueEndpointConfigurer.java    |  24 +--
 .../HazelcastReplicatedmapComponentConfigurer.java |  10 +-
 .../HazelcastReplicatedmapEndpointConfigurer.java  |  18 +-
 .../HazelcastRingbufferComponentConfigurer.java    |   8 +-
 .../HazelcastRingbufferEndpointConfigurer.java     |  12 +-
 .../seda/HazelcastSedaComponentConfigurer.java     |  10 +-
 .../seda/HazelcastSedaEndpointConfigurer.java      |  28 +--
 .../set/HazelcastSetComponentConfigurer.java       |  10 +-
 .../set/HazelcastSetEndpointConfigurer.java        |  18 +-
 .../topic/HazelcastTopicComponentConfigurer.java   |  10 +-
 .../topic/HazelcastTopicEndpointConfigurer.java    |  20 +-
 .../component/hbase/HBaseComponentConfigurer.java  |  10 +-
 .../component/hbase/HBaseEndpointConfigurer.java   |  36 ++--
 .../component/hdfs/HdfsComponentConfigurer.java    |  10 +-
 .../component/hdfs/HdfsEndpointConfigurer.java     |  94 ++++----
 .../hipchat/HipchatComponentConfigurer.java        |   6 +-
 .../hipchat/HipchatEndpointConfigurer.java         |  50 ++---
 .../component/http/HttpComponentConfigurer.java    |  38 ++--
 .../component/http/HttpEndpointConfigurer.java     | 104 ++++-----
 .../iec60870/client/ClientComponentConfigurer.java |   8 +-
 .../iec60870/client/ClientEndpointConfigurer.java  |  44 ++--
 .../iec60870/server/ServerComponentConfigurer.java |   8 +-
 .../iec60870/server/ServerEndpointConfigurer.java  |  46 ++--
 .../component/jdbc/JdbcComponentConfigurer.java    |   6 +-
 .../component/jdbc/JdbcEndpointConfigurer.java     |  30 +--
 .../jetty9/JettyHttpComponent9Configurer.java      |  64 +++---
 .../jetty9/JettyHttpEndpoint9Configurer.java       |  68 +++---
 .../component/jms/JmsComponentConfigurer.java      | 192 ++++++++---------
 .../camel/component/jms/JmsEndpointConfigurer.java | 188 ++++++++--------
 .../language/LanguageComponentConfigurer.java      |   4 +-
 .../language/LanguageEndpointConfigurer.java       |  16 +-
 .../component/log/LogComponentConfigurer.java      |   6 +-
 .../camel/component/log/LogEndpointConfigurer.java |  56 ++---
 .../master/MasterComponentConfigurer.java          |   8 +-
 .../component/master/MasterEndpointConfigurer.java |  10 +-
 .../milo/server/MiloServerComponentConfigurer.java |  16 +-
 .../camel/component/milo/server/milo-server.json   |   6 +-
 .../src/main/docs/milo-server-component.adoc       |   6 +-
 .../component/milo/server/MiloServerComponent.java | 207 +++++++++---------
 .../milo/MonitorItemMultiConnectionsCertTest.java  |   4 +-
 .../server/ServerSetCertificateManagerTest.java    |   4 +-
 .../milo/server/ServerSetSecurityPoliciesTest.java |   2 +-
 .../component/mina/MinaComponentConfigurer.java    |  56 ++---
 .../component/mina/MinaEndpointConfigurer.java     |  58 ++---
 .../component/mock/MockComponentConfigurer.java    |   4 +-
 .../component/mock/MockEndpointConfigurer.java     |  26 +--
 .../component/netty/NettyComponentConfigurer.java  | 144 ++++++-------
 .../component/netty/NettyEndpointConfigurer.java   | 142 ++++++------
 .../component/ref/RefComponentConfigurer.java      |   6 +-
 .../camel/component/ref/RefEndpointConfigurer.java |  12 +-
 .../component/rest/RestApiComponentConfigurer.java |   4 +-
 .../component/rest/RestApiEndpointConfigurer.java  |  14 +-
 .../component/rest/RestComponentConfigurer.java    |  16 +-
 .../component/rest/RestEndpointConfigurer.java     |  36 ++--
 .../component/saga/SagaComponentConfigurer.java    |   4 +-
 .../component/saga/SagaEndpointConfigurer.java     |   6 +-
 .../scheduler/SchedulerComponentConfigurer.java    |   6 +-
 .../scheduler/SchedulerEndpointConfigurer.java     |  44 ++--
 .../component/seda/SedaComponentConfigurer.java    |  18 +-
 .../component/seda/SedaEndpointConfigurer.java     |  40 ++--
 .../service/ServiceComponentConfigurer.java        |   8 +-
 .../service/ServiceEndpointConfigurer.java         |  10 +-
 .../servlet/ServletComponentConfigurer.java        |  20 +-
 .../servlet/ServletEndpointConfigurer.java         |  48 ++---
 .../component/event/EventComponentConfigurer.java  |   6 +-
 .../component/event/EventEndpointConfigurer.java   |  12 +-
 .../component/sql/SqlComponentConfigurer.java      |  10 +-
 .../camel/component/sql/SqlEndpointConfigurer.java |  96 ++++-----
 .../sql/stored/SqlStoredComponentConfigurer.java   |   6 +-
 .../sql/stored/SqlStoredEndpointConfigurer.java    |  18 +-
 .../component/ssh/SshComponentConfigurer.java      |  34 +--
 .../camel/component/ssh/SshEndpointConfigurer.java |  70 +++---
 .../stream/StreamComponentConfigurer.java          |   6 +-
 .../component/stream/StreamEndpointConfigurer.java |  42 ++--
 .../component/timer/TimerComponentConfigurer.java  |   4 +-
 .../component/timer/TimerEndpointConfigurer.java   |  28 +--
 .../undertow/UndertowComponentConfigurer.java      |  20 +-
 .../undertow/UndertowEndpointConfigurer.java       |  60 +++---
 .../validator/ValidatorComponentConfigurer.java    |   6 +-
 .../validator/ValidatorEndpointConfigurer.java     |  24 +--
 .../component/xslt/XsltComponentConfigurer.java    |  14 +-
 .../component/xslt/XsltEndpointConfigurer.java     |  30 +--
 .../dsl/MiloServerComponentBuilderFactory.java     |  45 ++--
 367 files changed, 6000 insertions(+), 6010 deletions(-)

diff --git a/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java b/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java
index e30db8a..2fc1d67 100644
--- a/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java
+++ b/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java
@@ -46,13 +46,13 @@ public class ActiveMQComponentConfigurer extends JmsComponentConfigurer implemen
         ActiveMQComponent target = (ActiveMQComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "brokerurl":
-        case "brokerURL": target.getBrokerURL(); return true;
+        case "brokerURL": return target.getBrokerURL();
         case "trustallpackages":
-        case "trustAllPackages": target.isTrustAllPackages(); return true;
+        case "trustAllPackages": return target.isTrustAllPackages();
         case "usepooledconnection":
-        case "usePooledConnection": target.isUsePooledConnection(); return true;
+        case "usePooledConnection": return target.isUsePooledConnection();
         case "usesingleconnection":
-        case "useSingleConnection": target.isUseSingleConnection(); return true;
+        case "useSingleConnection": return target.isUseSingleConnection();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java
index d9e5392..ade8fcc 100644
--- a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java
+++ b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java
@@ -37,7 +37,7 @@ public class WsComponentConfigurer extends AhcComponentConfigurer implements Gen
         WsComponent target = (WsComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java
index a045b83..be3a22d 100644
--- a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java
+++ b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java
@@ -49,15 +49,15 @@ public class WsEndpointConfigurer extends AhcEndpointConfigurer implements Gener
         WsEndpoint target = (WsEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "sendmessageonerror":
-        case "sendMessageOnError": target.isSendMessageOnError(); return true;
+        case "sendMessageOnError": return target.isSendMessageOnError();
         case "usestreaming":
-        case "useStreaming": target.isUseStreaming(); return true;
+        case "useStreaming": return target.isUseStreaming();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java
index df68745..3a152f2 100644
--- a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java
+++ b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java
@@ -59,21 +59,21 @@ public class AhcComponentConfigurer extends PropertyConfigurerSupport implements
         AhcComponent target = (AhcComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "allowjavaserializedobject":
-        case "allowJavaSerializedObject": target.isAllowJavaSerializedObject(); return true;
+        case "allowJavaSerializedObject": return target.isAllowJavaSerializedObject();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "binding": target.getBinding(); return true;
-        case "client": target.getClient(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "binding": return target.getBinding();
+        case "client": return target.getClient();
         case "clientconfig":
-        case "clientConfig": target.getClientConfig(); return true;
+        case "clientConfig": return target.getClientConfig();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getSslContextParameters(); return true;
+        case "sslContextParameters": return target.getSslContextParameters();
         case "useglobalsslcontextparameters":
-        case "useGlobalSslContextParameters": target.isUseGlobalSslContextParameters(); return true;
+        case "useGlobalSslContextParameters": return target.isUseGlobalSslContextParameters();
         default: return null;
         }
     }
diff --git a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java
index 2343d59..597e0f6 100644
--- a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java
+++ b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java
@@ -77,33 +77,33 @@ public class AhcEndpointConfigurer extends PropertyConfigurerSupport implements
         AhcEndpoint target = (AhcEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "binding": target.getBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "binding": return target.getBinding();
         case "bridgeendpoint":
-        case "bridgeEndpoint": target.isBridgeEndpoint(); return true;
+        case "bridgeEndpoint": return target.isBridgeEndpoint();
         case "buffersize":
-        case "bufferSize": target.getBufferSize(); return true;
+        case "bufferSize": return target.getBufferSize();
         case "clientconfig":
-        case "clientConfig": target.getClientConfig(); return true;
+        case "clientConfig": return target.getClientConfig();
         case "clientconfigoptions":
-        case "clientConfigOptions": target.getClientConfigOptions(); return true;
+        case "clientConfigOptions": return target.getClientConfigOptions();
         case "clientconfigrealmoptions":
-        case "clientConfigRealmOptions": target.getClientConfigRealmOptions(); return true;
+        case "clientConfigRealmOptions": return target.getClientConfigRealmOptions();
         case "connectionclose":
-        case "connectionClose": target.isConnectionClose(); return true;
+        case "connectionClose": return target.isConnectionClose();
         case "cookiehandler":
-        case "cookieHandler": target.getCookieHandler(); return true;
+        case "cookieHandler": return target.getCookieHandler();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getSslContextParameters(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "sslContextParameters": return target.getSslContextParameters();
+        case "synchronous": return target.isSynchronous();
         case "throwexceptiononfailure":
-        case "throwExceptionOnFailure": target.isThrowExceptionOnFailure(); return true;
+        case "throwExceptionOnFailure": return target.isThrowExceptionOnFailure();
         case "transferexception":
-        case "transferException": target.isTransferException(); return true;
+        case "transferException": return target.isTransferException();
         default: return null;
         }
     }
diff --git a/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java b/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java
index 795079e..d1af48c 100644
--- a/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java
+++ b/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java
@@ -37,7 +37,7 @@ public class AMQPComponentConfigurer extends JmsComponentConfigurer implements G
         AMQPComponent target = (AMQPComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "includeamqpannotations":
-        case "includeAmqpAnnotations": target.isIncludeAmqpAnnotations(); return true;
+        case "includeAmqpAnnotations": return target.isIncludeAmqpAnnotations();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java
index 0ed5fe2..2679f24 100644
--- a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java
+++ b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java
@@ -46,13 +46,13 @@ public class ApnsComponentConfigurer extends PropertyConfigurerSupport implement
         ApnsComponent target = (ApnsComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "apnsservice":
-        case "apnsService": target.getApnsService(); return true;
+        case "apnsService": return target.getApnsService();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java
index 123f3d9..20dc6e6 100644
--- a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java
+++ b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java
@@ -98,46 +98,46 @@ public class ApnsEndpointConfigurer extends PropertyConfigurerSupport implements
         ApnsEndpoint target = (ApnsEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
-        case "tokens": target.getTokens(); return true;
+        case "timeUnit": return target.getTimeUnit();
+        case "tokens": return target.getTokens();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         default: return null;
         }
     }
diff --git a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java
index c25885c..337140d 100644
--- a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java
+++ b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java
@@ -45,12 +45,12 @@ public class AS2ComponentConfigurer extends PropertyConfigurerSupport implements
         AS2Component target = (AS2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java
index 91ca0fe..fa2ac28 100644
--- a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java
+++ b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java
@@ -174,96 +174,96 @@ public class AS2EndpointConfigurer extends PropertyConfigurerSupport implements
         AS2Endpoint target = (AS2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "as2from":
-        case "as2From": target.getConfiguration().getAs2From(); return true;
+        case "as2From": return target.getConfiguration().getAs2From();
         case "as2messagestructure":
-        case "as2MessageStructure": target.getConfiguration().getAs2MessageStructure(); return true;
+        case "as2MessageStructure": return target.getConfiguration().getAs2MessageStructure();
         case "as2to":
-        case "as2To": target.getConfiguration().getAs2To(); return true;
+        case "as2To": return target.getConfiguration().getAs2To();
         case "as2version":
-        case "as2Version": target.getConfiguration().getAs2Version(); return true;
+        case "as2Version": return target.getConfiguration().getAs2Version();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "clientfqdn":
-        case "clientFqdn": target.getConfiguration().getClientFqdn(); return true;
+        case "clientFqdn": return target.getConfiguration().getClientFqdn();
         case "compressionalgorithm":
-        case "compressionAlgorithm": target.getConfiguration().getCompressionAlgorithm(); return true;
+        case "compressionAlgorithm": return target.getConfiguration().getCompressionAlgorithm();
         case "decryptingprivatekey":
-        case "decryptingPrivateKey": target.getConfiguration().getDecryptingPrivateKey(); return true;
-        case "delay": target.getDelay(); return true;
+        case "decryptingPrivateKey": return target.getConfiguration().getDecryptingPrivateKey();
+        case "delay": return target.getDelay();
         case "dispositionnotificationto":
-        case "dispositionNotificationTo": target.getConfiguration().getDispositionNotificationTo(); return true;
+        case "dispositionNotificationTo": return target.getConfiguration().getDispositionNotificationTo();
         case "edimessagetransferencoding":
-        case "ediMessageTransferEncoding": target.getConfiguration().getEdiMessageTransferEncoding(); return true;
+        case "ediMessageTransferEncoding": return target.getConfiguration().getEdiMessageTransferEncoding();
         case "edimessagetype":
-        case "ediMessageType": target.getConfiguration().getEdiMessageType(); return true;
+        case "ediMessageType": return target.getConfiguration().getEdiMessageType();
         case "encryptingalgorithm":
-        case "encryptingAlgorithm": target.getConfiguration().getEncryptingAlgorithm(); return true;
+        case "encryptingAlgorithm": return target.getConfiguration().getEncryptingAlgorithm();
         case "encryptingcertificatechain":
-        case "encryptingCertificateChain": target.getConfiguration().getEncryptingCertificateChain(); return true;
+        case "encryptingCertificateChain": return target.getConfiguration().getEncryptingCertificateChain();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "from": target.getConfiguration().getFrom(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "from": return target.getConfiguration().getFrom();
+        case "greedy": return target.isGreedy();
         case "inbody":
-        case "inBody": target.getInBody(); return true;
+        case "inBody": return target.getInBody();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "mdnmessagetemplate":
-        case "mdnMessageTemplate": target.getConfiguration().getMdnMessageTemplate(); return true;
+        case "mdnMessageTemplate": return target.getConfiguration().getMdnMessageTemplate();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "requesturi":
-        case "requestUri": target.getConfiguration().getRequestUri(); return true;
+        case "requestUri": return target.getConfiguration().getRequestUri();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
-        case "server": target.getConfiguration().getServer(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
+        case "server": return target.getConfiguration().getServer();
         case "serverfqdn":
-        case "serverFqdn": target.getConfiguration().getServerFqdn(); return true;
+        case "serverFqdn": return target.getConfiguration().getServerFqdn();
         case "serverportnumber":
-        case "serverPortNumber": target.getConfiguration().getServerPortNumber(); return true;
+        case "serverPortNumber": return target.getConfiguration().getServerPortNumber();
         case "signedreceiptmicalgorithms":
-        case "signedReceiptMicAlgorithms": target.getConfiguration().getSignedReceiptMicAlgorithms(); return true;
+        case "signedReceiptMicAlgorithms": return target.getConfiguration().getSignedReceiptMicAlgorithms();
         case "signingalgorithm":
-        case "signingAlgorithm": target.getConfiguration().getSigningAlgorithm(); return true;
+        case "signingAlgorithm": return target.getConfiguration().getSigningAlgorithm();
         case "signingcertificatechain":
-        case "signingCertificateChain": target.getConfiguration().getSigningCertificateChain(); return true;
+        case "signingCertificateChain": return target.getConfiguration().getSigningCertificateChain();
         case "signingprivatekey":
-        case "signingPrivateKey": target.getConfiguration().getSigningPrivateKey(); return true;
+        case "signingPrivateKey": return target.getConfiguration().getSigningPrivateKey();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "subject": target.getConfiguration().getSubject(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "subject": return target.getConfiguration().getSubject();
+        case "synchronous": return target.isSynchronous();
         case "targethostname":
-        case "targetHostname": target.getConfiguration().getTargetHostname(); return true;
+        case "targetHostname": return target.getConfiguration().getTargetHostname();
         case "targetportnumber":
-        case "targetPortNumber": target.getConfiguration().getTargetPortNumber(); return true;
+        case "targetPortNumber": return target.getConfiguration().getTargetPortNumber();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         case "useragent":
-        case "userAgent": target.getConfiguration().getUserAgent(); return true;
+        case "userAgent": return target.getConfiguration().getUserAgent();
         default: return null;
         }
     }
diff --git a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java
index c43c730..65e1469 100644
--- a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java
+++ b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java
@@ -43,11 +43,11 @@ public class AsteriskComponentConfigurer extends PropertyConfigurerSupport imple
         AsteriskComponent target = (AsteriskComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java
index bc11d69..241f035 100644
--- a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java
+++ b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java
@@ -58,21 +58,21 @@ public class AsteriskEndpointConfigurer extends PropertyConfigurerSupport implem
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AsteriskEndpoint target = (AsteriskEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "action": target.getAction(); return true;
+        case "action": return target.getAction();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "hostname": target.getHostname(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "hostname": return target.getHostname();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "password": target.getPassword(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "username": target.getUsername(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "password": return target.getPassword();
+        case "synchronous": return target.isSynchronous();
+        case "username": return target.getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java
index e996507..5ea9ab6 100644
--- a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java
+++ b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java
@@ -54,18 +54,18 @@ public class AtmosComponentConfigurer extends PropertyConfigurerSupport implemen
         AtmosComponent target = (AtmosComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "fulltokenid":
-        case "fullTokenId": target.getFullTokenId(); return true;
+        case "fullTokenId": return target.getFullTokenId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "secretkey":
-        case "secretKey": target.getSecretKey(); return true;
+        case "secretKey": return target.getSecretKey();
         case "sslvalidation":
-        case "sslValidation": target.isSslValidation(); return true;
-        case "uri": target.getUri(); return true;
+        case "sslValidation": return target.isSslValidation();
+        case "uri": return target.getUri();
         default: return null;
         }
     }
diff --git a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java
index d067493..dfa6424 100644
--- a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java
+++ b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java
@@ -73,30 +73,30 @@ public class AtmosEndpointConfigurer extends PropertyConfigurerSupport implement
         AtmosEndpoint target = (AtmosEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "fulltokenid":
-        case "fullTokenId": target.getConfiguration().getFullTokenId(); return true;
+        case "fullTokenId": return target.getConfiguration().getFullTokenId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "localpath":
-        case "localPath": target.getConfiguration().getLocalPath(); return true;
+        case "localPath": return target.getConfiguration().getLocalPath();
         case "newremotepath":
-        case "newRemotePath": target.getConfiguration().getNewRemotePath(); return true;
-        case "query": target.getConfiguration().getQuery(); return true;
+        case "newRemotePath": return target.getConfiguration().getNewRemotePath();
+        case "query": return target.getConfiguration().getQuery();
         case "remotepath":
-        case "remotePath": target.getConfiguration().getRemotePath(); return true;
+        case "remotePath": return target.getConfiguration().getRemotePath();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sslvalidation":
-        case "sslValidation": target.getConfiguration().isSslValidation(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "uri": target.getConfiguration().getUri(); return true;
+        case "sslValidation": return target.getConfiguration().isSslValidation();
+        case "synchronous": return target.isSynchronous();
+        case "uri": return target.getConfiguration().getUri();
         default: return null;
         }
     }
diff --git a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java
index 1e0f7ed..a7a6e20 100644
--- a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java
+++ b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java
@@ -37,7 +37,7 @@ public class WebsocketComponentConfigurer extends ServletComponentConfigurer imp
         WebsocketComponent target = (WebsocketComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java
index c7629d9..c49570b 100644
--- a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java
+++ b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java
@@ -82,37 +82,37 @@ public class WebsocketEndpointConfigurer extends ServletEndpointConfigurer imple
         WebsocketEndpoint target = (WebsocketEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "authhost":
-        case "authHost": target.getAuthHost(); return true;
+        case "authHost": return target.getAuthHost();
         case "bridgeendpoint":
-        case "bridgeEndpoint": target.isBridgeEndpoint(); return true;
+        case "bridgeEndpoint": return target.isBridgeEndpoint();
         case "connectionclose":
-        case "connectionClose": target.isConnectionClose(); return true;
+        case "connectionClose": return target.isConnectionClose();
         case "cookiehandler":
-        case "cookieHandler": target.getCookieHandler(); return true;
+        case "cookieHandler": return target.getCookieHandler();
         case "copyheaders":
-        case "copyHeaders": target.isCopyHeaders(); return true;
+        case "copyHeaders": return target.isCopyHeaders();
         case "httpmethod":
-        case "httpMethod": target.getHttpMethod(); return true;
+        case "httpMethod": return target.getHttpMethod();
         case "ignoreresponsebody":
-        case "ignoreResponseBody": target.isIgnoreResponseBody(); return true;
+        case "ignoreResponseBody": return target.isIgnoreResponseBody();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "okstatuscoderange":
-        case "okStatusCodeRange": target.getOkStatusCodeRange(); return true;
+        case "okStatusCodeRange": return target.getOkStatusCodeRange();
         case "preservehostheader":
-        case "preserveHostHeader": target.isPreserveHostHeader(); return true;
+        case "preserveHostHeader": return target.isPreserveHostHeader();
         case "proxyauthscheme":
-        case "proxyAuthScheme": target.getProxyAuthScheme(); return true;
+        case "proxyAuthScheme": return target.getProxyAuthScheme();
         case "proxyhost":
-        case "proxyHost": target.getProxyHost(); return true;
+        case "proxyHost": return target.getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getProxyPort(); return true;
+        case "proxyPort": return target.getProxyPort();
         case "sendtoall":
-        case "sendToAll": target.isSendToAll(); return true;
+        case "sendToAll": return target.isSendToAll();
         case "throwexceptiononfailure":
-        case "throwExceptionOnFailure": target.isThrowExceptionOnFailure(); return true;
+        case "throwExceptionOnFailure": return target.isThrowExceptionOnFailure();
         case "usestreaming":
-        case "useStreaming": target.isUseStreaming(); return true;
+        case "useStreaming": return target.isUseStreaming();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java
index eae0d44..a5bda1b 100644
--- a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java
+++ b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java
@@ -40,9 +40,9 @@ public class AtomComponentConfigurer extends PropertyConfigurerSupport implement
         AtomComponent target = (AtomComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         default: return null;
         }
     }
diff --git a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java
index 54fc5c3..e27297b 100644
--- a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java
+++ b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java
@@ -114,56 +114,56 @@ public class AtomEndpointConfigurer extends PropertyConfigurerSupport implements
         AtomEndpoint target = (AtomEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "feedheader":
-        case "feedHeader": target.isFeedHeader(); return true;
-        case "filter": target.isFilter(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "feedHeader": return target.isFeedHeader();
+        case "filter": return target.isFilter();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "lastupdate":
-        case "lastUpdate": target.getLastUpdate(); return true;
-        case "password": target.getPassword(); return true;
+        case "lastUpdate": return target.getLastUpdate();
+        case "password": return target.getPassword();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "sortentries":
-        case "sortEntries": target.isSortEntries(); return true;
+        case "sortEntries": return target.isSortEntries();
         case "splitentries":
-        case "splitEntries": target.isSplitEntries(); return true;
+        case "splitEntries": return target.isSplitEntries();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "throttleentries":
-        case "throttleEntries": target.isThrottleEntries(); return true;
+        case "throttleEntries": return target.isThrottleEntries();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
-        case "username": target.getUsername(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
+        case "username": return target.getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java
index 09bc976..2bc90c2 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java
@@ -88,36 +88,36 @@ public class AtomixMapComponentConfigurer extends PropertyConfigurerSupport impl
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixMapComponent target = (AtomixMapComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "atomix": return getOrCreateConfiguration(target).getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "configurationuri":
-        case "configurationUri": target.getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultAction": return getOrCreateConfiguration(target).getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return getOrCreateConfiguration(target).getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
-        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
-        case "key": getOrCreateConfiguration(target).getKey(); return true;
+        case "defaultResourceOptions": return getOrCreateConfiguration(target).getDefaultResourceOptions();
+        case "ephemeral": return getOrCreateConfiguration(target).isEphemeral();
+        case "key": return getOrCreateConfiguration(target).getKey();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getNodes();
         case "readconsistency":
-        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "readConsistency": return getOrCreateConfiguration(target).getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceConfigs": return getOrCreateConfiguration(target).getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resourceOptions": return getOrCreateConfiguration(target).getResourceOptions();
         case "resultheader":
-        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "resultHeader": return getOrCreateConfiguration(target).getResultHeader();
         case "transportclassname":
-        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
-        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        case "transportClassName": return getOrCreateConfiguration(target).getTransportClassName();
+        case "ttl": return getOrCreateConfiguration(target).getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java
index 6abaf51..b54e2ff 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java
@@ -87,40 +87,40 @@ public class AtomixMapEndpointConfigurer extends PropertyConfigurerSupport imple
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixMapEndpoint target = (AtomixMapEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "atomix": return target.getConfiguration().getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "configurationuri":
-        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfiguration().getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultAction": return target.getConfiguration().getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return target.getConfiguration().getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
-        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "defaultResourceOptions": return target.getConfiguration().getDefaultResourceOptions();
+        case "ephemeral": return target.getConfiguration().isEphemeral();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "key": target.getConfiguration().getKey(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "key": return target.getConfiguration().getKey();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getConfiguration().getNodes();
         case "readconsistency":
-        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "readConsistency": return target.getConfiguration().getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceConfigs": return target.getConfiguration().getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resourceOptions": return target.getConfiguration().getResourceOptions();
         case "resultheader":
-        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "resultHeader": return target.getConfiguration().getResultHeader();
+        case "synchronous": return target.isSynchronous();
         case "transportclassname":
-        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
-        case "ttl": target.getConfiguration().getTtl(); return true;
+        case "transportClassName": return target.getConfiguration().getTransportClassName();
+        case "ttl": return target.getConfiguration().getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java
index 5e65abf..d70fc2e 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java
@@ -93,40 +93,40 @@ public class AtomixMessagingComponentConfigurer extends PropertyConfigurerSuppor
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixMessagingComponent target = (AtomixMessagingComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "atomix": return getOrCreateConfiguration(target).getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "broadcasttype":
-        case "broadcastType": getOrCreateConfiguration(target).getBroadcastType(); return true;
+        case "broadcastType": return getOrCreateConfiguration(target).getBroadcastType();
         case "channelname":
-        case "channelName": getOrCreateConfiguration(target).getChannelName(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "channelName": return getOrCreateConfiguration(target).getChannelName();
+        case "configuration": return target.getConfiguration();
         case "configurationuri":
-        case "configurationUri": target.getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultAction": return getOrCreateConfiguration(target).getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return getOrCreateConfiguration(target).getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
-        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "defaultResourceOptions": return getOrCreateConfiguration(target).getDefaultResourceOptions();
+        case "ephemeral": return getOrCreateConfiguration(target).isEphemeral();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "membername":
-        case "memberName": getOrCreateConfiguration(target).getMemberName(); return true;
-        case "nodes": target.getNodes(); return true;
+        case "memberName": return getOrCreateConfiguration(target).getMemberName();
+        case "nodes": return target.getNodes();
         case "readconsistency":
-        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "readConsistency": return getOrCreateConfiguration(target).getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceConfigs": return getOrCreateConfiguration(target).getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resourceOptions": return getOrCreateConfiguration(target).getResourceOptions();
         case "resultheader":
-        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "resultHeader": return getOrCreateConfiguration(target).getResultHeader();
         case "transportclassname":
-        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        case "transportClassName": return getOrCreateConfiguration(target).getTransportClassName();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java
index c79eaf4..bce0cc9 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java
@@ -92,44 +92,44 @@ public class AtomixMessagingEndpointConfigurer extends PropertyConfigurerSupport
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixMessagingEndpoint target = (AtomixMessagingEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "atomix": return target.getConfiguration().getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "broadcasttype":
-        case "broadcastType": target.getConfiguration().getBroadcastType(); return true;
+        case "broadcastType": return target.getConfiguration().getBroadcastType();
         case "channelname":
-        case "channelName": target.getConfiguration().getChannelName(); return true;
+        case "channelName": return target.getConfiguration().getChannelName();
         case "configurationuri":
-        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfiguration().getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultAction": return target.getConfiguration().getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return target.getConfiguration().getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
-        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "defaultResourceOptions": return target.getConfiguration().getDefaultResourceOptions();
+        case "ephemeral": return target.getConfiguration().isEphemeral();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "membername":
-        case "memberName": target.getConfiguration().getMemberName(); return true;
-        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "memberName": return target.getConfiguration().getMemberName();
+        case "nodes": return target.getConfiguration().getNodes();
         case "readconsistency":
-        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "readConsistency": return target.getConfiguration().getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceConfigs": return target.getConfiguration().getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resourceOptions": return target.getConfiguration().getResourceOptions();
         case "resultheader":
-        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "resultHeader": return target.getConfiguration().getResultHeader();
+        case "synchronous": return target.isSynchronous();
         case "transportclassname":
-        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        case "transportClassName": return target.getConfiguration().getTransportClassName();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java
index 83802ef..9a9daad 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java
@@ -85,34 +85,34 @@ public class AtomixMultiMapComponentConfigurer extends PropertyConfigurerSupport
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixMultiMapComponent target = (AtomixMultiMapComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "atomix": return getOrCreateConfiguration(target).getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "configurationuri":
-        case "configurationUri": target.getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultAction": return getOrCreateConfiguration(target).getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return getOrCreateConfiguration(target).getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
-        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
-        case "key": getOrCreateConfiguration(target).getKey(); return true;
+        case "defaultResourceOptions": return getOrCreateConfiguration(target).getDefaultResourceOptions();
+        case "ephemeral": return getOrCreateConfiguration(target).isEphemeral();
+        case "key": return getOrCreateConfiguration(target).getKey();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getNodes();
         case "readconsistency":
-        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "readConsistency": return getOrCreateConfiguration(target).getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceConfigs": return getOrCreateConfiguration(target).getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resourceOptions": return getOrCreateConfiguration(target).getResourceOptions();
         case "resultheader":
-        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "resultHeader": return getOrCreateConfiguration(target).getResultHeader();
         case "transportclassname":
-        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
-        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        case "transportClassName": return getOrCreateConfiguration(target).getTransportClassName();
+        case "ttl": return getOrCreateConfiguration(target).getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java
index 9c3c352..6b500b9 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java
@@ -78,34 +78,34 @@ public class AtomixMultiMapEndpointConfigurer extends PropertyConfigurerSupport
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixMultiMapEndpoint target = (AtomixMultiMapEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "atomix": return target.getConfiguration().getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "configurationuri":
-        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfiguration().getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultAction": return target.getConfiguration().getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return target.getConfiguration().getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
-        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
-        case "key": target.getConfiguration().getKey(); return true;
+        case "defaultResourceOptions": return target.getConfiguration().getDefaultResourceOptions();
+        case "ephemeral": return target.getConfiguration().isEphemeral();
+        case "key": return target.getConfiguration().getKey();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getConfiguration().getNodes();
         case "readconsistency":
-        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "readConsistency": return target.getConfiguration().getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceConfigs": return target.getConfiguration().getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resourceOptions": return target.getConfiguration().getResourceOptions();
         case "resultheader":
-        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "resultHeader": return target.getConfiguration().getResultHeader();
+        case "synchronous": return target.isSynchronous();
         case "transportclassname":
-        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
-        case "ttl": target.getConfiguration().getTtl(); return true;
+        case "transportClassName": return target.getConfiguration().getTransportClassName();
+        case "ttl": return target.getConfiguration().getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java
index 2f02ca5..10fc51a 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java
@@ -84,34 +84,34 @@ public class AtomixQueueComponentConfigurer extends PropertyConfigurerSupport im
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixQueueComponent target = (AtomixQueueComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "atomix": return getOrCreateConfiguration(target).getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "configurationuri":
-        case "configurationUri": target.getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultAction": return getOrCreateConfiguration(target).getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return getOrCreateConfiguration(target).getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
-        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "defaultResourceOptions": return getOrCreateConfiguration(target).getDefaultResourceOptions();
+        case "ephemeral": return getOrCreateConfiguration(target).isEphemeral();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getNodes();
         case "readconsistency":
-        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "readConsistency": return getOrCreateConfiguration(target).getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceConfigs": return getOrCreateConfiguration(target).getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resourceOptions": return getOrCreateConfiguration(target).getResourceOptions();
         case "resultheader":
-        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "resultHeader": return getOrCreateConfiguration(target).getResultHeader();
         case "transportclassname":
-        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        case "transportClassName": return getOrCreateConfiguration(target).getTransportClassName();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java
index 0750d5e..834c4f9 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java
@@ -83,38 +83,38 @@ public class AtomixQueueEndpointConfigurer extends PropertyConfigurerSupport imp
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixQueueEndpoint target = (AtomixQueueEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "atomix": return target.getConfiguration().getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "configurationuri":
-        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfiguration().getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultAction": return target.getConfiguration().getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return target.getConfiguration().getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
-        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "defaultResourceOptions": return target.getConfiguration().getDefaultResourceOptions();
+        case "ephemeral": return target.getConfiguration().isEphemeral();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getConfiguration().getNodes();
         case "readconsistency":
-        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "readConsistency": return target.getConfiguration().getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceConfigs": return target.getConfiguration().getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resourceOptions": return target.getConfiguration().getResourceOptions();
         case "resultheader":
-        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "resultHeader": return target.getConfiguration().getResultHeader();
+        case "synchronous": return target.isSynchronous();
         case "transportclassname":
-        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        case "transportClassName": return target.getConfiguration().getTransportClassName();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java
index a8bf920..32429f4 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java
@@ -86,35 +86,35 @@ public class AtomixSetComponentConfigurer extends PropertyConfigurerSupport impl
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixSetComponent target = (AtomixSetComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "atomix": return getOrCreateConfiguration(target).getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "configurationuri":
-        case "configurationUri": target.getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultAction": return getOrCreateConfiguration(target).getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return getOrCreateConfiguration(target).getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
-        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "defaultResourceOptions": return getOrCreateConfiguration(target).getDefaultResourceOptions();
+        case "ephemeral": return getOrCreateConfiguration(target).isEphemeral();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getNodes();
         case "readconsistency":
-        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "readConsistency": return getOrCreateConfiguration(target).getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceConfigs": return getOrCreateConfiguration(target).getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resourceOptions": return getOrCreateConfiguration(target).getResourceOptions();
         case "resultheader":
-        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "resultHeader": return getOrCreateConfiguration(target).getResultHeader();
         case "transportclassname":
-        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
-        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        case "transportClassName": return getOrCreateConfiguration(target).getTransportClassName();
+        case "ttl": return getOrCreateConfiguration(target).getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java
index 85c0c80..be1291a 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java
@@ -85,39 +85,39 @@ public class AtomixSetEndpointConfigurer extends PropertyConfigurerSupport imple
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixSetEndpoint target = (AtomixSetEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "atomix": return target.getConfiguration().getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "configurationuri":
-        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfiguration().getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultAction": return target.getConfiguration().getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return target.getConfiguration().getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
-        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "defaultResourceOptions": return target.getConfiguration().getDefaultResourceOptions();
+        case "ephemeral": return target.getConfiguration().isEphemeral();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getConfiguration().getNodes();
         case "readconsistency":
-        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "readConsistency": return target.getConfiguration().getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceConfigs": return target.getConfiguration().getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resourceOptions": return target.getConfiguration().getResourceOptions();
         case "resultheader":
-        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "resultHeader": return target.getConfiguration().getResultHeader();
+        case "synchronous": return target.isSynchronous();
         case "transportclassname":
-        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
-        case "ttl": target.getConfiguration().getTtl(); return true;
+        case "transportClassName": return target.getConfiguration().getTransportClassName();
+        case "ttl": return target.getConfiguration().getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java
index 83ddf7f..b433774 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java
@@ -86,35 +86,35 @@ public class AtomixValueComponentConfigurer extends PropertyConfigurerSupport im
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixValueComponent target = (AtomixValueComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "atomix": return getOrCreateConfiguration(target).getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "configurationuri":
-        case "configurationUri": target.getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultAction": return getOrCreateConfiguration(target).getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return getOrCreateConfiguration(target).getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
-        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "defaultResourceOptions": return getOrCreateConfiguration(target).getDefaultResourceOptions();
+        case "ephemeral": return getOrCreateConfiguration(target).isEphemeral();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getNodes();
         case "readconsistency":
-        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "readConsistency": return getOrCreateConfiguration(target).getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceConfigs": return getOrCreateConfiguration(target).getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resourceOptions": return getOrCreateConfiguration(target).getResourceOptions();
         case "resultheader":
-        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "resultHeader": return getOrCreateConfiguration(target).getResultHeader();
         case "transportclassname":
-        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
-        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        case "transportClassName": return getOrCreateConfiguration(target).getTransportClassName();
+        case "ttl": return getOrCreateConfiguration(target).getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java
index 5fcffae..f8eb04b 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java
@@ -85,39 +85,39 @@ public class AtomixValueEndpointConfigurer extends PropertyConfigurerSupport imp
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         AtomixValueEndpoint target = (AtomixValueEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "atomix": return target.getConfiguration().getAtomix();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "configurationuri":
-        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "configurationUri": return target.getConfiguration().getConfigurationUri();
         case "defaultaction":
-        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultAction": return target.getConfiguration().getDefaultAction();
         case "defaultresourceconfig":
-        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultResourceConfig": return target.getConfiguration().getDefaultResourceConfig();
         case "defaultresourceoptions":
-        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
-        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "defaultResourceOptions": return target.getConfiguration().getDefaultResourceOptions();
+        case "ephemeral": return target.getConfiguration().isEphemeral();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "nodes": return target.getConfiguration().getNodes();
         case "readconsistency":
-        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "readConsistency": return target.getConfiguration().getReadConsistency();
         case "resourceconfigs":
-        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceConfigs": return target.getConfiguration().getResourceConfigs();
         case "resourceoptions":
-        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resourceOptions": return target.getConfiguration().getResourceOptions();
         case "resultheader":
-        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "resultHeader": return target.getConfiguration().getResultHeader();
+        case "synchronous": return target.isSynchronous();
         case "transportclassname":
-        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
-        case "ttl": target.getConfiguration().getTtl(); return true;
+        case "transportClassName": return target.getConfiguration().getTransportClassName();
+        case "ttl": return target.getConfiguration().getTtl();
         default: return null;
         }
     }
diff --git a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java
index 7333d18..dc82b58 100644
--- a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java
+++ b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java
@@ -69,23 +69,23 @@ public class AvroComponentConfigurer extends PropertyConfigurerSupport implement
         AvroComponent target = (AvroComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "protocol": getOrCreateConfiguration(target).getProtocol(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "protocol": return getOrCreateConfiguration(target).getProtocol();
         case "protocolclassname":
-        case "protocolClassName": getOrCreateConfiguration(target).getProtocolClassName(); return true;
+        case "protocolClassName": return getOrCreateConfiguration(target).getProtocolClassName();
         case "protocollocation":
-        case "protocolLocation": getOrCreateConfiguration(target).getProtocolLocation(); return true;
+        case "protocolLocation": return getOrCreateConfiguration(target).getProtocolLocation();
         case "reflectionprotocol":
-        case "reflectionProtocol": getOrCreateConfiguration(target).isReflectionProtocol(); return true;
+        case "reflectionProtocol": return getOrCreateConfiguration(target).isReflectionProtocol();
         case "singleparameter":
-        case "singleParameter": getOrCreateConfiguration(target).isSingleParameter(); return true;
+        case "singleParameter": return getOrCreateConfiguration(target).isSingleParameter();
         case "uriauthority":
-        case "uriAuthority": getOrCreateConfiguration(target).getUriAuthority(); return true;
+        case "uriAuthority": return getOrCreateConfiguration(target).getUriAuthority();
         default: return null;
         }
     }
diff --git a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java
index 54f4226..8d86da5 100644
--- a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java
+++ b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java
@@ -68,27 +68,27 @@ public class AvroEndpointConfigurer extends PropertyConfigurerSupport implements
         AvroEndpoint target = (AvroEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "protocol": target.getConfiguration().getProtocol(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "protocol": return target.getConfiguration().getProtocol();
         case "protocolclassname":
-        case "protocolClassName": target.getConfiguration().getProtocolClassName(); return true;
+        case "protocolClassName": return target.getConfiguration().getProtocolClassName();
         case "protocollocation":
-        case "protocolLocation": target.getConfiguration().getProtocolLocation(); return true;
+        case "protocolLocation": return target.getConfiguration().getProtocolLocation();
         case "reflectionprotocol":
-        case "reflectionProtocol": target.getConfiguration().isReflectionProtocol(); return true;
+        case "reflectionProtocol": return target.getConfiguration().isReflectionProtocol();
         case "singleparameter":
-        case "singleParameter": target.getConfiguration().isSingleParameter(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "singleParameter": return target.getConfiguration().isSingleParameter();
+        case "synchronous": return target.isSynchronous();
         case "uriauthority":
-        case "uriAuthority": target.getConfiguration().getUriAuthority(); return true;
+        case "uriAuthority": return target.getConfiguration().getUriAuthority();
         default: return null;
         }
     }
diff --git a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java
index 32c8cd2..c3cb310 100644
--- a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java
+++ b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java
@@ -77,27 +77,27 @@ public class CwComponentConfigurer extends PropertyConfigurerSupport implements
         CwComponent target = (CwComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazoncwclient":
-        case "amazonCwClient": getOrCreateConfiguration(target).getAmazonCwClient(); return true;
+        case "amazonCwClient": return getOrCreateConfiguration(target).getAmazonCwClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "name": getOrCreateConfiguration(target).getName(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "name": return getOrCreateConfiguration(target).getName();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
-        case "timestamp": getOrCreateConfiguration(target).getTimestamp(); return true;
-        case "unit": getOrCreateConfiguration(target).getUnit(); return true;
-        case "value": getOrCreateConfiguration(target).getValue(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
+        case "timestamp": return getOrCreateConfiguration(target).getTimestamp();
+        case "unit": return getOrCreateConfiguration(target).getUnit();
+        case "value": return getOrCreateConfiguration(target).getValue();
         default: return null;
         }
     }
diff --git a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java
index 2a2c640..b05d25d 100644
--- a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java
+++ b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java
@@ -70,27 +70,27 @@ public class CwEndpointConfigurer extends PropertyConfigurerSupport implements G
         CwEndpoint target = (CwEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazoncwclient":
-        case "amazonCwClient": target.getConfiguration().getAmazonCwClient(); return true;
+        case "amazonCwClient": return target.getConfiguration().getAmazonCwClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "name": target.getConfiguration().getName(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "name": return target.getConfiguration().getName();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "timestamp": target.getConfiguration().getTimestamp(); return true;
-        case "unit": target.getConfiguration().getUnit(); return true;
-        case "value": target.getConfiguration().getValue(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
+        case "timestamp": return target.getConfiguration().getTimestamp();
+        case "unit": return target.getConfiguration().getUnit();
+        case "value": return target.getConfiguration().getValue();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java
index 2d41f0f..6fd18e2 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java
@@ -86,34 +86,34 @@ public class DdbComponentConfigurer extends PropertyConfigurerSupport implements
         DdbComponent target = (DdbComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonddbclient":
-        case "amazonDDBClient": getOrCreateConfiguration(target).getAmazonDDBClient(); return true;
+        case "amazonDDBClient": return getOrCreateConfiguration(target).getAmazonDDBClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "consistentread":
-        case "consistentRead": getOrCreateConfiguration(target).isConsistentRead(); return true;
+        case "consistentRead": return getOrCreateConfiguration(target).isConsistentRead();
         case "keyattributename":
-        case "keyAttributeName": getOrCreateConfiguration(target).getKeyAttributeName(); return true;
+        case "keyAttributeName": return getOrCreateConfiguration(target).getKeyAttributeName();
         case "keyattributetype":
-        case "keyAttributeType": getOrCreateConfiguration(target).getKeyAttributeType(); return true;
+        case "keyAttributeType": return getOrCreateConfiguration(target).getKeyAttributeType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
         case "readcapacity":
-        case "readCapacity": getOrCreateConfiguration(target).getReadCapacity(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "readCapacity": return getOrCreateConfiguration(target).getReadCapacity();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "writecapacity":
-        case "writeCapacity": getOrCreateConfiguration(target).getWriteCapacity(); return true;
+        case "writeCapacity": return getOrCreateConfiguration(target).getWriteCapacity();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java
index acc244c..5fb12ff 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java
@@ -79,34 +79,34 @@ public class DdbEndpointConfigurer extends PropertyConfigurerSupport implements
         DdbEndpoint target = (DdbEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonddbclient":
-        case "amazonDDBClient": target.getConfiguration().getAmazonDDBClient(); return true;
+        case "amazonDDBClient": return target.getConfiguration().getAmazonDDBClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "consistentread":
-        case "consistentRead": target.getConfiguration().isConsistentRead(); return true;
+        case "consistentRead": return target.getConfiguration().isConsistentRead();
         case "keyattributename":
-        case "keyAttributeName": target.getConfiguration().getKeyAttributeName(); return true;
+        case "keyAttributeName": return target.getConfiguration().getKeyAttributeName();
         case "keyattributetype":
-        case "keyAttributeType": target.getConfiguration().getKeyAttributeType(); return true;
+        case "keyAttributeType": return target.getConfiguration().getKeyAttributeType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
         case "readcapacity":
-        case "readCapacity": target.getConfiguration().getReadCapacity(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "readCapacity": return target.getConfiguration().getReadCapacity();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         case "writecapacity":
-        case "writeCapacity": target.getConfiguration().getWriteCapacity(); return true;
+        case "writeCapacity": return target.getConfiguration().getWriteCapacity();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java
index 25bf78c..f31eb2a 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java
@@ -78,29 +78,29 @@ public class DdbStreamComponentConfigurer extends PropertyConfigurerSupport impl
         DdbStreamComponent target = (DdbStreamComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazondynamodbstreamsclient":
-        case "amazonDynamoDbStreamsClient": getOrCreateConfiguration(target).getAmazonDynamoDbStreamsClient(); return true;
+        case "amazonDynamoDbStreamsClient": return getOrCreateConfiguration(target).getAmazonDynamoDbStreamsClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "iteratortype":
-        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "iteratorType": return getOrCreateConfiguration(target).getIteratorType();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return getOrCreateConfiguration(target).getMaxResultsPerRequest();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "sequencenumberprovider":
-        case "sequenceNumberProvider": getOrCreateConfiguration(target).getSequenceNumberProvider(); return true;
+        case "sequenceNumberProvider": return getOrCreateConfiguration(target).getSequenceNumberProvider();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java
index 15c767e..f304928 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java
@@ -122,62 +122,62 @@ public class DdbStreamEndpointConfigurer extends PropertyConfigurerSupport imple
         DdbStreamEndpoint target = (DdbStreamEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazondynamodbstreamsclient":
-        case "amazonDynamoDbStreamsClient": target.getConfiguration().getAmazonDynamoDbStreamsClient(); return true;
+        case "amazonDynamoDbStreamsClient": return target.getConfiguration().getAmazonDynamoDbStreamsClient();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "iteratortype":
-        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "iteratorType": return target.getConfiguration().getIteratorType();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return target.getConfiguration().getMaxResultsPerRequest();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "sequencenumberprovider":
-        case "sequenceNumberProvider": target.getConfiguration().getSequenceNumberProvider(); return true;
+        case "sequenceNumberProvider": return target.getConfiguration().getSequenceNumberProvider();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java
index 1dcea65..f37d4d5 100644
--- a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java
+++ b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class EC2ComponentConfigurer extends PropertyConfigurerSupport implements
         EC2Component target = (EC2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonec2client":
-        case "amazonEc2Client": getOrCreateConfiguration(target).getAmazonEc2Client(); return true;
+        case "amazonEc2Client": return getOrCreateConfiguration(target).getAmazonEc2Client();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java
index 0a13970..e32e676 100644
--- a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java
+++ b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class EC2EndpointConfigurer extends PropertyConfigurerSupport implements
         EC2Endpoint target = (EC2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonec2client":
-        case "amazonEc2Client": target.getConfiguration().getAmazonEc2Client(); return true;
+        case "amazonEc2Client": return target.getConfiguration().getAmazonEc2Client();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java
index 371881c..e0c905b 100644
--- a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java
+++ b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java
@@ -71,24 +71,24 @@ public class ECSComponentConfigurer extends PropertyConfigurerSupport implements
         ECSComponent target = (ECSComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "ecsclient":
-        case "ecsClient": getOrCreateConfiguration(target).getEcsClient(); return true;
+        case "ecsClient": return getOrCreateConfiguration(target).getEcsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java
index 9817e5b..1eb82e6 100644
--- a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java
+++ b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java
@@ -64,24 +64,24 @@ public class ECSEndpointConfigurer extends PropertyConfigurerSupport implements
         ECSEndpoint target = (ECSEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "ecsclient":
-        case "ecsClient": target.getConfiguration().getEcsClient(); return true;
+        case "ecsClient": return target.getConfiguration().getEcsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java
index c84df26..9529b52 100644
--- a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java
+++ b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java
@@ -71,24 +71,24 @@ public class EKSComponentConfigurer extends PropertyConfigurerSupport implements
         EKSComponent target = (EKSComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "eksclient":
-        case "eksClient": getOrCreateConfiguration(target).getEksClient(); return true;
+        case "eksClient": return getOrCreateConfiguration(target).getEksClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java
index 6e86b76..caaff33 100644
--- a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java
+++ b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java
@@ -64,24 +64,24 @@ public class EKSEndpointConfigurer extends PropertyConfigurerSupport implements
         EKSEndpoint target = (EKSEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "eksclient":
-        case "eksClient": target.getConfiguration().getEksClient(); return true;
+        case "eksClient": return target.getConfiguration().getEksClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java
index 2236671..03de71a 100644
--- a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java
+++ b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java
@@ -71,24 +71,24 @@ public class IAMComponentConfigurer extends PropertyConfigurerSupport implements
         IAMComponent target = (IAMComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "iamclient":
-        case "iamClient": getOrCreateConfiguration(target).getIamClient(); return true;
+        case "iamClient": return getOrCreateConfiguration(target).getIamClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java
index dd9d3ef..929f5cf 100644
--- a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java
+++ b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java
@@ -64,24 +64,24 @@ public class IAMEndpointConfigurer extends PropertyConfigurerSupport implements
         IAMEndpoint target = (IAMEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "iamclient":
-        case "iamClient": target.getConfiguration().getIamClient(); return true;
+        case "iamClient": return target.getConfiguration().getIamClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java
index b4320ce..94bc8f3 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java
@@ -69,23 +69,23 @@ public class KinesisFirehoseComponentConfigurer extends PropertyConfigurerSuppor
         KinesisFirehoseComponent target = (KinesisFirehoseComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonkinesisfirehoseclient":
-        case "amazonKinesisFirehoseClient": getOrCreateConfiguration(target).getAmazonKinesisFirehoseClient(); return true;
+        case "amazonKinesisFirehoseClient": return getOrCreateConfiguration(target).getAmazonKinesisFirehoseClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java
index 559ba22..f003384 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java
@@ -62,23 +62,23 @@ public class KinesisFirehoseEndpointConfigurer extends PropertyConfigurerSupport
         KinesisFirehoseEndpoint target = (KinesisFirehoseEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonkinesisfirehoseclient":
-        case "amazonKinesisFirehoseClient": target.getConfiguration().getAmazonKinesisFirehoseClient(); return true;
+        case "amazonKinesisFirehoseClient": return target.getConfiguration().getAmazonKinesisFirehoseClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java
index e7d6154..645c008 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java
@@ -87,35 +87,35 @@ public class KinesisComponentConfigurer extends PropertyConfigurerSupport implem
         KinesisComponent target = (KinesisComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonkinesisclient":
-        case "amazonKinesisClient": getOrCreateConfiguration(target).getAmazonKinesisClient(); return true;
+        case "amazonKinesisClient": return getOrCreateConfiguration(target).getAmazonKinesisClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "iteratortype":
-        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "iteratorType": return getOrCreateConfiguration(target).getIteratorType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return getOrCreateConfiguration(target).getMaxResultsPerRequest();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "sequencenumber":
-        case "sequenceNumber": getOrCreateConfiguration(target).getSequenceNumber(); return true;
+        case "sequenceNumber": return getOrCreateConfiguration(target).getSequenceNumber();
         case "shardclosed":
-        case "shardClosed": getOrCreateConfiguration(target).getShardClosed(); return true;
+        case "shardClosed": return getOrCreateConfiguration(target).getShardClosed();
         case "shardid":
-        case "shardId": getOrCreateConfiguration(target).getShardId(); return true;
+        case "shardId": return getOrCreateConfiguration(target).getShardId();
         default: return null;
         }
     }
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java
index 0e02de6..5a52d34 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java
@@ -131,68 +131,68 @@ public class KinesisEndpointConfigurer extends PropertyConfigurerSupport impleme
         KinesisEndpoint target = (KinesisEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonkinesisclient":
-        case "amazonKinesisClient": target.getConfiguration().getAmazonKinesisClient(); return true;
+        case "amazonKinesisClient": return target.getConfiguration().getAmazonKinesisClient();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "iteratortype":
-        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "iteratorType": return target.getConfiguration().getIteratorType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return target.getConfiguration().getMaxResultsPerRequest();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "sequencenumber":
-        case "sequenceNumber": target.getConfiguration().getSequenceNumber(); return true;
+        case "sequenceNumber": return target.getConfiguration().getSequenceNumber();
         case "shardclosed":
-        case "shardClosed": target.getConfiguration().getShardClosed(); return true;
+        case "shardClosed": return target.getConfiguration().getShardClosed();
         case "shardid":
-        case "shardId": target.getConfiguration().getShardId(); return true;
+        case "shardId": return target.getConfiguration().getShardId();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         default: return null;
         }
     }
diff --git a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java
index 17b49e8..02776f7 100644
--- a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java
+++ b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java
@@ -71,24 +71,24 @@ public class KMSComponentConfigurer extends PropertyConfigurerSupport implements
         KMSComponent target = (KMSComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "kmsclient":
-        case "kmsClient": getOrCreateConfiguration(target).getKmsClient(); return true;
+        case "kmsClient": return getOrCreateConfiguration(target).getKmsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java
index 54f09ac..1ff79a3 100644
--- a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java
+++ b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java
@@ -64,24 +64,24 @@ public class KMSEndpointConfigurer extends PropertyConfigurerSupport implements
         KMSEndpoint target = (KMSEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "kmsclient":
-        case "kmsClient": target.getConfiguration().getKmsClient(); return true;
+        case "kmsClient": return target.getConfiguration().getKmsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java
index f2be92a..2f778dd 100644
--- a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java
+++ b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java
@@ -71,24 +71,24 @@ public class LambdaComponentConfigurer extends PropertyConfigurerSupport impleme
         LambdaComponent target = (LambdaComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "awslambdaclient":
-        case "awsLambdaClient": getOrCreateConfiguration(target).getAwsLambdaClient(); return true;
+        case "awsLambdaClient": return getOrCreateConfiguration(target).getAwsLambdaClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java
index a245ecd..7bebbe4 100644
--- a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java
+++ b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java
@@ -64,24 +64,24 @@ public class LambdaEndpointConfigurer extends PropertyConfigurerSupport implemen
         LambdaEndpoint target = (LambdaEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "awslambdaclient":
-        case "awsLambdaClient": target.getConfiguration().getAwsLambdaClient(); return true;
+        case "awsLambdaClient": return target.getConfiguration().getAwsLambdaClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java
index f90e0e3..26d5045 100644
--- a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java
+++ b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java
@@ -71,24 +71,24 @@ public class MQComponentConfigurer extends PropertyConfigurerSupport implements
         MQComponent target = (MQComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonmqclient":
-        case "amazonMqClient": getOrCreateConfiguration(target).getAmazonMqClient(); return true;
+        case "amazonMqClient": return getOrCreateConfiguration(target).getAmazonMqClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java
index dbf8401..525b2e7 100644
--- a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java
+++ b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java
@@ -64,24 +64,24 @@ public class MQEndpointConfigurer extends PropertyConfigurerSupport implements G
         MQEndpoint target = (MQEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonmqclient":
-        case "amazonMqClient": target.getConfiguration().getAmazonMqClient(); return true;
+        case "amazonMqClient": return target.getConfiguration().getAmazonMqClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java
index 6695d05..458bece 100644
--- a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java
+++ b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java
@@ -71,24 +71,24 @@ public class MSKComponentConfigurer extends PropertyConfigurerSupport implements
         MSKComponent target = (MSKComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "mskclient":
-        case "mskClient": getOrCreateConfiguration(target).getMskClient(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "mskClient": return getOrCreateConfiguration(target).getMskClient();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java
index 3ca4a34..023c584 100644
--- a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java
+++ b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java
@@ -64,24 +64,24 @@ public class MSKEndpointConfigurer extends PropertyConfigurerSupport implements
         MSKEndpoint target = (MSKEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "mskclient":
-        case "mskClient": target.getConfiguration().getMskClient(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "mskClient": return target.getConfiguration().getMskClient();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java
index 896bdb0..ddec581 100644
--- a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java
+++ b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java
@@ -149,75 +149,75 @@ public class S3ComponentConfigurer extends PropertyConfigurerSupport implements
         S3Component target = (S3Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "acceleratemodeenabled":
-        case "accelerateModeEnabled": getOrCreateConfiguration(target).isAccelerateModeEnabled(); return true;
+        case "accelerateModeEnabled": return getOrCreateConfiguration(target).isAccelerateModeEnabled();
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazons3client":
-        case "amazonS3Client": getOrCreateConfiguration(target).getAmazonS3Client(); return true;
+        case "amazonS3Client": return getOrCreateConfiguration(target).getAmazonS3Client();
         case "autocreatebucket":
-        case "autoCreateBucket": getOrCreateConfiguration(target).isAutoCreateBucket(); return true;
+        case "autoCreateBucket": return getOrCreateConfiguration(target).isAutoCreateBucket();
         case "autoclosebody":
-        case "autocloseBody": getOrCreateConfiguration(target).isAutocloseBody(); return true;
+        case "autocloseBody": return getOrCreateConfiguration(target).isAutocloseBody();
         case "awskmskeyid":
-        case "awsKMSKeyId": getOrCreateConfiguration(target).getAwsKMSKeyId(); return true;
+        case "awsKMSKeyId": return getOrCreateConfiguration(target).getAwsKMSKeyId();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "chunkedencodingdisabled":
-        case "chunkedEncodingDisabled": getOrCreateConfiguration(target).isChunkedEncodingDisabled(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "chunkedEncodingDisabled": return getOrCreateConfiguration(target).isChunkedEncodingDisabled();
+        case "configuration": return target.getConfiguration();
         case "deleteafterread":
-        case "deleteAfterRead": getOrCreateConfiguration(target).isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return getOrCreateConfiguration(target).isDeleteAfterRead();
         case "deleteafterwrite":
-        case "deleteAfterWrite": getOrCreateConfiguration(target).isDeleteAfterWrite(); return true;
-        case "delimiter": getOrCreateConfiguration(target).getDelimiter(); return true;
+        case "deleteAfterWrite": return getOrCreateConfiguration(target).isDeleteAfterWrite();
+        case "delimiter": return getOrCreateConfiguration(target).getDelimiter();
         case "dualstackenabled":
-        case "dualstackEnabled": getOrCreateConfiguration(target).isDualstackEnabled(); return true;
+        case "dualstackEnabled": return getOrCreateConfiguration(target).isDualstackEnabled();
         case "encryptionmaterials":
-        case "encryptionMaterials": getOrCreateConfiguration(target).getEncryptionMaterials(); return true;
+        case "encryptionMaterials": return getOrCreateConfiguration(target).getEncryptionMaterials();
         case "endpointconfiguration":
-        case "endpointConfiguration": getOrCreateConfiguration(target).getEndpointConfiguration(); return true;
+        case "endpointConfiguration": return getOrCreateConfiguration(target).getEndpointConfiguration();
         case "filename":
-        case "fileName": getOrCreateConfiguration(target).getFileName(); return true;
+        case "fileName": return getOrCreateConfiguration(target).getFileName();
         case "forceglobalbucketaccessenabled":
-        case "forceGlobalBucketAccessEnabled": getOrCreateConfiguration(target).isForceGlobalBucketAccessEnabled(); return true;
+        case "forceGlobalBucketAccessEnabled": return getOrCreateConfiguration(target).isForceGlobalBucketAccessEnabled();
         case "includebody":
-        case "includeBody": getOrCreateConfiguration(target).isIncludeBody(); return true;
+        case "includeBody": return getOrCreateConfiguration(target).isIncludeBody();
         case "keyname":
-        case "keyName": getOrCreateConfiguration(target).getKeyName(); return true;
+        case "keyName": return getOrCreateConfiguration(target).getKeyName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "multipartupload":
-        case "multiPartUpload": getOrCreateConfiguration(target).isMultiPartUpload(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "multiPartUpload": return getOrCreateConfiguration(target).isMultiPartUpload();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "partsize":
-        case "partSize": getOrCreateConfiguration(target).getPartSize(); return true;
+        case "partSize": return getOrCreateConfiguration(target).getPartSize();
         case "pathstyleaccess":
-        case "pathStyleAccess": getOrCreateConfiguration(target).isPathStyleAccess(); return true;
+        case "pathStyleAccess": return getOrCreateConfiguration(target).isPathStyleAccess();
         case "payloadsigningenabled":
-        case "payloadSigningEnabled": getOrCreateConfiguration(target).isPayloadSigningEnabled(); return true;
-        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
-        case "prefix": getOrCreateConfiguration(target).getPrefix(); return true;
+        case "payloadSigningEnabled": return getOrCreateConfiguration(target).isPayloadSigningEnabled();
+        case "policy": return getOrCreateConfiguration(target).getPolicy();
+        case "prefix": return getOrCreateConfiguration(target).getPrefix();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "serversideencryption":
-        case "serverSideEncryption": getOrCreateConfiguration(target).getServerSideEncryption(); return true;
+        case "serverSideEncryption": return getOrCreateConfiguration(target).getServerSideEncryption();
         case "storageclass":
-        case "storageClass": getOrCreateConfiguration(target).getStorageClass(); return true;
+        case "storageClass": return getOrCreateConfiguration(target).getStorageClass();
         case "useawskms":
-        case "useAwsKMS": getOrCreateConfiguration(target).isUseAwsKMS(); return true;
+        case "useAwsKMS": return getOrCreateConfiguration(target).isUseAwsKMS();
         case "useencryption":
-        case "useEncryption": getOrCreateConfiguration(target).isUseEncryption(); return true;
+        case "useEncryption": return getOrCreateConfiguration(target).isUseEncryption();
         case "useiamcredentials":
-        case "useIAMCredentials": getOrCreateConfiguration(target).isUseIAMCredentials(); return true;
+        case "useIAMCredentials": return getOrCreateConfiguration(target).isUseIAMCredentials();
         default: return null;
         }
     }
diff --git a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java
index 4a02a84..f4be12f 100644
--- a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java
+++ b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java
@@ -199,112 +199,112 @@ public class S3EndpointConfigurer extends PropertyConfigurerSupport implements G
         S3Endpoint target = (S3Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "acceleratemodeenabled":
-        case "accelerateModeEnabled": target.getConfiguration().isAccelerateModeEnabled(); return true;
+        case "accelerateModeEnabled": return target.getConfiguration().isAccelerateModeEnabled();
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazons3client":
-        case "amazonS3Client": target.getConfiguration().getAmazonS3Client(); return true;
+        case "amazonS3Client": return target.getConfiguration().getAmazonS3Client();
         case "autocreatebucket":
-        case "autoCreateBucket": target.getConfiguration().isAutoCreateBucket(); return true;
+        case "autoCreateBucket": return target.getConfiguration().isAutoCreateBucket();
         case "autoclosebody":
-        case "autocloseBody": target.getConfiguration().isAutocloseBody(); return true;
+        case "autocloseBody": return target.getConfiguration().isAutocloseBody();
         case "awskmskeyid":
-        case "awsKMSKeyId": target.getConfiguration().getAwsKMSKeyId(); return true;
+        case "awsKMSKeyId": return target.getConfiguration().getAwsKMSKeyId();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "chunkedencodingdisabled":
-        case "chunkedEncodingDisabled": target.getConfiguration().isChunkedEncodingDisabled(); return true;
-        case "delay": target.getDelay(); return true;
+        case "chunkedEncodingDisabled": return target.getConfiguration().isChunkedEncodingDisabled();
+        case "delay": return target.getDelay();
         case "deleteafterread":
-        case "deleteAfterRead": target.getConfiguration().isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return target.getConfiguration().isDeleteAfterRead();
         case "deleteafterwrite":
-        case "deleteAfterWrite": target.getConfiguration().isDeleteAfterWrite(); return true;
-        case "delimiter": target.getConfiguration().getDelimiter(); return true;
+        case "deleteAfterWrite": return target.getConfiguration().isDeleteAfterWrite();
+        case "delimiter": return target.getConfiguration().getDelimiter();
         case "dualstackenabled":
-        case "dualstackEnabled": target.getConfiguration().isDualstackEnabled(); return true;
+        case "dualstackEnabled": return target.getConfiguration().isDualstackEnabled();
         case "encryptionmaterials":
-        case "encryptionMaterials": target.getConfiguration().getEncryptionMaterials(); return true;
+        case "encryptionMaterials": return target.getConfiguration().getEncryptionMaterials();
         case "endpointconfiguration":
-        case "endpointConfiguration": target.getConfiguration().getEndpointConfiguration(); return true;
+        case "endpointConfiguration": return target.getConfiguration().getEndpointConfiguration();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "filename":
-        case "fileName": target.getConfiguration().getFileName(); return true;
+        case "fileName": return target.getConfiguration().getFileName();
         case "forceglobalbucketaccessenabled":
-        case "forceGlobalBucketAccessEnabled": target.getConfiguration().isForceGlobalBucketAccessEnabled(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "forceGlobalBucketAccessEnabled": return target.getConfiguration().isForceGlobalBucketAccessEnabled();
+        case "greedy": return target.isGreedy();
         case "includebody":
-        case "includeBody": target.getConfiguration().isIncludeBody(); return true;
+        case "includeBody": return target.getConfiguration().isIncludeBody();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "keyname":
-        case "keyName": target.getConfiguration().getKeyName(); return true;
+        case "keyName": return target.getConfiguration().getKeyName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxconnections":
-        case "maxConnections": target.getMaxConnections(); return true;
+        case "maxConnections": return target.getMaxConnections();
         case "maxmessagesperpoll":
-        case "maxMessagesPerPoll": target.getMaxMessagesPerPoll(); return true;
+        case "maxMessagesPerPoll": return target.getMaxMessagesPerPoll();
         case "multipartupload":
-        case "multiPartUpload": target.getConfiguration().isMultiPartUpload(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "multiPartUpload": return target.getConfiguration().isMultiPartUpload();
+        case "operation": return target.getConfiguration().getOperation();
         case "partsize":
-        case "partSize": target.getConfiguration().getPartSize(); return true;
+        case "partSize": return target.getConfiguration().getPartSize();
         case "pathstyleaccess":
-        case "pathStyleAccess": target.getConfiguration().isPathStyleAccess(); return true;
+        case "pathStyleAccess": return target.getConfiguration().isPathStyleAccess();
         case "payloadsigningenabled":
-        case "payloadSigningEnabled": target.getConfiguration().isPayloadSigningEnabled(); return true;
-        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "payloadSigningEnabled": return target.getConfiguration().isPayloadSigningEnabled();
+        case "policy": return target.getConfiguration().getPolicy();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
-        case "prefix": target.getConfiguration().getPrefix(); return true;
+        case "pollStrategy": return target.getPollStrategy();
+        case "prefix": return target.getConfiguration().getPrefix();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "serversideencryption":
-        case "serverSideEncryption": target.getConfiguration().getServerSideEncryption(); return true;
+        case "serverSideEncryption": return target.getConfiguration().getServerSideEncryption();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
+        case "startScheduler": return target.isStartScheduler();
         case "storageclass":
-        case "storageClass": target.getConfiguration().getStorageClass(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "storageClass": return target.getConfiguration().getStorageClass();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "useawskms":
-        case "useAwsKMS": target.getConfiguration().isUseAwsKMS(); return true;
+        case "useAwsKMS": return target.getConfiguration().isUseAwsKMS();
         case "useencryption":
-        case "useEncryption": target.getConfiguration().isUseEncryption(); return true;
+        case "useEncryption": return target.getConfiguration().isUseEncryption();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         case "useiamcredentials":
-        case "useIAMCredentials": target.getConfiguration().isUseIAMCredentials(); return true;
+        case "useIAMCredentials": return target.getConfiguration().isUseIAMCredentials();
         default: return null;
         }
     }
diff --git a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java
index 895888e..025529b 100644
--- a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java
+++ b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java
@@ -40,9 +40,9 @@ public class SdbComponentConfigurer extends PropertyConfigurerSupport implements
         SdbComponent target = (SdbComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java
index 64af6c7..f5d2c8e 100644
--- a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java
+++ b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java
@@ -70,28 +70,28 @@ public class SdbEndpointConfigurer extends PropertyConfigurerSupport implements
         SdbEndpoint target = (SdbEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonsdbclient":
-        case "amazonSDBClient": target.getConfiguration().getAmazonSDBClient(); return true;
+        case "amazonSDBClient": return target.getConfiguration().getAmazonSDBClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "consistentread":
-        case "consistentRead": target.getConfiguration().isConsistentRead(); return true;
+        case "consistentRead": return target.getConfiguration().isConsistentRead();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxnumberofdomains":
-        case "maxNumberOfDomains": target.getConfiguration().getMaxNumberOfDomains(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "maxNumberOfDomains": return target.getConfiguration().getMaxNumberOfDomains();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java
index d446f9a..f8d119f 100644
--- a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java
+++ b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java
@@ -79,29 +79,29 @@ public class SesComponentConfigurer extends PropertyConfigurerSupport implements
         SesComponent target = (SesComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonsesclient":
-        case "amazonSESClient": getOrCreateConfiguration(target).getAmazonSESClient(); return true;
+        case "amazonSESClient": return getOrCreateConfiguration(target).getAmazonSESClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "replytoaddresses":
-        case "replyToAddresses": getOrCreateConfiguration(target).getReplyToAddresses(); return true;
+        case "replyToAddresses": return getOrCreateConfiguration(target).getReplyToAddresses();
         case "returnpath":
-        case "returnPath": getOrCreateConfiguration(target).getReturnPath(); return true;
+        case "returnPath": return getOrCreateConfiguration(target).getReturnPath();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
-        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
-        case "to": getOrCreateConfiguration(target).getTo(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
+        case "subject": return getOrCreateConfiguration(target).getSubject();
+        case "to": return getOrCreateConfiguration(target).getTo();
         default: return null;
         }
     }
diff --git a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java
index b9ba0ac..b840ba4 100644
--- a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java
+++ b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java
@@ -72,29 +72,29 @@ public class SesEndpointConfigurer extends PropertyConfigurerSupport implements
         SesEndpoint target = (SesEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonsesclient":
-        case "amazonSESClient": target.getConfiguration().getAmazonSESClient(); return true;
+        case "amazonSESClient": return target.getConfiguration().getAmazonSESClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "replytoaddresses":
-        case "replyToAddresses": target.getConfiguration().getReplyToAddresses(); return true;
+        case "replyToAddresses": return target.getConfiguration().getReplyToAddresses();
         case "returnpath":
-        case "returnPath": target.getConfiguration().getReturnPath(); return true;
+        case "returnPath": return target.getConfiguration().getReturnPath();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "subject": target.getConfiguration().getSubject(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "to": target.getConfiguration().getTo(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "subject": return target.getConfiguration().getSubject();
+        case "synchronous": return target.isSynchronous();
+        case "to": return target.getConfiguration().getTo();
         default: return null;
         }
     }
diff --git a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java
index 348e6a7..e7b5e9b 100644
--- a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java
+++ b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java
@@ -94,39 +94,39 @@ public class SnsComponentConfigurer extends PropertyConfigurerSupport implements
         SnsComponent target = (SnsComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonsnsclient":
-        case "amazonSNSClient": getOrCreateConfiguration(target).getAmazonSNSClient(); return true;
+        case "amazonSNSClient": return getOrCreateConfiguration(target).getAmazonSNSClient();
         case "amazonsqsclient":
-        case "amazonSQSClient": getOrCreateConfiguration(target).getAmazonSQSClient(); return true;
+        case "amazonSQSClient": return getOrCreateConfiguration(target).getAmazonSQSClient();
         case "autocreatetopic":
-        case "autoCreateTopic": getOrCreateConfiguration(target).isAutoCreateTopic(); return true;
+        case "autoCreateTopic": return getOrCreateConfiguration(target).isAutoCreateTopic();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": getOrCreateConfiguration(target).getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return getOrCreateConfiguration(target).getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messagestructure":
-        case "messageStructure": getOrCreateConfiguration(target).getMessageStructure(); return true;
-        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
+        case "messageStructure": return getOrCreateConfiguration(target).getMessageStructure();
+        case "policy": return getOrCreateConfiguration(target).getPolicy();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
         case "queueurl":
-        case "queueUrl": getOrCreateConfiguration(target).getQueueUrl(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "queueUrl": return getOrCreateConfiguration(target).getQueueUrl();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": getOrCreateConfiguration(target).isServerSideEncryptionEnabled(); return true;
-        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
+        case "serverSideEncryptionEnabled": return getOrCreateConfiguration(target).isServerSideEncryptionEnabled();
+        case "subject": return getOrCreateConfiguration(target).getSubject();
         case "subscribesnstosqs":
-        case "subscribeSNStoSQS": getOrCreateConfiguration(target).isSubscribeSNStoSQS(); return true;
+        case "subscribeSNStoSQS": return getOrCreateConfiguration(target).isSubscribeSNStoSQS();
         default: return null;
         }
     }
diff --git a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java
index 54786f3..5e04a50 100644
--- a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java
+++ b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java
@@ -90,41 +90,41 @@ public class SnsEndpointConfigurer extends PropertyConfigurerSupport implements
         SnsEndpoint target = (SnsEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonsnsclient":
-        case "amazonSNSClient": target.getConfiguration().getAmazonSNSClient(); return true;
+        case "amazonSNSClient": return target.getConfiguration().getAmazonSNSClient();
         case "amazonsqsclient":
-        case "amazonSQSClient": target.getConfiguration().getAmazonSQSClient(); return true;
+        case "amazonSQSClient": return target.getConfiguration().getAmazonSQSClient();
         case "autocreatetopic":
-        case "autoCreateTopic": target.getConfiguration().isAutoCreateTopic(); return true;
+        case "autoCreateTopic": return target.getConfiguration().isAutoCreateTopic();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": target.getConfiguration().getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return target.getConfiguration().getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messagestructure":
-        case "messageStructure": target.getConfiguration().getMessageStructure(); return true;
-        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "messageStructure": return target.getConfiguration().getMessageStructure();
+        case "policy": return target.getConfiguration().getPolicy();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
         case "queueurl":
-        case "queueUrl": target.getConfiguration().getQueueUrl(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "queueUrl": return target.getConfiguration().getQueueUrl();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": target.getConfiguration().isServerSideEncryptionEnabled(); return true;
-        case "subject": target.getConfiguration().getSubject(); return true;
+        case "serverSideEncryptionEnabled": return target.getConfiguration().isServerSideEncryptionEnabled();
+        case "subject": return target.getConfiguration().getSubject();
         case "subscribesnstosqs":
-        case "subscribeSNStoSQS": target.getConfiguration().isSubscribeSNStoSQS(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "subscribeSNStoSQS": return target.getConfiguration().isSubscribeSNStoSQS();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java
index 90f6ac6..f46f7a1 100644
--- a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java
+++ b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java
@@ -150,76 +150,76 @@ public class SqsComponentConfigurer extends PropertyConfigurerSupport implements
         SqsComponent target = (SqsComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonawshost":
-        case "amazonAWSHost": getOrCreateConfiguration(target).getAmazonAWSHost(); return true;
+        case "amazonAWSHost": return getOrCreateConfiguration(target).getAmazonAWSHost();
         case "amazonsqsclient":
-        case "amazonSQSClient": getOrCreateConfiguration(target).getAmazonSQSClient(); return true;
+        case "amazonSQSClient": return getOrCreateConfiguration(target).getAmazonSQSClient();
         case "attributenames":
-        case "attributeNames": getOrCreateConfiguration(target).getAttributeNames(); return true;
+        case "attributeNames": return getOrCreateConfiguration(target).getAttributeNames();
         case "autocreatequeue":
-        case "autoCreateQueue": getOrCreateConfiguration(target).isAutoCreateQueue(); return true;
+        case "autoCreateQueue": return getOrCreateConfiguration(target).isAutoCreateQueue();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "concurrentconsumers":
-        case "concurrentConsumers": getOrCreateConfiguration(target).getConcurrentConsumers(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "concurrentConsumers": return getOrCreateConfiguration(target).getConcurrentConsumers();
+        case "configuration": return target.getConfiguration();
         case "defaultvisibilitytimeout":
-        case "defaultVisibilityTimeout": getOrCreateConfiguration(target).getDefaultVisibilityTimeout(); return true;
+        case "defaultVisibilityTimeout": return getOrCreateConfiguration(target).getDefaultVisibilityTimeout();
         case "delayqueue":
-        case "delayQueue": getOrCreateConfiguration(target).isDelayQueue(); return true;
+        case "delayQueue": return getOrCreateConfiguration(target).isDelayQueue();
         case "delayseconds":
-        case "delaySeconds": getOrCreateConfiguration(target).getDelaySeconds(); return true;
+        case "delaySeconds": return getOrCreateConfiguration(target).getDelaySeconds();
         case "deleteafterread":
-        case "deleteAfterRead": getOrCreateConfiguration(target).isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return getOrCreateConfiguration(target).isDeleteAfterRead();
         case "deleteiffiltered":
-        case "deleteIfFiltered": getOrCreateConfiguration(target).isDeleteIfFiltered(); return true;
+        case "deleteIfFiltered": return getOrCreateConfiguration(target).isDeleteIfFiltered();
         case "extendmessagevisibility":
-        case "extendMessageVisibility": getOrCreateConfiguration(target).isExtendMessageVisibility(); return true;
+        case "extendMessageVisibility": return getOrCreateConfiguration(target).isExtendMessageVisibility();
         case "kmsdatakeyreuseperiodseconds":
-        case "kmsDataKeyReusePeriodSeconds": getOrCreateConfiguration(target).getKmsDataKeyReusePeriodSeconds(); return true;
+        case "kmsDataKeyReusePeriodSeconds": return getOrCreateConfiguration(target).getKmsDataKeyReusePeriodSeconds();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": getOrCreateConfiguration(target).getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return getOrCreateConfiguration(target).getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maximummessagesize":
-        case "maximumMessageSize": getOrCreateConfiguration(target).getMaximumMessageSize(); return true;
+        case "maximumMessageSize": return getOrCreateConfiguration(target).getMaximumMessageSize();
         case "messageattributenames":
-        case "messageAttributeNames": getOrCreateConfiguration(target).getMessageAttributeNames(); return true;
+        case "messageAttributeNames": return getOrCreateConfiguration(target).getMessageAttributeNames();
         case "messagededuplicationidstrategy":
-        case "messageDeduplicationIdStrategy": getOrCreateConfiguration(target).getMessageDeduplicationIdStrategy(); return true;
+        case "messageDeduplicationIdStrategy": return getOrCreateConfiguration(target).getMessageDeduplicationIdStrategy();
         case "messagegroupidstrategy":
-        case "messageGroupIdStrategy": getOrCreateConfiguration(target).getMessageGroupIdStrategy(); return true;
+        case "messageGroupIdStrategy": return getOrCreateConfiguration(target).getMessageGroupIdStrategy();
         case "messageretentionperiod":
-        case "messageRetentionPeriod": getOrCreateConfiguration(target).getMessageRetentionPeriod(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
-        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
-        case "protocol": getOrCreateConfiguration(target).getProtocol(); return true;
+        case "messageRetentionPeriod": return getOrCreateConfiguration(target).getMessageRetentionPeriod();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
+        case "policy": return getOrCreateConfiguration(target).getPolicy();
+        case "protocol": return getOrCreateConfiguration(target).getProtocol();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
         case "queueownerawsaccountid":
-        case "queueOwnerAWSAccountId": getOrCreateConfiguration(target).getQueueOwnerAWSAccountId(); return true;
+        case "queueOwnerAWSAccountId": return getOrCreateConfiguration(target).getQueueOwnerAWSAccountId();
         case "queueurl":
-        case "queueUrl": getOrCreateConfiguration(target).getQueueUrl(); return true;
+        case "queueUrl": return getOrCreateConfiguration(target).getQueueUrl();
         case "receivemessagewaittimeseconds":
-        case "receiveMessageWaitTimeSeconds": getOrCreateConfiguration(target).getReceiveMessageWaitTimeSeconds(); return true;
+        case "receiveMessageWaitTimeSeconds": return getOrCreateConfiguration(target).getReceiveMessageWaitTimeSeconds();
         case "redrivepolicy":
-        case "redrivePolicy": getOrCreateConfiguration(target).getRedrivePolicy(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "redrivePolicy": return getOrCreateConfiguration(target).getRedrivePolicy();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": getOrCreateConfiguration(target).isServerSideEncryptionEnabled(); return true;
+        case "serverSideEncryptionEnabled": return getOrCreateConfiguration(target).isServerSideEncryptionEnabled();
         case "visibilitytimeout":
-        case "visibilityTimeout": getOrCreateConfiguration(target).getVisibilityTimeout(); return true;
+        case "visibilityTimeout": return getOrCreateConfiguration(target).getVisibilityTimeout();
         case "waittimeseconds":
-        case "waitTimeSeconds": getOrCreateConfiguration(target).getWaitTimeSeconds(); return true;
+        case "waitTimeSeconds": return getOrCreateConfiguration(target).getWaitTimeSeconds();
         default: return null;
         }
     }
diff --git a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java
index 87bf267..a4a9d42 100644
--- a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java
+++ b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java
@@ -200,113 +200,113 @@ public class SqsEndpointConfigurer extends PropertyConfigurerSupport implements
         SqsEndpoint target = (SqsEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonawshost":
-        case "amazonAWSHost": target.getConfiguration().getAmazonAWSHost(); return true;
+        case "amazonAWSHost": return target.getConfiguration().getAmazonAWSHost();
         case "amazonsqsclient":
-        case "amazonSQSClient": target.getConfiguration().getAmazonSQSClient(); return true;
+        case "amazonSQSClient": return target.getConfiguration().getAmazonSQSClient();
         case "attributenames":
-        case "attributeNames": target.getConfiguration().getAttributeNames(); return true;
+        case "attributeNames": return target.getConfiguration().getAttributeNames();
         case "autocreatequeue":
-        case "autoCreateQueue": target.getConfiguration().isAutoCreateQueue(); return true;
+        case "autoCreateQueue": return target.getConfiguration().isAutoCreateQueue();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "concurrentconsumers":
-        case "concurrentConsumers": target.getConfiguration().getConcurrentConsumers(); return true;
+        case "concurrentConsumers": return target.getConfiguration().getConcurrentConsumers();
         case "defaultvisibilitytimeout":
-        case "defaultVisibilityTimeout": target.getConfiguration().getDefaultVisibilityTimeout(); return true;
-        case "delay": target.getDelay(); return true;
+        case "defaultVisibilityTimeout": return target.getConfiguration().getDefaultVisibilityTimeout();
+        case "delay": return target.getDelay();
         case "delayqueue":
-        case "delayQueue": target.getConfiguration().isDelayQueue(); return true;
+        case "delayQueue": return target.getConfiguration().isDelayQueue();
         case "delayseconds":
-        case "delaySeconds": target.getConfiguration().getDelaySeconds(); return true;
+        case "delaySeconds": return target.getConfiguration().getDelaySeconds();
         case "deleteafterread":
-        case "deleteAfterRead": target.getConfiguration().isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return target.getConfiguration().isDeleteAfterRead();
         case "deleteiffiltered":
-        case "deleteIfFiltered": target.getConfiguration().isDeleteIfFiltered(); return true;
+        case "deleteIfFiltered": return target.getConfiguration().isDeleteIfFiltered();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "extendmessagevisibility":
-        case "extendMessageVisibility": target.getConfiguration().isExtendMessageVisibility(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "extendMessageVisibility": return target.getConfiguration().isExtendMessageVisibility();
+        case "greedy": return target.isGreedy();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "kmsdatakeyreuseperiodseconds":
-        case "kmsDataKeyReusePeriodSeconds": target.getConfiguration().getKmsDataKeyReusePeriodSeconds(); return true;
+        case "kmsDataKeyReusePeriodSeconds": return target.getConfiguration().getKmsDataKeyReusePeriodSeconds();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": target.getConfiguration().getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return target.getConfiguration().getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxmessagesperpoll":
-        case "maxMessagesPerPoll": target.getMaxMessagesPerPoll(); return true;
+        case "maxMessagesPerPoll": return target.getMaxMessagesPerPoll();
         case "maximummessagesize":
-        case "maximumMessageSize": target.getConfiguration().getMaximumMessageSize(); return true;
+        case "maximumMessageSize": return target.getConfiguration().getMaximumMessageSize();
         case "messageattributenames":
-        case "messageAttributeNames": target.getConfiguration().getMessageAttributeNames(); return true;
+        case "messageAttributeNames": return target.getConfiguration().getMessageAttributeNames();
         case "messagededuplicationidstrategy":
-        case "messageDeduplicationIdStrategy": target.getConfiguration().getMessageDeduplicationIdStrategy(); return true;
+        case "messageDeduplicationIdStrategy": return target.getConfiguration().getMessageDeduplicationIdStrategy();
         case "messagegroupidstrategy":
-        case "messageGroupIdStrategy": target.getConfiguration().getMessageGroupIdStrategy(); return true;
+        case "messageGroupIdStrategy": return target.getConfiguration().getMessageGroupIdStrategy();
         case "messageretentionperiod":
-        case "messageRetentionPeriod": target.getConfiguration().getMessageRetentionPeriod(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
-        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "messageRetentionPeriod": return target.getConfiguration().getMessageRetentionPeriod();
+        case "operation": return target.getConfiguration().getOperation();
+        case "policy": return target.getConfiguration().getPolicy();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
-        case "protocol": target.getConfiguration().getProtocol(); return true;
+        case "pollStrategy": return target.getPollStrategy();
+        case "protocol": return target.getConfiguration().getProtocol();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
         case "queueownerawsaccountid":
-        case "queueOwnerAWSAccountId": target.getConfiguration().getQueueOwnerAWSAccountId(); return true;
+        case "queueOwnerAWSAccountId": return target.getConfiguration().getQueueOwnerAWSAccountId();
         case "queueurl":
-        case "queueUrl": target.getConfiguration().getQueueUrl(); return true;
+        case "queueUrl": return target.getConfiguration().getQueueUrl();
         case "receivemessagewaittimeseconds":
-        case "receiveMessageWaitTimeSeconds": target.getConfiguration().getReceiveMessageWaitTimeSeconds(); return true;
+        case "receiveMessageWaitTimeSeconds": return target.getConfiguration().getReceiveMessageWaitTimeSeconds();
         case "redrivepolicy":
-        case "redrivePolicy": target.getConfiguration().getRedrivePolicy(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "redrivePolicy": return target.getConfiguration().getRedrivePolicy();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": target.getConfiguration().isServerSideEncryptionEnabled(); return true;
+        case "serverSideEncryptionEnabled": return target.getConfiguration().isServerSideEncryptionEnabled();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         case "visibilitytimeout":
-        case "visibilityTimeout": target.getConfiguration().getVisibilityTimeout(); return true;
+        case "visibilityTimeout": return target.getConfiguration().getVisibilityTimeout();
         case "waittimeseconds":
-        case "waitTimeSeconds": target.getConfiguration().getWaitTimeSeconds(); return true;
+        case "waitTimeSeconds": return target.getConfiguration().getWaitTimeSeconds();
         default: return null;
         }
     }
diff --git a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java
index eebf212..cab89eb 100644
--- a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java
+++ b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java
@@ -127,61 +127,61 @@ public class SWFComponentConfigurer extends PropertyConfigurerSupport implements
         SWFComponent target = (SWFComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "activitylist":
-        case "activityList": getOrCreateConfiguration(target).getActivityList(); return true;
+        case "activityList": return getOrCreateConfiguration(target).getActivityList();
         case "activityschedulingoptions":
-        case "activitySchedulingOptions": getOrCreateConfiguration(target).getActivitySchedulingOptions(); return true;
+        case "activitySchedulingOptions": return getOrCreateConfiguration(target).getActivitySchedulingOptions();
         case "activitythreadpoolsize":
-        case "activityThreadPoolSize": getOrCreateConfiguration(target).getActivityThreadPoolSize(); return true;
+        case "activityThreadPoolSize": return getOrCreateConfiguration(target).getActivityThreadPoolSize();
         case "activitytypeexecutionoptions":
-        case "activityTypeExecutionOptions": getOrCreateConfiguration(target).getActivityTypeExecutionOptions(); return true;
+        case "activityTypeExecutionOptions": return getOrCreateConfiguration(target).getActivityTypeExecutionOptions();
         case "activitytyperegistrationoptions":
-        case "activityTypeRegistrationOptions": getOrCreateConfiguration(target).getActivityTypeRegistrationOptions(); return true;
+        case "activityTypeRegistrationOptions": return getOrCreateConfiguration(target).getActivityTypeRegistrationOptions();
         case "amazonswclient":
-        case "amazonSWClient": getOrCreateConfiguration(target).getAmazonSWClient(); return true;
+        case "amazonSWClient": return getOrCreateConfiguration(target).getAmazonSWClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "childpolicy":
-        case "childPolicy": getOrCreateConfiguration(target).getChildPolicy(); return true;
+        case "childPolicy": return getOrCreateConfiguration(target).getChildPolicy();
         case "clientconfigurationparameters":
-        case "clientConfigurationParameters": getOrCreateConfiguration(target).getClientConfigurationParameters(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "clientConfigurationParameters": return getOrCreateConfiguration(target).getClientConfigurationParameters();
+        case "configuration": return target.getConfiguration();
         case "dataconverter":
-        case "dataConverter": getOrCreateConfiguration(target).getDataConverter(); return true;
+        case "dataConverter": return getOrCreateConfiguration(target).getDataConverter();
         case "domainname":
-        case "domainName": getOrCreateConfiguration(target).getDomainName(); return true;
+        case "domainName": return getOrCreateConfiguration(target).getDomainName();
         case "eventname":
-        case "eventName": getOrCreateConfiguration(target).getEventName(); return true;
+        case "eventName": return getOrCreateConfiguration(target).getEventName();
         case "executionstarttoclosetimeout":
-        case "executionStartToCloseTimeout": getOrCreateConfiguration(target).getExecutionStartToCloseTimeout(); return true;
+        case "executionStartToCloseTimeout": return getOrCreateConfiguration(target).getExecutionStartToCloseTimeout();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "swclientparameters":
-        case "sWClientParameters": getOrCreateConfiguration(target).getSWClientParameters(); return true;
+        case "sWClientParameters": return getOrCreateConfiguration(target).getSWClientParameters();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "signalname":
-        case "signalName": getOrCreateConfiguration(target).getSignalName(); return true;
+        case "signalName": return getOrCreateConfiguration(target).getSignalName();
         case "startworkflowoptionsparameters":
-        case "startWorkflowOptionsParameters": getOrCreateConfiguration(target).getStartWorkflowOptionsParameters(); return true;
+        case "startWorkflowOptionsParameters": return getOrCreateConfiguration(target).getStartWorkflowOptionsParameters();
         case "stateresulttype":
-        case "stateResultType": getOrCreateConfiguration(target).getStateResultType(); return true;
+        case "stateResultType": return getOrCreateConfiguration(target).getStateResultType();
         case "taskstarttoclosetimeout":
-        case "taskStartToCloseTimeout": getOrCreateConfiguration(target).getTaskStartToCloseTimeout(); return true;
+        case "taskStartToCloseTimeout": return getOrCreateConfiguration(target).getTaskStartToCloseTimeout();
         case "terminationdetails":
-        case "terminationDetails": getOrCreateConfiguration(target).getTerminationDetails(); return true;
+        case "terminationDetails": return getOrCreateConfiguration(target).getTerminationDetails();
         case "terminationreason":
-        case "terminationReason": getOrCreateConfiguration(target).getTerminationReason(); return true;
-        case "version": getOrCreateConfiguration(target).getVersion(); return true;
+        case "terminationReason": return getOrCreateConfiguration(target).getTerminationReason();
+        case "version": return getOrCreateConfiguration(target).getVersion();
         case "workflowlist":
-        case "workflowList": getOrCreateConfiguration(target).getWorkflowList(); return true;
+        case "workflowList": return getOrCreateConfiguration(target).getWorkflowList();
         case "workflowtyperegistrationoptions":
-        case "workflowTypeRegistrationOptions": getOrCreateConfiguration(target).getWorkflowTypeRegistrationOptions(); return true;
+        case "workflowTypeRegistrationOptions": return getOrCreateConfiguration(target).getWorkflowTypeRegistrationOptions();
         default: return null;
         }
     }
diff --git a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java
index 3914a62..832ae1d 100644
--- a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java
+++ b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java
@@ -126,65 +126,65 @@ public class SWFEndpointConfigurer extends PropertyConfigurerSupport implements
         SWFEndpoint target = (SWFEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "activitylist":
-        case "activityList": target.getConfiguration().getActivityList(); return true;
+        case "activityList": return target.getConfiguration().getActivityList();
         case "activityschedulingoptions":
-        case "activitySchedulingOptions": target.getConfiguration().getActivitySchedulingOptions(); return true;
+        case "activitySchedulingOptions": return target.getConfiguration().getActivitySchedulingOptions();
         case "activitythreadpoolsize":
-        case "activityThreadPoolSize": target.getConfiguration().getActivityThreadPoolSize(); return true;
+        case "activityThreadPoolSize": return target.getConfiguration().getActivityThreadPoolSize();
         case "activitytypeexecutionoptions":
-        case "activityTypeExecutionOptions": target.getConfiguration().getActivityTypeExecutionOptions(); return true;
+        case "activityTypeExecutionOptions": return target.getConfiguration().getActivityTypeExecutionOptions();
         case "activitytyperegistrationoptions":
-        case "activityTypeRegistrationOptions": target.getConfiguration().getActivityTypeRegistrationOptions(); return true;
+        case "activityTypeRegistrationOptions": return target.getConfiguration().getActivityTypeRegistrationOptions();
         case "amazonswclient":
-        case "amazonSWClient": target.getConfiguration().getAmazonSWClient(); return true;
+        case "amazonSWClient": return target.getConfiguration().getAmazonSWClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "childpolicy":
-        case "childPolicy": target.getConfiguration().getChildPolicy(); return true;
+        case "childPolicy": return target.getConfiguration().getChildPolicy();
         case "clientconfigurationparameters":
-        case "clientConfigurationParameters": target.getConfiguration().getClientConfigurationParameters(); return true;
+        case "clientConfigurationParameters": return target.getConfiguration().getClientConfigurationParameters();
         case "dataconverter":
-        case "dataConverter": target.getConfiguration().getDataConverter(); return true;
+        case "dataConverter": return target.getConfiguration().getDataConverter();
         case "domainname":
-        case "domainName": target.getConfiguration().getDomainName(); return true;
+        case "domainName": return target.getConfiguration().getDomainName();
         case "eventname":
-        case "eventName": target.getConfiguration().getEventName(); return true;
+        case "eventName": return target.getConfiguration().getEventName();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "executionstarttoclosetimeout":
-        case "executionStartToCloseTimeout": target.getConfiguration().getExecutionStartToCloseTimeout(); return true;
+        case "executionStartToCloseTimeout": return target.getConfiguration().getExecutionStartToCloseTimeout();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
+        case "region": return target.getConfiguration().getRegion();
         case "swclientparameters":
-        case "sWClientParameters": target.getConfiguration().getSWClientParameters(); return true;
+        case "sWClientParameters": return target.getConfiguration().getSWClientParameters();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "signalname":
-        case "signalName": target.getConfiguration().getSignalName(); return true;
+        case "signalName": return target.getConfiguration().getSignalName();
         case "startworkflowoptionsparameters":
-        case "startWorkflowOptionsParameters": target.getConfiguration().getStartWorkflowOptionsParameters(); return true;
+        case "startWorkflowOptionsParameters": return target.getConfiguration().getStartWorkflowOptionsParameters();
         case "stateresulttype":
-        case "stateResultType": target.getConfiguration().getStateResultType(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "stateResultType": return target.getConfiguration().getStateResultType();
+        case "synchronous": return target.isSynchronous();
         case "taskstarttoclosetimeout":
-        case "taskStartToCloseTimeout": target.getConfiguration().getTaskStartToCloseTimeout(); return true;
+        case "taskStartToCloseTimeout": return target.getConfiguration().getTaskStartToCloseTimeout();
         case "terminationdetails":
-        case "terminationDetails": target.getConfiguration().getTerminationDetails(); return true;
+        case "terminationDetails": return target.getConfiguration().getTerminationDetails();
         case "terminationreason":
-        case "terminationReason": target.getConfiguration().getTerminationReason(); return true;
-        case "version": target.getConfiguration().getVersion(); return true;
+        case "terminationReason": return target.getConfiguration().getTerminationReason();
+        case "version": return target.getConfiguration().getVersion();
         case "workflowlist":
-        case "workflowList": target.getConfiguration().getWorkflowList(); return true;
+        case "workflowList": return target.getConfiguration().getWorkflowList();
         case "workflowtyperegistrationoptions":
-        case "workflowTypeRegistrationOptions": target.getConfiguration().getWorkflowTypeRegistrationOptions(); return true;
+        case "workflowTypeRegistrationOptions": return target.getConfiguration().getWorkflowTypeRegistrationOptions();
         default: return null;
         }
     }
diff --git a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java
index 3892ccb..dadd33b 100644
--- a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java
+++ b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java
@@ -80,30 +80,30 @@ public class TranslateComponentConfigurer extends PropertyConfigurerSupport impl
         TranslateComponent target = (TranslateComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "autodetectsourcelanguage":
-        case "autodetectSourceLanguage": getOrCreateConfiguration(target).isAutodetectSourceLanguage(); return true;
+        case "autodetectSourceLanguage": return getOrCreateConfiguration(target).isAutodetectSourceLanguage();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "sourcelanguage":
-        case "sourceLanguage": getOrCreateConfiguration(target).getSourceLanguage(); return true;
+        case "sourceLanguage": return getOrCreateConfiguration(target).getSourceLanguage();
         case "targetlanguage":
-        case "targetLanguage": getOrCreateConfiguration(target).getTargetLanguage(); return true;
+        case "targetLanguage": return getOrCreateConfiguration(target).getTargetLanguage();
         case "translateclient":
-        case "translateClient": getOrCreateConfiguration(target).getTranslateClient(); return true;
+        case "translateClient": return getOrCreateConfiguration(target).getTranslateClient();
         default: return null;
         }
     }
diff --git a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java
index 5a66c68..e521cb0 100644
--- a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java
+++ b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java
@@ -73,30 +73,30 @@ public class TranslateEndpointConfigurer extends PropertyConfigurerSupport imple
         TranslateEndpoint target = (TranslateEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "autodetectsourcelanguage":
-        case "autodetectSourceLanguage": target.getConfiguration().isAutodetectSourceLanguage(); return true;
+        case "autodetectSourceLanguage": return target.getConfiguration().isAutodetectSourceLanguage();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sourcelanguage":
-        case "sourceLanguage": target.getConfiguration().getSourceLanguage(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "sourceLanguage": return target.getConfiguration().getSourceLanguage();
+        case "synchronous": return target.isSynchronous();
         case "targetlanguage":
-        case "targetLanguage": target.getConfiguration().getTargetLanguage(); return true;
+        case "targetLanguage": return target.getConfiguration().getTargetLanguage();
         case "translateclient":
-        case "translateClient": target.getConfiguration().getTranslateClient(); return true;
+        case "translateClient": return target.getConfiguration().getTranslateClient();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java
index 4ebd50c..4e1feb7 100644
--- a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java
+++ b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java
@@ -77,27 +77,27 @@ public class Cw2ComponentConfigurer extends PropertyConfigurerSupport implements
         Cw2Component target = (Cw2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazoncwclient":
-        case "amazonCwClient": getOrCreateConfiguration(target).getAmazonCwClient(); return true;
+        case "amazonCwClient": return getOrCreateConfiguration(target).getAmazonCwClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "name": getOrCreateConfiguration(target).getName(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "name": return getOrCreateConfiguration(target).getName();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
-        case "timestamp": getOrCreateConfiguration(target).getTimestamp(); return true;
-        case "unit": getOrCreateConfiguration(target).getUnit(); return true;
-        case "value": getOrCreateConfiguration(target).getValue(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
+        case "timestamp": return getOrCreateConfiguration(target).getTimestamp();
+        case "unit": return getOrCreateConfiguration(target).getUnit();
+        case "value": return getOrCreateConfiguration(target).getValue();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java
index ece6c1c..31b3981 100644
--- a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java
+++ b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java
@@ -70,27 +70,27 @@ public class Cw2EndpointConfigurer extends PropertyConfigurerSupport implements
         Cw2Endpoint target = (Cw2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazoncwclient":
-        case "amazonCwClient": target.getConfiguration().getAmazonCwClient(); return true;
+        case "amazonCwClient": return target.getConfiguration().getAmazonCwClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "name": target.getConfiguration().getName(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "name": return target.getConfiguration().getName();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "timestamp": target.getConfiguration().getTimestamp(); return true;
-        case "unit": target.getConfiguration().getUnit(); return true;
-        case "value": target.getConfiguration().getValue(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
+        case "timestamp": return target.getConfiguration().getTimestamp();
+        case "unit": return target.getConfiguration().getUnit();
+        case "value": return target.getConfiguration().getValue();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java
index 424f072..5d168f1 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java
@@ -86,34 +86,34 @@ public class Ddb2ComponentConfigurer extends PropertyConfigurerSupport implement
         Ddb2Component target = (Ddb2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonddbclient":
-        case "amazonDDBClient": getOrCreateConfiguration(target).getAmazonDDBClient(); return true;
+        case "amazonDDBClient": return getOrCreateConfiguration(target).getAmazonDDBClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "consistentread":
-        case "consistentRead": getOrCreateConfiguration(target).isConsistentRead(); return true;
+        case "consistentRead": return getOrCreateConfiguration(target).isConsistentRead();
         case "keyattributename":
-        case "keyAttributeName": getOrCreateConfiguration(target).getKeyAttributeName(); return true;
+        case "keyAttributeName": return getOrCreateConfiguration(target).getKeyAttributeName();
         case "keyattributetype":
-        case "keyAttributeType": getOrCreateConfiguration(target).getKeyAttributeType(); return true;
+        case "keyAttributeType": return getOrCreateConfiguration(target).getKeyAttributeType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
         case "readcapacity":
-        case "readCapacity": getOrCreateConfiguration(target).getReadCapacity(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "readCapacity": return getOrCreateConfiguration(target).getReadCapacity();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "writecapacity":
-        case "writeCapacity": getOrCreateConfiguration(target).getWriteCapacity(); return true;
+        case "writeCapacity": return getOrCreateConfiguration(target).getWriteCapacity();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java
index 9699fc9..4957f35 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java
@@ -79,34 +79,34 @@ public class Ddb2EndpointConfigurer extends PropertyConfigurerSupport implements
         Ddb2Endpoint target = (Ddb2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonddbclient":
-        case "amazonDDBClient": target.getConfiguration().getAmazonDDBClient(); return true;
+        case "amazonDDBClient": return target.getConfiguration().getAmazonDDBClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "consistentread":
-        case "consistentRead": target.getConfiguration().isConsistentRead(); return true;
+        case "consistentRead": return target.getConfiguration().isConsistentRead();
         case "keyattributename":
-        case "keyAttributeName": target.getConfiguration().getKeyAttributeName(); return true;
+        case "keyAttributeName": return target.getConfiguration().getKeyAttributeName();
         case "keyattributetype":
-        case "keyAttributeType": target.getConfiguration().getKeyAttributeType(); return true;
+        case "keyAttributeType": return target.getConfiguration().getKeyAttributeType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
         case "readcapacity":
-        case "readCapacity": target.getConfiguration().getReadCapacity(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "readCapacity": return target.getConfiguration().getReadCapacity();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         case "writecapacity":
-        case "writeCapacity": target.getConfiguration().getWriteCapacity(); return true;
+        case "writeCapacity": return target.getConfiguration().getWriteCapacity();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java
index c485109..2092adc 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java
@@ -78,29 +78,29 @@ public class Ddb2StreamComponentConfigurer extends PropertyConfigurerSupport imp
         Ddb2StreamComponent target = (Ddb2StreamComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazondynamodbstreamsclient":
-        case "amazonDynamoDbStreamsClient": getOrCreateConfiguration(target).getAmazonDynamoDbStreamsClient(); return true;
+        case "amazonDynamoDbStreamsClient": return getOrCreateConfiguration(target).getAmazonDynamoDbStreamsClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "iteratortype":
-        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "iteratorType": return getOrCreateConfiguration(target).getIteratorType();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return getOrCreateConfiguration(target).getMaxResultsPerRequest();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "sequencenumberprovider":
-        case "sequenceNumberProvider": getOrCreateConfiguration(target).getSequenceNumberProvider(); return true;
+        case "sequenceNumberProvider": return getOrCreateConfiguration(target).getSequenceNumberProvider();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java
index 0536860..c828c78 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java
@@ -122,62 +122,62 @@ public class Ddb2StreamEndpointConfigurer extends PropertyConfigurerSupport impl
         Ddb2StreamEndpoint target = (Ddb2StreamEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazondynamodbstreamsclient":
-        case "amazonDynamoDbStreamsClient": target.getConfiguration().getAmazonDynamoDbStreamsClient(); return true;
+        case "amazonDynamoDbStreamsClient": return target.getConfiguration().getAmazonDynamoDbStreamsClient();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "iteratortype":
-        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "iteratorType": return target.getConfiguration().getIteratorType();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return target.getConfiguration().getMaxResultsPerRequest();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "sequencenumberprovider":
-        case "sequenceNumberProvider": target.getConfiguration().getSequenceNumberProvider(); return true;
+        case "sequenceNumberProvider": return target.getConfiguration().getSequenceNumberProvider();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java
index 12cab3f..d58b645 100644
--- a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java
+++ b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class AWS2EC2ComponentConfigurer extends PropertyConfigurerSupport implem
         AWS2EC2Component target = (AWS2EC2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonec2client":
-        case "amazonEc2Client": getOrCreateConfiguration(target).getAmazonEc2Client(); return true;
+        case "amazonEc2Client": return getOrCreateConfiguration(target).getAmazonEc2Client();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java
index 4cbde54..7339f91 100644
--- a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java
+++ b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class AWS2EC2EndpointConfigurer extends PropertyConfigurerSupport impleme
         AWS2EC2Endpoint target = (AWS2EC2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonec2client":
-        case "amazonEc2Client": target.getConfiguration().getAmazonEc2Client(); return true;
+        case "amazonEc2Client": return target.getConfiguration().getAmazonEc2Client();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java
index 35db0ee..b123a6b 100644
--- a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java
+++ b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class ECS2ComponentConfigurer extends PropertyConfigurerSupport implement
         ECS2Component target = (ECS2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "ecsclient":
-        case "ecsClient": getOrCreateConfiguration(target).getEcsClient(); return true;
+        case "ecsClient": return getOrCreateConfiguration(target).getEcsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java
index a43414b..7c6d502 100644
--- a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java
+++ b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class ECS2EndpointConfigurer extends PropertyConfigurerSupport implements
         ECS2Endpoint target = (ECS2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "ecsclient":
-        case "ecsClient": target.getConfiguration().getEcsClient(); return true;
+        case "ecsClient": return target.getConfiguration().getEcsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java
index 176fb93..c9ec167 100644
--- a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java
+++ b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class EKS2ComponentConfigurer extends PropertyConfigurerSupport implement
         EKS2Component target = (EKS2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "eksclient":
-        case "eksClient": getOrCreateConfiguration(target).getEksClient(); return true;
+        case "eksClient": return getOrCreateConfiguration(target).getEksClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java
index c0c4e24..fcf1b56 100644
--- a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java
+++ b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class EKS2EndpointConfigurer extends PropertyConfigurerSupport implements
         EKS2Endpoint target = (EKS2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "eksclient":
-        case "eksClient": target.getConfiguration().getEksClient(); return true;
+        case "eksClient": return target.getConfiguration().getEksClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java
index 964cc7d..50a95d7 100644
--- a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java
+++ b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class IAM2ComponentConfigurer extends PropertyConfigurerSupport implement
         IAM2Component target = (IAM2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "iamclient":
-        case "iamClient": getOrCreateConfiguration(target).getIamClient(); return true;
+        case "iamClient": return getOrCreateConfiguration(target).getIamClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java
index cc069aa..3f44b60 100644
--- a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java
+++ b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class IAM2EndpointConfigurer extends PropertyConfigurerSupport implements
         IAM2Endpoint target = (IAM2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "iamclient":
-        case "iamClient": target.getConfiguration().getIamClient(); return true;
+        case "iamClient": return target.getConfiguration().getIamClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java
index 78f24db..177dd52 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java
@@ -69,23 +69,23 @@ public class KinesisFirehose2ComponentConfigurer extends PropertyConfigurerSuppo
         KinesisFirehose2Component target = (KinesisFirehose2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonkinesisfirehoseclient":
-        case "amazonKinesisFirehoseClient": getOrCreateConfiguration(target).getAmazonKinesisFirehoseClient(); return true;
+        case "amazonKinesisFirehoseClient": return getOrCreateConfiguration(target).getAmazonKinesisFirehoseClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java
index b38615e..36ac274 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java
@@ -62,23 +62,23 @@ public class KinesisFirehose2EndpointConfigurer extends PropertyConfigurerSuppor
         KinesisFirehose2Endpoint target = (KinesisFirehose2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonkinesisfirehoseclient":
-        case "amazonKinesisFirehoseClient": target.getConfiguration().getAmazonKinesisFirehoseClient(); return true;
+        case "amazonKinesisFirehoseClient": return target.getConfiguration().getAmazonKinesisFirehoseClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java
index 3129769..35b7210 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java
@@ -87,35 +87,35 @@ public class Kinesis2ComponentConfigurer extends PropertyConfigurerSupport imple
         Kinesis2Component target = (Kinesis2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonkinesisclient":
-        case "amazonKinesisClient": getOrCreateConfiguration(target).getAmazonKinesisClient(); return true;
+        case "amazonKinesisClient": return getOrCreateConfiguration(target).getAmazonKinesisClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "iteratortype":
-        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "iteratorType": return getOrCreateConfiguration(target).getIteratorType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return getOrCreateConfiguration(target).getMaxResultsPerRequest();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "sequencenumber":
-        case "sequenceNumber": getOrCreateConfiguration(target).getSequenceNumber(); return true;
+        case "sequenceNumber": return getOrCreateConfiguration(target).getSequenceNumber();
         case "shardclosed":
-        case "shardClosed": getOrCreateConfiguration(target).getShardClosed(); return true;
+        case "shardClosed": return getOrCreateConfiguration(target).getShardClosed();
         case "shardid":
-        case "shardId": getOrCreateConfiguration(target).getShardId(); return true;
+        case "shardId": return getOrCreateConfiguration(target).getShardId();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java
index ab3f7f1..5798d49 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java
@@ -131,68 +131,68 @@ public class Kinesis2EndpointConfigurer extends PropertyConfigurerSupport implem
         Kinesis2Endpoint target = (Kinesis2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonkinesisclient":
-        case "amazonKinesisClient": target.getConfiguration().getAmazonKinesisClient(); return true;
+        case "amazonKinesisClient": return target.getConfiguration().getAmazonKinesisClient();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "iteratortype":
-        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "iteratorType": return target.getConfiguration().getIteratorType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxresultsperrequest":
-        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "maxResultsPerRequest": return target.getConfiguration().getMaxResultsPerRequest();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "sequencenumber":
-        case "sequenceNumber": target.getConfiguration().getSequenceNumber(); return true;
+        case "sequenceNumber": return target.getConfiguration().getSequenceNumber();
         case "shardclosed":
-        case "shardClosed": target.getConfiguration().getShardClosed(); return true;
+        case "shardClosed": return target.getConfiguration().getShardClosed();
         case "shardid":
-        case "shardId": target.getConfiguration().getShardId(); return true;
+        case "shardId": return target.getConfiguration().getShardId();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java
index fd53ca5..c5e6c99 100644
--- a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java
+++ b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class KMS2ComponentConfigurer extends PropertyConfigurerSupport implement
         KMS2Component target = (KMS2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "kmsclient":
-        case "kmsClient": getOrCreateConfiguration(target).getKmsClient(); return true;
+        case "kmsClient": return getOrCreateConfiguration(target).getKmsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java
index 95656fe..a04572a 100644
--- a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java
+++ b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class KMS2EndpointConfigurer extends PropertyConfigurerSupport implements
         KMS2Endpoint target = (KMS2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "kmsclient":
-        case "kmsClient": target.getConfiguration().getKmsClient(); return true;
+        case "kmsClient": return target.getConfiguration().getKmsClient();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java
index 6ceae12..afbe82b 100644
--- a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java
+++ b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class Lambda2ComponentConfigurer extends PropertyConfigurerSupport implem
         Lambda2Component target = (Lambda2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "awslambdaclient":
-        case "awsLambdaClient": getOrCreateConfiguration(target).getAwsLambdaClient(); return true;
+        case "awsLambdaClient": return getOrCreateConfiguration(target).getAwsLambdaClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java
index d5a1891..16e49a04 100644
--- a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java
+++ b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class Lambda2EndpointConfigurer extends PropertyConfigurerSupport impleme
         Lambda2Endpoint target = (Lambda2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "awslambdaclient":
-        case "awsLambdaClient": target.getConfiguration().getAwsLambdaClient(); return true;
+        case "awsLambdaClient": return target.getConfiguration().getAwsLambdaClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java
index 67e2462..940b3fc 100644
--- a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java
+++ b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class MQ2ComponentConfigurer extends PropertyConfigurerSupport implements
         MQ2Component target = (MQ2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonmqclient":
-        case "amazonMqClient": getOrCreateConfiguration(target).getAmazonMqClient(); return true;
+        case "amazonMqClient": return getOrCreateConfiguration(target).getAmazonMqClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java
index 2d9e1c6..7e473c2 100644
--- a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java
+++ b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class MQ2EndpointConfigurer extends PropertyConfigurerSupport implements
         MQ2Endpoint target = (MQ2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonmqclient":
-        case "amazonMqClient": target.getConfiguration().getAmazonMqClient(); return true;
+        case "amazonMqClient": return target.getConfiguration().getAmazonMqClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java
index 701fd54..58abe84 100644
--- a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java
+++ b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java
@@ -71,24 +71,24 @@ public class MSK2ComponentConfigurer extends PropertyConfigurerSupport implement
         MSK2Component target = (MSK2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "mskclient":
-        case "mskClient": getOrCreateConfiguration(target).getMskClient(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "mskClient": return getOrCreateConfiguration(target).getMskClient();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java
index 022ae52..a08cee1 100644
--- a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java
+++ b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java
@@ -64,24 +64,24 @@ public class MSK2EndpointConfigurer extends PropertyConfigurerSupport implements
         MSK2Endpoint target = (MSK2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "mskclient":
-        case "mskClient": target.getConfiguration().getMskClient(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "mskClient": return target.getConfiguration().getMskClient();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java
index 41ba0de..5c3e534 100644
--- a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java
+++ b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java
@@ -125,59 +125,59 @@ public class AWS2S3ComponentConfigurer extends PropertyConfigurerSupport impleme
         AWS2S3Component target = (AWS2S3Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazons3client":
-        case "amazonS3Client": getOrCreateConfiguration(target).getAmazonS3Client(); return true;
+        case "amazonS3Client": return getOrCreateConfiguration(target).getAmazonS3Client();
         case "autocreatebucket":
-        case "autoCreateBucket": getOrCreateConfiguration(target).isAutoCreateBucket(); return true;
+        case "autoCreateBucket": return getOrCreateConfiguration(target).isAutoCreateBucket();
         case "autoclosebody":
-        case "autocloseBody": getOrCreateConfiguration(target).isAutocloseBody(); return true;
+        case "autocloseBody": return getOrCreateConfiguration(target).isAutocloseBody();
         case "awskmskeyid":
-        case "awsKMSKeyId": getOrCreateConfiguration(target).getAwsKMSKeyId(); return true;
+        case "awsKMSKeyId": return getOrCreateConfiguration(target).getAwsKMSKeyId();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "deleteafterread":
-        case "deleteAfterRead": getOrCreateConfiguration(target).isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return getOrCreateConfiguration(target).isDeleteAfterRead();
         case "deleteafterwrite":
-        case "deleteAfterWrite": getOrCreateConfiguration(target).isDeleteAfterWrite(); return true;
-        case "delimiter": getOrCreateConfiguration(target).getDelimiter(); return true;
+        case "deleteAfterWrite": return getOrCreateConfiguration(target).isDeleteAfterWrite();
+        case "delimiter": return getOrCreateConfiguration(target).getDelimiter();
         case "filename":
-        case "fileName": getOrCreateConfiguration(target).getFileName(); return true;
+        case "fileName": return getOrCreateConfiguration(target).getFileName();
         case "includebody":
-        case "includeBody": getOrCreateConfiguration(target).isIncludeBody(); return true;
+        case "includeBody": return getOrCreateConfiguration(target).isIncludeBody();
         case "keyname":
-        case "keyName": getOrCreateConfiguration(target).getKeyName(); return true;
+        case "keyName": return getOrCreateConfiguration(target).getKeyName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "multipartupload":
-        case "multiPartUpload": getOrCreateConfiguration(target).isMultiPartUpload(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "multiPartUpload": return getOrCreateConfiguration(target).isMultiPartUpload();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "overrideendpoint":
-        case "overrideEndpoint": getOrCreateConfiguration(target).isOverrideEndpoint(); return true;
+        case "overrideEndpoint": return getOrCreateConfiguration(target).isOverrideEndpoint();
         case "partsize":
-        case "partSize": getOrCreateConfiguration(target).getPartSize(); return true;
-        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
-        case "prefix": getOrCreateConfiguration(target).getPrefix(); return true;
+        case "partSize": return getOrCreateConfiguration(target).getPartSize();
+        case "policy": return getOrCreateConfiguration(target).getPolicy();
+        case "prefix": return getOrCreateConfiguration(target).getPrefix();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "storageclass":
-        case "storageClass": getOrCreateConfiguration(target).getStorageClass(); return true;
+        case "storageClass": return getOrCreateConfiguration(target).getStorageClass();
         case "uriendpointoverride":
-        case "uriEndpointOverride": getOrCreateConfiguration(target).getUriEndpointOverride(); return true;
+        case "uriEndpointOverride": return getOrCreateConfiguration(target).getUriEndpointOverride();
         case "useawskms":
-        case "useAwsKMS": getOrCreateConfiguration(target).isUseAwsKMS(); return true;
+        case "useAwsKMS": return getOrCreateConfiguration(target).isUseAwsKMS();
         case "useiamcredentials":
-        case "useIAMCredentials": getOrCreateConfiguration(target).isUseIAMCredentials(); return true;
+        case "useIAMCredentials": return getOrCreateConfiguration(target).isUseIAMCredentials();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java
index acd5708..27a89f0 100644
--- a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java
+++ b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java
@@ -175,96 +175,96 @@ public class AWS2S3EndpointConfigurer extends PropertyConfigurerSupport implemen
         AWS2S3Endpoint target = (AWS2S3Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazons3client":
-        case "amazonS3Client": target.getConfiguration().getAmazonS3Client(); return true;
+        case "amazonS3Client": return target.getConfiguration().getAmazonS3Client();
         case "autocreatebucket":
-        case "autoCreateBucket": target.getConfiguration().isAutoCreateBucket(); return true;
+        case "autoCreateBucket": return target.getConfiguration().isAutoCreateBucket();
         case "autoclosebody":
-        case "autocloseBody": target.getConfiguration().isAutocloseBody(); return true;
+        case "autocloseBody": return target.getConfiguration().isAutocloseBody();
         case "awskmskeyid":
-        case "awsKMSKeyId": target.getConfiguration().getAwsKMSKeyId(); return true;
+        case "awsKMSKeyId": return target.getConfiguration().getAwsKMSKeyId();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
         case "deleteafterread":
-        case "deleteAfterRead": target.getConfiguration().isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return target.getConfiguration().isDeleteAfterRead();
         case "deleteafterwrite":
-        case "deleteAfterWrite": target.getConfiguration().isDeleteAfterWrite(); return true;
-        case "delimiter": target.getConfiguration().getDelimiter(); return true;
+        case "deleteAfterWrite": return target.getConfiguration().isDeleteAfterWrite();
+        case "delimiter": return target.getConfiguration().getDelimiter();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "filename":
-        case "fileName": target.getConfiguration().getFileName(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "fileName": return target.getConfiguration().getFileName();
+        case "greedy": return target.isGreedy();
         case "includebody":
-        case "includeBody": target.getConfiguration().isIncludeBody(); return true;
+        case "includeBody": return target.getConfiguration().isIncludeBody();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "keyname":
-        case "keyName": target.getConfiguration().getKeyName(); return true;
+        case "keyName": return target.getConfiguration().getKeyName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxconnections":
-        case "maxConnections": target.getMaxConnections(); return true;
+        case "maxConnections": return target.getMaxConnections();
         case "maxmessagesperpoll":
-        case "maxMessagesPerPoll": target.getMaxMessagesPerPoll(); return true;
+        case "maxMessagesPerPoll": return target.getMaxMessagesPerPoll();
         case "multipartupload":
-        case "multiPartUpload": target.getConfiguration().isMultiPartUpload(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "multiPartUpload": return target.getConfiguration().isMultiPartUpload();
+        case "operation": return target.getConfiguration().getOperation();
         case "overrideendpoint":
-        case "overrideEndpoint": target.getConfiguration().isOverrideEndpoint(); return true;
+        case "overrideEndpoint": return target.getConfiguration().isOverrideEndpoint();
         case "partsize":
-        case "partSize": target.getConfiguration().getPartSize(); return true;
-        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "partSize": return target.getConfiguration().getPartSize();
+        case "policy": return target.getConfiguration().getPolicy();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
-        case "prefix": target.getConfiguration().getPrefix(); return true;
+        case "pollStrategy": return target.getPollStrategy();
+        case "prefix": return target.getConfiguration().getPrefix();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
+        case "startScheduler": return target.isStartScheduler();
         case "storageclass":
-        case "storageClass": target.getConfiguration().getStorageClass(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "storageClass": return target.getConfiguration().getStorageClass();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "uriendpointoverride":
-        case "uriEndpointOverride": target.getConfiguration().getUriEndpointOverride(); return true;
+        case "uriEndpointOverride": return target.getConfiguration().getUriEndpointOverride();
         case "useawskms":
-        case "useAwsKMS": target.getConfiguration().isUseAwsKMS(); return true;
+        case "useAwsKMS": return target.getConfiguration().isUseAwsKMS();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         case "useiamcredentials":
-        case "useIAMCredentials": target.getConfiguration().isUseIAMCredentials(); return true;
+        case "useIAMCredentials": return target.getConfiguration().isUseIAMCredentials();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java
index f5499e5..d953311 100644
--- a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java
+++ b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java
@@ -79,29 +79,29 @@ public class Ses2ComponentConfigurer extends PropertyConfigurerSupport implement
         Ses2Component target = (Ses2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonsesclient":
-        case "amazonSESClient": getOrCreateConfiguration(target).getAmazonSESClient(); return true;
+        case "amazonSESClient": return getOrCreateConfiguration(target).getAmazonSESClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "replytoaddresses":
-        case "replyToAddresses": getOrCreateConfiguration(target).getReplyToAddresses(); return true;
+        case "replyToAddresses": return getOrCreateConfiguration(target).getReplyToAddresses();
         case "returnpath":
-        case "returnPath": getOrCreateConfiguration(target).getReturnPath(); return true;
+        case "returnPath": return getOrCreateConfiguration(target).getReturnPath();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
-        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
-        case "to": getOrCreateConfiguration(target).getTo(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
+        case "subject": return getOrCreateConfiguration(target).getSubject();
+        case "to": return getOrCreateConfiguration(target).getTo();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java
index 7805f9c..7d50a5f 100644
--- a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java
+++ b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java
@@ -72,29 +72,29 @@ public class Ses2EndpointConfigurer extends PropertyConfigurerSupport implements
         Ses2Endpoint target = (Ses2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonsesclient":
-        case "amazonSESClient": target.getConfiguration().getAmazonSESClient(); return true;
+        case "amazonSESClient": return target.getConfiguration().getAmazonSESClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "replytoaddresses":
-        case "replyToAddresses": target.getConfiguration().getReplyToAddresses(); return true;
+        case "replyToAddresses": return target.getConfiguration().getReplyToAddresses();
         case "returnpath":
-        case "returnPath": target.getConfiguration().getReturnPath(); return true;
+        case "returnPath": return target.getConfiguration().getReturnPath();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
-        case "subject": target.getConfiguration().getSubject(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "to": target.getConfiguration().getTo(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
+        case "subject": return target.getConfiguration().getSubject();
+        case "synchronous": return target.isSynchronous();
+        case "to": return target.getConfiguration().getTo();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java
index 208b6f9..724d00c 100644
--- a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java
+++ b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java
@@ -91,37 +91,37 @@ public class Sns2ComponentConfigurer extends PropertyConfigurerSupport implement
         Sns2Component target = (Sns2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonsnsclient":
-        case "amazonSNSClient": getOrCreateConfiguration(target).getAmazonSNSClient(); return true;
+        case "amazonSNSClient": return getOrCreateConfiguration(target).getAmazonSNSClient();
         case "autocreatetopic":
-        case "autoCreateTopic": getOrCreateConfiguration(target).isAutoCreateTopic(); return true;
+        case "autoCreateTopic": return getOrCreateConfiguration(target).isAutoCreateTopic();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": getOrCreateConfiguration(target).getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return getOrCreateConfiguration(target).getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messagestructure":
-        case "messageStructure": getOrCreateConfiguration(target).getMessageStructure(); return true;
-        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
+        case "messageStructure": return getOrCreateConfiguration(target).getMessageStructure();
+        case "policy": return getOrCreateConfiguration(target).getPolicy();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
         case "queueurl":
-        case "queueUrl": getOrCreateConfiguration(target).getQueueUrl(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "queueUrl": return getOrCreateConfiguration(target).getQueueUrl();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": getOrCreateConfiguration(target).isServerSideEncryptionEnabled(); return true;
-        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
+        case "serverSideEncryptionEnabled": return getOrCreateConfiguration(target).isServerSideEncryptionEnabled();
+        case "subject": return getOrCreateConfiguration(target).getSubject();
         case "subscribesnstosqs":
-        case "subscribeSNStoSQS": getOrCreateConfiguration(target).isSubscribeSNStoSQS(); return true;
+        case "subscribeSNStoSQS": return getOrCreateConfiguration(target).isSubscribeSNStoSQS();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java
index 37fac23..738d1be 100644
--- a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java
+++ b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java
@@ -87,39 +87,39 @@ public class Sns2EndpointConfigurer extends PropertyConfigurerSupport implements
         Sns2Endpoint target = (Sns2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonsnsclient":
-        case "amazonSNSClient": target.getConfiguration().getAmazonSNSClient(); return true;
+        case "amazonSNSClient": return target.getConfiguration().getAmazonSNSClient();
         case "autocreatetopic":
-        case "autoCreateTopic": target.getConfiguration().isAutoCreateTopic(); return true;
+        case "autoCreateTopic": return target.getConfiguration().isAutoCreateTopic();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": target.getConfiguration().getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return target.getConfiguration().getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messagestructure":
-        case "messageStructure": target.getConfiguration().getMessageStructure(); return true;
-        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "messageStructure": return target.getConfiguration().getMessageStructure();
+        case "policy": return target.getConfiguration().getPolicy();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
         case "queueurl":
-        case "queueUrl": target.getConfiguration().getQueueUrl(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "queueUrl": return target.getConfiguration().getQueueUrl();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": target.getConfiguration().isServerSideEncryptionEnabled(); return true;
-        case "subject": target.getConfiguration().getSubject(); return true;
+        case "serverSideEncryptionEnabled": return target.getConfiguration().isServerSideEncryptionEnabled();
+        case "subject": return target.getConfiguration().getSubject();
         case "subscribesnstosqs":
-        case "subscribeSNStoSQS": target.getConfiguration().isSubscribeSNStoSQS(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "subscribeSNStoSQS": return target.getConfiguration().isSubscribeSNStoSQS();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java b/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java
index 654dd5f..425da8a 100644
--- a/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java
+++ b/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java
@@ -150,76 +150,76 @@ public class Sqs2ComponentConfigurer extends PropertyConfigurerSupport implement
         Sqs2Component target = (Sqs2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "amazonawshost":
-        case "amazonAWSHost": getOrCreateConfiguration(target).getAmazonAWSHost(); return true;
+        case "amazonAWSHost": return getOrCreateConfiguration(target).getAmazonAWSHost();
         case "amazonsqsclient":
-        case "amazonSQSClient": getOrCreateConfiguration(target).getAmazonSQSClient(); return true;
+        case "amazonSQSClient": return getOrCreateConfiguration(target).getAmazonSQSClient();
         case "attributenames":
-        case "attributeNames": getOrCreateConfiguration(target).getAttributeNames(); return true;
+        case "attributeNames": return getOrCreateConfiguration(target).getAttributeNames();
         case "autocreatequeue":
-        case "autoCreateQueue": getOrCreateConfiguration(target).isAutoCreateQueue(); return true;
+        case "autoCreateQueue": return getOrCreateConfiguration(target).isAutoCreateQueue();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "concurrentconsumers":
-        case "concurrentConsumers": getOrCreateConfiguration(target).getConcurrentConsumers(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "concurrentConsumers": return getOrCreateConfiguration(target).getConcurrentConsumers();
+        case "configuration": return target.getConfiguration();
         case "defaultvisibilitytimeout":
-        case "defaultVisibilityTimeout": getOrCreateConfiguration(target).getDefaultVisibilityTimeout(); return true;
+        case "defaultVisibilityTimeout": return getOrCreateConfiguration(target).getDefaultVisibilityTimeout();
         case "delayqueue":
-        case "delayQueue": getOrCreateConfiguration(target).isDelayQueue(); return true;
+        case "delayQueue": return getOrCreateConfiguration(target).isDelayQueue();
         case "delayseconds":
-        case "delaySeconds": getOrCreateConfiguration(target).getDelaySeconds(); return true;
+        case "delaySeconds": return getOrCreateConfiguration(target).getDelaySeconds();
         case "deleteafterread":
-        case "deleteAfterRead": getOrCreateConfiguration(target).isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return getOrCreateConfiguration(target).isDeleteAfterRead();
         case "deleteiffiltered":
-        case "deleteIfFiltered": getOrCreateConfiguration(target).isDeleteIfFiltered(); return true;
+        case "deleteIfFiltered": return getOrCreateConfiguration(target).isDeleteIfFiltered();
         case "extendmessagevisibility":
-        case "extendMessageVisibility": getOrCreateConfiguration(target).isExtendMessageVisibility(); return true;
+        case "extendMessageVisibility": return getOrCreateConfiguration(target).isExtendMessageVisibility();
         case "kmsdatakeyreuseperiodseconds":
-        case "kmsDataKeyReusePeriodSeconds": getOrCreateConfiguration(target).getKmsDataKeyReusePeriodSeconds(); return true;
+        case "kmsDataKeyReusePeriodSeconds": return getOrCreateConfiguration(target).getKmsDataKeyReusePeriodSeconds();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": getOrCreateConfiguration(target).getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return getOrCreateConfiguration(target).getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maximummessagesize":
-        case "maximumMessageSize": getOrCreateConfiguration(target).getMaximumMessageSize(); return true;
+        case "maximumMessageSize": return getOrCreateConfiguration(target).getMaximumMessageSize();
         case "messageattributenames":
-        case "messageAttributeNames": getOrCreateConfiguration(target).getMessageAttributeNames(); return true;
+        case "messageAttributeNames": return getOrCreateConfiguration(target).getMessageAttributeNames();
         case "messagededuplicationidstrategy":
-        case "messageDeduplicationIdStrategy": getOrCreateConfiguration(target).getMessageDeduplicationIdStrategy(); return true;
+        case "messageDeduplicationIdStrategy": return getOrCreateConfiguration(target).getMessageDeduplicationIdStrategy();
         case "messagegroupidstrategy":
-        case "messageGroupIdStrategy": getOrCreateConfiguration(target).getMessageGroupIdStrategy(); return true;
+        case "messageGroupIdStrategy": return getOrCreateConfiguration(target).getMessageGroupIdStrategy();
         case "messageretentionperiod":
-        case "messageRetentionPeriod": getOrCreateConfiguration(target).getMessageRetentionPeriod(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
-        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
-        case "protocol": getOrCreateConfiguration(target).getProtocol(); return true;
+        case "messageRetentionPeriod": return getOrCreateConfiguration(target).getMessageRetentionPeriod();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
+        case "policy": return getOrCreateConfiguration(target).getPolicy();
+        case "protocol": return getOrCreateConfiguration(target).getProtocol();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
         case "queueownerawsaccountid":
-        case "queueOwnerAWSAccountId": getOrCreateConfiguration(target).getQueueOwnerAWSAccountId(); return true;
+        case "queueOwnerAWSAccountId": return getOrCreateConfiguration(target).getQueueOwnerAWSAccountId();
         case "queueurl":
-        case "queueUrl": getOrCreateConfiguration(target).getQueueUrl(); return true;
+        case "queueUrl": return getOrCreateConfiguration(target).getQueueUrl();
         case "receivemessagewaittimeseconds":
-        case "receiveMessageWaitTimeSeconds": getOrCreateConfiguration(target).getReceiveMessageWaitTimeSeconds(); return true;
+        case "receiveMessageWaitTimeSeconds": return getOrCreateConfiguration(target).getReceiveMessageWaitTimeSeconds();
         case "redrivepolicy":
-        case "redrivePolicy": getOrCreateConfiguration(target).getRedrivePolicy(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "redrivePolicy": return getOrCreateConfiguration(target).getRedrivePolicy();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": getOrCreateConfiguration(target).isServerSideEncryptionEnabled(); return true;
+        case "serverSideEncryptionEnabled": return getOrCreateConfiguration(target).isServerSideEncryptionEnabled();
         case "visibilitytimeout":
-        case "visibilityTimeout": getOrCreateConfiguration(target).getVisibilityTimeout(); return true;
+        case "visibilityTimeout": return getOrCreateConfiguration(target).getVisibilityTimeout();
         case "waittimeseconds":
-        case "waitTimeSeconds": getOrCreateConfiguration(target).getWaitTimeSeconds(); return true;
+        case "waitTimeSeconds": return getOrCreateConfiguration(target).getWaitTimeSeconds();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2EndpointConfigurer.java b/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2EndpointConfigurer.java
index d09eaf6..19fe1cd 100644
--- a/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2EndpointConfigurer.java
+++ b/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2EndpointConfigurer.java
@@ -200,113 +200,113 @@ public class Sqs2EndpointConfigurer extends PropertyConfigurerSupport implements
         Sqs2Endpoint target = (Sqs2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "amazonawshost":
-        case "amazonAWSHost": target.getConfiguration().getAmazonAWSHost(); return true;
+        case "amazonAWSHost": return target.getConfiguration().getAmazonAWSHost();
         case "amazonsqsclient":
-        case "amazonSQSClient": target.getConfiguration().getAmazonSQSClient(); return true;
+        case "amazonSQSClient": return target.getConfiguration().getAmazonSQSClient();
         case "attributenames":
-        case "attributeNames": target.getConfiguration().getAttributeNames(); return true;
+        case "attributeNames": return target.getConfiguration().getAttributeNames();
         case "autocreatequeue":
-        case "autoCreateQueue": target.getConfiguration().isAutoCreateQueue(); return true;
+        case "autoCreateQueue": return target.getConfiguration().isAutoCreateQueue();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "concurrentconsumers":
-        case "concurrentConsumers": target.getConfiguration().getConcurrentConsumers(); return true;
+        case "concurrentConsumers": return target.getConfiguration().getConcurrentConsumers();
         case "defaultvisibilitytimeout":
-        case "defaultVisibilityTimeout": target.getConfiguration().getDefaultVisibilityTimeout(); return true;
-        case "delay": target.getDelay(); return true;
+        case "defaultVisibilityTimeout": return target.getConfiguration().getDefaultVisibilityTimeout();
+        case "delay": return target.getDelay();
         case "delayqueue":
-        case "delayQueue": target.getConfiguration().isDelayQueue(); return true;
+        case "delayQueue": return target.getConfiguration().isDelayQueue();
         case "delayseconds":
-        case "delaySeconds": target.getConfiguration().getDelaySeconds(); return true;
+        case "delaySeconds": return target.getConfiguration().getDelaySeconds();
         case "deleteafterread":
-        case "deleteAfterRead": target.getConfiguration().isDeleteAfterRead(); return true;
+        case "deleteAfterRead": return target.getConfiguration().isDeleteAfterRead();
         case "deleteiffiltered":
-        case "deleteIfFiltered": target.getConfiguration().isDeleteIfFiltered(); return true;
+        case "deleteIfFiltered": return target.getConfiguration().isDeleteIfFiltered();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "extendmessagevisibility":
-        case "extendMessageVisibility": target.getConfiguration().isExtendMessageVisibility(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "extendMessageVisibility": return target.getConfiguration().isExtendMessageVisibility();
+        case "greedy": return target.isGreedy();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "kmsdatakeyreuseperiodseconds":
-        case "kmsDataKeyReusePeriodSeconds": target.getConfiguration().getKmsDataKeyReusePeriodSeconds(); return true;
+        case "kmsDataKeyReusePeriodSeconds": return target.getConfiguration().getKmsDataKeyReusePeriodSeconds();
         case "kmsmasterkeyid":
-        case "kmsMasterKeyId": target.getConfiguration().getKmsMasterKeyId(); return true;
+        case "kmsMasterKeyId": return target.getConfiguration().getKmsMasterKeyId();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxmessagesperpoll":
-        case "maxMessagesPerPoll": target.getMaxMessagesPerPoll(); return true;
+        case "maxMessagesPerPoll": return target.getMaxMessagesPerPoll();
         case "maximummessagesize":
-        case "maximumMessageSize": target.getConfiguration().getMaximumMessageSize(); return true;
+        case "maximumMessageSize": return target.getConfiguration().getMaximumMessageSize();
         case "messageattributenames":
-        case "messageAttributeNames": target.getConfiguration().getMessageAttributeNames(); return true;
+        case "messageAttributeNames": return target.getConfiguration().getMessageAttributeNames();
         case "messagededuplicationidstrategy":
-        case "messageDeduplicationIdStrategy": target.getConfiguration().getMessageDeduplicationIdStrategy(); return true;
+        case "messageDeduplicationIdStrategy": return target.getConfiguration().getMessageDeduplicationIdStrategy();
         case "messagegroupidstrategy":
-        case "messageGroupIdStrategy": target.getConfiguration().getMessageGroupIdStrategy(); return true;
+        case "messageGroupIdStrategy": return target.getConfiguration().getMessageGroupIdStrategy();
         case "messageretentionperiod":
-        case "messageRetentionPeriod": target.getConfiguration().getMessageRetentionPeriod(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
-        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "messageRetentionPeriod": return target.getConfiguration().getMessageRetentionPeriod();
+        case "operation": return target.getConfiguration().getOperation();
+        case "policy": return target.getConfiguration().getPolicy();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
-        case "protocol": target.getConfiguration().getProtocol(); return true;
+        case "pollStrategy": return target.getPollStrategy();
+        case "protocol": return target.getConfiguration().getProtocol();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
         case "queueownerawsaccountid":
-        case "queueOwnerAWSAccountId": target.getConfiguration().getQueueOwnerAWSAccountId(); return true;
+        case "queueOwnerAWSAccountId": return target.getConfiguration().getQueueOwnerAWSAccountId();
         case "queueurl":
-        case "queueUrl": target.getConfiguration().getQueueUrl(); return true;
+        case "queueUrl": return target.getConfiguration().getQueueUrl();
         case "receivemessagewaittimeseconds":
-        case "receiveMessageWaitTimeSeconds": target.getConfiguration().getReceiveMessageWaitTimeSeconds(); return true;
+        case "receiveMessageWaitTimeSeconds": return target.getConfiguration().getReceiveMessageWaitTimeSeconds();
         case "redrivepolicy":
-        case "redrivePolicy": target.getConfiguration().getRedrivePolicy(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "redrivePolicy": return target.getConfiguration().getRedrivePolicy();
+        case "region": return target.getConfiguration().getRegion();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "serversideencryptionenabled":
-        case "serverSideEncryptionEnabled": target.getConfiguration().isServerSideEncryptionEnabled(); return true;
+        case "serverSideEncryptionEnabled": return target.getConfiguration().isServerSideEncryptionEnabled();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         case "visibilitytimeout":
-        case "visibilityTimeout": target.getConfiguration().getVisibilityTimeout(); return true;
+        case "visibilityTimeout": return target.getConfiguration().getVisibilityTimeout();
         case "waittimeseconds":
-        case "waitTimeSeconds": target.getConfiguration().getWaitTimeSeconds(); return true;
+        case "waitTimeSeconds": return target.getConfiguration().getWaitTimeSeconds();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2ComponentConfigurer.java b/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2ComponentConfigurer.java
index 53cf5cf..13dbc6e 100644
--- a/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2ComponentConfigurer.java
+++ b/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2ComponentConfigurer.java
@@ -80,30 +80,30 @@ public class Translate2ComponentConfigurer extends PropertyConfigurerSupport imp
         Translate2Component target = (Translate2Component) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "accessKey": return getOrCreateConfiguration(target).getAccessKey();
         case "autodetectsourcelanguage":
-        case "autodetectSourceLanguage": getOrCreateConfiguration(target).isAutodetectSourceLanguage(); return true;
+        case "autodetectSourceLanguage": return getOrCreateConfiguration(target).isAutodetectSourceLanguage();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "proxyhost":
-        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyHost": return getOrCreateConfiguration(target).getProxyHost();
         case "proxyport":
-        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyPort": return getOrCreateConfiguration(target).getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
-        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "proxyProtocol": return getOrCreateConfiguration(target).getProxyProtocol();
+        case "region": return getOrCreateConfiguration(target).getRegion();
         case "secretkey":
-        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "secretKey": return getOrCreateConfiguration(target).getSecretKey();
         case "sourcelanguage":
-        case "sourceLanguage": getOrCreateConfiguration(target).getSourceLanguage(); return true;
+        case "sourceLanguage": return getOrCreateConfiguration(target).getSourceLanguage();
         case "targetlanguage":
-        case "targetLanguage": getOrCreateConfiguration(target).getTargetLanguage(); return true;
+        case "targetLanguage": return getOrCreateConfiguration(target).getTargetLanguage();
         case "translateclient":
-        case "translateClient": getOrCreateConfiguration(target).getTranslateClient(); return true;
+        case "translateClient": return getOrCreateConfiguration(target).getTranslateClient();
         default: return null;
         }
     }
diff --git a/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2EndpointConfigurer.java b/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2EndpointConfigurer.java
index bacac0b..ae6023c 100644
--- a/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2EndpointConfigurer.java
+++ b/components/camel-aws2-translate/src/generated/java/org/apache/camel/component/aws2/translate/Translate2EndpointConfigurer.java
@@ -73,30 +73,30 @@ public class Translate2EndpointConfigurer extends PropertyConfigurerSupport impl
         Translate2Endpoint target = (Translate2Endpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesskey":
-        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "accessKey": return target.getConfiguration().getAccessKey();
         case "autodetectsourcelanguage":
-        case "autodetectSourceLanguage": target.getConfiguration().isAutodetectSourceLanguage(); return true;
+        case "autodetectSourceLanguage": return target.getConfiguration().isAutodetectSourceLanguage();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "proxyprotocol":
-        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
-        case "region": target.getConfiguration().getRegion(); return true;
+        case "proxyProtocol": return target.getConfiguration().getProxyProtocol();
+        case "region": return target.getConfiguration().getRegion();
         case "secretkey":
-        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "secretKey": return target.getConfiguration().getSecretKey();
         case "sourcelanguage":
-        case "sourceLanguage": target.getConfiguration().getSourceLanguage(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "sourceLanguage": return target.getConfiguration().getSourceLanguage();
+        case "synchronous": return target.isSynchronous();
         case "targetlanguage":
-        case "targetLanguage": target.getConfiguration().getTargetLanguage(); return true;
+        case "targetLanguage": return target.getConfiguration().getTargetLanguage();
         case "translateclient":
-        case "translateClient": target.getConfiguration().getTranslateClient(); return true;
+        case "translateClient": return target.getConfiguration().getTranslateClient();
         default: return null;
         }
     }
diff --git a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceComponentConfigurer.java b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceComponentConfigurer.java
index b62053b..a73a745 100644
--- a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceComponentConfigurer.java
+++ b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceComponentConfigurer.java
@@ -101,44 +101,44 @@ public class BlobServiceComponentConfigurer extends PropertyConfigurerSupport im
         BlobServiceComponent target = (BlobServiceComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "azureblobclient":
-        case "azureBlobClient": getOrCreateConfiguration(target).getAzureBlobClient(); return true;
+        case "azureBlobClient": return getOrCreateConfiguration(target).getAzureBlobClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "blobmetadata":
-        case "blobMetadata": getOrCreateConfiguration(target).getBlobMetadata(); return true;
+        case "blobMetadata": return getOrCreateConfiguration(target).getBlobMetadata();
         case "bloboffset":
-        case "blobOffset": getOrCreateConfiguration(target).getBlobOffset(); return true;
+        case "blobOffset": return getOrCreateConfiguration(target).getBlobOffset();
         case "blobprefix":
-        case "blobPrefix": getOrCreateConfiguration(target).getBlobPrefix(); return true;
+        case "blobPrefix": return getOrCreateConfiguration(target).getBlobPrefix();
         case "blobtype":
-        case "blobType": getOrCreateConfiguration(target).getBlobType(); return true;
+        case "blobType": return getOrCreateConfiguration(target).getBlobType();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "closestreamafterread":
-        case "closeStreamAfterRead": getOrCreateConfiguration(target).isCloseStreamAfterRead(); return true;
+        case "closeStreamAfterRead": return getOrCreateConfiguration(target).isCloseStreamAfterRead();
         case "closestreamafterwrite":
-        case "closeStreamAfterWrite": getOrCreateConfiguration(target).isCloseStreamAfterWrite(); return true;
-        case "configuration": target.getConfiguration(); return true;
-        case "credentials": getOrCreateConfiguration(target).getCredentials(); return true;
+        case "closeStreamAfterWrite": return getOrCreateConfiguration(target).isCloseStreamAfterWrite();
+        case "configuration": return target.getConfiguration();
+        case "credentials": return getOrCreateConfiguration(target).getCredentials();
         case "credentialsaccountkey":
-        case "credentialsAccountKey": getOrCreateConfiguration(target).getCredentialsAccountKey(); return true;
+        case "credentialsAccountKey": return getOrCreateConfiguration(target).getCredentialsAccountKey();
         case "credentialsaccountname":
-        case "credentialsAccountName": getOrCreateConfiguration(target).getCredentialsAccountName(); return true;
+        case "credentialsAccountName": return getOrCreateConfiguration(target).getCredentialsAccountName();
         case "datalength":
-        case "dataLength": getOrCreateConfiguration(target).getDataLength(); return true;
+        case "dataLength": return getOrCreateConfiguration(target).getDataLength();
         case "filedir":
-        case "fileDir": getOrCreateConfiguration(target).getFileDir(); return true;
+        case "fileDir": return getOrCreateConfiguration(target).getFileDir();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "publicforread":
-        case "publicForRead": getOrCreateConfiguration(target).isPublicForRead(); return true;
+        case "publicForRead": return getOrCreateConfiguration(target).isPublicForRead();
         case "streamreadsize":
-        case "streamReadSize": getOrCreateConfiguration(target).getStreamReadSize(); return true;
+        case "streamReadSize": return getOrCreateConfiguration(target).getStreamReadSize();
         case "streamwritesize":
-        case "streamWriteSize": getOrCreateConfiguration(target).getStreamWriteSize(); return true;
+        case "streamWriteSize": return getOrCreateConfiguration(target).getStreamWriteSize();
         case "useflatlisting":
-        case "useFlatListing": getOrCreateConfiguration(target).isUseFlatListing(); return true;
+        case "useFlatListing": return getOrCreateConfiguration(target).isUseFlatListing();
         default: return null;
         }
     }
diff --git a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceEndpointConfigurer.java b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceEndpointConfigurer.java
index 6cab48f..cbfff3e 100644
--- a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceEndpointConfigurer.java
+++ b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/blob/BlobServiceEndpointConfigurer.java
@@ -100,48 +100,48 @@ public class BlobServiceEndpointConfigurer extends PropertyConfigurerSupport imp
         BlobServiceEndpoint target = (BlobServiceEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "azureblobclient":
-        case "azureBlobClient": target.getConfiguration().getAzureBlobClient(); return true;
+        case "azureBlobClient": return target.getConfiguration().getAzureBlobClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "blobmetadata":
-        case "blobMetadata": target.getConfiguration().getBlobMetadata(); return true;
+        case "blobMetadata": return target.getConfiguration().getBlobMetadata();
         case "bloboffset":
-        case "blobOffset": target.getConfiguration().getBlobOffset(); return true;
+        case "blobOffset": return target.getConfiguration().getBlobOffset();
         case "blobprefix":
-        case "blobPrefix": target.getConfiguration().getBlobPrefix(); return true;
+        case "blobPrefix": return target.getConfiguration().getBlobPrefix();
         case "blobtype":
-        case "blobType": target.getConfiguration().getBlobType(); return true;
+        case "blobType": return target.getConfiguration().getBlobType();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "closestreamafterread":
-        case "closeStreamAfterRead": target.getConfiguration().isCloseStreamAfterRead(); return true;
+        case "closeStreamAfterRead": return target.getConfiguration().isCloseStreamAfterRead();
         case "closestreamafterwrite":
-        case "closeStreamAfterWrite": target.getConfiguration().isCloseStreamAfterWrite(); return true;
-        case "credentials": target.getConfiguration().getCredentials(); return true;
+        case "closeStreamAfterWrite": return target.getConfiguration().isCloseStreamAfterWrite();
+        case "credentials": return target.getConfiguration().getCredentials();
         case "credentialsaccountkey":
-        case "credentialsAccountKey": target.getConfiguration().getCredentialsAccountKey(); return true;
+        case "credentialsAccountKey": return target.getConfiguration().getCredentialsAccountKey();
         case "credentialsaccountname":
-        case "credentialsAccountName": target.getConfiguration().getCredentialsAccountName(); return true;
+        case "credentialsAccountName": return target.getConfiguration().getCredentialsAccountName();
         case "datalength":
-        case "dataLength": target.getConfiguration().getDataLength(); return true;
+        case "dataLength": return target.getConfiguration().getDataLength();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "filedir":
-        case "fileDir": target.getConfiguration().getFileDir(); return true;
+        case "fileDir": return target.getConfiguration().getFileDir();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "publicforread":
-        case "publicForRead": target.getConfiguration().isPublicForRead(); return true;
+        case "publicForRead": return target.getConfiguration().isPublicForRead();
         case "streamreadsize":
-        case "streamReadSize": target.getConfiguration().getStreamReadSize(); return true;
+        case "streamReadSize": return target.getConfiguration().getStreamReadSize();
         case "streamwritesize":
-        case "streamWriteSize": target.getConfiguration().getStreamWriteSize(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "streamWriteSize": return target.getConfiguration().getStreamWriteSize();
+        case "synchronous": return target.isSynchronous();
         case "useflatlisting":
-        case "useFlatListing": target.getConfiguration().isUseFlatListing(); return true;
+        case "useFlatListing": return target.getConfiguration().isUseFlatListing();
         default: return null;
         }
     }
diff --git a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceComponentConfigurer.java b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceComponentConfigurer.java
index fe30f45..6a2ee32 100644
--- a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceComponentConfigurer.java
+++ b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceComponentConfigurer.java
@@ -74,26 +74,26 @@ public class QueueServiceComponentConfigurer extends PropertyConfigurerSupport i
         QueueServiceComponent target = (QueueServiceComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "azurequeueclient":
-        case "azureQueueClient": getOrCreateConfiguration(target).getAzureQueueClient(); return true;
+        case "azureQueueClient": return getOrCreateConfiguration(target).getAzureQueueClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
-        case "credentials": getOrCreateConfiguration(target).getCredentials(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
+        case "credentials": return getOrCreateConfiguration(target).getCredentials();
         case "credentialsaccountkey":
-        case "credentialsAccountKey": getOrCreateConfiguration(target).getCredentialsAccountKey(); return true;
+        case "credentialsAccountKey": return getOrCreateConfiguration(target).getCredentialsAccountKey();
         case "credentialsaccountname":
-        case "credentialsAccountName": getOrCreateConfiguration(target).getCredentialsAccountName(); return true;
+        case "credentialsAccountName": return getOrCreateConfiguration(target).getCredentialsAccountName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messagetimetolive":
-        case "messageTimeToLive": getOrCreateConfiguration(target).getMessageTimeToLive(); return true;
+        case "messageTimeToLive": return getOrCreateConfiguration(target).getMessageTimeToLive();
         case "messagevisibilitydelay":
-        case "messageVisibilityDelay": getOrCreateConfiguration(target).getMessageVisibilityDelay(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "messageVisibilityDelay": return getOrCreateConfiguration(target).getMessageVisibilityDelay();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "queueprefix":
-        case "queuePrefix": getOrCreateConfiguration(target).getQueuePrefix(); return true;
+        case "queuePrefix": return getOrCreateConfiguration(target).getQueuePrefix();
         default: return null;
         }
     }
diff --git a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceEndpointConfigurer.java b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceEndpointConfigurer.java
index ecc4093..9b2673c 100644
--- a/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceEndpointConfigurer.java
+++ b/components/camel-azure/src/generated/java/org/apache/camel/component/azure/queue/QueueServiceEndpointConfigurer.java
@@ -73,30 +73,30 @@ public class QueueServiceEndpointConfigurer extends PropertyConfigurerSupport im
         QueueServiceEndpoint target = (QueueServiceEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "azurequeueclient":
-        case "azureQueueClient": target.getConfiguration().getAzureQueueClient(); return true;
+        case "azureQueueClient": return target.getConfiguration().getAzureQueueClient();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "credentials": target.getConfiguration().getCredentials(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "credentials": return target.getConfiguration().getCredentials();
         case "credentialsaccountkey":
-        case "credentialsAccountKey": target.getConfiguration().getCredentialsAccountKey(); return true;
+        case "credentialsAccountKey": return target.getConfiguration().getCredentialsAccountKey();
         case "credentialsaccountname":
-        case "credentialsAccountName": target.getConfiguration().getCredentialsAccountName(); return true;
+        case "credentialsAccountName": return target.getConfiguration().getCredentialsAccountName();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messagetimetolive":
-        case "messageTimeToLive": target.getConfiguration().getMessageTimeToLive(); return true;
+        case "messageTimeToLive": return target.getConfiguration().getMessageTimeToLive();
         case "messagevisibilitydelay":
-        case "messageVisibilityDelay": target.getConfiguration().getMessageVisibilityDelay(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "messageVisibilityDelay": return target.getConfiguration().getMessageVisibilityDelay();
+        case "operation": return target.getConfiguration().getOperation();
         case "queueprefix":
-        case "queuePrefix": target.getConfiguration().getQueuePrefix(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "queuePrefix": return target.getConfiguration().getQueuePrefix();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorComponentConfigurer.java b/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorComponentConfigurer.java
index fd7ead3..c0d5789 100644
--- a/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorComponentConfigurer.java
+++ b/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorComponentConfigurer.java
@@ -55,19 +55,19 @@ public class BeanValidatorComponentConfigurer extends PropertyConfigurerSupport
         BeanValidatorComponent target = (BeanValidatorComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "constraintvalidatorfactory":
-        case "constraintValidatorFactory": target.getConstraintValidatorFactory(); return true;
+        case "constraintValidatorFactory": return target.getConstraintValidatorFactory();
         case "ignorexmlconfiguration":
-        case "ignoreXmlConfiguration": target.isIgnoreXmlConfiguration(); return true;
+        case "ignoreXmlConfiguration": return target.isIgnoreXmlConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messageinterpolator":
-        case "messageInterpolator": target.getMessageInterpolator(); return true;
+        case "messageInterpolator": return target.getMessageInterpolator();
         case "traversableresolver":
-        case "traversableResolver": target.getTraversableResolver(); return true;
+        case "traversableResolver": return target.getTraversableResolver();
         case "validationproviderresolver":
-        case "validationProviderResolver": target.getValidationProviderResolver(); return true;
+        case "validationProviderResolver": return target.getValidationProviderResolver();
         default: return null;
         }
     }
diff --git a/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorEndpointConfigurer.java b/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorEndpointConfigurer.java
index c1437c8..54efbd8 100644
--- a/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorEndpointConfigurer.java
+++ b/components/camel-bean-validator/src/generated/java/org/apache/camel/component/bean/validator/BeanValidatorEndpointConfigurer.java
@@ -62,23 +62,23 @@ public class BeanValidatorEndpointConfigurer extends PropertyConfigurerSupport i
         BeanValidatorEndpoint target = (BeanValidatorEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "constraintvalidatorfactory":
-        case "constraintValidatorFactory": target.getConstraintValidatorFactory(); return true;
-        case "group": target.getGroup(); return true;
+        case "constraintValidatorFactory": return target.getConstraintValidatorFactory();
+        case "group": return target.getGroup();
         case "ignorexmlconfiguration":
-        case "ignoreXmlConfiguration": target.isIgnoreXmlConfiguration(); return true;
+        case "ignoreXmlConfiguration": return target.isIgnoreXmlConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "messageinterpolator":
-        case "messageInterpolator": target.getMessageInterpolator(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "messageInterpolator": return target.getMessageInterpolator();
+        case "synchronous": return target.isSynchronous();
         case "traversableresolver":
-        case "traversableResolver": target.getTraversableResolver(); return true;
+        case "traversableResolver": return target.getTraversableResolver();
         case "validationproviderresolver":
-        case "validationProviderResolver": target.getValidationProviderResolver(); return true;
+        case "validationProviderResolver": return target.getValidationProviderResolver();
         case "validatorfactory":
-        case "validatorFactory": target.getValidatorFactory(); return true;
+        case "validatorFactory": return target.getValidatorFactory();
         default: return null;
         }
     }
diff --git a/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanComponentConfigurer.java b/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanComponentConfigurer.java
index 1d72246..386460c 100644
--- a/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanComponentConfigurer.java
+++ b/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanComponentConfigurer.java
@@ -44,11 +44,11 @@ public class BeanComponentConfigurer extends PropertyConfigurerSupport implement
         BeanComponent target = (BeanComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "cache": target.getCache(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "cache": return target.getCache();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "scope": target.getScope(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "scope": return target.getScope();
         default: return null;
         }
     }
diff --git a/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanEndpointConfigurer.java b/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanEndpointConfigurer.java
index a0d4a94..2da4b84 100644
--- a/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanEndpointConfigurer.java
+++ b/components/camel-bean/src/generated/java/org/apache/camel/component/bean/BeanEndpointConfigurer.java
@@ -50,14 +50,14 @@ public class BeanEndpointConfigurer extends PropertyConfigurerSupport implements
         BeanEndpoint target = (BeanEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "cache": target.getCache(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "cache": return target.getCache();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "method": target.getMethod(); return true;
-        case "parameters": target.getParameters(); return true;
-        case "scope": target.getScope(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "method": return target.getMethod();
+        case "parameters": return target.getParameters();
+        case "scope": return target.getScope();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkComponentConfigurer.java b/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkComponentConfigurer.java
index 98f0d0d..f1602e3 100644
--- a/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkComponentConfigurer.java
+++ b/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkComponentConfigurer.java
@@ -46,13 +46,13 @@ public class BeanstalkComponentConfigurer extends PropertyConfigurerSupport impl
         BeanstalkComponent target = (BeanstalkComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "connectionsettingsfactory":
-        case "connectionSettingsFactory": target.getConnectionSettingsFactory(); return true;
+        case "connectionSettingsFactory": return target.getConnectionSettingsFactory();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkEndpointConfigurer.java b/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkEndpointConfigurer.java
index 464314c..133f148 100644
--- a/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkEndpointConfigurer.java
+++ b/components/camel-beanstalk/src/generated/java/org/apache/camel/component/beanstalk/BeanstalkEndpointConfigurer.java
@@ -116,58 +116,58 @@ public class BeanstalkEndpointConfigurer extends PropertyConfigurerSupport imple
         BeanstalkEndpoint target = (BeanstalkEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "awaitjob":
-        case "awaitJob": target.isAwaitJob(); return true;
+        case "awaitJob": return target.isAwaitJob();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "command": target.getCommand(); return true;
-        case "delay": target.getDelay(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "command": return target.getCommand();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "jobdelay":
-        case "jobDelay": target.getJobDelay(); return true;
+        case "jobDelay": return target.getJobDelay();
         case "jobpriority":
-        case "jobPriority": target.getJobPriority(); return true;
+        case "jobPriority": return target.getJobPriority();
         case "jobtimetorun":
-        case "jobTimeToRun": target.getJobTimeToRun(); return true;
+        case "jobTimeToRun": return target.getJobTimeToRun();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "onfailure":
-        case "onFailure": target.getOnFailure(); return true;
+        case "onFailure": return target.getOnFailure();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "useblockio":
-        case "useBlockIO": target.isUseBlockIO(); return true;
+        case "useBlockIO": return target.isUseBlockIO();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         default: return null;
         }
     }
diff --git a/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaComponentConfigurer.java b/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaComponentConfigurer.java
index 56fe582..57abd12 100644
--- a/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaComponentConfigurer.java
+++ b/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaComponentConfigurer.java
@@ -40,9 +40,9 @@ public class BonitaComponentConfigurer extends PropertyConfigurerSupport impleme
         BonitaComponent target = (BonitaComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaEndpointConfigurer.java b/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaEndpointConfigurer.java
index 68fe448..5f2349e 100644
--- a/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaEndpointConfigurer.java
+++ b/components/camel-bonita/src/generated/java/org/apache/camel/component/bonita/BonitaEndpointConfigurer.java
@@ -53,16 +53,16 @@ public class BonitaEndpointConfigurer extends PropertyConfigurerSupport implemen
         BonitaEndpoint target = (BonitaEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "hostname": target.getConfiguration().getHostname(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "hostname": return target.getConfiguration().getHostname();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "password": target.getConfiguration().getPassword(); return true;
-        case "port": target.getConfiguration().getPort(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "password": return target.getConfiguration().getPassword();
+        case "port": return target.getConfiguration().getPort();
         case "processname":
-        case "processName": target.getConfiguration().getProcessName(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "username": target.getConfiguration().getUsername(); return true;
+        case "processName": return target.getConfiguration().getProcessName();
+        case "synchronous": return target.isSynchronous();
+        case "username": return target.getConfiguration().getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxComponentConfigurer.java b/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxComponentConfigurer.java
index b0a5af8..022c803 100644
--- a/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxComponentConfigurer.java
+++ b/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxComponentConfigurer.java
@@ -97,42 +97,42 @@ public class BoxComponentConfigurer extends PropertyConfigurerSupport implements
         BoxComponent target = (BoxComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesstokencache":
-        case "accessTokenCache": getOrCreateConfiguration(target).getAccessTokenCache(); return true;
+        case "accessTokenCache": return getOrCreateConfiguration(target).getAccessTokenCache();
         case "authenticationtype":
-        case "authenticationType": getOrCreateConfiguration(target).getAuthenticationType(); return true;
+        case "authenticationType": return getOrCreateConfiguration(target).getAuthenticationType();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "clientid":
-        case "clientId": getOrCreateConfiguration(target).getClientId(); return true;
+        case "clientId": return getOrCreateConfiguration(target).getClientId();
         case "clientsecret":
-        case "clientSecret": getOrCreateConfiguration(target).getClientSecret(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "clientSecret": return getOrCreateConfiguration(target).getClientSecret();
+        case "configuration": return target.getConfiguration();
         case "encryptionalgorithm":
-        case "encryptionAlgorithm": getOrCreateConfiguration(target).getEncryptionAlgorithm(); return true;
+        case "encryptionAlgorithm": return getOrCreateConfiguration(target).getEncryptionAlgorithm();
         case "enterpriseid":
-        case "enterpriseId": getOrCreateConfiguration(target).getEnterpriseId(); return true;
+        case "enterpriseId": return getOrCreateConfiguration(target).getEnterpriseId();
         case "httpparams":
-        case "httpParams": getOrCreateConfiguration(target).getHttpParams(); return true;
+        case "httpParams": return getOrCreateConfiguration(target).getHttpParams();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxcacheentries":
-        case "maxCacheEntries": getOrCreateConfiguration(target).getMaxCacheEntries(); return true;
+        case "maxCacheEntries": return getOrCreateConfiguration(target).getMaxCacheEntries();
         case "privatekeyfile":
-        case "privateKeyFile": getOrCreateConfiguration(target).getPrivateKeyFile(); return true;
+        case "privateKeyFile": return getOrCreateConfiguration(target).getPrivateKeyFile();
         case "privatekeypassword":
-        case "privateKeyPassword": getOrCreateConfiguration(target).getPrivateKeyPassword(); return true;
+        case "privateKeyPassword": return getOrCreateConfiguration(target).getPrivateKeyPassword();
         case "publickeyid":
-        case "publicKeyId": getOrCreateConfiguration(target).getPublicKeyId(); return true;
+        case "publicKeyId": return getOrCreateConfiguration(target).getPublicKeyId();
         case "sslcontextparameters":
-        case "sslContextParameters": getOrCreateConfiguration(target).getSslContextParameters(); return true;
+        case "sslContextParameters": return getOrCreateConfiguration(target).getSslContextParameters();
         case "userid":
-        case "userId": getOrCreateConfiguration(target).getUserId(); return true;
+        case "userId": return getOrCreateConfiguration(target).getUserId();
         case "username":
-        case "userName": getOrCreateConfiguration(target).getUserName(); return true;
+        case "userName": return getOrCreateConfiguration(target).getUserName();
         case "userpassword":
-        case "userPassword": getOrCreateConfiguration(target).getUserPassword(); return true;
+        case "userPassword": return getOrCreateConfiguration(target).getUserPassword();
         default: return null;
         }
     }
diff --git a/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxEndpointConfigurer.java b/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxEndpointConfigurer.java
index 7c233ce..2ead202 100644
--- a/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxEndpointConfigurer.java
+++ b/components/camel-box/camel-box-component/src/generated/java/org/apache/camel/component/box/BoxEndpointConfigurer.java
@@ -144,77 +144,77 @@ public class BoxEndpointConfigurer extends PropertyConfigurerSupport implements
         BoxEndpoint target = (BoxEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesstokencache":
-        case "accessTokenCache": target.getConfiguration().getAccessTokenCache(); return true;
+        case "accessTokenCache": return target.getConfiguration().getAccessTokenCache();
         case "authenticationtype":
-        case "authenticationType": target.getConfiguration().getAuthenticationType(); return true;
+        case "authenticationType": return target.getConfiguration().getAuthenticationType();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "clientid":
-        case "clientId": target.getConfiguration().getClientId(); return true;
+        case "clientId": return target.getConfiguration().getClientId();
         case "clientsecret":
-        case "clientSecret": target.getConfiguration().getClientSecret(); return true;
-        case "delay": target.getDelay(); return true;
+        case "clientSecret": return target.getConfiguration().getClientSecret();
+        case "delay": return target.getDelay();
         case "encryptionalgorithm":
-        case "encryptionAlgorithm": target.getConfiguration().getEncryptionAlgorithm(); return true;
+        case "encryptionAlgorithm": return target.getConfiguration().getEncryptionAlgorithm();
         case "enterpriseid":
-        case "enterpriseId": target.getConfiguration().getEnterpriseId(); return true;
+        case "enterpriseId": return target.getConfiguration().getEnterpriseId();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "httpparams":
-        case "httpParams": target.getConfiguration().getHttpParams(); return true;
+        case "httpParams": return target.getConfiguration().getHttpParams();
         case "inbody":
-        case "inBody": target.getInBody(); return true;
+        case "inBody": return target.getInBody();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maxcacheentries":
-        case "maxCacheEntries": target.getConfiguration().getMaxCacheEntries(); return true;
+        case "maxCacheEntries": return target.getConfiguration().getMaxCacheEntries();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "privatekeyfile":
-        case "privateKeyFile": target.getConfiguration().getPrivateKeyFile(); return true;
+        case "privateKeyFile": return target.getConfiguration().getPrivateKeyFile();
         case "privatekeypassword":
-        case "privateKeyPassword": target.getConfiguration().getPrivateKeyPassword(); return true;
+        case "privateKeyPassword": return target.getConfiguration().getPrivateKeyPassword();
         case "publickeyid":
-        case "publicKeyId": target.getConfiguration().getPublicKeyId(); return true;
+        case "publicKeyId": return target.getConfiguration().getPublicKeyId();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getConfiguration().getSslContextParameters(); return true;
+        case "sslContextParameters": return target.getConfiguration().getSslContextParameters();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         case "userid":
-        case "userId": target.getConfiguration().getUserId(); return true;
+        case "userId": return target.getConfiguration().getUserId();
         case "username":
-        case "userName": target.getConfiguration().getUserName(); return true;
+        case "userName": return target.getConfiguration().getUserName();
         case "userpassword":
-        case "userPassword": target.getConfiguration().getUserPassword(); return true;
+        case "userPassword": return target.getConfiguration().getUserPassword();
         default: return null;
         }
     }
diff --git a/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeComponentConfigurer.java b/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeComponentConfigurer.java
index ce8c47f..aaad4fd 100644
--- a/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeComponentConfigurer.java
+++ b/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeComponentConfigurer.java
@@ -45,12 +45,12 @@ public class BraintreeComponentConfigurer extends PropertyConfigurerSupport impl
         BraintreeComponent target = (BraintreeComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeEndpointConfigurer.java b/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeEndpointConfigurer.java
index 90d1315..65452ff 100644
--- a/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeEndpointConfigurer.java
+++ b/components/camel-braintree/src/generated/java/org/apache/camel/component/braintree/BraintreeEndpointConfigurer.java
@@ -131,68 +131,68 @@ public class BraintreeEndpointConfigurer extends PropertyConfigurerSupport imple
         BraintreeEndpoint target = (BraintreeEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "accesstoken":
-        case "accessToken": target.getConfiguration().getAccessToken(); return true;
+        case "accessToken": return target.getConfiguration().getAccessToken();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "delay": target.getDelay(); return true;
-        case "environment": target.getConfiguration().getEnvironment(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "delay": return target.getDelay();
+        case "environment": return target.getConfiguration().getEnvironment();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "httploglevel":
-        case "httpLogLevel": target.getConfiguration().getHttpLogLevel(); return true;
+        case "httpLogLevel": return target.getConfiguration().getHttpLogLevel();
         case "httplogname":
-        case "httpLogName": target.getConfiguration().getHttpLogName(); return true;
+        case "httpLogName": return target.getConfiguration().getHttpLogName();
         case "httpreadtimeout":
-        case "httpReadTimeout": target.getConfiguration().getHttpReadTimeout(); return true;
+        case "httpReadTimeout": return target.getConfiguration().getHttpReadTimeout();
         case "inbody":
-        case "inBody": target.getInBody(); return true;
+        case "inBody": return target.getInBody();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "loghandlerenabled":
-        case "logHandlerEnabled": target.getConfiguration().isLogHandlerEnabled(); return true;
+        case "logHandlerEnabled": return target.getConfiguration().isLogHandlerEnabled();
         case "merchantid":
-        case "merchantId": target.getConfiguration().getMerchantId(); return true;
+        case "merchantId": return target.getConfiguration().getMerchantId();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "privatekey":
-        case "privateKey": target.getConfiguration().getPrivateKey(); return true;
+        case "privateKey": return target.getConfiguration().getPrivateKey();
         case "proxyhost":
-        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyHost": return target.getConfiguration().getProxyHost();
         case "proxyport":
-        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyPort": return target.getConfiguration().getProxyPort();
         case "publickey":
-        case "publicKey": target.getConfiguration().getPublicKey(); return true;
+        case "publicKey": return target.getConfiguration().getPublicKey();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
         default: return null;
         }
     }
diff --git a/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseComponentConfigurer.java b/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseComponentConfigurer.java
index 5538954..30c2650 100644
--- a/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseComponentConfigurer.java
+++ b/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseComponentConfigurer.java
@@ -43,11 +43,11 @@ public class BrowseComponentConfigurer extends PropertyConfigurerSupport impleme
         BrowseComponent target = (BrowseComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseEndpointConfigurer.java b/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseEndpointConfigurer.java
index 760dca1..42bd598 100644
--- a/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseEndpointConfigurer.java
+++ b/components/camel-browse/src/generated/java/org/apache/camel/component/browse/BrowseEndpointConfigurer.java
@@ -51,16 +51,16 @@ public class BrowseEndpointConfigurer extends PropertyConfigurerSupport implemen
         BrowseEndpoint target = (BrowseEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheComponentConfigurer.java b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheComponentConfigurer.java
index 59bdcdc..9b8182e 100644
--- a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheComponentConfigurer.java
+++ b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheComponentConfigurer.java
@@ -90,38 +90,38 @@ public class CaffeineCacheComponentConfigurer extends PropertyConfigurerSupport
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         CaffeineCacheComponent target = (CaffeineCacheComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "action": getOrCreateConfiguration(target).getAction(); return true;
+        case "action": return getOrCreateConfiguration(target).getAction();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "cache": getOrCreateConfiguration(target).getCache(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "cache": return getOrCreateConfiguration(target).getCache();
         case "cacheloader":
-        case "cacheLoader": getOrCreateConfiguration(target).getCacheLoader(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "cacheLoader": return getOrCreateConfiguration(target).getCacheLoader();
+        case "configuration": return target.getConfiguration();
         case "createcacheifnotexist":
-        case "createCacheIfNotExist": getOrCreateConfiguration(target).isCreateCacheIfNotExist(); return true;
+        case "createCacheIfNotExist": return getOrCreateConfiguration(target).isCreateCacheIfNotExist();
         case "evictiontype":
-        case "evictionType": getOrCreateConfiguration(target).getEvictionType(); return true;
+        case "evictionType": return getOrCreateConfiguration(target).getEvictionType();
         case "expireafteraccesstime":
-        case "expireAfterAccessTime": getOrCreateConfiguration(target).getExpireAfterAccessTime(); return true;
+        case "expireAfterAccessTime": return getOrCreateConfiguration(target).getExpireAfterAccessTime();
         case "expireafterwritetime":
-        case "expireAfterWriteTime": getOrCreateConfiguration(target).getExpireAfterWriteTime(); return true;
+        case "expireAfterWriteTime": return getOrCreateConfiguration(target).getExpireAfterWriteTime();
         case "initialcapacity":
-        case "initialCapacity": getOrCreateConfiguration(target).getInitialCapacity(); return true;
-        case "key": getOrCreateConfiguration(target).getKey(); return true;
+        case "initialCapacity": return getOrCreateConfiguration(target).getInitialCapacity();
+        case "key": return getOrCreateConfiguration(target).getKey();
         case "keytype":
-        case "keyType": getOrCreateConfiguration(target).getKeyType(); return true;
+        case "keyType": return getOrCreateConfiguration(target).getKeyType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maximumsize":
-        case "maximumSize": getOrCreateConfiguration(target).getMaximumSize(); return true;
+        case "maximumSize": return getOrCreateConfiguration(target).getMaximumSize();
         case "removallistener":
-        case "removalListener": getOrCreateConfiguration(target).getRemovalListener(); return true;
+        case "removalListener": return getOrCreateConfiguration(target).getRemovalListener();
         case "statscounter":
-        case "statsCounter": getOrCreateConfiguration(target).getStatsCounter(); return true;
+        case "statsCounter": return getOrCreateConfiguration(target).getStatsCounter();
         case "statsenabled":
-        case "statsEnabled": getOrCreateConfiguration(target).isStatsEnabled(); return true;
+        case "statsEnabled": return getOrCreateConfiguration(target).isStatsEnabled();
         case "valuetype":
-        case "valueType": getOrCreateConfiguration(target).getValueType(); return true;
+        case "valueType": return getOrCreateConfiguration(target).getValueType();
         default: return null;
         }
     }
diff --git a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheEndpointConfigurer.java b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheEndpointConfigurer.java
index 5332811..d82e466 100644
--- a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheEndpointConfigurer.java
+++ b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/cache/CaffeineCacheEndpointConfigurer.java
@@ -83,38 +83,38 @@ public class CaffeineCacheEndpointConfigurer extends PropertyConfigurerSupport i
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         CaffeineCacheEndpoint target = (CaffeineCacheEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "action": target.getConfiguration().getAction(); return true;
+        case "action": return target.getConfiguration().getAction();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "cache": target.getConfiguration().getCache(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "cache": return target.getConfiguration().getCache();
         case "cacheloader":
-        case "cacheLoader": target.getConfiguration().getCacheLoader(); return true;
+        case "cacheLoader": return target.getConfiguration().getCacheLoader();
         case "createcacheifnotexist":
-        case "createCacheIfNotExist": target.getConfiguration().isCreateCacheIfNotExist(); return true;
+        case "createCacheIfNotExist": return target.getConfiguration().isCreateCacheIfNotExist();
         case "evictiontype":
-        case "evictionType": target.getConfiguration().getEvictionType(); return true;
+        case "evictionType": return target.getConfiguration().getEvictionType();
         case "expireafteraccesstime":
-        case "expireAfterAccessTime": target.getConfiguration().getExpireAfterAccessTime(); return true;
+        case "expireAfterAccessTime": return target.getConfiguration().getExpireAfterAccessTime();
         case "expireafterwritetime":
-        case "expireAfterWriteTime": target.getConfiguration().getExpireAfterWriteTime(); return true;
+        case "expireAfterWriteTime": return target.getConfiguration().getExpireAfterWriteTime();
         case "initialcapacity":
-        case "initialCapacity": target.getConfiguration().getInitialCapacity(); return true;
-        case "key": target.getConfiguration().getKey(); return true;
+        case "initialCapacity": return target.getConfiguration().getInitialCapacity();
+        case "key": return target.getConfiguration().getKey();
         case "keytype":
-        case "keyType": target.getConfiguration().getKeyType(); return true;
+        case "keyType": return target.getConfiguration().getKeyType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maximumsize":
-        case "maximumSize": target.getConfiguration().getMaximumSize(); return true;
+        case "maximumSize": return target.getConfiguration().getMaximumSize();
         case "removallistener":
-        case "removalListener": target.getConfiguration().getRemovalListener(); return true;
+        case "removalListener": return target.getConfiguration().getRemovalListener();
         case "statscounter":
-        case "statsCounter": target.getConfiguration().getStatsCounter(); return true;
+        case "statsCounter": return target.getConfiguration().getStatsCounter();
         case "statsenabled":
-        case "statsEnabled": target.getConfiguration().isStatsEnabled(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "statsEnabled": return target.getConfiguration().isStatsEnabled();
+        case "synchronous": return target.isSynchronous();
         case "valuetype":
-        case "valueType": target.getConfiguration().getValueType(); return true;
+        case "valueType": return target.getConfiguration().getValueType();
         default: return null;
         }
     }
diff --git a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheComponentConfigurer.java b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheComponentConfigurer.java
index fd6cdab..a57f1ef 100644
--- a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheComponentConfigurer.java
+++ b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheComponentConfigurer.java
@@ -90,38 +90,38 @@ public class CaffeineLoadCacheComponentConfigurer extends PropertyConfigurerSupp
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         CaffeineLoadCacheComponent target = (CaffeineLoadCacheComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "action": getOrCreateConfiguration(target).getAction(); return true;
+        case "action": return getOrCreateConfiguration(target).getAction();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "cache": getOrCreateConfiguration(target).getCache(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "cache": return getOrCreateConfiguration(target).getCache();
         case "cacheloader":
-        case "cacheLoader": getOrCreateConfiguration(target).getCacheLoader(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "cacheLoader": return getOrCreateConfiguration(target).getCacheLoader();
+        case "configuration": return target.getConfiguration();
         case "createcacheifnotexist":
-        case "createCacheIfNotExist": getOrCreateConfiguration(target).isCreateCacheIfNotExist(); return true;
+        case "createCacheIfNotExist": return getOrCreateConfiguration(target).isCreateCacheIfNotExist();
         case "evictiontype":
-        case "evictionType": getOrCreateConfiguration(target).getEvictionType(); return true;
+        case "evictionType": return getOrCreateConfiguration(target).getEvictionType();
         case "expireafteraccesstime":
-        case "expireAfterAccessTime": getOrCreateConfiguration(target).getExpireAfterAccessTime(); return true;
+        case "expireAfterAccessTime": return getOrCreateConfiguration(target).getExpireAfterAccessTime();
         case "expireafterwritetime":
-        case "expireAfterWriteTime": getOrCreateConfiguration(target).getExpireAfterWriteTime(); return true;
+        case "expireAfterWriteTime": return getOrCreateConfiguration(target).getExpireAfterWriteTime();
         case "initialcapacity":
-        case "initialCapacity": getOrCreateConfiguration(target).getInitialCapacity(); return true;
-        case "key": getOrCreateConfiguration(target).getKey(); return true;
+        case "initialCapacity": return getOrCreateConfiguration(target).getInitialCapacity();
+        case "key": return getOrCreateConfiguration(target).getKey();
         case "keytype":
-        case "keyType": getOrCreateConfiguration(target).getKeyType(); return true;
+        case "keyType": return getOrCreateConfiguration(target).getKeyType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maximumsize":
-        case "maximumSize": getOrCreateConfiguration(target).getMaximumSize(); return true;
+        case "maximumSize": return getOrCreateConfiguration(target).getMaximumSize();
         case "removallistener":
-        case "removalListener": getOrCreateConfiguration(target).getRemovalListener(); return true;
+        case "removalListener": return getOrCreateConfiguration(target).getRemovalListener();
         case "statscounter":
-        case "statsCounter": getOrCreateConfiguration(target).getStatsCounter(); return true;
+        case "statsCounter": return getOrCreateConfiguration(target).getStatsCounter();
         case "statsenabled":
-        case "statsEnabled": getOrCreateConfiguration(target).isStatsEnabled(); return true;
+        case "statsEnabled": return getOrCreateConfiguration(target).isStatsEnabled();
         case "valuetype":
-        case "valueType": getOrCreateConfiguration(target).getValueType(); return true;
+        case "valueType": return getOrCreateConfiguration(target).getValueType();
         default: return null;
         }
     }
diff --git a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheEndpointConfigurer.java b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheEndpointConfigurer.java
index f9d7aee..f1e442c 100644
--- a/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheEndpointConfigurer.java
+++ b/components/camel-caffeine/src/generated/java/org/apache/camel/component/caffeine/load/CaffeineLoadCacheEndpointConfigurer.java
@@ -83,38 +83,38 @@ public class CaffeineLoadCacheEndpointConfigurer extends PropertyConfigurerSuppo
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         CaffeineLoadCacheEndpoint target = (CaffeineLoadCacheEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "action": target.getConfiguration().getAction(); return true;
+        case "action": return target.getConfiguration().getAction();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "cache": target.getConfiguration().getCache(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "cache": return target.getConfiguration().getCache();
         case "cacheloader":
-        case "cacheLoader": target.getConfiguration().getCacheLoader(); return true;
+        case "cacheLoader": return target.getConfiguration().getCacheLoader();
         case "createcacheifnotexist":
-        case "createCacheIfNotExist": target.getConfiguration().isCreateCacheIfNotExist(); return true;
+        case "createCacheIfNotExist": return target.getConfiguration().isCreateCacheIfNotExist();
         case "evictiontype":
-        case "evictionType": target.getConfiguration().getEvictionType(); return true;
+        case "evictionType": return target.getConfiguration().getEvictionType();
         case "expireafteraccesstime":
-        case "expireAfterAccessTime": target.getConfiguration().getExpireAfterAccessTime(); return true;
+        case "expireAfterAccessTime": return target.getConfiguration().getExpireAfterAccessTime();
         case "expireafterwritetime":
-        case "expireAfterWriteTime": target.getConfiguration().getExpireAfterWriteTime(); return true;
+        case "expireAfterWriteTime": return target.getConfiguration().getExpireAfterWriteTime();
         case "initialcapacity":
-        case "initialCapacity": target.getConfiguration().getInitialCapacity(); return true;
-        case "key": target.getConfiguration().getKey(); return true;
+        case "initialCapacity": return target.getConfiguration().getInitialCapacity();
+        case "key": return target.getConfiguration().getKey();
         case "keytype":
-        case "keyType": target.getConfiguration().getKeyType(); return true;
+        case "keyType": return target.getConfiguration().getKeyType();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "maximumsize":
-        case "maximumSize": target.getConfiguration().getMaximumSize(); return true;
+        case "maximumSize": return target.getConfiguration().getMaximumSize();
         case "removallistener":
-        case "removalListener": target.getConfiguration().getRemovalListener(); return true;
+        case "removalListener": return target.getConfiguration().getRemovalListener();
         case "statscounter":
-        case "statsCounter": target.getConfiguration().getStatsCounter(); return true;
+        case "statsCounter": return target.getConfiguration().getStatsCounter();
         case "statsenabled":
-        case "statsEnabled": target.getConfiguration().isStatsEnabled(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "statsEnabled": return target.getConfiguration().isStatsEnabled();
+        case "synchronous": return target.isSynchronous();
         case "valuetype":
-        case "valueType": target.getConfiguration().getValueType(); return true;
+        case "valueType": return target.getConfiguration().getValueType();
         default: return null;
         }
     }
diff --git a/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraComponentConfigurer.java b/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraComponentConfigurer.java
index 701285b..4738b84 100644
--- a/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraComponentConfigurer.java
+++ b/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraComponentConfigurer.java
@@ -43,11 +43,11 @@ public class CassandraComponentConfigurer extends PropertyConfigurerSupport impl
         CassandraComponent target = (CassandraComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraEndpointConfigurer.java b/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraEndpointConfigurer.java
index e9ef9bb..b0b1383 100644
--- a/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraEndpointConfigurer.java
+++ b/components/camel-cassandraql/src/generated/java/org/apache/camel/component/cassandra/CassandraEndpointConfigurer.java
@@ -121,60 +121,60 @@ public class CassandraEndpointConfigurer extends PropertyConfigurerSupport imple
         CassandraEndpoint target = (CassandraEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "cluster": target.getCluster(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "cluster": return target.getCluster();
         case "clustername":
-        case "clusterName": target.getClusterName(); return true;
+        case "clusterName": return target.getClusterName();
         case "consistencylevel":
-        case "consistencyLevel": target.getConsistencyLevel(); return true;
-        case "cql": target.getCql(); return true;
-        case "delay": target.getDelay(); return true;
+        case "consistencyLevel": return target.getConsistencyLevel();
+        case "cql": return target.getCql();
+        case "delay": return target.getDelay();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "loadbalancingpolicy":
-        case "loadBalancingPolicy": target.getLoadBalancingPolicy(); return true;
-        case "password": target.getPassword(); return true;
+        case "loadBalancingPolicy": return target.getLoadBalancingPolicy();
+        case "password": return target.getPassword();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "preparestatements":
-        case "prepareStatements": target.isPrepareStatements(); return true;
+        case "prepareStatements": return target.isPrepareStatements();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "resultsetconversionstrategy":
-        case "resultSetConversionStrategy": target.getResultSetConversionStrategy(); return true;
+        case "resultSetConversionStrategy": return target.getResultSetConversionStrategy();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
-        case "session": target.getSession(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
+        case "session": return target.getSession();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startScheduler": return target.isStartScheduler();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
-        case "username": target.getUsername(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
+        case "username": return target.getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptComponentConfigurer.java b/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptComponentConfigurer.java
index 771374a..148abd2 100644
--- a/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptComponentConfigurer.java
+++ b/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptComponentConfigurer.java
@@ -40,9 +40,9 @@ public class ChatScriptComponentConfigurer extends PropertyConfigurerSupport imp
         ChatScriptComponent target = (ChatScriptComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptEndpointConfigurer.java b/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptEndpointConfigurer.java
index ba9b829..f6a4f5e 100644
--- a/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptEndpointConfigurer.java
+++ b/components/camel-chatscript/src/generated/java/org/apache/camel/component/chatscript/ChatScriptEndpointConfigurer.java
@@ -48,14 +48,14 @@ public class ChatScriptEndpointConfigurer extends PropertyConfigurerSupport impl
         ChatScriptEndpoint target = (ChatScriptEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "chatusername":
-        case "chatUserName": target.getChatUserName(); return true;
+        case "chatUserName": return target.getChatUserName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "resetchat":
-        case "resetChat": target.isResetChat(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "resetChat": return target.isResetChat();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkComponentConfigurer.java b/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkComponentConfigurer.java
index 7281a1e..112a5eb 100644
--- a/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkComponentConfigurer.java
+++ b/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkComponentConfigurer.java
@@ -40,9 +40,9 @@ public class ChunkComponentConfigurer extends PropertyConfigurerSupport implemen
         ChunkComponent target = (ChunkComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkEndpointConfigurer.java b/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkEndpointConfigurer.java
index bd319a8..bfbcfc8 100644
--- a/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkEndpointConfigurer.java
+++ b/components/camel-chunk/src/generated/java/org/apache/camel/component/chunk/ChunkEndpointConfigurer.java
@@ -58,20 +58,20 @@ public class ChunkEndpointConfigurer extends PropertyConfigurerSupport implement
         ChunkEndpoint target = (ChunkEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "contentcache":
-        case "contentCache": target.isContentCache(); return true;
-        case "encoding": target.getEncoding(); return true;
-        case "extension": target.getExtension(); return true;
+        case "contentCache": return target.isContentCache();
+        case "encoding": return target.getEncoding();
+        case "extension": return target.getExtension();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "synchronous": return target.isSynchronous();
         case "themefolder":
-        case "themeFolder": target.getThemeFolder(); return true;
+        case "themeFolder": return target.getThemeFolder();
         case "themelayer":
-        case "themeLayer": target.getThemeLayer(); return true;
+        case "themeLayer": return target.getThemeLayer();
         case "themesubfolder":
-        case "themeSubfolder": target.getThemeSubfolder(); return true;
+        case "themeSubfolder": return target.getThemeSubfolder();
         default: return null;
         }
     }
diff --git a/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMComponentConfigurer.java b/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMComponentConfigurer.java
index 048780b..4e1df63 100644
--- a/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMComponentConfigurer.java
+++ b/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMComponentConfigurer.java
@@ -40,9 +40,9 @@ public class CMComponentConfigurer extends PropertyConfigurerSupport implements
         CMComponent target = (CMComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMEndpointConfigurer.java b/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMEndpointConfigurer.java
index 5160796..33ca897 100644
--- a/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMEndpointConfigurer.java
+++ b/components/camel-cm-sms/src/generated/java/org/apache/camel/component/cm/CMEndpointConfigurer.java
@@ -54,18 +54,18 @@ public class CMEndpointConfigurer extends PropertyConfigurerSupport implements G
         CMEndpoint target = (CMEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "defaultfrom":
-        case "defaultFrom": target.getConfiguration().getDefaultFrom(); return true;
+        case "defaultFrom": return target.getConfiguration().getDefaultFrom();
         case "defaultmaxnumberofparts":
-        case "defaultMaxNumberOfParts": target.getConfiguration().getDefaultMaxNumberOfParts(); return true;
+        case "defaultMaxNumberOfParts": return target.getConfiguration().getDefaultMaxNumberOfParts();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "producttoken":
-        case "productToken": target.getConfiguration().getProductToken(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "productToken": return target.getConfiguration().getProductToken();
+        case "synchronous": return target.isSynchronous();
         case "testconnectiononstartup":
-        case "testConnectionOnStartup": target.getConfiguration().isTestConnectionOnStartup(); return true;
+        case "testConnectionOnStartup": return target.getConfiguration().isTestConnectionOnStartup();
         default: return null;
         }
     }
diff --git a/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISComponentConfigurer.java b/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISComponentConfigurer.java
index 1a442f8..e9d9528 100644
--- a/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISComponentConfigurer.java
+++ b/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISComponentConfigurer.java
@@ -46,13 +46,13 @@ public class CMISComponentConfigurer extends PropertyConfigurerSupport implement
         CMISComponent target = (CMISComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "sessionfacadefactory":
-        case "sessionFacadeFactory": target.getSessionFacadeFactory(); return true;
+        case "sessionFacadeFactory": return target.getSessionFacadeFactory();
         default: return null;
         }
     }
diff --git a/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISEndpointConfigurer.java b/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISEndpointConfigurer.java
index 909228f..56566d4 100644
--- a/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISEndpointConfigurer.java
+++ b/components/camel-cmis/src/generated/java/org/apache/camel/component/cmis/CMISEndpointConfigurer.java
@@ -75,31 +75,31 @@ public class CMISEndpointConfigurer extends PropertyConfigurerSupport implements
         CMISEndpoint target = (CMISEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "pagesize":
-        case "pageSize": target.getSessionFacade().getPageSize(); return true;
-        case "password": target.getSessionFacade().getPassword(); return true;
-        case "query": target.getSessionFacade().getQuery(); return true;
+        case "pageSize": return target.getSessionFacade().getPageSize();
+        case "password": return target.getSessionFacade().getPassword();
+        case "query": return target.getSessionFacade().getQuery();
         case "querymode":
-        case "queryMode": target.isQueryMode(); return true;
+        case "queryMode": return target.isQueryMode();
         case "readcontent":
-        case "readContent": target.getSessionFacade().isReadContent(); return true;
+        case "readContent": return target.getSessionFacade().isReadContent();
         case "readcount":
-        case "readCount": target.getSessionFacade().getReadCount(); return true;
+        case "readCount": return target.getSessionFacade().getReadCount();
         case "repositoryid":
-        case "repositoryId": target.getSessionFacade().getRepositoryId(); return true;
+        case "repositoryId": return target.getSessionFacade().getRepositoryId();
         case "sessionfacadefactory":
-        case "sessionFacadeFactory": target.getSessionFacadeFactory(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "username": target.getSessionFacade().getUsername(); return true;
+        case "sessionFacadeFactory": return target.getSessionFacadeFactory();
+        case "synchronous": return target.isSynchronous();
+        case "username": return target.getSessionFacade().getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPComponentConfigurer.java b/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPComponentConfigurer.java
index c5d1da9..84f9ca8 100644
--- a/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPComponentConfigurer.java
+++ b/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPComponentConfigurer.java
@@ -43,11 +43,11 @@ public class CoAPComponentConfigurer extends PropertyConfigurerSupport implement
         CoAPComponent target = (CoAPComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPEndpointConfigurer.java b/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPEndpointConfigurer.java
index 07866e1..115aa5c 100644
--- a/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPEndpointConfigurer.java
+++ b/components/camel-coap/src/generated/java/org/apache/camel/coap/CoAPEndpointConfigurer.java
@@ -79,36 +79,36 @@ public class CoAPEndpointConfigurer extends PropertyConfigurerSupport implements
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         CoAPEndpoint target = (CoAPEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "alias": target.getAlias(); return true;
+        case "alias": return target.getAlias();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "ciphersuites":
-        case "cipherSuites": target.getCipherSuites(); return true;
+        case "cipherSuites": return target.getCipherSuites();
         case "clientauthentication":
-        case "clientAuthentication": target.getClientAuthentication(); return true;
+        case "clientAuthentication": return target.getClientAuthentication();
         case "coapmethodrestrict":
-        case "coapMethodRestrict": target.getCoapMethodRestrict(); return true;
+        case "coapMethodRestrict": return target.getCoapMethodRestrict();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "privatekey":
-        case "privateKey": target.getPrivateKey(); return true;
+        case "privateKey": return target.getPrivateKey();
         case "pskstore":
-        case "pskStore": target.getPskStore(); return true;
+        case "pskStore": return target.getPskStore();
         case "publickey":
-        case "publicKey": target.getPublicKey(); return true;
+        case "publicKey": return target.getPublicKey();
         case "recommendedciphersuitesonly":
-        case "recommendedCipherSuitesOnly": target.isRecommendedCipherSuitesOnly(); return true;
+        case "recommendedCipherSuitesOnly": return target.isRecommendedCipherSuitesOnly();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getSslContextParameters(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "sslContextParameters": return target.getSslContextParameters();
+        case "synchronous": return target.isSynchronous();
         case "trustedrpkstore":
-        case "trustedRpkStore": target.getTrustedRpkStore(); return true;
+        case "trustedRpkStore": return target.getTrustedRpkStore();
         default: return null;
         }
     }
diff --git a/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdComponentConfigurer.java b/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdComponentConfigurer.java
index 87bcb42..6daf512 100644
--- a/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdComponentConfigurer.java
+++ b/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdComponentConfigurer.java
@@ -63,24 +63,24 @@ public class CometdComponentConfigurer extends PropertyConfigurerSupport impleme
         CometdComponent target = (CometdComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "extensions": target.getExtensions(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "extensions": return target.getExtensions();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "securitypolicy":
-        case "securityPolicy": target.getSecurityPolicy(); return true;
+        case "securityPolicy": return target.getSecurityPolicy();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getSslContextParameters(); return true;
+        case "sslContextParameters": return target.getSslContextParameters();
         case "sslkeypassword":
-        case "sslKeyPassword": target.getSslKeyPassword(); return true;
+        case "sslKeyPassword": return target.getSslKeyPassword();
         case "sslkeystore":
-        case "sslKeystore": target.getSslKeystore(); return true;
+        case "sslKeystore": return target.getSslKeystore();
         case "sslpassword":
-        case "sslPassword": target.getSslPassword(); return true;
+        case "sslPassword": return target.getSslPassword();
         case "useglobalsslcontextparameters":
-        case "useGlobalSslContextParameters": target.isUseGlobalSslContextParameters(); return true;
+        case "useGlobalSslContextParameters": return target.isUseGlobalSslContextParameters();
         default: return null;
         }
     }
diff --git a/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdEndpointConfigurer.java b/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdEndpointConfigurer.java
index 814b8cf..eafe805 100644
--- a/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdEndpointConfigurer.java
+++ b/components/camel-cometd/src/generated/java/org/apache/camel/component/cometd/CometdEndpointConfigurer.java
@@ -85,38 +85,38 @@ public class CometdEndpointConfigurer extends PropertyConfigurerSupport implemen
         CometdEndpoint target = (CometdEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "allowedorigins":
-        case "allowedOrigins": target.getAllowedOrigins(); return true;
+        case "allowedOrigins": return target.getAllowedOrigins();
         case "baseresource":
-        case "baseResource": target.getBaseResource(); return true;
+        case "baseResource": return target.getBaseResource();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "crossoriginfilteron":
-        case "crossOriginFilterOn": target.isCrossOriginFilterOn(); return true;
+        case "crossOriginFilterOn": return target.isCrossOriginFilterOn();
         case "disconnectlocalsession":
-        case "disconnectLocalSession": target.isDisconnectLocalSession(); return true;
+        case "disconnectLocalSession": return target.isDisconnectLocalSession();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "filterpath":
-        case "filterPath": target.getFilterPath(); return true;
-        case "interval": target.getInterval(); return true;
+        case "filterPath": return target.getFilterPath();
+        case "interval": return target.getInterval();
         case "jsoncommented":
-        case "jsonCommented": target.isJsonCommented(); return true;
+        case "jsonCommented": return target.isJsonCommented();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "loglevel":
-        case "logLevel": target.getLogLevel(); return true;
+        case "logLevel": return target.getLogLevel();
         case "maxinterval":
-        case "maxInterval": target.getMaxInterval(); return true;
+        case "maxInterval": return target.getMaxInterval();
         case "multiframeinterval":
-        case "multiFrameInterval": target.getMultiFrameInterval(); return true;
+        case "multiFrameInterval": return target.getMultiFrameInterval();
         case "sessionheadersenabled":
-        case "sessionHeadersEnabled": target.isSessionHeadersEnabled(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "timeout": target.getTimeout(); return true;
+        case "sessionHeadersEnabled": return target.isSessionHeadersEnabled();
+        case "synchronous": return target.isSynchronous();
+        case "timeout": return target.getTimeout();
         default: return null;
         }
     }
diff --git a/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulComponentConfigurer.java b/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulComponentConfigurer.java
index 1daef8a..9f50f78 100644
--- a/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulComponentConfigurer.java
+++ b/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulComponentConfigurer.java
@@ -111,49 +111,49 @@ public class ConsulComponentConfigurer extends PropertyConfigurerSupport impleme
         ConsulComponent target = (ConsulComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "acltoken":
-        case "aclToken": getOrCreateConfiguration(target).getAclToken(); return true;
-        case "action": getOrCreateConfiguration(target).getAction(); return true;
+        case "aclToken": return getOrCreateConfiguration(target).getAclToken();
+        case "action": return getOrCreateConfiguration(target).getAction();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "blockseconds":
-        case "blockSeconds": getOrCreateConfiguration(target).getBlockSeconds(); return true;
+        case "blockSeconds": return getOrCreateConfiguration(target).getBlockSeconds();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "connecttimeoutmillis":
-        case "connectTimeoutMillis": getOrCreateConfiguration(target).getConnectTimeoutMillis(); return true;
+        case "connectTimeoutMillis": return getOrCreateConfiguration(target).getConnectTimeoutMillis();
         case "consistencymode":
-        case "consistencyMode": getOrCreateConfiguration(target).getConsistencyMode(); return true;
+        case "consistencyMode": return getOrCreateConfiguration(target).getConsistencyMode();
         case "consulclient":
-        case "consulClient": getOrCreateConfiguration(target).getConsulClient(); return true;
-        case "datacenter": getOrCreateConfiguration(target).getDatacenter(); return true;
+        case "consulClient": return getOrCreateConfiguration(target).getConsulClient();
+        case "datacenter": return getOrCreateConfiguration(target).getDatacenter();
         case "firstindex":
-        case "firstIndex": getOrCreateConfiguration(target).getFirstIndex(); return true;
-        case "key": getOrCreateConfiguration(target).getKey(); return true;
+        case "firstIndex": return getOrCreateConfiguration(target).getFirstIndex();
+        case "key": return getOrCreateConfiguration(target).getKey();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "nearnode":
-        case "nearNode": getOrCreateConfiguration(target).getNearNode(); return true;
+        case "nearNode": return getOrCreateConfiguration(target).getNearNode();
         case "nodemeta":
-        case "nodeMeta": getOrCreateConfiguration(target).getNodeMeta(); return true;
-        case "password": getOrCreateConfiguration(target).getPassword(); return true;
+        case "nodeMeta": return getOrCreateConfiguration(target).getNodeMeta();
+        case "password": return getOrCreateConfiguration(target).getPassword();
         case "pinginstance":
-        case "pingInstance": getOrCreateConfiguration(target).isPingInstance(); return true;
+        case "pingInstance": return getOrCreateConfiguration(target).isPingInstance();
         case "readtimeoutmillis":
-        case "readTimeoutMillis": getOrCreateConfiguration(target).getReadTimeoutMillis(); return true;
-        case "recursive": getOrCreateConfiguration(target).isRecursive(); return true;
+        case "readTimeoutMillis": return getOrCreateConfiguration(target).getReadTimeoutMillis();
+        case "recursive": return getOrCreateConfiguration(target).isRecursive();
         case "sslcontextparameters":
-        case "sslContextParameters": getOrCreateConfiguration(target).getSslContextParameters(); return true;
-        case "tags": getOrCreateConfiguration(target).getTags(); return true;
-        case "url": getOrCreateConfiguration(target).getUrl(); return true;
+        case "sslContextParameters": return getOrCreateConfiguration(target).getSslContextParameters();
+        case "tags": return getOrCreateConfiguration(target).getTags();
+        case "url": return getOrCreateConfiguration(target).getUrl();
         case "useglobalsslcontextparameters":
-        case "useGlobalSslContextParameters": target.isUseGlobalSslContextParameters(); return true;
+        case "useGlobalSslContextParameters": return target.isUseGlobalSslContextParameters();
         case "username":
-        case "userName": getOrCreateConfiguration(target).getUserName(); return true;
+        case "userName": return getOrCreateConfiguration(target).getUserName();
         case "valueasstring":
-        case "valueAsString": getOrCreateConfiguration(target).isValueAsString(); return true;
+        case "valueAsString": return getOrCreateConfiguration(target).isValueAsString();
         case "writetimeoutmillis":
-        case "writeTimeoutMillis": getOrCreateConfiguration(target).getWriteTimeoutMillis(); return true;
+        case "writeTimeoutMillis": return getOrCreateConfiguration(target).getWriteTimeoutMillis();
         default: return null;
         }
     }
diff --git a/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulEndpointConfigurer.java b/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulEndpointConfigurer.java
index 1f7d32a..e8c11b8 100644
--- a/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulEndpointConfigurer.java
+++ b/components/camel-consul/src/generated/java/org/apache/camel/component/consul/ConsulEndpointConfigurer.java
@@ -107,51 +107,51 @@ public class ConsulEndpointConfigurer extends PropertyConfigurerSupport implemen
         ConsulEndpoint target = (ConsulEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "acltoken":
-        case "aclToken": target.getConfiguration().getAclToken(); return true;
-        case "action": target.getConfiguration().getAction(); return true;
+        case "aclToken": return target.getConfiguration().getAclToken();
+        case "action": return target.getConfiguration().getAction();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "blockseconds":
-        case "blockSeconds": target.getConfiguration().getBlockSeconds(); return true;
+        case "blockSeconds": return target.getConfiguration().getBlockSeconds();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "connecttimeoutmillis":
-        case "connectTimeoutMillis": target.getConfiguration().getConnectTimeoutMillis(); return true;
+        case "connectTimeoutMillis": return target.getConfiguration().getConnectTimeoutMillis();
         case "consistencymode":
-        case "consistencyMode": target.getConfiguration().getConsistencyMode(); return true;
+        case "consistencyMode": return target.getConfiguration().getConsistencyMode();
         case "consulclient":
-        case "consulClient": target.getConfiguration().getConsulClient(); return true;
-        case "datacenter": target.getConfiguration().getDatacenter(); return true;
+        case "consulClient": return target.getConfiguration().getConsulClient();
+        case "datacenter": return target.getConfiguration().getDatacenter();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "firstindex":
-        case "firstIndex": target.getConfiguration().getFirstIndex(); return true;
-        case "key": target.getConfiguration().getKey(); return true;
+        case "firstIndex": return target.getConfiguration().getFirstIndex();
+        case "key": return target.getConfiguration().getKey();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "nearnode":
-        case "nearNode": target.getConfiguration().getNearNode(); return true;
+        case "nearNode": return target.getConfiguration().getNearNode();
         case "nodemeta":
-        case "nodeMeta": target.getConfiguration().getNodeMeta(); return true;
-        case "password": target.getConfiguration().getPassword(); return true;
+        case "nodeMeta": return target.getConfiguration().getNodeMeta();
+        case "password": return target.getConfiguration().getPassword();
         case "pinginstance":
-        case "pingInstance": target.getConfiguration().isPingInstance(); return true;
+        case "pingInstance": return target.getConfiguration().isPingInstance();
         case "readtimeoutmillis":
-        case "readTimeoutMillis": target.getConfiguration().getReadTimeoutMillis(); return true;
-        case "recursive": target.getConfiguration().isRecursive(); return true;
+        case "readTimeoutMillis": return target.getConfiguration().getReadTimeoutMillis();
+        case "recursive": return target.getConfiguration().isRecursive();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getConfiguration().getSslContextParameters(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "tags": target.getConfiguration().getTags(); return true;
-        case "url": target.getConfiguration().getUrl(); return true;
+        case "sslContextParameters": return target.getConfiguration().getSslContextParameters();
+        case "synchronous": return target.isSynchronous();
+        case "tags": return target.getConfiguration().getTags();
+        case "url": return target.getConfiguration().getUrl();
         case "username":
-        case "userName": target.getConfiguration().getUserName(); return true;
+        case "userName": return target.getConfiguration().getUserName();
         case "valueasstring":
-        case "valueAsString": target.getConfiguration().isValueAsString(); return true;
+        case "valueAsString": return target.getConfiguration().isValueAsString();
         case "writetimeoutmillis":
-        case "writeTimeoutMillis": target.getConfiguration().getWriteTimeoutMillis(); return true;
+        case "writeTimeoutMillis": return target.getConfiguration().getWriteTimeoutMillis();
         default: return null;
         }
     }
diff --git a/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusComponentConfigurer.java b/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusComponentConfigurer.java
index f2bb50f..416912e 100644
--- a/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusComponentConfigurer.java
+++ b/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusComponentConfigurer.java
@@ -40,9 +40,9 @@ public class ControlBusComponentConfigurer extends PropertyConfigurerSupport imp
         ControlBusComponent target = (ControlBusComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusEndpointConfigurer.java b/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusEndpointConfigurer.java
index cf126fe..271e4db 100644
--- a/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusEndpointConfigurer.java
+++ b/components/camel-controlbus/src/generated/java/org/apache/camel/component/controlbus/ControlBusEndpointConfigurer.java
@@ -54,19 +54,19 @@ public class ControlBusEndpointConfigurer extends PropertyConfigurerSupport impl
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         ControlBusEndpoint target = (ControlBusEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "action": target.getAction(); return true;
-        case "async": target.isAsync(); return true;
+        case "action": return target.getAction();
+        case "async": return target.isAsync();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "logginglevel":
-        case "loggingLevel": target.getLoggingLevel(); return true;
+        case "loggingLevel": return target.getLoggingLevel();
         case "restartdelay":
-        case "restartDelay": target.getRestartDelay(); return true;
+        case "restartDelay": return target.getRestartDelay();
         case "routeid":
-        case "routeId": target.getRouteId(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "routeId": return target.getRouteId();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaComponentConfigurer.java b/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaComponentConfigurer.java
index 305a07d..ace75bd 100644
--- a/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaComponentConfigurer.java
+++ b/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaComponentConfigurer.java
@@ -78,28 +78,28 @@ public class CordaComponentConfigurer extends PropertyConfigurerSupport implemen
         CordaComponent target = (CordaComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "configuration": return target.getConfiguration();
         case "contractstateclass":
-        case "contractStateClass": getOrCreateConfiguration(target).getContractStateClass(); return true;
+        case "contractStateClass": return getOrCreateConfiguration(target).getContractStateClass();
         case "flowlogicarguments":
-        case "flowLogicArguments": getOrCreateConfiguration(target).getFlowLogicArguments(); return true;
+        case "flowLogicArguments": return getOrCreateConfiguration(target).getFlowLogicArguments();
         case "flowlogicclass":
-        case "flowLogicClass": getOrCreateConfiguration(target).getFlowLogicClass(); return true;
+        case "flowLogicClass": return getOrCreateConfiguration(target).getFlowLogicClass();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return getOrCreateConfiguration(target).getOperation();
         case "pagespecification":
-        case "pageSpecification": getOrCreateConfiguration(target).getPageSpecification(); return true;
-        case "password": getOrCreateConfiguration(target).getPassword(); return true;
+        case "pageSpecification": return getOrCreateConfiguration(target).getPageSpecification();
+        case "password": return getOrCreateConfiguration(target).getPassword();
         case "processsnapshot":
-        case "processSnapshot": getOrCreateConfiguration(target).isProcessSnapshot(); return true;
+        case "processSnapshot": return getOrCreateConfiguration(target).isProcessSnapshot();
         case "querycriteria":
-        case "queryCriteria": getOrCreateConfiguration(target).getQueryCriteria(); return true;
-        case "sort": getOrCreateConfiguration(target).getSort(); return true;
-        case "username": getOrCreateConfiguration(target).getUsername(); return true;
+        case "queryCriteria": return getOrCreateConfiguration(target).getQueryCriteria();
+        case "sort": return getOrCreateConfiguration(target).getSort();
+        case "username": return getOrCreateConfiguration(target).getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaEndpointConfigurer.java b/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaEndpointConfigurer.java
index 8e269c4..a93f18a 100644
--- a/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaEndpointConfigurer.java
+++ b/components/camel-corda/src/generated/java/org/apache/camel/component/corda/CordaEndpointConfigurer.java
@@ -77,32 +77,32 @@ public class CordaEndpointConfigurer extends PropertyConfigurerSupport implement
         CordaEndpoint target = (CordaEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "contractstateclass":
-        case "contractStateClass": target.getConfiguration().getContractStateClass(); return true;
+        case "contractStateClass": return target.getConfiguration().getContractStateClass();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "flowlogicarguments":
-        case "flowLogicArguments": target.getConfiguration().getFlowLogicArguments(); return true;
+        case "flowLogicArguments": return target.getConfiguration().getFlowLogicArguments();
         case "flowlogicclass":
-        case "flowLogicClass": target.getConfiguration().getFlowLogicClass(); return true;
+        case "flowLogicClass": return target.getConfiguration().getFlowLogicClass();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "operation": target.getConfiguration().getOperation(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "operation": return target.getConfiguration().getOperation();
         case "pagespecification":
-        case "pageSpecification": target.getConfiguration().getPageSpecification(); return true;
-        case "password": target.getConfiguration().getPassword(); return true;
+        case "pageSpecification": return target.getConfiguration().getPageSpecification();
+        case "password": return target.getConfiguration().getPassword();
         case "processsnapshot":
-        case "processSnapshot": target.getConfiguration().isProcessSnapshot(); return true;
+        case "processSnapshot": return target.getConfiguration().isProcessSnapshot();
         case "querycriteria":
-        case "queryCriteria": target.getConfiguration().getQueryCriteria(); return true;
-        case "sort": target.getConfiguration().getSort(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "username": target.getConfiguration().getUsername(); return true;
+        case "queryCriteria": return target.getConfiguration().getQueryCriteria();
+        case "sort": return target.getConfiguration().getSort();
+        case "synchronous": return target.isSynchronous();
+        case "username": return target.getConfiguration().getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseComponentConfigurer.java b/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseComponentConfigurer.java
index 6eb31c6..6195a57 100644
--- a/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseComponentConfigurer.java
+++ b/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseComponentConfigurer.java
@@ -43,11 +43,11 @@ public class CouchbaseComponentConfigurer extends PropertyConfigurerSupport impl
         CouchbaseComponent target = (CouchbaseComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseEndpointConfigurer.java b/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseEndpointConfigurer.java
index 7bc2c77..11f5452 100644
--- a/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseEndpointConfigurer.java
+++ b/components/camel-couchbase/src/generated/java/org/apache/camel/component/couchbase/CouchbaseEndpointConfigurer.java
@@ -172,93 +172,93 @@ public class CouchbaseEndpointConfigurer extends PropertyConfigurerSupport imple
         CouchbaseEndpoint target = (CouchbaseEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "additionalhosts":
-        case "additionalHosts": target.getAdditionalHosts(); return true;
+        case "additionalHosts": return target.getAdditionalHosts();
         case "autostartidforinserts":
-        case "autoStartIdForInserts": target.isAutoStartIdForInserts(); return true;
+        case "autoStartIdForInserts": return target.isAutoStartIdForInserts();
         case "backofferrorthreshold":
-        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffErrorThreshold": return target.getBackoffErrorThreshold();
         case "backoffidlethreshold":
-        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffIdleThreshold": return target.getBackoffIdleThreshold();
         case "backoffmultiplier":
-        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "backoffMultiplier": return target.getBackoffMultiplier();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "bucket": target.getBucket(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "bucket": return target.getBucket();
         case "consumerprocessedstrategy":
-        case "consumerProcessedStrategy": target.getConsumerProcessedStrategy(); return true;
-        case "delay": target.getDelay(); return true;
-        case "descending": target.isDescending(); return true;
+        case "consumerProcessedStrategy": return target.getConsumerProcessedStrategy();
+        case "delay": return target.getDelay();
+        case "descending": return target.isDescending();
         case "designdocumentname":
-        case "designDocumentName": target.getDesignDocumentName(); return true;
+        case "designDocumentName": return target.getDesignDocumentName();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "greedy": target.isGreedy(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "greedy": return target.isGreedy();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
-        case "key": target.getKey(); return true;
+        case "initialDelay": return target.getInitialDelay();
+        case "key": return target.getKey();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "limit": target.getLimit(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "limit": return target.getLimit();
         case "maxreconnectdelay":
-        case "maxReconnectDelay": target.getMaxReconnectDelay(); return true;
+        case "maxReconnectDelay": return target.getMaxReconnectDelay();
         case "obspollinterval":
-        case "obsPollInterval": target.getObsPollInterval(); return true;
+        case "obsPollInterval": return target.getObsPollInterval();
         case "obstimeout":
-        case "obsTimeout": target.getObsTimeout(); return true;
+        case "obsTimeout": return target.getObsTimeout();
         case "opqueuemaxblocktime":
-        case "opQueueMaxBlockTime": target.getOpQueueMaxBlockTime(); return true;
+        case "opQueueMaxBlockTime": return target.getOpQueueMaxBlockTime();
         case "optimeout":
-        case "opTimeOut": target.getOpTimeOut(); return true;
-        case "operation": target.getOperation(); return true;
-        case "password": target.getPassword(); return true;
+        case "opTimeOut": return target.getOpTimeOut();
+        case "operation": return target.getOperation();
+        case "password": return target.getPassword();
         case "persistto":
-        case "persistTo": target.getPersistTo(); return true;
+        case "persistTo": return target.getPersistTo();
         case "pollstrategy":
-        case "pollStrategy": target.getPollStrategy(); return true;
+        case "pollStrategy": return target.getPollStrategy();
         case "producerretryattempts":
-        case "producerRetryAttempts": target.getProducerRetryAttempts(); return true;
+        case "producerRetryAttempts": return target.getProducerRetryAttempts();
         case "producerretrypause":
-        case "producerRetryPause": target.getProducerRetryPause(); return true;
+        case "producerRetryPause": return target.getProducerRetryPause();
         case "rangeendkey":
-        case "rangeEndKey": target.getRangeEndKey(); return true;
+        case "rangeEndKey": return target.getRangeEndKey();
         case "rangestartkey":
-        case "rangeStartKey": target.getRangeStartKey(); return true;
+        case "rangeStartKey": return target.getRangeStartKey();
         case "readbuffersize":
-        case "readBufferSize": target.getReadBufferSize(); return true;
+        case "readBufferSize": return target.getReadBufferSize();
         case "repeatcount":
-        case "repeatCount": target.getRepeatCount(); return true;
+        case "repeatCount": return target.getRepeatCount();
         case "replicateto":
-        case "replicateTo": target.getReplicateTo(); return true;
+        case "replicateTo": return target.getReplicateTo();
         case "runlogginglevel":
-        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "runLoggingLevel": return target.getRunLoggingLevel();
         case "scheduledexecutorservice":
-        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
-        case "scheduler": target.getScheduler(); return true;
+        case "scheduledExecutorService": return target.getScheduledExecutorService();
+        case "scheduler": return target.getScheduler();
         case "schedulerproperties":
-        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "schedulerProperties": return target.getSchedulerProperties();
         case "sendemptymessagewhenidle":
-        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sendEmptyMessageWhenIdle": return target.isSendEmptyMessageWhenIdle();
         case "shouldoptimize":
-        case "shouldOptimize": target.isShouldOptimize(); return true;
-        case "skip": target.getSkip(); return true;
+        case "shouldOptimize": return target.isShouldOptimize();
+        case "skip": return target.getSkip();
         case "startscheduler":
-        case "startScheduler": target.isStartScheduler(); return true;
+        case "startScheduler": return target.isStartScheduler();
         case "startingidforinsertsfrom":
-        case "startingIdForInsertsFrom": target.getStartingIdForInsertsFrom(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "startingIdForInsertsFrom": return target.getStartingIdForInsertsFrom();
+        case "synchronous": return target.isSynchronous();
         case "timeunit":
-        case "timeUnit": target.getTimeUnit(); return true;
+        case "timeUnit": return target.getTimeUnit();
         case "timeoutexceptionthreshold":
-        case "timeoutExceptionThreshold": target.getTimeoutExceptionThreshold(); return true;
+        case "timeoutExceptionThreshold": return target.getTimeoutExceptionThreshold();
         case "usefixeddelay":
-        case "useFixedDelay": target.isUseFixedDelay(); return true;
-        case "username": target.getUsername(); return true;
+        case "useFixedDelay": return target.isUseFixedDelay();
+        case "username": return target.getUsername();
         case "viewname":
-        case "viewName": target.getViewName(); return true;
+        case "viewName": return target.getViewName();
         default: return null;
         }
     }
diff --git a/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbComponentConfigurer.java b/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbComponentConfigurer.java
index 9b31fa9..4c703da 100644
--- a/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbComponentConfigurer.java
+++ b/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbComponentConfigurer.java
@@ -43,11 +43,11 @@ public class CouchDbComponentConfigurer extends PropertyConfigurerSupport implem
         CouchDbComponent target = (CouchDbComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbEndpointConfigurer.java b/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbEndpointConfigurer.java
index 916371f..fca5138 100644
--- a/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbEndpointConfigurer.java
+++ b/components/camel-couchdb/src/generated/java/org/apache/camel/component/couchdb/CouchDbEndpointConfigurer.java
@@ -68,25 +68,25 @@ public class CouchDbEndpointConfigurer extends PropertyConfigurerSupport impleme
         CouchDbEndpoint target = (CouchDbEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "createdatabase":
-        case "createDatabase": target.isCreateDatabase(); return true;
-        case "deletes": target.isDeletes(); return true;
+        case "createDatabase": return target.isCreateDatabase();
+        case "deletes": return target.isDeletes();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "heartbeat": target.getHeartbeat(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "heartbeat": return target.getHeartbeat();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "password": target.getPassword(); return true;
-        case "since": target.getSince(); return true;
-        case "style": target.getStyle(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "updates": target.isUpdates(); return true;
-        case "username": target.getUsername(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "password": return target.getPassword();
+        case "since": return target.getSince();
+        case "style": return target.getStyle();
+        case "synchronous": return target.isSynchronous();
+        case "updates": return target.isUpdates();
+        case "username": return target.getUsername();
         default: return null;
         }
     }
diff --git a/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronComponentConfigurer.java b/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronComponentConfigurer.java
index fc4d122..ff590ae 100644
--- a/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronComponentConfigurer.java
+++ b/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronComponentConfigurer.java
@@ -43,11 +43,11 @@ public class CronComponentConfigurer extends PropertyConfigurerSupport implement
         CronComponent target = (CronComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "cronservice":
-        case "cronService": target.getCronService(); return true;
+        case "cronService": return target.getCronService();
         default: return null;
         }
     }
diff --git a/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronEndpointConfigurer.java b/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronEndpointConfigurer.java
index 00d1d38..8700bf9 100644
--- a/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronEndpointConfigurer.java
+++ b/components/camel-cron/src/generated/java/org/apache/camel/component/cron/CronEndpointConfigurer.java
@@ -50,15 +50,15 @@ public class CronEndpointConfigurer extends PropertyConfigurerSupport implements
         CronEndpoint target = (CronEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "schedule": target.getConfiguration().getSchedule(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "schedule": return target.getConfiguration().getSchedule();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsComponentConfigurer.java b/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsComponentConfigurer.java
index 9f6c10337..5cf4bd4 100644
--- a/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsComponentConfigurer.java
+++ b/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsComponentConfigurer.java
@@ -46,13 +46,13 @@ public class CryptoCmsComponentConfigurer extends PropertyConfigurerSupport impl
         CryptoCmsComponent target = (CryptoCmsComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "envelopeddatadecryptorconfiguration":
-        case "envelopedDataDecryptorConfiguration": target.getEnvelopedDataDecryptorConfiguration(); return true;
+        case "envelopedDataDecryptorConfiguration": return target.getEnvelopedDataDecryptorConfiguration();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "signeddataverifierconfiguration":
-        case "signedDataVerifierConfiguration": target.getSignedDataVerifierConfiguration(); return true;
+        case "signedDataVerifierConfiguration": return target.getSignedDataVerifierConfiguration();
         default: return null;
         }
     }
diff --git a/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsEndpointConfigurer.java b/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsEndpointConfigurer.java
index 9ff88a0..471b4ff 100644
--- a/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsEndpointConfigurer.java
+++ b/components/camel-crypto-cms/src/generated/java/org/apache/camel/component/crypto/cms/CryptoCmsEndpointConfigurer.java
@@ -81,35 +81,35 @@ public class CryptoCmsEndpointConfigurer extends PropertyConfigurerSupport imple
         CryptoCmsEndpoint target = (CryptoCmsEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "contentencryptionalgorithm":
-        case "contentEncryptionAlgorithm": target.getEncryptConfig().getContentEncryptionAlgorithm(); return true;
+        case "contentEncryptionAlgorithm": return target.getEncryptConfig().getContentEncryptionAlgorithm();
         case "frombase64":
-        case "fromBase64": target.getVerifyConfig().isFromBase64(); return true;
+        case "fromBase64": return target.getVerifyConfig().isFromBase64();
         case "includecontent":
-        case "includeContent": target.getSignConfig().getIncludeContent(); return true;
+        case "includeContent": return target.getSignConfig().getIncludeContent();
         case "keystore":
-        case "keyStore": target.getVerifyConfig().getKeyStore(); return true;
+        case "keyStore": return target.getVerifyConfig().getKeyStore();
         case "keystoreparameters":
-        case "keyStoreParameters": target.getVerifyConfig().getKeyStoreParameters(); return true;
+        case "keyStoreParameters": return target.getVerifyConfig().getKeyStoreParameters();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "originatorinformationprovider":
-        case "originatorInformationProvider": target.getEncryptConfig().getOriginatorInformationProvider(); return true;
-        case "password": target.getDecryptConfig().getPassword(); return true;
-        case "recipient": target.getEncryptConfig().getRecipient(); return true;
+        case "originatorInformationProvider": return target.getEncryptConfig().getOriginatorInformationProvider();
+        case "password": return target.getDecryptConfig().getPassword();
+        case "recipient": return target.getEncryptConfig().getRecipient();
         case "secretkeylength":
-        case "secretKeyLength": target.getEncryptConfig().getSecretKeyLength(); return true;
+        case "secretKeyLength": return target.getEncryptConfig().getSecretKeyLength();
         case "signeddataheaderbase64":
-        case "signedDataHeaderBase64": target.getVerifyConfig().isSignedDataHeaderBase64(); return true;
-        case "signer": target.getSignConfig().getSigner(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "signedDataHeaderBase64": return target.getVerifyConfig().isSignedDataHeaderBase64();
+        case "signer": return target.getSignConfig().getSigner();
+        case "synchronous": return target.isSynchronous();
         case "tobase64":
-        case "toBase64": target.getSignConfig().getToBase64(); return true;
+        case "toBase64": return target.getSignConfig().getToBase64();
         case "unprotectedattributesgeneratorprovider":
-        case "unprotectedAttributesGeneratorProvider": target.getEncryptConfig().getUnprotectedAttributesGeneratorProvider(); return true;
+        case "unprotectedAttributesGeneratorProvider": return target.getEncryptConfig().getUnprotectedAttributesGeneratorProvider();
         case "verifysignaturesofallsigners":
-        case "verifySignaturesOfAllSigners": target.getVerifyConfig().isVerifySignaturesOfAllSigners(); return true;
+        case "verifySignaturesOfAllSigners": return target.getVerifyConfig().isVerifySignaturesOfAllSigners();
         default: return null;
         }
     }
diff --git a/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureComponentConfigurer.java b/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureComponentConfigurer.java
index e16ad7f..9132dd2 100644
--- a/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureComponentConfigurer.java
+++ b/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureComponentConfigurer.java
@@ -96,41 +96,41 @@ public class DigitalSignatureComponentConfigurer extends PropertyConfigurerSuppo
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         DigitalSignatureComponent target = (DigitalSignatureComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "algorithm": getOrCreateConfiguration(target).getAlgorithm(); return true;
-        case "alias": getOrCreateConfiguration(target).getAlias(); return true;
+        case "algorithm": return getOrCreateConfiguration(target).getAlgorithm();
+        case "alias": return getOrCreateConfiguration(target).getAlias();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "buffersize":
-        case "bufferSize": getOrCreateConfiguration(target).getBufferSize(); return true;
-        case "certificate": getOrCreateConfiguration(target).getCertificate(); return true;
+        case "bufferSize": return getOrCreateConfiguration(target).getBufferSize();
+        case "certificate": return getOrCreateConfiguration(target).getCertificate();
         case "certificatename":
-        case "certificateName": getOrCreateConfiguration(target).getCertificateName(); return true;
+        case "certificateName": return getOrCreateConfiguration(target).getCertificateName();
         case "clearheaders":
-        case "clearHeaders": getOrCreateConfiguration(target).isClearHeaders(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "clearHeaders": return getOrCreateConfiguration(target).isClearHeaders();
+        case "configuration": return target.getConfiguration();
         case "keystoreparameters":
-        case "keyStoreParameters": getOrCreateConfiguration(target).getKeyStoreParameters(); return true;
-        case "keystore": getOrCreateConfiguration(target).getKeystore(); return true;
+        case "keyStoreParameters": return getOrCreateConfiguration(target).getKeyStoreParameters();
+        case "keystore": return getOrCreateConfiguration(target).getKeystore();
         case "keystorename":
-        case "keystoreName": getOrCreateConfiguration(target).getKeystoreName(); return true;
+        case "keystoreName": return getOrCreateConfiguration(target).getKeystoreName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "password": getOrCreateConfiguration(target).getPassword(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "password": return getOrCreateConfiguration(target).getPassword();
         case "privatekey":
-        case "privateKey": getOrCreateConfiguration(target).getPrivateKey(); return true;
+        case "privateKey": return getOrCreateConfiguration(target).getPrivateKey();
         case "privatekeyname":
-        case "privateKeyName": getOrCreateConfiguration(target).getPrivateKeyName(); return true;
-        case "provider": getOrCreateConfiguration(target).getProvider(); return true;
+        case "privateKeyName": return getOrCreateConfiguration(target).getPrivateKeyName();
+        case "provider": return getOrCreateConfiguration(target).getProvider();
         case "publickey":
-        case "publicKey": getOrCreateConfiguration(target).getPublicKey(); return true;
+        case "publicKey": return getOrCreateConfiguration(target).getPublicKey();
         case "publickeyname":
-        case "publicKeyName": getOrCreateConfiguration(target).getPublicKeyName(); return true;
+        case "publicKeyName": return getOrCreateConfiguration(target).getPublicKeyName();
         case "securerandom":
-        case "secureRandom": getOrCreateConfiguration(target).getSecureRandom(); return true;
+        case "secureRandom": return getOrCreateConfiguration(target).getSecureRandom();
         case "securerandomname":
-        case "secureRandomName": getOrCreateConfiguration(target).getSecureRandomName(); return true;
+        case "secureRandomName": return getOrCreateConfiguration(target).getSecureRandomName();
         case "signatureheadername":
-        case "signatureHeaderName": getOrCreateConfiguration(target).getSignatureHeaderName(); return true;
+        case "signatureHeaderName": return getOrCreateConfiguration(target).getSignatureHeaderName();
         default: return null;
         }
     }
diff --git a/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureEndpointConfigurer.java b/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureEndpointConfigurer.java
index 5ee03ef..859880f 100644
--- a/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureEndpointConfigurer.java
+++ b/components/camel-crypto/src/generated/java/org/apache/camel/component/crypto/DigitalSignatureEndpointConfigurer.java
@@ -89,41 +89,41 @@ public class DigitalSignatureEndpointConfigurer extends PropertyConfigurerSuppor
     public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
         DigitalSignatureEndpoint target = (DigitalSignatureEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
-        case "algorithm": target.getConfiguration().getAlgorithm(); return true;
-        case "alias": target.getConfiguration().getAlias(); return true;
+        case "algorithm": return target.getConfiguration().getAlgorithm();
+        case "alias": return target.getConfiguration().getAlias();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "buffersize":
-        case "bufferSize": target.getConfiguration().getBufferSize(); return true;
-        case "certificate": target.getConfiguration().getCertificate(); return true;
+        case "bufferSize": return target.getConfiguration().getBufferSize();
+        case "certificate": return target.getConfiguration().getCertificate();
         case "certificatename":
-        case "certificateName": target.getConfiguration().getCertificateName(); return true;
+        case "certificateName": return target.getConfiguration().getCertificateName();
         case "clearheaders":
-        case "clearHeaders": target.getConfiguration().isClearHeaders(); return true;
+        case "clearHeaders": return target.getConfiguration().isClearHeaders();
         case "keystoreparameters":
-        case "keyStoreParameters": target.getConfiguration().getKeyStoreParameters(); return true;
-        case "keystore": target.getConfiguration().getKeystore(); return true;
+        case "keyStoreParameters": return target.getConfiguration().getKeyStoreParameters();
+        case "keystore": return target.getConfiguration().getKeystore();
         case "keystorename":
-        case "keystoreName": target.getConfiguration().getKeystoreName(); return true;
+        case "keystoreName": return target.getConfiguration().getKeystoreName();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "password": target.getConfiguration().getPassword(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "password": return target.getConfiguration().getPassword();
         case "privatekey":
-        case "privateKey": target.getConfiguration().getPrivateKey(); return true;
+        case "privateKey": return target.getConfiguration().getPrivateKey();
         case "privatekeyname":
-        case "privateKeyName": target.getConfiguration().getPrivateKeyName(); return true;
-        case "provider": target.getConfiguration().getProvider(); return true;
+        case "privateKeyName": return target.getConfiguration().getPrivateKeyName();
+        case "provider": return target.getConfiguration().getProvider();
         case "publickey":
-        case "publicKey": target.getConfiguration().getPublicKey(); return true;
+        case "publicKey": return target.getConfiguration().getPublicKey();
         case "publickeyname":
-        case "publicKeyName": target.getConfiguration().getPublicKeyName(); return true;
+        case "publicKeyName": return target.getConfiguration().getPublicKeyName();
         case "securerandom":
-        case "secureRandom": target.getConfiguration().getSecureRandom(); return true;
+        case "secureRandom": return target.getConfiguration().getSecureRandom();
         case "securerandomname":
-        case "secureRandomName": target.getConfiguration().getSecureRandomName(); return true;
+        case "secureRandomName": return target.getConfiguration().getSecureRandomName();
         case "signatureheadername":
-        case "signatureHeaderName": target.getConfiguration().getSignatureHeaderName(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "signatureHeaderName": return target.getConfiguration().getSignatureHeaderName();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfComponentConfigurer.java b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfComponentConfigurer.java
index 20449a6..23c1d92 100644
--- a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfComponentConfigurer.java
+++ b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfComponentConfigurer.java
@@ -52,17 +52,17 @@ public class CxfComponentConfigurer extends PropertyConfigurerSupport implements
         CxfComponent target = (CxfComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "allowstreaming":
-        case "allowStreaming": target.getAllowStreaming(); return true;
+        case "allowStreaming": return target.getAllowStreaming();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "useglobalsslcontextparameters":
-        case "useGlobalSslContextParameters": target.isUseGlobalSslContextParameters(); return true;
+        case "useGlobalSslContextParameters": return target.isUseGlobalSslContextParameters();
         default: return null;
         }
     }
diff --git a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfEndpointConfigurer.java b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfEndpointConfigurer.java
index f21550b..326c39d 100644
--- a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfEndpointConfigurer.java
+++ b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/CxfEndpointConfigurer.java
@@ -136,71 +136,71 @@ public class CxfEndpointConfigurer extends PropertyConfigurerSupport implements
         CxfEndpoint target = (CxfEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "allowstreaming":
-        case "allowStreaming": target.getAllowStreaming(); return true;
+        case "allowStreaming": return target.getAllowStreaming();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bindingid":
-        case "bindingId": target.getBindingId(); return true;
+        case "bindingId": return target.getBindingId();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "bus": target.getBus(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "bus": return target.getBus();
         case "continuationtimeout":
-        case "continuationTimeout": target.getContinuationTimeout(); return true;
+        case "continuationTimeout": return target.getContinuationTimeout();
         case "cookiehandler":
-        case "cookieHandler": target.getCookieHandler(); return true;
+        case "cookieHandler": return target.getCookieHandler();
         case "cxfbinding":
-        case "cxfBinding": target.getCxfBinding(); return true;
+        case "cxfBinding": return target.getCxfBinding();
         case "cxfconfigurer":
-        case "cxfConfigurer": target.getCxfConfigurer(); return true;
+        case "cxfConfigurer": return target.getCxfConfigurer();
         case "dataformat":
-        case "dataFormat": target.getDataFormat(); return true;
+        case "dataFormat": return target.getDataFormat();
         case "defaultbus":
-        case "defaultBus": target.isDefaultBus(); return true;
+        case "defaultBus": return target.isDefaultBus();
         case "defaultoperationname":
-        case "defaultOperationName": target.getDefaultOperationName(); return true;
+        case "defaultOperationName": return target.getDefaultOperationName();
         case "defaultoperationnamespace":
-        case "defaultOperationNamespace": target.getDefaultOperationNamespace(); return true;
+        case "defaultOperationNamespace": return target.getDefaultOperationNamespace();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "hostnameverifier":
-        case "hostnameVerifier": target.getHostnameVerifier(); return true;
+        case "hostnameVerifier": return target.getHostnameVerifier();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "loggingfeatureenabled":
-        case "loggingFeatureEnabled": target.isLoggingFeatureEnabled(); return true;
+        case "loggingFeatureEnabled": return target.isLoggingFeatureEnabled();
         case "loggingsizelimit":
-        case "loggingSizeLimit": target.getLoggingSizeLimit(); return true;
+        case "loggingSizeLimit": return target.getLoggingSizeLimit();
         case "mergeprotocolheaders":
-        case "mergeProtocolHeaders": target.isMergeProtocolHeaders(); return true;
+        case "mergeProtocolHeaders": return target.isMergeProtocolHeaders();
         case "mtomenabled":
-        case "mtomEnabled": target.isMtomEnabled(); return true;
-        case "password": target.getPassword(); return true;
+        case "mtomEnabled": return target.isMtomEnabled();
+        case "password": return target.getPassword();
         case "portname":
-        case "portName": target.getPortName(); return true;
-        case "properties": target.getProperties(); return true;
+        case "portName": return target.getPortName();
+        case "properties": return target.getProperties();
         case "publishedendpointurl":
-        case "publishedEndpointUrl": target.getPublishedEndpointUrl(); return true;
+        case "publishedEndpointUrl": return target.getPublishedEndpointUrl();
         case "serviceclass":
-        case "serviceClass": target.getServiceClass(); return true;
+        case "serviceClass": return target.getServiceClass();
         case "servicename":
-        case "serviceName": target.getServiceName(); return true;
+        case "serviceName": return target.getServiceName();
         case "skipfaultlogging":
-        case "skipFaultLogging": target.isSkipFaultLogging(); return true;
+        case "skipFaultLogging": return target.isSkipFaultLogging();
         case "skippayloadmessagepartcheck":
-        case "skipPayloadMessagePartCheck": target.isSkipPayloadMessagePartCheck(); return true;
+        case "skipPayloadMessagePartCheck": return target.isSkipPayloadMessagePartCheck();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getSslContextParameters(); return true;
-        case "synchronous": target.isSynchronous(); return true;
-        case "username": target.getUsername(); return true;
-        case "wrapped": target.isWrapped(); return true;
+        case "sslContextParameters": return target.getSslContextParameters();
+        case "synchronous": return target.isSynchronous();
+        case "username": return target.getUsername();
+        case "wrapped": return target.isWrapped();
         case "wrappedstyle":
-        case "wrappedStyle": target.getWrappedStyle(); return true;
+        case "wrappedStyle": return target.getWrappedStyle();
         case "wsdlurl":
-        case "wsdlURL": target.getWsdlURL(); return true;
+        case "wsdlURL": return target.getWsdlURL();
         default: return null;
         }
     }
diff --git a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsComponentConfigurer.java b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsComponentConfigurer.java
index 1fd6978..6626da8 100644
--- a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsComponentConfigurer.java
+++ b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsComponentConfigurer.java
@@ -49,15 +49,15 @@ public class CxfRsComponentConfigurer extends PropertyConfigurerSupport implemen
         CxfRsComponent target = (CxfRsComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "useglobalsslcontextparameters":
-        case "useGlobalSslContextParameters": target.isUseGlobalSslContextParameters(); return true;
+        case "useGlobalSslContextParameters": return target.isUseGlobalSslContextParameters();
         default: return null;
         }
     }
diff --git a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsEndpointConfigurer.java b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsEndpointConfigurer.java
index e611d44..b1f99bf 100644
--- a/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsEndpointConfigurer.java
+++ b/components/camel-cxf/src/generated/java/org/apache/camel/component/cxf/jaxrs/CxfRsEndpointConfigurer.java
@@ -125,64 +125,64 @@ public class CxfRsEndpointConfigurer extends PropertyConfigurerSupport implement
         CxfRsEndpoint target = (CxfRsEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
-        case "binding": target.getBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
+        case "binding": return target.getBinding();
         case "bindingstyle":
-        case "bindingStyle": target.getBindingStyle(); return true;
+        case "bindingStyle": return target.getBindingStyle();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
-        case "bus": target.getBus(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
+        case "bus": return target.getBus();
         case "continuationtimeout":
-        case "continuationTimeout": target.getContinuationTimeout(); return true;
+        case "continuationTimeout": return target.getContinuationTimeout();
         case "cookiehandler":
-        case "cookieHandler": target.getCookieHandler(); return true;
+        case "cookieHandler": return target.getCookieHandler();
         case "cxfrsconfigurer":
-        case "cxfRsConfigurer": target.getCxfRsConfigurer(); return true;
+        case "cxfRsConfigurer": return target.getCxfRsConfigurer();
         case "defaultbus":
-        case "defaultBus": target.isDefaultBus(); return true;
+        case "defaultBus": return target.isDefaultBus();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
-        case "features": target.getFeatures(); return true;
+        case "exchangePattern": return target.getExchangePattern();
+        case "features": return target.getFeatures();
         case "headerfilterstrategy":
-        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "headerFilterStrategy": return target.getHeaderFilterStrategy();
         case "hostnameverifier":
-        case "hostnameVerifier": target.getHostnameVerifier(); return true;
+        case "hostnameVerifier": return target.getHostnameVerifier();
         case "httpclientapi":
-        case "httpClientAPI": target.isHttpClientAPI(); return true;
+        case "httpClientAPI": return target.isHttpClientAPI();
         case "ignoredeletemethodmessagebody":
-        case "ignoreDeleteMethodMessageBody": target.isIgnoreDeleteMethodMessageBody(); return true;
+        case "ignoreDeleteMethodMessageBody": return target.isIgnoreDeleteMethodMessageBody();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         case "loggingfeatureenabled":
-        case "loggingFeatureEnabled": target.isLoggingFeatureEnabled(); return true;
+        case "loggingFeatureEnabled": return target.isLoggingFeatureEnabled();
         case "loggingsizelimit":
-        case "loggingSizeLimit": target.getLoggingSizeLimit(); return true;
+        case "loggingSizeLimit": return target.getLoggingSizeLimit();
         case "maxclientcachesize":
-        case "maxClientCacheSize": target.getMaxClientCacheSize(); return true;
+        case "maxClientCacheSize": return target.getMaxClientCacheSize();
         case "modelref":
-        case "modelRef": target.getModelRef(); return true;
+        case "modelRef": return target.getModelRef();
         case "performinvocation":
-        case "performInvocation": target.isPerformInvocation(); return true;
+        case "performInvocation": return target.isPerformInvocation();
         case "propagatecontexts":
-        case "propagateContexts": target.isPropagateContexts(); return true;
-        case "providers": target.getProviders(); return true;
+        case "propagateContexts": return target.isPropagateContexts();
+        case "providers": return target.getProviders();
         case "publishedendpointurl":
-        case "publishedEndpointUrl": target.getPublishedEndpointUrl(); return true;
+        case "publishedEndpointUrl": return target.getPublishedEndpointUrl();
         case "resourceclasses":
-        case "resourceClasses": target.getResourceClasses(); return true;
+        case "resourceClasses": return target.getResourceClasses();
         case "schemalocations":
-        case "schemaLocations": target.getSchemaLocations(); return true;
+        case "schemaLocations": return target.getSchemaLocations();
         case "servicebeans":
-        case "serviceBeans": target.getServiceBeans(); return true;
+        case "serviceBeans": return target.getServiceBeans();
         case "skipfaultlogging":
-        case "skipFaultLogging": target.isSkipFaultLogging(); return true;
+        case "skipFaultLogging": return target.isSkipFaultLogging();
         case "sslcontextparameters":
-        case "sslContextParameters": target.getSslContextParameters(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "sslContextParameters": return target.getSslContextParameters();
+        case "synchronous": return target.isSynchronous();
         case "throwexceptiononfailure":
-        case "throwExceptionOnFailure": target.isThrowExceptionOnFailure(); return true;
+        case "throwExceptionOnFailure": return target.isThrowExceptionOnFailure();
         default: return null;
         }
     }
diff --git a/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatComponentConfigurer.java b/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatComponentConfigurer.java
index e6e9d50..83153ce 100644
--- a/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatComponentConfigurer.java
+++ b/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatComponentConfigurer.java
@@ -40,9 +40,9 @@ public class DataFormatComponentConfigurer extends PropertyConfigurerSupport imp
         DataFormatComponent target = (DataFormatComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatEndpointConfigurer.java b/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatEndpointConfigurer.java
index 1cf58be..b19b41c 100644
--- a/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatEndpointConfigurer.java
+++ b/components/camel-dataformat/src/generated/java/org/apache/camel/component/dataformat/DataFormatEndpointConfigurer.java
@@ -42,10 +42,10 @@ public class DataFormatEndpointConfigurer extends PropertyConfigurerSupport impl
         DataFormatEndpoint target = (DataFormatEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
+        case "synchronous": return target.isSynchronous();
         default: return null;
         }
     }
diff --git a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetComponentConfigurer.java b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetComponentConfigurer.java
index d9bf225..34e033d 100644
--- a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetComponentConfigurer.java
+++ b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetComponentConfigurer.java
@@ -43,11 +43,11 @@ public class DataSetComponentConfigurer extends PropertyConfigurerSupport implem
         DataSetComponent target = (DataSetComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetEndpointConfigurer.java b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetEndpointConfigurer.java
index aa92276..8f6c08d 100644
--- a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetEndpointConfigurer.java
+++ b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetEndpointConfigurer.java
@@ -61,23 +61,23 @@ public class DataSetEndpointConfigurer extends MockEndpointConfigurer implements
         DataSetEndpoint target = (DataSetEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "consumedelay":
-        case "consumeDelay": target.getConsumeDelay(); return true;
+        case "consumeDelay": return target.getConsumeDelay();
         case "datasetindex":
-        case "dataSetIndex": target.getDataSetIndex(); return true;
+        case "dataSetIndex": return target.getDataSetIndex();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "initialdelay":
-        case "initialDelay": target.getInitialDelay(); return true;
+        case "initialDelay": return target.getInitialDelay();
         case "minrate":
-        case "minRate": target.getMinRate(); return true;
+        case "minRate": return target.getMinRate();
         case "preloadsize":
-        case "preloadSize": target.getPreloadSize(); return true;
+        case "preloadSize": return target.getPreloadSize();
         case "producedelay":
-        case "produceDelay": target.getProduceDelay(); return true;
+        case "produceDelay": return target.getProduceDelay();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestComponentConfigurer.java b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestComponentConfigurer.java
index acaf955..dfd8f62 100644
--- a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestComponentConfigurer.java
+++ b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestComponentConfigurer.java
@@ -40,9 +40,9 @@ public class DataSetTestComponentConfigurer extends PropertyConfigurerSupport im
         DataSetTestComponent target = (DataSetTestComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "lazystartproducer":
-        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "lazyStartProducer": return target.isLazyStartProducer();
         default: return null;
         }
     }
diff --git a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestEndpointConfigurer.java b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestEndpointConfigurer.java
index 1b94953..ed0ec0d 100644
--- a/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestEndpointConfigurer.java
+++ b/components/camel-dataset/src/generated/java/org/apache/camel/component/dataset/DataSetTestEndpointConfigurer.java
@@ -43,10 +43,10 @@ public class DataSetTestEndpointConfigurer extends MockEndpointConfigurer implem
         DataSetTestEndpoint target = (DataSetTestEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "anyorder":
-        case "anyOrder": target.isAnyOrder(); return true;
-        case "delimiter": target.getDelimiter(); return true;
-        case "split": target.isSplit(); return true;
-        case "timeout": target.getTimeout(); return true;
+        case "anyOrder": return target.isAnyOrder();
+        case "delimiter": return target.getDelimiter();
+        case "split": return target.isSplit();
+        case "timeout": return target.getTimeout();
         default: return super.getOptionValue(obj, name, ignoreCase);
         }
     }
diff --git a/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbComponentConfigurer.java b/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbComponentConfigurer.java
index 99a44e4..edbe4b1 100644
--- a/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbComponentConfigurer.java
+++ b/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbComponentConfigurer.java
@@ -166,88 +166,88 @@ public class DebeziumMongodbComponentConfigurer extends PropertyConfigurerSuppor
         DebeziumMongodbComponent target = (DebeziumMongodbComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "additionalproperties":
-        case "additionalProperties": getOrCreateConfiguration(target).getAdditionalProperties(); return true;
+        case "additionalProperties": return getOrCreateConfiguration(target).getAdditionalProperties();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "collectionblacklist":
-        case "collectionBlacklist": getOrCreateConfiguration(target).getCollectionBlacklist(); return true;
+        case "collectionBlacklist": return getOrCreateConfiguration(target).getCollectionBlacklist();
         case "collectionwhitelist":
-        case "collectionWhitelist": getOrCreateConfiguration(target).getCollectionWhitelist(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "collectionWhitelist": return getOrCreateConfiguration(target).getCollectionWhitelist();
+        case "configuration": return target.getConfiguration();
         case "connectbackoffinitialdelayms":
-        case "connectBackoffInitialDelayMs": getOrCreateConfiguration(target).getConnectBackoffInitialDelayMs(); return true;
+        case "connectBackoffInitialDelayMs": return getOrCreateConfiguration(target).getConnectBackoffInitialDelayMs();
         case "connectbackoffmaxdelayms":
-        case "connectBackoffMaxDelayMs": getOrCreateConfiguration(target).getConnectBackoffMaxDelayMs(); return true;
+        case "connectBackoffMaxDelayMs": return getOrCreateConfiguration(target).getConnectBackoffMaxDelayMs();
         case "connectmaxattempts":
-        case "connectMaxAttempts": getOrCreateConfiguration(target).getConnectMaxAttempts(); return true;
+        case "connectMaxAttempts": return getOrCreateConfiguration(target).getConnectMaxAttempts();
         case "databaseblacklist":
-        case "databaseBlacklist": getOrCreateConfiguration(target).getDatabaseBlacklist(); return true;
+        case "databaseBlacklist": return getOrCreateConfiguration(target).getDatabaseBlacklist();
         case "databasehistoryfilefilename":
-        case "databaseHistoryFileFilename": getOrCreateConfiguration(target).getDatabaseHistoryFileFilename(); return true;
+        case "databaseHistoryFileFilename": return getOrCreateConfiguration(target).getDatabaseHistoryFileFilename();
         case "databasewhitelist":
-        case "databaseWhitelist": getOrCreateConfiguration(target).getDatabaseWhitelist(); return true;
+        case "databaseWhitelist": return getOrCreateConfiguration(target).getDatabaseWhitelist();
         case "fieldblacklist":
-        case "fieldBlacklist": getOrCreateConfiguration(target).getFieldBlacklist(); return true;
+        case "fieldBlacklist": return getOrCreateConfiguration(target).getFieldBlacklist();
         case "fieldrenames":
-        case "fieldRenames": getOrCreateConfiguration(target).getFieldRenames(); return true;
+        case "fieldRenames": return getOrCreateConfiguration(target).getFieldRenames();
         case "heartbeatintervalms":
-        case "heartbeatIntervalMs": getOrCreateConfiguration(target).getHeartbeatIntervalMs(); return true;
+        case "heartbeatIntervalMs": return getOrCreateConfiguration(target).getHeartbeatIntervalMs();
         case "heartbeattopicsprefix":
-        case "heartbeatTopicsPrefix": getOrCreateConfiguration(target).getHeartbeatTopicsPrefix(); return true;
+        case "heartbeatTopicsPrefix": return getOrCreateConfiguration(target).getHeartbeatTopicsPrefix();
         case "initialsyncmaxthreads":
-        case "initialSyncMaxThreads": getOrCreateConfiguration(target).getInitialSyncMaxThreads(); return true;
+        case "initialSyncMaxThreads": return getOrCreateConfiguration(target).getInitialSyncMaxThreads();
         case "internalkeyconverter":
-        case "internalKeyConverter": getOrCreateConfiguration(target).getInternalKeyConverter(); return true;
+        case "internalKeyConverter": return getOrCreateConfiguration(target).getInternalKeyConverter();
         case "internalvalueconverter":
-        case "internalValueConverter": getOrCreateConfiguration(target).getInternalValueConverter(); return true;
+        case "internalValueConverter": return getOrCreateConfiguration(target).getInternalValueConverter();
         case "maxbatchsize":
-        case "maxBatchSize": getOrCreateConfiguration(target).getMaxBatchSize(); return true;
+        case "maxBatchSize": return getOrCreateConfiguration(target).getMaxBatchSize();
         case "maxqueuesize":
-        case "maxQueueSize": getOrCreateConfiguration(target).getMaxQueueSize(); return true;
+        case "maxQueueSize": return getOrCreateConfiguration(target).getMaxQueueSize();
         case "mongodbhosts":
-        case "mongodbHosts": getOrCreateConfiguration(target).getMongodbHosts(); return true;
+        case "mongodbHosts": return getOrCreateConfiguration(target).getMongodbHosts();
         case "mongodbmembersautodiscover":
-        case "mongodbMembersAutoDiscover": getOrCreateConfiguration(target).isMongodbMembersAutoDiscover(); return true;
+        case "mongodbMembersAutoDiscover": return getOrCreateConfiguration(target).isMongodbMembersAutoDiscover();
         case "mongodbname":
-        case "mongodbName": getOrCreateConfiguration(target).getMongodbName(); return true;
+        case "mongodbName": return getOrCreateConfiguration(target).getMongodbName();
         case "mongodbpassword":
-        case "mongodbPassword": getOrCreateConfiguration(target).getMongodbPassword(); return true;
+        case "mongodbPassword": return getOrCreateConfiguration(target).getMongodbPassword();
         case "mongodbsslenabled":
-        case "mongodbSslEnabled": getOrCreateConfiguration(target).isMongodbSslEnabled(); return true;
+        case "mongodbSslEnabled": return getOrCreateConfiguration(target).isMongodbSslEnabled();
         case "mongodbsslinvalidhostnameallowed":
-        case "mongodbSslInvalidHostnameAllowed": getOrCreateConfiguration(target).isMongodbSslInvalidHostnameAllowed(); return true;
+        case "mongodbSslInvalidHostnameAllowed": return getOrCreateConfiguration(target).isMongodbSslInvalidHostnameAllowed();
         case "mongodbuser":
-        case "mongodbUser": getOrCreateConfiguration(target).getMongodbUser(); return true;
+        case "mongodbUser": return getOrCreateConfiguration(target).getMongodbUser();
         case "offsetcommitpolicy":
-        case "offsetCommitPolicy": getOrCreateConfiguration(target).getOffsetCommitPolicy(); return true;
+        case "offsetCommitPolicy": return getOrCreateConfiguration(target).getOffsetCommitPolicy();
         case "offsetcommittimeoutms":
-        case "offsetCommitTimeoutMs": getOrCreateConfiguration(target).getOffsetCommitTimeoutMs(); return true;
+        case "offsetCommitTimeoutMs": return getOrCreateConfiguration(target).getOffsetCommitTimeoutMs();
         case "offsetflushintervalms":
-        case "offsetFlushIntervalMs": getOrCreateConfiguration(target).getOffsetFlushIntervalMs(); return true;
+        case "offsetFlushIntervalMs": return getOrCreateConfiguration(target).getOffsetFlushIntervalMs();
         case "offsetstorage":
-        case "offsetStorage": getOrCreateConfiguration(target).getOffsetStorage(); return true;
+        case "offsetStorage": return getOrCreateConfiguration(target).getOffsetStorage();
         case "offsetstoragefilename":
-        case "offsetStorageFileName": getOrCreateConfiguration(target).getOffsetStorageFileName(); return true;
+        case "offsetStorageFileName": return getOrCreateConfiguration(target).getOffsetStorageFileName();
         case "offsetstoragepartitions":
-        case "offsetStoragePartitions": getOrCreateConfiguration(target).getOffsetStoragePartitions(); return true;
+        case "offsetStoragePartitions": return getOrCreateConfiguration(target).getOffsetStoragePartitions();
         case "offsetstoragereplicationfactor":
-        case "offsetStorageReplicationFactor": getOrCreateConfiguration(target).getOffsetStorageReplicationFactor(); return true;
+        case "offsetStorageReplicationFactor": return getOrCreateConfiguration(target).getOffsetStorageReplicationFactor();
         case "offsetstoragetopic":
-        case "offsetStorageTopic": getOrCreateConfiguration(target).getOffsetStorageTopic(); return true;
+        case "offsetStorageTopic": return getOrCreateConfiguration(target).getOffsetStorageTopic();
         case "pollintervalms":
-        case "pollIntervalMs": getOrCreateConfiguration(target).getPollIntervalMs(); return true;
+        case "pollIntervalMs": return getOrCreateConfiguration(target).getPollIntervalMs();
         case "snapshotdelayms":
-        case "snapshotDelayMs": getOrCreateConfiguration(target).getSnapshotDelayMs(); return true;
+        case "snapshotDelayMs": return getOrCreateConfiguration(target).getSnapshotDelayMs();
         case "snapshotfetchsize":
-        case "snapshotFetchSize": getOrCreateConfiguration(target).getSnapshotFetchSize(); return true;
+        case "snapshotFetchSize": return getOrCreateConfiguration(target).getSnapshotFetchSize();
         case "snapshotmode":
-        case "snapshotMode": getOrCreateConfiguration(target).getSnapshotMode(); return true;
+        case "snapshotMode": return getOrCreateConfiguration(target).getSnapshotMode();
         case "sourcestructversion":
-        case "sourceStructVersion": getOrCreateConfiguration(target).getSourceStructVersion(); return true;
+        case "sourceStructVersion": return getOrCreateConfiguration(target).getSourceStructVersion();
         case "tombstonesondelete":
-        case "tombstonesOnDelete": getOrCreateConfiguration(target).isTombstonesOnDelete(); return true;
+        case "tombstonesOnDelete": return getOrCreateConfiguration(target).isTombstonesOnDelete();
         default: return null;
         }
     }
diff --git a/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbEndpointConfigurer.java b/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbEndpointConfigurer.java
index b326b1b..2c38de6 100644
--- a/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbEndpointConfigurer.java
+++ b/components/camel-debezium-mongodb/src/generated/java/org/apache/camel/component/debezium/DebeziumMongodbEndpointConfigurer.java
@@ -165,92 +165,92 @@ public class DebeziumMongodbEndpointConfigurer extends PropertyConfigurerSupport
         DebeziumMongodbEndpoint target = (DebeziumMongodbEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "additionalproperties":
-        case "additionalProperties": target.getConfiguration().getAdditionalProperties(); return true;
+        case "additionalProperties": return target.getConfiguration().getAdditionalProperties();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "collectionblacklist":
-        case "collectionBlacklist": target.getConfiguration().getCollectionBlacklist(); return true;
+        case "collectionBlacklist": return target.getConfiguration().getCollectionBlacklist();
         case "collectionwhitelist":
-        case "collectionWhitelist": target.getConfiguration().getCollectionWhitelist(); return true;
+        case "collectionWhitelist": return target.getConfiguration().getCollectionWhitelist();
         case "connectbackoffinitialdelayms":
-        case "connectBackoffInitialDelayMs": target.getConfiguration().getConnectBackoffInitialDelayMs(); return true;
+        case "connectBackoffInitialDelayMs": return target.getConfiguration().getConnectBackoffInitialDelayMs();
         case "connectbackoffmaxdelayms":
-        case "connectBackoffMaxDelayMs": target.getConfiguration().getConnectBackoffMaxDelayMs(); return true;
+        case "connectBackoffMaxDelayMs": return target.getConfiguration().getConnectBackoffMaxDelayMs();
         case "connectmaxattempts":
-        case "connectMaxAttempts": target.getConfiguration().getConnectMaxAttempts(); return true;
+        case "connectMaxAttempts": return target.getConfiguration().getConnectMaxAttempts();
         case "databaseblacklist":
-        case "databaseBlacklist": target.getConfiguration().getDatabaseBlacklist(); return true;
+        case "databaseBlacklist": return target.getConfiguration().getDatabaseBlacklist();
         case "databasehistoryfilefilename":
-        case "databaseHistoryFileFilename": target.getConfiguration().getDatabaseHistoryFileFilename(); return true;
+        case "databaseHistoryFileFilename": return target.getConfiguration().getDatabaseHistoryFileFilename();
         case "databasewhitelist":
-        case "databaseWhitelist": target.getConfiguration().getDatabaseWhitelist(); return true;
+        case "databaseWhitelist": return target.getConfiguration().getDatabaseWhitelist();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "fieldblacklist":
-        case "fieldBlacklist": target.getConfiguration().getFieldBlacklist(); return true;
+        case "fieldBlacklist": return target.getConfiguration().getFieldBlacklist();
         case "fieldrenames":
-        case "fieldRenames": target.getConfiguration().getFieldRenames(); return true;
+        case "fieldRenames": return target.getConfiguration().getFieldRenames();
         case "heartbeatintervalms":
-        case "heartbeatIntervalMs": target.getConfiguration().getHeartbeatIntervalMs(); return true;
+        case "heartbeatIntervalMs": return target.getConfiguration().getHeartbeatIntervalMs();
         case "heartbeattopicsprefix":
-        case "heartbeatTopicsPrefix": target.getConfiguration().getHeartbeatTopicsPrefix(); return true;
+        case "heartbeatTopicsPrefix": return target.getConfiguration().getHeartbeatTopicsPrefix();
         case "initialsyncmaxthreads":
-        case "initialSyncMaxThreads": target.getConfiguration().getInitialSyncMaxThreads(); return true;
+        case "initialSyncMaxThreads": return target.getConfiguration().getInitialSyncMaxThreads();
         case "internalkeyconverter":
-        case "internalKeyConverter": target.getConfiguration().getInternalKeyConverter(); return true;
+        case "internalKeyConverter": return target.getConfiguration().getInternalKeyConverter();
         case "internalvalueconverter":
-        case "internalValueConverter": target.getConfiguration().getInternalValueConverter(); return true;
+        case "internalValueConverter": return target.getConfiguration().getInternalValueConverter();
         case "maxbatchsize":
-        case "maxBatchSize": target.getConfiguration().getMaxBatchSize(); return true;
+        case "maxBatchSize": return target.getConfiguration().getMaxBatchSize();
         case "maxqueuesize":
-        case "maxQueueSize": target.getConfiguration().getMaxQueueSize(); return true;
+        case "maxQueueSize": return target.getConfiguration().getMaxQueueSize();
         case "mongodbhosts":
-        case "mongodbHosts": target.getConfiguration().getMongodbHosts(); return true;
+        case "mongodbHosts": return target.getConfiguration().getMongodbHosts();
         case "mongodbmembersautodiscover":
-        case "mongodbMembersAutoDiscover": target.getConfiguration().isMongodbMembersAutoDiscover(); return true;
+        case "mongodbMembersAutoDiscover": return target.getConfiguration().isMongodbMembersAutoDiscover();
         case "mongodbname":
-        case "mongodbName": target.getConfiguration().getMongodbName(); return true;
+        case "mongodbName": return target.getConfiguration().getMongodbName();
         case "mongodbpassword":
-        case "mongodbPassword": target.getConfiguration().getMongodbPassword(); return true;
+        case "mongodbPassword": return target.getConfiguration().getMongodbPassword();
         case "mongodbsslenabled":
-        case "mongodbSslEnabled": target.getConfiguration().isMongodbSslEnabled(); return true;
+        case "mongodbSslEnabled": return target.getConfiguration().isMongodbSslEnabled();
         case "mongodbsslinvalidhostnameallowed":
-        case "mongodbSslInvalidHostnameAllowed": target.getConfiguration().isMongodbSslInvalidHostnameAllowed(); return true;
+        case "mongodbSslInvalidHostnameAllowed": return target.getConfiguration().isMongodbSslInvalidHostnameAllowed();
         case "mongodbuser":
-        case "mongodbUser": target.getConfiguration().getMongodbUser(); return true;
+        case "mongodbUser": return target.getConfiguration().getMongodbUser();
         case "offsetcommitpolicy":
-        case "offsetCommitPolicy": target.getConfiguration().getOffsetCommitPolicy(); return true;
+        case "offsetCommitPolicy": return target.getConfiguration().getOffsetCommitPolicy();
         case "offsetcommittimeoutms":
-        case "offsetCommitTimeoutMs": target.getConfiguration().getOffsetCommitTimeoutMs(); return true;
+        case "offsetCommitTimeoutMs": return target.getConfiguration().getOffsetCommitTimeoutMs();
         case "offsetflushintervalms":
-        case "offsetFlushIntervalMs": target.getConfiguration().getOffsetFlushIntervalMs(); return true;
+        case "offsetFlushIntervalMs": return target.getConfiguration().getOffsetFlushIntervalMs();
         case "offsetstorage":
-        case "offsetStorage": target.getConfiguration().getOffsetStorage(); return true;
+        case "offsetStorage": return target.getConfiguration().getOffsetStorage();
         case "offsetstoragefilename":
-        case "offsetStorageFileName": target.getConfiguration().getOffsetStorageFileName(); return true;
+        case "offsetStorageFileName": return target.getConfiguration().getOffsetStorageFileName();
         case "offsetstoragepartitions":
-        case "offsetStoragePartitions": target.getConfiguration().getOffsetStoragePartitions(); return true;
+        case "offsetStoragePartitions": return target.getConfiguration().getOffsetStoragePartitions();
         case "offsetstoragereplicationfactor":
-        case "offsetStorageReplicationFactor": target.getConfiguration().getOffsetStorageReplicationFactor(); return true;
+        case "offsetStorageReplicationFactor": return target.getConfiguration().getOffsetStorageReplicationFactor();
         case "offsetstoragetopic":
-        case "offsetStorageTopic": target.getConfiguration().getOffsetStorageTopic(); return true;
+        case "offsetStorageTopic": return target.getConfiguration().getOffsetStorageTopic();
         case "pollintervalms":
-        case "pollIntervalMs": target.getConfiguration().getPollIntervalMs(); return true;
+        case "pollIntervalMs": return target.getConfiguration().getPollIntervalMs();
         case "snapshotdelayms":
-        case "snapshotDelayMs": target.getConfiguration().getSnapshotDelayMs(); return true;
+        case "snapshotDelayMs": return target.getConfiguration().getSnapshotDelayMs();
         case "snapshotfetchsize":
-        case "snapshotFetchSize": target.getConfiguration().getSnapshotFetchSize(); return true;
+        case "snapshotFetchSize": return target.getConfiguration().getSnapshotFetchSize();
         case "snapshotmode":
-        case "snapshotMode": target.getConfiguration().getSnapshotMode(); return true;
+        case "snapshotMode": return target.getConfiguration().getSnapshotMode();
         case "sourcestructversion":
-        case "sourceStructVersion": target.getConfiguration().getSourceStructVersion(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "sourceStructVersion": return target.getConfiguration().getSourceStructVersion();
+        case "synchronous": return target.isSynchronous();
         case "tombstonesondelete":
-        case "tombstonesOnDelete": target.getConfiguration().isTombstonesOnDelete(); return true;
+        case "tombstonesOnDelete": return target.getConfiguration().isTombstonesOnDelete();
         default: return null;
         }
     }
diff --git a/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlComponentConfigurer.java b/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlComponentConfigurer.java
index 8a44885..5e4b4bb 100644
--- a/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlComponentConfigurer.java
+++ b/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlComponentConfigurer.java
@@ -256,148 +256,148 @@ public class DebeziumMySqlComponentConfigurer extends PropertyConfigurerSupport
         DebeziumMySqlComponent target = (DebeziumMySqlComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "additionalproperties":
-        case "additionalProperties": getOrCreateConfiguration(target).getAdditionalProperties(); return true;
+        case "additionalProperties": return getOrCreateConfiguration(target).getAdditionalProperties();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bigintunsignedhandlingmode":
-        case "bigintUnsignedHandlingMode": getOrCreateConfiguration(target).getBigintUnsignedHandlingMode(); return true;
+        case "bigintUnsignedHandlingMode": return getOrCreateConfiguration(target).getBigintUnsignedHandlingMode();
         case "binlogbuffersize":
-        case "binlogBufferSize": getOrCreateConfiguration(target).getBinlogBufferSize(); return true;
+        case "binlogBufferSize": return getOrCreateConfiguration(target).getBinlogBufferSize();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "columnblacklist":
-        case "columnBlacklist": getOrCreateConfiguration(target).getColumnBlacklist(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "columnBlacklist": return getOrCreateConfiguration(target).getColumnBlacklist();
+        case "configuration": return target.getConfiguration();
         case "connectkeepalive":
-        case "connectKeepAlive": getOrCreateConfiguration(target).isConnectKeepAlive(); return true;
+        case "connectKeepAlive": return getOrCreateConfiguration(target).isConnectKeepAlive();
         case "connectkeepaliveintervalms":
-        case "connectKeepAliveIntervalMs": getOrCreateConfiguration(target).getConnectKeepAliveIntervalMs(); return true;
+        case "connectKeepAliveIntervalMs": return getOrCreateConfiguration(target).getConnectKeepAliveIntervalMs();
         case "connecttimeoutms":
-        case "connectTimeoutMs": getOrCreateConfiguration(target).getConnectTimeoutMs(); return true;
+        case "connectTimeoutMs": return getOrCreateConfiguration(target).getConnectTimeoutMs();
         case "databaseblacklist":
-        case "databaseBlacklist": getOrCreateConfiguration(target).getDatabaseBlacklist(); return true;
+        case "databaseBlacklist": return getOrCreateConfiguration(target).getDatabaseBlacklist();
         case "databasehistory":
-        case "databaseHistory": getOrCreateConfiguration(target).getDatabaseHistory(); return true;
+        case "databaseHistory": return getOrCreateConfiguration(target).getDatabaseHistory();
         case "databasehistoryfilefilename":
-        case "databaseHistoryFileFilename": getOrCreateConfiguration(target).getDatabaseHistoryFileFilename(); return true;
+        case "databaseHistoryFileFilename": return getOrCreateConfiguration(target).getDatabaseHistoryFileFilename();
         case "databasehistorykafkabootstrapservers":
-        case "databaseHistoryKafkaBootstrapServers": getOrCreateConfiguration(target).getDatabaseHistoryKafkaBootstrapServers(); return true;
+        case "databaseHistoryKafkaBootstrapServers": return getOrCreateConfiguration(target).getDatabaseHistoryKafkaBootstrapServers();
         case "databasehistorykafkarecoveryattempts":
-        case "databaseHistoryKafkaRecoveryAttempts": getOrCreateConfiguration(target).getDatabaseHistoryKafkaRecoveryAttempts(); return true;
+        case "databaseHistoryKafkaRecoveryAttempts": return getOrCreateConfiguration(target).getDatabaseHistoryKafkaRecoveryAttempts();
         case "databasehistorykafkarecoverypollintervalms":
-        case "databaseHistoryKafkaRecoveryPollIntervalMs": getOrCreateConfiguration(target).getDatabaseHistoryKafkaRecoveryPollIntervalMs(); return true;
+        case "databaseHistoryKafkaRecoveryPollIntervalMs": return getOrCreateConfiguration(target).getDatabaseHistoryKafkaRecoveryPollIntervalMs();
         case "databasehistorykafkatopic":
-        case "databaseHistoryKafkaTopic": getOrCreateConfiguration(target).getDatabaseHistoryKafkaTopic(); return true;
+        case "databaseHistoryKafkaTopic": return getOrCreateConfiguration(target).getDatabaseHistoryKafkaTopic();
         case "databasehistoryskipunparseableddl":
-        case "databaseHistorySkipUnparseableDdl": getOrCreateConfiguration(target).isDatabaseHistorySkipUnparseableDdl(); return true;
+        case "databaseHistorySkipUnparseableDdl": return getOrCreateConfiguration(target).isDatabaseHistorySkipUnparseableDdl();
         case "databasehistorystoreonlymonitoredtablesddl":
-        case "databaseHistoryStoreOnlyMonitoredTablesDdl": getOrCreateConfiguration(target).isDatabaseHistoryStoreOnlyMonitoredTablesDdl(); return true;
+        case "databaseHistoryStoreOnlyMonitoredTablesDdl": return getOrCreateConfiguration(target).isDatabaseHistoryStoreOnlyMonitoredTablesDdl();
         case "databasehostname":
-        case "databaseHostname": getOrCreateConfiguration(target).getDatabaseHostname(); return true;
+        case "databaseHostname": return getOrCreateConfiguration(target).getDatabaseHostname();
         case "databaseinitialstatements":
-        case "databaseInitialStatements": getOrCreateConfiguration(target).getDatabaseInitialStatements(); return true;
+        case "databaseInitialStatements": return getOrCreateConfiguration(target).getDatabaseInitialStatements();
         case "databasejdbcdriver":
-        case "databaseJdbcDriver": getOrCreateConfiguration(target).getDatabaseJdbcDriver(); return true;
+        case "databaseJdbcDriver": return getOrCreateConfiguration(target).getDatabaseJdbcDriver();
         case "databasepassword":
-        case "databasePassword": getOrCreateConfiguration(target).getDatabasePassword(); return true;
+        case "databasePassword": return getOrCreateConfiguration(target).getDatabasePassword();
         case "databaseport":
-        case "databasePort": getOrCreateConfiguration(target).getDatabasePort(); return true;
+        case "databasePort": return getOrCreateConfiguration(target).getDatabasePort();
         case "databaseserverid":
-        case "databaseServerId": getOrCreateConfiguration(target).getDatabaseServerId(); return true;
+        case "databaseServerId": return getOrCreateConfiguration(target).getDatabaseServerId();
         case "databaseserveridoffset":
-        case "databaseServerIdOffset": getOrCreateConfiguration(target).getDatabaseServerIdOffset(); return true;
+        case "databaseServerIdOffset": return getOrCreateConfiguration(target).getDatabaseServerIdOffset();
         case "databaseservername":
-        case "databaseServerName": getOrCreateConfiguration(target).getDatabaseServerName(); return true;
+        case "databaseServerName": return getOrCreateConfiguration(target).getDatabaseServerName();
         case "databasesslkeystore":
-        case "databaseSslKeystore": getOrCreateConfiguration(target).getDatabaseSslKeystore(); return true;
+        case "databaseSslKeystore": return getOrCreateConfiguration(target).getDatabaseSslKeystore();
         case "databasesslkeystorepassword":
-        case "databaseSslKeystorePassword": getOrCreateConfiguration(target).getDatabaseSslKeystorePassword(); return true;
+        case "databaseSslKeystorePassword": return getOrCreateConfiguration(target).getDatabaseSslKeystorePassword();
         case "databasesslmode":
-        case "databaseSslMode": getOrCreateConfiguration(target).getDatabaseSslMode(); return true;
+        case "databaseSslMode": return getOrCreateConfiguration(target).getDatabaseSslMode();
         case "databasessltruststore":
-        case "databaseSslTruststore": getOrCreateConfiguration(target).getDatabaseSslTruststore(); return true;
+        case "databaseSslTruststore": return getOrCreateConfiguration(target).getDatabaseSslTruststore();
         case "databasessltruststorepassword":
-        case "databaseSslTruststorePassword": getOrCreateConfiguration(target).getDatabaseSslTruststorePassword(); return true;
+        case "databaseSslTruststorePassword": return getOrCreateConfiguration(target).getDatabaseSslTruststorePassword();
         case "databaseuser":
-        case "databaseUser": getOrCreateConfiguration(target).getDatabaseUser(); return true;
+        case "databaseUser": return getOrCreateConfiguration(target).getDatabaseUser();
         case "databasewhitelist":
-        case "databaseWhitelist": getOrCreateConfiguration(target).getDatabaseWhitelist(); return true;
+        case "databaseWhitelist": return getOrCreateConfiguration(target).getDatabaseWhitelist();
         case "decimalhandlingmode":
-        case "decimalHandlingMode": getOrCreateConfiguration(target).getDecimalHandlingMode(); return true;
+        case "decimalHandlingMode": return getOrCreateConfiguration(target).getDecimalHandlingMode();
         case "enabletimeadjuster":
-        case "enableTimeAdjuster": getOrCreateConfiguration(target).isEnableTimeAdjuster(); return true;
+        case "enableTimeAdjuster": return getOrCreateConfiguration(target).isEnableTimeAdjuster();
         case "eventdeserializationfailurehandlingmode":
-        case "eventDeserializationFailureHandlingMode": getOrCreateConfiguration(target).getEventDeserializationFailureHandlingMode(); return true;
+        case "eventDeserializationFailureHandlingMode": return getOrCreateConfiguration(target).getEventDeserializationFailureHandlingMode();
         case "gtidnewchannelposition":
-        case "gtidNewChannelPosition": getOrCreateConfiguration(target).getGtidNewChannelPosition(); return true;
+        case "gtidNewChannelPosition": return getOrCreateConfiguration(target).getGtidNewChannelPosition();
         case "gtidsourceexcludes":
-        case "gtidSourceExcludes": getOrCreateConfiguration(target).getGtidSourceExcludes(); return true;
+        case "gtidSourceExcludes": return getOrCreateConfiguration(target).getGtidSourceExcludes();
         case "gtidsourcefilterdmlevents":
-        case "gtidSourceFilterDmlEvents": getOrCreateConfiguration(target).isGtidSourceFilterDmlEvents(); return true;
+        case "gtidSourceFilterDmlEvents": return getOrCreateConfiguration(target).isGtidSourceFilterDmlEvents();
         case "gtidsourceincludes":
-        case "gtidSourceIncludes": getOrCreateConfiguration(target).getGtidSourceIncludes(); return true;
+        case "gtidSourceIncludes": return getOrCreateConfiguration(target).getGtidSourceIncludes();
         case "heartbeatintervalms":
-        case "heartbeatIntervalMs": getOrCreateConfiguration(target).getHeartbeatIntervalMs(); return true;
+        case "heartbeatIntervalMs": return getOrCreateConfiguration(target).getHeartbeatIntervalMs();
         case "heartbeattopicsprefix":
-        case "heartbeatTopicsPrefix": getOrCreateConfiguration(target).getHeartbeatTopicsPrefix(); return true;
+        case "heartbeatTopicsPrefix": return getOrCreateConfiguration(target).getHeartbeatTopicsPrefix();
         case "includequery":
-        case "includeQuery": getOrCreateConfiguration(target).isIncludeQuery(); return true;
+        case "includeQuery": return getOrCreateConfiguration(target).isIncludeQuery();
         case "includeschemachanges":
-        case "includeSchemaChanges": getOrCreateConfiguration(target).isIncludeSchemaChanges(); return true;
+        case "includeSchemaChanges": return getOrCreateConfiguration(target).isIncludeSchemaChanges();
         case "inconsistentschemahandlingmode":
-        case "inconsistentSchemaHandlingMode": getOrCreateConfiguration(target).getInconsistentSchemaHandlingMode(); return true;
+        case "inconsistentSchemaHandlingMode": return getOrCreateConfiguration(target).getInconsistentSchemaHandlingMode();
         case "internalkeyconverter":
-        case "internalKeyConverter": getOrCreateConfiguration(target).getInternalKeyConverter(); return true;
+        case "internalKeyConverter": return getOrCreateConfiguration(target).getInternalKeyConverter();
         case "internalvalueconverter":
-        case "internalValueConverter": getOrCreateConfiguration(target).getInternalValueConverter(); return true;
+        case "internalValueConverter": return getOrCreateConfiguration(target).getInternalValueConverter();
         case "maxbatchsize":
-        case "maxBatchSize": getOrCreateConfiguration(target).getMaxBatchSize(); return true;
+        case "maxBatchSize": return getOrCreateConfiguration(target).getMaxBatchSize();
         case "maxqueuesize":
-        case "maxQueueSize": getOrCreateConfiguration(target).getMaxQueueSize(); return true;
+        case "maxQueueSize": return getOrCreateConfiguration(target).getMaxQueueSize();
         case "messagekeycolumns":
-        case "messageKeyColumns": getOrCreateConfiguration(target).getMessageKeyColumns(); return true;
+        case "messageKeyColumns": return getOrCreateConfiguration(target).getMessageKeyColumns();
         case "offsetcommitpolicy":
-        case "offsetCommitPolicy": getOrCreateConfiguration(target).getOffsetCommitPolicy(); return true;
+        case "offsetCommitPolicy": return getOrCreateConfiguration(target).getOffsetCommitPolicy();
         case "offsetcommittimeoutms":
-        case "offsetCommitTimeoutMs": getOrCreateConfiguration(target).getOffsetCommitTimeoutMs(); return true;
+        case "offsetCommitTimeoutMs": return getOrCreateConfiguration(target).getOffsetCommitTimeoutMs();
         case "offsetflushintervalms":
-        case "offsetFlushIntervalMs": getOrCreateConfiguration(target).getOffsetFlushIntervalMs(); return true;
+        case "offsetFlushIntervalMs": return getOrCreateConfiguration(target).getOffsetFlushIntervalMs();
         case "offsetstorage":
-        case "offsetStorage": getOrCreateConfiguration(target).getOffsetStorage(); return true;
+        case "offsetStorage": return getOrCreateConfiguration(target).getOffsetStorage();
         case "offsetstoragefilename":
-        case "offsetStorageFileName": getOrCreateConfiguration(target).getOffsetStorageFileName(); return true;
+        case "offsetStorageFileName": return getOrCreateConfiguration(target).getOffsetStorageFileName();
         case "offsetstoragepartitions":
-        case "offsetStoragePartitions": getOrCreateConfiguration(target).getOffsetStoragePartitions(); return true;
+        case "offsetStoragePartitions": return getOrCreateConfiguration(target).getOffsetStoragePartitions();
         case "offsetstoragereplicationfactor":
-        case "offsetStorageReplicationFactor": getOrCreateConfiguration(target).getOffsetStorageReplicationFactor(); return true;
+        case "offsetStorageReplicationFactor": return getOrCreateConfiguration(target).getOffsetStorageReplicationFactor();
         case "offsetstoragetopic":
-        case "offsetStorageTopic": getOrCreateConfiguration(target).getOffsetStorageTopic(); return true;
+        case "offsetStorageTopic": return getOrCreateConfiguration(target).getOffsetStorageTopic();
         case "pollintervalms":
-        case "pollIntervalMs": getOrCreateConfiguration(target).getPollIntervalMs(); return true;
+        case "pollIntervalMs": return getOrCreateConfiguration(target).getPollIntervalMs();
         case "snapshotdelayms":
-        case "snapshotDelayMs": getOrCreateConfiguration(target).getSnapshotDelayMs(); return true;
+        case "snapshotDelayMs": return getOrCreateConfiguration(target).getSnapshotDelayMs();
         case "snapshotfetchsize":
-        case "snapshotFetchSize": getOrCreateConfiguration(target).getSnapshotFetchSize(); return true;
+        case "snapshotFetchSize": return getOrCreateConfiguration(target).getSnapshotFetchSize();
         case "snapshotlockingmode":
-        case "snapshotLockingMode": getOrCreateConfiguration(target).getSnapshotLockingMode(); return true;
+        case "snapshotLockingMode": return getOrCreateConfiguration(target).getSnapshotLockingMode();
         case "snapshotmode":
-        case "snapshotMode": getOrCreateConfiguration(target).getSnapshotMode(); return true;
+        case "snapshotMode": return getOrCreateConfiguration(target).getSnapshotMode();
         case "snapshotnewtables":
-        case "snapshotNewTables": getOrCreateConfiguration(target).getSnapshotNewTables(); return true;
+        case "snapshotNewTables": return getOrCreateConfiguration(target).getSnapshotNewTables();
         case "snapshotselectstatementoverrides":
-        case "snapshotSelectStatementOverrides": getOrCreateConfiguration(target).getSnapshotSelectStatementOverrides(); return true;
+        case "snapshotSelectStatementOverrides": return getOrCreateConfiguration(target).getSnapshotSelectStatementOverrides();
         case "sourcestructversion":
-        case "sourceStructVersion": getOrCreateConfiguration(target).getSourceStructVersion(); return true;
+        case "sourceStructVersion": return getOrCreateConfiguration(target).getSourceStructVersion();
         case "tableblacklist":
-        case "tableBlacklist": getOrCreateConfiguration(target).getTableBlacklist(); return true;
+        case "tableBlacklist": return getOrCreateConfiguration(target).getTableBlacklist();
         case "tableignorebuiltin":
-        case "tableIgnoreBuiltin": getOrCreateConfiguration(target).isTableIgnoreBuiltin(); return true;
+        case "tableIgnoreBuiltin": return getOrCreateConfiguration(target).isTableIgnoreBuiltin();
         case "tablewhitelist":
-        case "tableWhitelist": getOrCreateConfiguration(target).getTableWhitelist(); return true;
+        case "tableWhitelist": return getOrCreateConfiguration(target).getTableWhitelist();
         case "timeprecisionmode":
-        case "timePrecisionMode": getOrCreateConfiguration(target).getTimePrecisionMode(); return true;
+        case "timePrecisionMode": return getOrCreateConfiguration(target).getTimePrecisionMode();
         case "tombstonesondelete":
-        case "tombstonesOnDelete": getOrCreateConfiguration(target).isTombstonesOnDelete(); return true;
+        case "tombstonesOnDelete": return getOrCreateConfiguration(target).isTombstonesOnDelete();
         default: return null;
         }
     }
diff --git a/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlEndpointConfigurer.java b/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlEndpointConfigurer.java
index 498ab62..3f5f9e3 100644
--- a/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlEndpointConfigurer.java
+++ b/components/camel-debezium-mysql/src/generated/java/org/apache/camel/component/debezium/DebeziumMySqlEndpointConfigurer.java
@@ -255,152 +255,152 @@ public class DebeziumMySqlEndpointConfigurer extends PropertyConfigurerSupport i
         DebeziumMySqlEndpoint target = (DebeziumMySqlEndpoint) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "additionalproperties":
-        case "additionalProperties": target.getConfiguration().getAdditionalProperties(); return true;
+        case "additionalProperties": return target.getConfiguration().getAdditionalProperties();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bigintunsignedhandlingmode":
-        case "bigintUnsignedHandlingMode": target.getConfiguration().getBigintUnsignedHandlingMode(); return true;
+        case "bigintUnsignedHandlingMode": return target.getConfiguration().getBigintUnsignedHandlingMode();
         case "binlogbuffersize":
-        case "binlogBufferSize": target.getConfiguration().getBinlogBufferSize(); return true;
+        case "binlogBufferSize": return target.getConfiguration().getBinlogBufferSize();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "columnblacklist":
-        case "columnBlacklist": target.getConfiguration().getColumnBlacklist(); return true;
+        case "columnBlacklist": return target.getConfiguration().getColumnBlacklist();
         case "connectkeepalive":
-        case "connectKeepAlive": target.getConfiguration().isConnectKeepAlive(); return true;
+        case "connectKeepAlive": return target.getConfiguration().isConnectKeepAlive();
         case "connectkeepaliveintervalms":
-        case "connectKeepAliveIntervalMs": target.getConfiguration().getConnectKeepAliveIntervalMs(); return true;
+        case "connectKeepAliveIntervalMs": return target.getConfiguration().getConnectKeepAliveIntervalMs();
         case "connecttimeoutms":
-        case "connectTimeoutMs": target.getConfiguration().getConnectTimeoutMs(); return true;
+        case "connectTimeoutMs": return target.getConfiguration().getConnectTimeoutMs();
         case "databaseblacklist":
-        case "databaseBlacklist": target.getConfiguration().getDatabaseBlacklist(); return true;
+        case "databaseBlacklist": return target.getConfiguration().getDatabaseBlacklist();
         case "databasehistory":
-        case "databaseHistory": target.getConfiguration().getDatabaseHistory(); return true;
+        case "databaseHistory": return target.getConfiguration().getDatabaseHistory();
         case "databasehistoryfilefilename":
-        case "databaseHistoryFileFilename": target.getConfiguration().getDatabaseHistoryFileFilename(); return true;
+        case "databaseHistoryFileFilename": return target.getConfiguration().getDatabaseHistoryFileFilename();
         case "databasehistorykafkabootstrapservers":
-        case "databaseHistoryKafkaBootstrapServers": target.getConfiguration().getDatabaseHistoryKafkaBootstrapServers(); return true;
+        case "databaseHistoryKafkaBootstrapServers": return target.getConfiguration().getDatabaseHistoryKafkaBootstrapServers();
         case "databasehistorykafkarecoveryattempts":
-        case "databaseHistoryKafkaRecoveryAttempts": target.getConfiguration().getDatabaseHistoryKafkaRecoveryAttempts(); return true;
+        case "databaseHistoryKafkaRecoveryAttempts": return target.getConfiguration().getDatabaseHistoryKafkaRecoveryAttempts();
         case "databasehistorykafkarecoverypollintervalms":
-        case "databaseHistoryKafkaRecoveryPollIntervalMs": target.getConfiguration().getDatabaseHistoryKafkaRecoveryPollIntervalMs(); return true;
+        case "databaseHistoryKafkaRecoveryPollIntervalMs": return target.getConfiguration().getDatabaseHistoryKafkaRecoveryPollIntervalMs();
         case "databasehistorykafkatopic":
-        case "databaseHistoryKafkaTopic": target.getConfiguration().getDatabaseHistoryKafkaTopic(); return true;
+        case "databaseHistoryKafkaTopic": return target.getConfiguration().getDatabaseHistoryKafkaTopic();
         case "databasehistoryskipunparseableddl":
-        case "databaseHistorySkipUnparseableDdl": target.getConfiguration().isDatabaseHistorySkipUnparseableDdl(); return true;
+        case "databaseHistorySkipUnparseableDdl": return target.getConfiguration().isDatabaseHistorySkipUnparseableDdl();
         case "databasehistorystoreonlymonitoredtablesddl":
-        case "databaseHistoryStoreOnlyMonitoredTablesDdl": target.getConfiguration().isDatabaseHistoryStoreOnlyMonitoredTablesDdl(); return true;
+        case "databaseHistoryStoreOnlyMonitoredTablesDdl": return target.getConfiguration().isDatabaseHistoryStoreOnlyMonitoredTablesDdl();
         case "databasehostname":
-        case "databaseHostname": target.getConfiguration().getDatabaseHostname(); return true;
+        case "databaseHostname": return target.getConfiguration().getDatabaseHostname();
         case "databaseinitialstatements":
-        case "databaseInitialStatements": target.getConfiguration().getDatabaseInitialStatements(); return true;
+        case "databaseInitialStatements": return target.getConfiguration().getDatabaseInitialStatements();
         case "databasejdbcdriver":
-        case "databaseJdbcDriver": target.getConfiguration().getDatabaseJdbcDriver(); return true;
+        case "databaseJdbcDriver": return target.getConfiguration().getDatabaseJdbcDriver();
         case "databasepassword":
-        case "databasePassword": target.getConfiguration().getDatabasePassword(); return true;
+        case "databasePassword": return target.getConfiguration().getDatabasePassword();
         case "databaseport":
-        case "databasePort": target.getConfiguration().getDatabasePort(); return true;
+        case "databasePort": return target.getConfiguration().getDatabasePort();
         case "databaseserverid":
-        case "databaseServerId": target.getConfiguration().getDatabaseServerId(); return true;
+        case "databaseServerId": return target.getConfiguration().getDatabaseServerId();
         case "databaseserveridoffset":
-        case "databaseServerIdOffset": target.getConfiguration().getDatabaseServerIdOffset(); return true;
+        case "databaseServerIdOffset": return target.getConfiguration().getDatabaseServerIdOffset();
         case "databaseservername":
-        case "databaseServerName": target.getConfiguration().getDatabaseServerName(); return true;
+        case "databaseServerName": return target.getConfiguration().getDatabaseServerName();
         case "databasesslkeystore":
-        case "databaseSslKeystore": target.getConfiguration().getDatabaseSslKeystore(); return true;
+        case "databaseSslKeystore": return target.getConfiguration().getDatabaseSslKeystore();
         case "databasesslkeystorepassword":
-        case "databaseSslKeystorePassword": target.getConfiguration().getDatabaseSslKeystorePassword(); return true;
+        case "databaseSslKeystorePassword": return target.getConfiguration().getDatabaseSslKeystorePassword();
         case "databasesslmode":
-        case "databaseSslMode": target.getConfiguration().getDatabaseSslMode(); return true;
+        case "databaseSslMode": return target.getConfiguration().getDatabaseSslMode();
         case "databasessltruststore":
-        case "databaseSslTruststore": target.getConfiguration().getDatabaseSslTruststore(); return true;
+        case "databaseSslTruststore": return target.getConfiguration().getDatabaseSslTruststore();
         case "databasessltruststorepassword":
-        case "databaseSslTruststorePassword": target.getConfiguration().getDatabaseSslTruststorePassword(); return true;
+        case "databaseSslTruststorePassword": return target.getConfiguration().getDatabaseSslTruststorePassword();
         case "databaseuser":
-        case "databaseUser": target.getConfiguration().getDatabaseUser(); return true;
+        case "databaseUser": return target.getConfiguration().getDatabaseUser();
         case "databasewhitelist":
-        case "databaseWhitelist": target.getConfiguration().getDatabaseWhitelist(); return true;
+        case "databaseWhitelist": return target.getConfiguration().getDatabaseWhitelist();
         case "decimalhandlingmode":
-        case "decimalHandlingMode": target.getConfiguration().getDecimalHandlingMode(); return true;
+        case "decimalHandlingMode": return target.getConfiguration().getDecimalHandlingMode();
         case "enabletimeadjuster":
-        case "enableTimeAdjuster": target.getConfiguration().isEnableTimeAdjuster(); return true;
+        case "enableTimeAdjuster": return target.getConfiguration().isEnableTimeAdjuster();
         case "eventdeserializationfailurehandlingmode":
-        case "eventDeserializationFailureHandlingMode": target.getConfiguration().getEventDeserializationFailureHandlingMode(); return true;
+        case "eventDeserializationFailureHandlingMode": return target.getConfiguration().getEventDeserializationFailureHandlingMode();
         case "exceptionhandler":
-        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exceptionHandler": return target.getExceptionHandler();
         case "exchangepattern":
-        case "exchangePattern": target.getExchangePattern(); return true;
+        case "exchangePattern": return target.getExchangePattern();
         case "gtidnewchannelposition":
-        case "gtidNewChannelPosition": target.getConfiguration().getGtidNewChannelPosition(); return true;
+        case "gtidNewChannelPosition": return target.getConfiguration().getGtidNewChannelPosition();
         case "gtidsourceexcludes":
-        case "gtidSourceExcludes": target.getConfiguration().getGtidSourceExcludes(); return true;
+        case "gtidSourceExcludes": return target.getConfiguration().getGtidSourceExcludes();
         case "gtidsourcefilterdmlevents":
-        case "gtidSourceFilterDmlEvents": target.getConfiguration().isGtidSourceFilterDmlEvents(); return true;
+        case "gtidSourceFilterDmlEvents": return target.getConfiguration().isGtidSourceFilterDmlEvents();
         case "gtidsourceincludes":
-        case "gtidSourceIncludes": target.getConfiguration().getGtidSourceIncludes(); return true;
+        case "gtidSourceIncludes": return target.getConfiguration().getGtidSourceIncludes();
         case "heartbeatintervalms":
-        case "heartbeatIntervalMs": target.getConfiguration().getHeartbeatIntervalMs(); return true;
+        case "heartbeatIntervalMs": return target.getConfiguration().getHeartbeatIntervalMs();
         case "heartbeattopicsprefix":
-        case "heartbeatTopicsPrefix": target.getConfiguration().getHeartbeatTopicsPrefix(); return true;
+        case "heartbeatTopicsPrefix": return target.getConfiguration().getHeartbeatTopicsPrefix();
         case "includequery":
-        case "includeQuery": target.getConfiguration().isIncludeQuery(); return true;
+        case "includeQuery": return target.getConfiguration().isIncludeQuery();
         case "includeschemachanges":
-        case "includeSchemaChanges": target.getConfiguration().isIncludeSchemaChanges(); return true;
+        case "includeSchemaChanges": return target.getConfiguration().isIncludeSchemaChanges();
         case "inconsistentschemahandlingmode":
-        case "inconsistentSchemaHandlingMode": target.getConfiguration().getInconsistentSchemaHandlingMode(); return true;
+        case "inconsistentSchemaHandlingMode": return target.getConfiguration().getInconsistentSchemaHandlingMode();
         case "internalkeyconverter":
-        case "internalKeyConverter": target.getConfiguration().getInternalKeyConverter(); return true;
+        case "internalKeyConverter": return target.getConfiguration().getInternalKeyConverter();
         case "internalvalueconverter":
-        case "internalValueConverter": target.getConfiguration().getInternalValueConverter(); return true;
+        case "internalValueConverter": return target.getConfiguration().getInternalValueConverter();
         case "maxbatchsize":
-        case "maxBatchSize": target.getConfiguration().getMaxBatchSize(); return true;
+        case "maxBatchSize": return target.getConfiguration().getMaxBatchSize();
         case "maxqueuesize":
-        case "maxQueueSize": target.getConfiguration().getMaxQueueSize(); return true;
+        case "maxQueueSize": return target.getConfiguration().getMaxQueueSize();
         case "messagekeycolumns":
-        case "messageKeyColumns": target.getConfiguration().getMessageKeyColumns(); return true;
+        case "messageKeyColumns": return target.getConfiguration().getMessageKeyColumns();
         case "offsetcommitpolicy":
-        case "offsetCommitPolicy": target.getConfiguration().getOffsetCommitPolicy(); return true;
+        case "offsetCommitPolicy": return target.getConfiguration().getOffsetCommitPolicy();
         case "offsetcommittimeoutms":
-        case "offsetCommitTimeoutMs": target.getConfiguration().getOffsetCommitTimeoutMs(); return true;
+        case "offsetCommitTimeoutMs": return target.getConfiguration().getOffsetCommitTimeoutMs();
         case "offsetflushintervalms":
-        case "offsetFlushIntervalMs": target.getConfiguration().getOffsetFlushIntervalMs(); return true;
+        case "offsetFlushIntervalMs": return target.getConfiguration().getOffsetFlushIntervalMs();
         case "offsetstorage":
-        case "offsetStorage": target.getConfiguration().getOffsetStorage(); return true;
+        case "offsetStorage": return target.getConfiguration().getOffsetStorage();
         case "offsetstoragefilename":
-        case "offsetStorageFileName": target.getConfiguration().getOffsetStorageFileName(); return true;
+        case "offsetStorageFileName": return target.getConfiguration().getOffsetStorageFileName();
         case "offsetstoragepartitions":
-        case "offsetStoragePartitions": target.getConfiguration().getOffsetStoragePartitions(); return true;
+        case "offsetStoragePartitions": return target.getConfiguration().getOffsetStoragePartitions();
         case "offsetstoragereplicationfactor":
-        case "offsetStorageReplicationFactor": target.getConfiguration().getOffsetStorageReplicationFactor(); return true;
+        case "offsetStorageReplicationFactor": return target.getConfiguration().getOffsetStorageReplicationFactor();
         case "offsetstoragetopic":
-        case "offsetStorageTopic": target.getConfiguration().getOffsetStorageTopic(); return true;
+        case "offsetStorageTopic": return target.getConfiguration().getOffsetStorageTopic();
         case "pollintervalms":
-        case "pollIntervalMs": target.getConfiguration().getPollIntervalMs(); return true;
+        case "pollIntervalMs": return target.getConfiguration().getPollIntervalMs();
         case "snapshotdelayms":
-        case "snapshotDelayMs": target.getConfiguration().getSnapshotDelayMs(); return true;
+        case "snapshotDelayMs": return target.getConfiguration().getSnapshotDelayMs();
         case "snapshotfetchsize":
-        case "snapshotFetchSize": target.getConfiguration().getSnapshotFetchSize(); return true;
+        case "snapshotFetchSize": return target.getConfiguration().getSnapshotFetchSize();
         case "snapshotlockingmode":
-        case "snapshotLockingMode": target.getConfiguration().getSnapshotLockingMode(); return true;
+        case "snapshotLockingMode": return target.getConfiguration().getSnapshotLockingMode();
         case "snapshotmode":
-        case "snapshotMode": target.getConfiguration().getSnapshotMode(); return true;
+        case "snapshotMode": return target.getConfiguration().getSnapshotMode();
         case "snapshotnewtables":
-        case "snapshotNewTables": target.getConfiguration().getSnapshotNewTables(); return true;
+        case "snapshotNewTables": return target.getConfiguration().getSnapshotNewTables();
         case "snapshotselectstatementoverrides":
-        case "snapshotSelectStatementOverrides": target.getConfiguration().getSnapshotSelectStatementOverrides(); return true;
+        case "snapshotSelectStatementOverrides": return target.getConfiguration().getSnapshotSelectStatementOverrides();
         case "sourcestructversion":
-        case "sourceStructVersion": target.getConfiguration().getSourceStructVersion(); return true;
-        case "synchronous": target.isSynchronous(); return true;
+        case "sourceStructVersion": return target.getConfiguration().getSourceStructVersion();
+        case "synchronous": return target.isSynchronous();
         case "tableblacklist":
-        case "tableBlacklist": target.getConfiguration().getTableBlacklist(); return true;
+        case "tableBlacklist": return target.getConfiguration().getTableBlacklist();
         case "tableignorebuiltin":
-        case "tableIgnoreBuiltin": target.getConfiguration().isTableIgnoreBuiltin(); return true;
+        case "tableIgnoreBuiltin": return target.getConfiguration().isTableIgnoreBuiltin();
         case "tablewhitelist":
-        case "tableWhitelist": target.getConfiguration().getTableWhitelist(); return true;
+        case "tableWhitelist": return target.getConfiguration().getTableWhitelist();
         case "timeprecisionmode":
-        case "timePrecisionMode": target.getConfiguration().getTimePrecisionMode(); return true;
+        case "timePrecisionMode": return target.getConfiguration().getTimePrecisionMode();
         case "tombstonesondelete":
-        case "tombstonesOnDelete": target.getConfiguration().isTombstonesOnDelete(); return true;
+        case "tombstonesOnDelete": return target.getConfiguration().isTombstonesOnDelete();
         default: return null;
         }
     }
diff --git a/components/camel-debezium-postgres/src/generated/java/org/apache/camel/component/debezium/DebeziumPostgresComponentConfigurer.java b/components/camel-debezium-postgres/src/generated/java/org/apache/camel/component/debezium/DebeziumPostgresComponentConfigurer.java
index 88ce7bb..346adb7 100644
--- a/components/camel-debezium-postgres/src/generated/java/org/apache/camel/component/debezium/DebeziumPostgresComponentConfigurer.java
+++ b/components/camel-debezium-postgres/src/generated/java/org/apache/camel/component/debezium/DebeziumPostgresComponentConfigurer.java
@@ -232,132 +232,132 @@ public class DebeziumPostgresComponentConfigurer extends PropertyConfigurerSuppo
         DebeziumPostgresComponent target = (DebeziumPostgresComponent) obj;
         switch (ignoreCase ? name.toLowerCase() : name) {
         case "additionalproperties":
-        case "additionalProperties": getOrCreateConfiguration(target).getAdditionalProperties(); return true;
+        case "additionalProperties": return getOrCreateConfiguration(target).getAdditionalProperties();
         case "basicpropertybinding":
-        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "basicPropertyBinding": return target.isBasicPropertyBinding();
         case "bridgeerrorhandler":
-        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "bridgeErrorHandler": return target.isBridgeErrorHandler();
         case "columnblacklist":
-        case "columnBlacklist": getOrCreateConfiguration(target).getColumnBlacklist(); return true;
-        case "configuration": target.getConfiguration(); return true;
+        case "columnBlacklist": return getOrCreateConfiguration(target).getColumnBlacklist();
+        case "configuration": return target.getConfiguration();
         case "databasedbname":
-        case "databaseDbname": getOrCreateConfiguration(target).getDatabaseDbname(); return true;
+        case "databaseDbname": return getOrCreateConfiguration(target).getDatabaseDbname();
         case "databasehistoryfilefilename":
-        case "databaseHistoryFileFilename": getOrCreateConfiguration(target).getDatabaseHistoryFileFilename(); return true;
+        case "databaseHistoryFileFilename": return getOrCreateConfiguration(target).getDatabaseHistoryFileFilename();
         case "databasehostname":
-        case "databaseHostname": getOrCreateConfiguration(target).getDatabaseHostname(); return true;
+        case "databaseHostname": return getOrCreateConfiguration(target).getDatabaseHostname();
         case "databaseinitialstatements":
-        case "databaseInitialStatements": getOrCreateConfiguration(target).getDatabaseInitialStatements(); return true;
+        case "databaseInitialStatements": return getOrCreateConfiguration(target).getDatabaseInitialStatements();
         case "databasepassword":
-        case "databasePassword": getOrCreateConfiguration(target).getDatabasePassword(); return true;
+        case "databasePassword": return getOrCreateConfiguration(target).getDatabasePassword();
         case "databaseport":
-        case "databasePort": getOrCreateConfiguration(target).getDatabasePort(); return true;
+        case "databasePort": return getOrCreateConfiguration(target).getDatabasePort();
         case "databaseservername":
-        case "databaseServerName": getOrCreateConfiguration(target).getDatabaseServerName(); return true;
+        case "databaseServerName": return getOrCreateConfiguration(target).getDatabaseServerName();
         case "databasesslcert":
-        case "databaseSslcert": getOrCreateConfiguration(target).getDatabaseSslcert(); return true;
+        case "databaseSslcert": return getOrCreateConfiguration(target).getDatabaseSslcert();
         case "databasesslfactory":
-        case "databaseSslfactory": getOrCreateConfiguration(target).getDatabaseSslfactory(); return true;
+        case "databaseSslfactory": return getOrCreateConfiguration(target).getDatabaseSslfactory();
         case "databasesslkey":
-        case "databaseSslkey": getOrCreateConfiguration(target).getDatabaseSslkey(); return true;
+        case "databaseSslkey": return getOrCreateConfiguration(target).getDatabaseSslkey();
         case "databasesslmode":
-        case "databaseSslmode": getOrCreateConfiguration(target).getDatabaseSslmode(); return true;
+        case "databaseSslmode": return getOrCreateConfiguration(target).getDatabaseSslmode();
         case "databasesslpassword":
-        case "databaseSslpassword": getOrCreateConfiguration(target).getDatabaseSslpassword(); return true;
+        case "databaseSslpassword": return getOrCreateConfiguration(target).getDatabaseSslpassword();
         case "databasesslrootcert":
-        case "databaseSslrootcert": getOrCreateConfiguration(target).getDatabaseSslrootcert(); return true;
... 11130 lines suppressed ...


[camel] 10/13: CAMEL-14762: camel-core - Configurer to include API for method name and type

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

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

commit 718801e44e1548c3a6ba5f5bf2441aa817188a9d
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 09:46:40 2020 +0100

    CAMEL-14762: camel-core - Configurer to include API for method name and type
---
 .../org/apache/camel/support/PropertyBindingSupport.java | 16 ++++++++++------
 1 file changed, 10 insertions(+), 6 deletions(-)

diff --git a/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java b/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java
index 14d698c..457f53f 100644
--- a/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java
+++ b/core/camel-support/src/main/java/org/apache/camel/support/PropertyBindingSupport.java
@@ -366,14 +366,18 @@ public final class PropertyBindingSupport {
         }
 
         // use configurer to get all the current options and its values
+        Map<String, Object> getterAllOption = null;
         if (configurer instanceof PropertyConfigurerGetter) {
             getter = (PropertyConfigurerGetter) configurer;
             final PropertyConfigurerGetter lambdaGetter = getter;
             final Object lambdaTarget = target;
-            // TODO: optimize to only load complex values as these are the only ones we
-            getter.getAllOptions(target).forEach((key, type) -> {
-                Object value = lambdaGetter.getOptionValue(lambdaTarget, key, true);
-                properties.put(key, value);
+            getterAllOption = getter.getAllOptions(target);
+            getterAllOption.forEach((key, type) -> {
+                // we only need the complex types
+                if (isComplexUserType((Class) type)) {
+                    Object value = lambdaGetter.getOptionValue(lambdaTarget, key, true);
+                    properties.put(key, value);
+                }
             });
         } else {
             // okay use reflection based
@@ -399,9 +403,9 @@ public final class PropertyBindingSupport {
             }
 
             Class<?> type;
-            if (getter != null) {
+            if (getterAllOption != null) {
                 // use getter configurer to know the property class type
-                type = (Class<?>) getter.getAllOptions(target).get(key);
+                type = (Class<?>) getterAllOption.get(key);
             } else {
                 // okay fallback to use reflection based
                 type = getGetterType(camelContext, target, key, false);


[camel] 01/13: CAMEL-14762: camel-core - Configurer to include API for method name and type

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

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

commit 21d8ad32d6be4830e069fdb2778cb61321bc44d9
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sat Mar 21 19:23:08 2020 +0100

    CAMEL-14762: camel-core - Configurer to include API for method name and type
---
 .../camel/spi/PropertyOptionsConfigurer.java       | 34 ++++++++++++++++++++++
 .../packaging/PropertyConfigurerGenerator.java     | 31 ++++++++++++++++++--
 2 files changed, 63 insertions(+), 2 deletions(-)

diff --git a/core/camel-api/src/main/java/org/apache/camel/spi/PropertyOptionsConfigurer.java b/core/camel-api/src/main/java/org/apache/camel/spi/PropertyOptionsConfigurer.java
new file mode 100644
index 0000000..9c7b3e9
--- /dev/null
+++ b/core/camel-api/src/main/java/org/apache/camel/spi/PropertyOptionsConfigurer.java
@@ -0,0 +1,34 @@
+/*
+ * 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.spi;
+
+import java.util.Map;
+
+/**
+ * A marker interface to identify the object as being a configurer which can
+ * provide details about the options the configurer supports.
+ */
+public interface PropertyOptionsConfigurer {
+
+    /**
+     * Provides a map of which options the cofigurer supports and their class type.
+     *
+     * @return options as map name -> class type.
+     */
+    Map<String, Object> options();
+
+}
diff --git a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
index bd3e683..86229bf 100644
--- a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
+++ b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
@@ -36,15 +36,19 @@ public final class PropertyConfigurerGenerator {
         w.write("/* " + AbstractGeneratorMojo.GENERATED_MSG + " */\n");
         w.write("package " + pn + ";\n");
         w.write("\n");
+        w.write("import java.util.Map;\n");
+        w.write("\n");
         w.write("import org.apache.camel.CamelContext;\n");
         w.write("import org.apache.camel.spi.GeneratedPropertyConfigurer;\n");
+        w.write("import org.apache.camel.spi.PropertyOptionsConfigurer;\n");
+        w.write("import org.apache.camel.util.CaseInsensitiveMap;\n");
         w.write("import "  + pfqn + ";\n");
         w.write("\n");
         w.write("/**\n");
         w.write(" * " + AbstractGeneratorMojo.GENERATED_MSG + "\n");
         w.write(" */\n");
         w.write("@SuppressWarnings(\"unchecked\")\n");
-        w.write("public class " + cn + " extends " + psn + " implements GeneratedPropertyConfigurer {\n");
+        w.write("public class " + cn + " extends " + psn + " implements GeneratedPropertyConfigurer, PropertyOptionsConfigurer {\n");
         w.write("\n");
         if (!options.isEmpty() || !hasSuper) {
 
@@ -83,8 +87,31 @@ public final class PropertyConfigurerGenerator {
                 w.write("        }\n");
             }
             w.write("    }\n");
+
+            // generate API that returns which
+            w.write("\n");
+            w.write("    @Override\n");
+            w.write("    public Map<String, Object> options() {\n");
+            if (hasSuper) {
+                w.write("        Map<String, Object> answer = super.options();\n");
+            } else {
+                w.write("        Map<String, Object> answer = new CaseInsensitiveMap();\n");
+            }
+            if (!options.isEmpty() || !hasSuper) {
+                for (BaseOptionModel option : options) {
+                    // type may contain generics so remove those
+                    String type = option.getJavaType();
+                    if (type.indexOf('<') != -1) {
+                        type = type.substring(0, type.indexOf('<'));
+                    }
+                    type = type.replace('$', '.');
+                    w.write(String.format("        answer.put(\"%s\", %s.class);\n", option.getName(), type));
+                }
+                w.write("        return answer;\n");
+                w.write("    }\n");
+            }
         }
-        w.write("\n");
+
         w.write("}\n");
         w.write("\n");
     }


[camel] 06/13: CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs

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

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

commit 21eece5fe03397f7869e999c273ef5e90a9ecf22
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 01:45:36 2020 +0100

    CAMEL-14762: Regen and fixed some components had invalid setter/getter pairs
---
 .../activemq/ActiveMQComponentConfigurer.java      |  31 +-
 .../activemq/ActiveMQEndpointConfigurer.java       |   7 +-
 .../component/activemq/ActiveMQComponent.java      |  28 ++
 .../component/ahc/ws/WsComponentConfigurer.java    |  22 +-
 .../component/ahc/ws/WsEndpointConfigurer.java     |  34 +-
 .../component/ahc/AhcComponentConfigurer.java      |  44 ++-
 .../camel/component/ahc/AhcEndpointConfigurer.java |  62 +++-
 .../component/amqp/AMQPComponentConfigurer.java    |  22 +-
 .../component/amqp/AMQPEndpointConfigurer.java     |   7 +-
 .../apache/camel/component/amqp/AMQPComponent.java |   7 +
 .../component/apns/ApnsComponentConfigurer.java    |  31 +-
 .../component/apns/ApnsEndpointConfigurer.java     |  83 ++++-
 .../component/as2/AS2ComponentConfigurer.java      |  30 +-
 .../camel/component/as2/AS2EndpointConfigurer.java | 159 +++++++++-
 .../asterisk/AsteriskComponentConfigurer.java      |  28 +-
 .../asterisk/AsteriskEndpointConfigurer.java       |  44 ++-
 .../component/atmos/AtmosComponentConfigurer.java  |  39 ++-
 .../component/atmos/AtmosEndpointConfigurer.java   |  58 +++-
 .../websocket/WebsocketComponentConfigurer.java    |  22 +-
 .../websocket/WebsocketEndpointConfigurer.java     |  67 +++-
 .../component/atom/AtomComponentConfigurer.java    |  25 +-
 .../component/atom/AtomEndpointConfigurer.java     |  99 +++++-
 .../client/map/AtomixMapComponentConfigurer.java   |  67 +++-
 .../client/map/AtomixMapEndpointConfigurer.java    |  73 ++++-
 .../AtomixMessagingComponentConfigurer.java        |  72 ++++-
 .../AtomixMessagingEndpointConfigurer.java         |  78 ++++-
 .../AtomixMultiMapComponentConfigurer.java         |  64 +++-
 .../multimap/AtomixMultiMapEndpointConfigurer.java |  64 +++-
 .../queue/AtomixQueueComponentConfigurer.java      |  63 +++-
 .../queue/AtomixQueueEndpointConfigurer.java       |  69 +++-
 .../client/set/AtomixSetComponentConfigurer.java   |  65 +++-
 .../client/set/AtomixSetEndpointConfigurer.java    |  71 ++++-
 .../value/AtomixValueComponentConfigurer.java      |  65 +++-
 .../value/AtomixValueEndpointConfigurer.java       |  71 ++++-
 .../component/avro/AvroComponentConfigurer.java    |  47 ++-
 .../component/avro/AvroEndpointConfigurer.java     |  53 +++-
 .../component/aws/cw/CwComponentConfigurer.java    |  55 +++-
 .../component/aws/cw/CwEndpointConfigurer.java     |  55 +++-
 .../component/aws/ddb/DdbComponentConfigurer.java  |  64 +++-
 .../component/aws/ddb/DdbEndpointConfigurer.java   |  64 +++-
 .../ddbstream/DdbStreamComponentConfigurer.java    |  56 +++-
 .../aws/ddbstream/DdbStreamEndpointConfigurer.java | 107 ++++++-
 .../component/aws/ec2/EC2ComponentConfigurer.java  |  49 ++-
 .../component/aws/ec2/EC2EndpointConfigurer.java   |  49 ++-
 .../component/aws/ecs/ECSComponentConfigurer.java  |  49 ++-
 .../component/aws/ecs/ECSEndpointConfigurer.java   |  49 ++-
 .../component/aws/eks/EKSComponentConfigurer.java  |  49 ++-
 .../component/aws/eks/EKSEndpointConfigurer.java   |  49 ++-
 .../component/aws/iam/IAMComponentConfigurer.java  |  49 ++-
 .../component/aws/iam/IAMEndpointConfigurer.java   |  49 ++-
 .../KinesisFirehoseComponentConfigurer.java        |  47 ++-
 .../KinesisFirehoseEndpointConfigurer.java         |  47 ++-
 .../aws/kinesis/KinesisComponentConfigurer.java    |  65 +++-
 .../aws/kinesis/KinesisEndpointConfigurer.java     | 116 ++++++-
 .../component/aws/kms/KMSComponentConfigurer.java  |  49 ++-
 .../component/aws/kms/KMSEndpointConfigurer.java   |  49 ++-
 .../aws/lambda/LambdaComponentConfigurer.java      |  49 ++-
 .../aws/lambda/LambdaEndpointConfigurer.java       |  49 ++-
 .../component/aws/mq/MQComponentConfigurer.java    |  49 ++-
 .../component/aws/mq/MQEndpointConfigurer.java     |  49 ++-
 .../component/aws/msk/MSKComponentConfigurer.java  |  49 ++-
 .../component/aws/msk/MSKEndpointConfigurer.java   |  49 ++-
 .../component/aws/s3/S3ComponentConfigurer.java    | 127 +++++++-
 .../component/aws/s3/S3EndpointConfigurer.java     | 184 ++++++++++-
 .../component/aws/sdb/SdbComponentConfigurer.java  |  25 +-
 .../component/aws/sdb/SdbEndpointConfigurer.java   |  55 +++-
 .../component/aws/ses/SesComponentConfigurer.java  |  57 +++-
 .../component/aws/ses/SesEndpointConfigurer.java   |  57 +++-
 .../component/aws/sns/SnsComponentConfigurer.java  |  72 ++++-
 .../component/aws/sns/SnsEndpointConfigurer.java   |  75 ++++-
 .../component/aws/sqs/SqsComponentConfigurer.java  | 128 +++++++-
 .../component/aws/sqs/SqsEndpointConfigurer.java   | 185 ++++++++++-
 .../component/aws/swf/SWFComponentConfigurer.java  | 105 +++++-
 .../component/aws/swf/SWFEndpointConfigurer.java   | 111 ++++++-
 .../translate/TranslateComponentConfigurer.java    |  58 +++-
 .../aws/translate/TranslateEndpointConfigurer.java |  58 +++-
 .../component/aws2/cw/Cw2ComponentConfigurer.java  |  55 +++-
 .../component/aws2/cw/Cw2EndpointConfigurer.java   |  55 +++-
 .../aws2/ddb/Ddb2ComponentConfigurer.java          |  64 +++-
 .../component/aws2/ddb/Ddb2EndpointConfigurer.java |  64 +++-
 .../ddbstream/Ddb2StreamComponentConfigurer.java   |  56 +++-
 .../ddbstream/Ddb2StreamEndpointConfigurer.java    | 107 ++++++-
 .../aws2/ec2/AWS2EC2ComponentConfigurer.java       |  49 ++-
 .../aws2/ec2/AWS2EC2EndpointConfigurer.java        |  49 ++-
 .../aws2/ecs/ECS2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/ecs/ECS2EndpointConfigurer.java |  49 ++-
 .../aws2/eks/EKS2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/eks/EKS2EndpointConfigurer.java |  49 ++-
 .../aws2/iam/IAM2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/iam/IAM2EndpointConfigurer.java |  49 ++-
 .../KinesisFirehose2ComponentConfigurer.java       |  47 ++-
 .../KinesisFirehose2EndpointConfigurer.java        |  47 ++-
 .../aws2/kinesis/Kinesis2ComponentConfigurer.java  |  65 +++-
 .../aws2/kinesis/Kinesis2EndpointConfigurer.java   | 116 ++++++-
 .../aws2/kms/KMS2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/kms/KMS2EndpointConfigurer.java |  49 ++-
 .../aws2/lambda/Lambda2ComponentConfigurer.java    |  49 ++-
 .../aws2/lambda/Lambda2EndpointConfigurer.java     |  49 ++-
 .../component/aws2/mq/MQ2ComponentConfigurer.java  |  49 ++-
 .../component/aws2/mq/MQ2EndpointConfigurer.java   |  49 ++-
 .../aws2/msk/MSK2ComponentConfigurer.java          |  49 ++-
 .../component/aws2/msk/MSK2EndpointConfigurer.java |  49 ++-
 .../aws2/s3/AWS2S3ComponentConfigurer.java         | 103 +++++-
 .../aws2/s3/AWS2S3EndpointConfigurer.java          | 160 +++++++++-
 .../aws2/ses/Ses2ComponentConfigurer.java          |  57 +++-
 .../component/aws2/ses/Ses2EndpointConfigurer.java |  57 +++-
 .../aws2/sns/Sns2ComponentConfigurer.java          |  69 +++-
 .../component/aws2/sns/Sns2EndpointConfigurer.java |  72 ++++-
 .../aws2/sqs/Sqs2ComponentConfigurer.java          | 128 +++++++-
 .../component/aws2/sqs/Sqs2EndpointConfigurer.java | 185 ++++++++++-
 .../translate/Translate2ComponentConfigurer.java   |  58 +++-
 .../translate/Translate2EndpointConfigurer.java    |  58 +++-
 .../azure/blob/BlobServiceComponentConfigurer.java |  79 ++++-
 .../azure/blob/BlobServiceEndpointConfigurer.java  |  85 ++++-
 .../queue/QueueServiceComponentConfigurer.java     |  52 ++-
 .../queue/QueueServiceEndpointConfigurer.java      |  58 +++-
 .../BeanValidatorComponentConfigurer.java          |  40 ++-
 .../validator/BeanValidatorEndpointConfigurer.java |  47 ++-
 .../component/bean/BeanComponentConfigurer.java    |  29 +-
 .../component/bean/BeanEndpointConfigurer.java     |  35 +-
 .../beanclass/ClassComponentConfigurer.java        |   7 +-
 .../beanclass/ClassEndpointConfigurer.java         |   7 +-
 .../beanstalk/BeanstalkComponentConfigurer.java    |  31 +-
 .../beanstalk/BeanstalkEndpointConfigurer.java     | 101 +++++-
 .../bonita/BonitaComponentConfigurer.java          |  25 +-
 .../component/bonita/BonitaEndpointConfigurer.java |  38 ++-
 .../component/box/BoxComponentConfigurer.java      |  75 ++++-
 .../camel/component/box/BoxEndpointConfigurer.java | 129 +++++++-
 .../braintree/BraintreeComponentConfigurer.java    |  30 +-
 .../braintree/BraintreeEndpointConfigurer.java     | 116 ++++++-
 .../browse/BrowseComponentConfigurer.java          |  28 +-
 .../component/browse/BrowseEndpointConfigurer.java |  36 ++-
 .../cache/CaffeineCacheComponentConfigurer.java    |  69 +++-
 .../cache/CaffeineCacheEndpointConfigurer.java     |  69 +++-
 .../load/CaffeineLoadCacheComponentConfigurer.java |  69 +++-
 .../load/CaffeineLoadCacheEndpointConfigurer.java  |  69 +++-
 .../cassandra/CassandraComponentConfigurer.java    |  28 +-
 .../cassandra/CassandraEndpointConfigurer.java     | 106 ++++++-
 .../chatscript/ChatScriptComponentConfigurer.java  |  25 +-
 .../chatscript/ChatScriptEndpointConfigurer.java   |  33 +-
 .../component/chunk/ChunkComponentConfigurer.java  |  25 +-
 .../component/chunk/ChunkEndpointConfigurer.java   |  43 ++-
 .../camel/component/cm/CMComponentConfigurer.java  |  25 +-
 .../camel/component/cm/CMEndpointConfigurer.java   |  39 ++-
 .../component/cmis/CMISComponentConfigurer.java    |  31 +-
 .../component/cmis/CMISEndpointConfigurer.java     |  60 +++-
 .../apache/camel/coap/CoAPComponentConfigurer.java |  28 +-
 .../apache/camel/coap/CoAPEndpointConfigurer.java  |  65 +++-
 .../cometd/CometdComponentConfigurer.java          |  48 ++-
 .../component/cometd/CometdEndpointConfigurer.java |  70 +++-
 .../consul/ConsulComponentConfigurer.java          |  89 +++++-
 .../component/consul/ConsulEndpointConfigurer.java |  92 +++++-
 .../controlbus/ControlBusComponentConfigurer.java  |  25 +-
 .../controlbus/ControlBusEndpointConfigurer.java   |  40 ++-
 .../component/corda/CordaComponentConfigurer.java  |  56 +++-
 .../component/corda/CordaEndpointConfigurer.java   |  62 +++-
 .../couchbase/CouchbaseComponentConfigurer.java    |  28 +-
 .../couchbase/CouchbaseEndpointConfigurer.java     | 157 ++++++++-
 .../couchdb/CouchDbComponentConfigurer.java        |  28 +-
 .../couchdb/CouchDbEndpointConfigurer.java         |  53 +++-
 .../component/cron/CronComponentConfigurer.java    |  28 +-
 .../component/cron/CronEndpointConfigurer.java     |  35 +-
 .../crypto/cms/CryptoCmsComponentConfigurer.java   |  31 +-
 .../crypto/cms/CryptoCmsEndpointConfigurer.java    |  66 +++-
 .../DigitalSignatureComponentConfigurer.java       |  75 ++++-
 .../crypto/DigitalSignatureEndpointConfigurer.java |  75 ++++-
 .../component/cxf/CxfComponentConfigurer.java      |  37 ++-
 .../camel/component/cxf/CxfEndpointConfigurer.java | 121 ++++++-
 .../cxf/jaxrs/CxfRsComponentConfigurer.java        |  34 +-
 .../cxf/jaxrs/CxfRsEndpointConfigurer.java         | 110 ++++++-
 .../apache/camel/component/cxf/CxfComponent.java   |   2 +-
 .../dataformat/DataFormatComponentConfigurer.java  |  25 +-
 .../dataformat/DataFormatEndpointConfigurer.java   |  27 +-
 .../dataset/DataSetComponentConfigurer.java        |  28 +-
 .../dataset/DataSetEndpointConfigurer.java         |  46 ++-
 .../dataset/DataSetTestComponentConfigurer.java    |  25 +-
 .../dataset/DataSetTestEndpointConfigurer.java     |  28 +-
 .../DebeziumMongodbComponentConfigurer.java        | 144 ++++++++-
 .../DebeziumMongodbEndpointConfigurer.java         | 150 ++++++++-
 ...goDbConnectorEmbeddedDebeziumConfiguration.java |   8 +-
 .../debezium/DebeziumMySqlComponentConfigurer.java | 234 +++++++++++++-
 .../debezium/DebeziumMySqlEndpointConfigurer.java  | 240 +++++++++++++-
 ...ySqlConnectorEmbeddedDebeziumConfiguration.java |  18 +-
 .../DebeziumPostgresComponentConfigurer.java       | 210 +++++++++++-
 .../DebeziumPostgresEndpointConfigurer.java        | 216 ++++++++++++-
 ...gresConnectorEmbeddedDebeziumConfiguration.java |   8 +-
 .../DebeziumSqlserverComponentConfigurer.java      | 156 ++++++++-
 .../DebeziumSqlserverEndpointConfigurer.java       | 162 +++++++++-
 ...rverConnectorEmbeddedDebeziumConfiguration.java |   4 +-
 .../DigitalOceanComponentConfigurer.java           |  25 +-
 .../DigitalOceanEndpointConfigurer.java            |  52 ++-
 .../direct/DirectComponentConfigurer.java          |  32 +-
 .../component/direct/DirectEndpointConfigurer.java |  43 ++-
 .../directvm/DirectVmComponentConfigurer.java      |  38 ++-
 .../directvm/DirectVmEndpointConfigurer.java       |  49 ++-
 .../disruptor/DisruptorComponentConfigurer.java    |  46 ++-
 .../disruptor/DisruptorEndpointConfigurer.java     |  58 +++-
 .../component/dns/DnsComponentConfigurer.java      |  25 +-
 .../camel/component/dns/DnsEndpointConfigurer.java |  27 +-
 .../docker/DockerComponentConfigurer.java          |  73 ++++-
 .../component/docker/DockerEndpointConfigurer.java |  79 ++++-
 .../component/dozer/DozerComponentConfigurer.java  |  25 +-
 .../component/dozer/DozerEndpointConfigurer.java   |  45 ++-
 .../component/drill/DrillComponentConfigurer.java  |  25 +-
 .../component/drill/DrillEndpointConfigurer.java   |  36 ++-
 .../dropbox/DropboxComponentConfigurer.java        |  28 +-
 .../dropbox/DropboxEndpointConfigurer.java         |  58 +++-
 .../ehcache/EhcacheComponentConfigurer.java        |  63 +++-
 .../ehcache/EhcacheEndpointConfigurer.java         |  71 ++++-
 .../ElasticsearchComponentConfigurer.java          |  55 +++-
 .../ElasticsearchEndpointConfigurer.java           |  71 ++++-
 .../elasticsearch/ElasticsearchConfiguration.java  |   4 +-
 .../elasticsearch/ElasticsearchProducer.java       |   4 +-
 .../component/elsql/ElsqlComponentConfigurer.java  |  40 ++-
 .../component/elsql/ElsqlEndpointConfigurer.java   | 160 +++++++++-
 .../elytron/ElytronComponentConfigurer.java        |  28 +-
 .../elytron/ElytronEndpointConfigurer.java         |   7 +-
 .../etcd/EtcdKeysComponentConfigurer.java          |  50 ++-
 .../component/etcd/EtcdKeysEndpointConfigurer.java |  47 ++-
 .../etcd/EtcdStatsComponentConfigurer.java         |  59 +++-
 .../etcd/EtcdStatsEndpointConfigurer.java          | 107 ++++++-
 .../etcd/EtcdWatchComponentConfigurer.java         |  53 +++-
 .../etcd/EtcdWatchEndpointConfigurer.java          |  56 +++-
 .../eventadmin/EventAdminComponentConfigurer.java  |  31 +-
 .../eventadmin/EventAdminEndpointConfigurer.java   |  38 ++-
 .../component/exec/ExecComponentConfigurer.java    |  25 +-
 .../component/exec/ExecEndpointConfigurer.java     |  48 ++-
 .../facebook/FacebookComponentConfigurer.java      | 111 ++++++-
 .../facebook/FacebookEndpointConfigurer.java       | 313 +++++++++++++++++-
 .../component/fhir/FhirComponentConfigurer.java    |  92 +++++-
 .../component/fhir/FhirEndpointConfigurer.java     | 146 ++++++++-
 .../file/watch/FileWatchComponentConfigurer.java   |  40 ++-
 .../file/watch/FileWatchEndpointConfigurer.java    |  58 +++-
 .../component/file/FileComponentConfigurer.java    |  28 +-
 .../component/file/FileEndpointConfigurer.java     | 278 +++++++++++++++-
 .../flatpack/FlatpackComponentConfigurer.java      |  28 +-
 .../flatpack/FlatpackEndpointConfigurer.java       |  98 +++++-
 .../component/flink/FlinkComponentConfigurer.java  |  37 ++-
 .../component/flink/FlinkEndpointConfigurer.java   |  41 ++-
 .../component/fop/FopComponentConfigurer.java      |  25 +-
 .../camel/component/fop/FopEndpointConfigurer.java |  33 +-
 .../freemarker/FreemarkerComponentConfigurer.java  |  27 +-
 .../freemarker/FreemarkerEndpointConfigurer.java   |  37 ++-
 .../file/remote/FtpComponentConfigurer.java        |  28 +-
 .../file/remote/FtpEndpointConfigurer.java         | 323 ++++++++++++++++++-
 .../file/remote/FtpsComponentConfigurer.java       |  22 +-
 .../file/remote/FtpsEndpointConfigurer.java        |  42 ++-
 .../file/remote/SftpComponentConfigurer.java       |  28 +-
 .../file/remote/SftpEndpointConfigurer.java        | 351 ++++++++++++++++++++-
 .../ganglia/GangliaComponentConfigurer.java        |  55 +++-
 .../ganglia/GangliaEndpointConfigurer.java         |  55 +++-
 .../geocoder/GeoCoderComponentConfigurer.java      |  25 +-
 .../geocoder/GeoCoderEndpointConfigurer.java       |  62 +++-
 .../component/git/GitComponentConfigurer.java      |  28 +-
 .../camel/component/git/GitEndpointConfigurer.java |  59 +++-
 .../github/GitHubComponentConfigurer.java          |  28 +-
 .../component/github/GitHubEndpointConfigurer.java |  56 +++-
 .../GoogleBigQueryComponentConfigurer.java         |  34 +-
 .../bigquery/GoogleBigQueryEndpointConfigurer.java |  33 +-
 .../sql/GoogleBigQuerySQLComponentConfigurer.java  |  31 +-
 .../sql/GoogleBigQuerySQLEndpointConfigurer.java   |  30 +-
 .../GoogleCalendarComponentConfigurer.java         |  58 +++-
 .../calendar/GoogleCalendarEndpointConfigurer.java | 109 ++++++-
 .../GoogleCalendarStreamComponentConfigurer.java   |  61 +++-
 .../GoogleCalendarStreamEndpointConfigurer.java    | 109 ++++++-
 .../drive/GoogleDriveComponentConfigurer.java      |  50 ++-
 .../drive/GoogleDriveEndpointConfigurer.java       | 104 +++++-
 .../google/mail/GoogleMailComponentConfigurer.java |  48 ++-
 .../google/mail/GoogleMailEndpointConfigurer.java  |  99 +++++-
 .../GoogleMailStreamComponentConfigurer.java       |  55 +++-
 .../stream/GoogleMailStreamEndpointConfigurer.java | 103 +++++-
 .../pubsub/GooglePubsubComponentConfigurer.java    |  39 ++-
 .../pubsub/GooglePubsubEndpointConfigurer.java     |  51 ++-
 .../google/pubsub/GooglePubsubConsumer.java        |   2 +-
 .../google/pubsub/GooglePubsubEndpoint.java        |   2 +-
 .../sheets/GoogleSheetsComponentConfigurer.java    |  48 ++-
 .../sheets/GoogleSheetsEndpointConfigurer.java     |  99 +++++-
 .../GoogleSheetsStreamComponentConfigurer.java     |  67 +++-
 .../GoogleSheetsStreamEndpointConfigurer.java      | 115 ++++++-
 .../component/gora/GoraComponentConfigurer.java    |  28 +-
 .../component/gora/GoraEndpointConfigurer.java     |  84 ++++-
 .../component/grape/GrapeComponentConfigurer.java  |  28 +-
 .../component/grape/GrapeEndpointConfigurer.java   |  27 +-
 .../graphql/GraphqlComponentConfigurer.java        |  25 +-
 .../graphql/GraphqlEndpointConfigurer.java         |  47 ++-
 .../camel/component/graphql/GraphqlEndpoint.java   |   2 +-
 .../component/grpc/GrpcComponentConfigurer.java    |  28 +-
 .../component/grpc/GrpcEndpointConfigurer.java     |  98 +++++-
 .../eventbus/GuavaEventBusComponentConfigurer.java |  34 +-
 .../eventbus/GuavaEventBusEndpointConfigurer.java  |  42 ++-
 .../HazelcastAtomicnumberComponentConfigurer.java  |  31 +-
 .../HazelcastAtomicnumberEndpointConfigurer.java   |  36 ++-
 .../HazelcastInstanceComponentConfigurer.java      |  31 +-
 .../HazelcastInstanceEndpointConfigurer.java       |  42 ++-
 .../list/HazelcastListComponentConfigurer.java     |  34 +-
 .../list/HazelcastListEndpointConfigurer.java      |  45 ++-
 .../map/HazelcastMapComponentConfigurer.java       |  34 +-
 .../map/HazelcastMapEndpointConfigurer.java        |  45 ++-
 .../HazelcastMultimapComponentConfigurer.java      |  34 +-
 .../HazelcastMultimapEndpointConfigurer.java       |  45 ++-
 .../queue/HazelcastQueueComponentConfigurer.java   |  34 +-
 .../queue/HazelcastQueueEndpointConfigurer.java    |  54 +++-
 .../HazelcastReplicatedmapComponentConfigurer.java |  34 +-
 .../HazelcastReplicatedmapEndpointConfigurer.java  |  45 ++-
 .../HazelcastRingbufferComponentConfigurer.java    |  31 +-
 .../HazelcastRingbufferEndpointConfigurer.java     |  36 ++-
 .../seda/HazelcastSedaComponentConfigurer.java     |  34 +-
 .../seda/HazelcastSedaEndpointConfigurer.java      |  59 +++-
 .../set/HazelcastSetComponentConfigurer.java       |  34 +-
 .../set/HazelcastSetEndpointConfigurer.java        |  45 ++-
 .../topic/HazelcastTopicComponentConfigurer.java   |  34 +-
 .../topic/HazelcastTopicEndpointConfigurer.java    |  47 ++-
 .../component/hbase/HBaseComponentConfigurer.java  |  33 +-
 .../component/hbase/HBaseEndpointConfigurer.java   |  69 +++-
 .../component/hdfs/HdfsComponentConfigurer.java    |  34 +-
 .../component/hdfs/HdfsEndpointConfigurer.java     | 151 ++++++++-
 .../apache/camel/component/hdfs/HdfsComponent.java |  10 +-
 .../hipchat/HipchatComponentConfigurer.java        |  28 +-
 .../hipchat/HipchatEndpointConfigurer.java         |  90 +++++-
 .../component/http/HttpComponentConfigurer.java    |  76 ++++-
 .../component/http/HttpEndpointConfigurer.java     | 173 +++++++++-
 .../iec60870/client/ClientComponentConfigurer.java |  31 +-
 .../iec60870/client/ClientEndpointConfigurer.java  |  81 ++++-
 .../iec60870/server/ServerComponentConfigurer.java |  31 +-
 .../iec60870/server/ServerEndpointConfigurer.java  |  84 ++++-
 .../infinispan/InfinispanComponentConfigurer.java  |  70 +++-
 .../infinispan/InfinispanEndpointConfigurer.java   |  76 ++++-
 .../influxdb/InfluxDbComponentConfigurer.java      |  25 +-
 .../influxdb/InfluxDbEndpointConfigurer.java       |  39 ++-
 .../component/iota/IOTAComponentConfigurer.java    |  25 +-
 .../component/iota/IOTAEndpointConfigurer.java     |  41 ++-
 .../component/ipfs/IPFSComponentConfigurer.java    |  31 +-
 .../component/ipfs/IPFSEndpointConfigurer.java     |  29 +-
 .../component/irc/IrcComponentConfigurer.java      |  31 +-
 .../camel/component/irc/IrcEndpointConfigurer.java |  97 +++++-
 .../ironmq/IronMQComponentConfigurer.java          |  28 +-
 .../component/ironmq/IronMQEndpointConfigurer.java | 110 ++++++-
 .../component/jbpm/JBPMComponentConfigurer.java    |  28 +-
 .../component/jbpm/JBPMEndpointConfigurer.java     | 103 +++++-
 .../jcache/JCacheComponentConfigurer.java          |  43 ++-
 .../component/jcache/JCacheEndpointConfigurer.java |  89 +++++-
 .../jclouds/JcloudsComponentConfigurer.java        |  34 +-
 .../jclouds/JcloudsEndpointConfigurer.java         |  64 +++-
 .../component/jcr/JcrComponentConfigurer.java      |  28 +-
 .../camel/component/jcr/JcrEndpointConfigurer.java |  62 +++-
 .../component/jdbc/JdbcComponentConfigurer.java    |  28 +-
 .../component/jdbc/JdbcEndpointConfigurer.java     |  61 +++-
 .../apache/camel/component/jdbc/JdbcComponent.java |   4 +
 .../camel/component/jetty/JettyHttpComponent.java  |   4 +
 .../jetty9/JettyHttpComponent9Configurer.java      | 114 ++++++-
 .../jetty9/JettyHttpEndpoint9Configurer.java       | 116 ++++++-
 .../raft/JGroupsRaftComponentConfigurer.java       |  40 ++-
 .../raft/JGroupsRaftEndpointConfigurer.java        |  39 ++-
 .../jgroups/JGroupsComponentConfigurer.java        |  36 ++-
 .../jgroups/JGroupsEndpointConfigurer.java         |  42 ++-
 .../validator/jing/JingComponentConfigurer.java    |  25 +-
 .../validator/jing/JingEndpointConfigurer.java     |  30 +-
 .../component/jira/JiraComponentConfigurer.java    |  51 ++-
 .../component/jira/JiraEndpointConfigurer.java     |  62 +++-
 .../component/jms/JmsComponentConfigurer.java      | 301 +++++++++++++++++-
 .../camel/component/jms/JmsEndpointConfigurer.java | 295 ++++++++++++++++-
 .../component/jmx/JMXComponentConfigurer.java      |  25 +-
 .../camel/component/jmx/JMXEndpointConfigurer.java | 105 +++++-
 .../component/jolt/JoltComponentConfigurer.java    |  27 +-
 .../component/jolt/JoltEndpointConfigurer.java     |  39 ++-
 .../component/jooq/JooqComponentConfigurer.java    |  40 ++-
 .../component/jooq/JooqEndpointConfigurer.java     |  91 +++++-
 .../component/jpa/JpaComponentConfigurer.java      |  40 ++-
 .../camel/component/jpa/JpaEndpointConfigurer.java | 149 ++++++++-
 .../component/scp/ScpComponentConfigurer.java      |  28 +-
 .../camel/component/scp/ScpEndpointConfigurer.java |  83 ++++-
 .../component/jslt/JsltComponentConfigurer.java    |  27 +-
 .../component/jslt/JsltEndpointConfigurer.java     |  33 +-
 .../JsonValidatorComponentConfigurer.java          |  25 +-
 .../JsonValidatorEndpointConfigurer.java           |  45 ++-
 .../component/jt400/Jt400ComponentConfigurer.java  |  31 +-
 .../component/jt400/Jt400EndpointConfigurer.java   | 110 ++++++-
 .../component/kafka/KafkaComponentConfigurer.java  | 302 +++++++++++++++++-
 .../component/kafka/KafkaEndpointConfigurer.java   | 302 +++++++++++++++++-
 .../KubernetesConfigMapsComponentConfigurer.java   |  25 +-
 .../KubernetesConfigMapsEndpointConfigurer.java    |  81 ++++-
 .../KubernetesDeploymentsComponentConfigurer.java  |  28 +-
 .../KubernetesDeploymentsEndpointConfigurer.java   | 104 +++++-
 .../hpa/KubernetesHPAComponentConfigurer.java      |  28 +-
 .../hpa/KubernetesHPAEndpointConfigurer.java       | 104 +++++-
 .../job/KubernetesJobComponentConfigurer.java      |  28 +-
 .../job/KubernetesJobEndpointConfigurer.java       | 104 +++++-
 .../KubernetesNamespacesComponentConfigurer.java   |  28 +-
 .../KubernetesNamespacesEndpointConfigurer.java    | 104 +++++-
 .../nodes/KubernetesNodesComponentConfigurer.java  |  28 +-
 .../nodes/KubernetesNodesEndpointConfigurer.java   | 104 +++++-
 ...rnetesPersistentVolumesComponentConfigurer.java |  25 +-
 ...ernetesPersistentVolumesEndpointConfigurer.java |  81 ++++-
 ...PersistentVolumesClaimsComponentConfigurer.java |  25 +-
 ...sPersistentVolumesClaimsEndpointConfigurer.java |  81 ++++-
 .../pods/KubernetesPodsComponentConfigurer.java    |  28 +-
 .../pods/KubernetesPodsEndpointConfigurer.java     | 104 +++++-
 ...sReplicationControllersComponentConfigurer.java |  28 +-
 ...esReplicationControllersEndpointConfigurer.java | 104 +++++-
 ...ubernetesResourcesQuotaComponentConfigurer.java |  25 +-
 ...KubernetesResourcesQuotaEndpointConfigurer.java |  81 ++++-
 .../KubernetesSecretsComponentConfigurer.java      |  25 +-
 .../KubernetesSecretsEndpointConfigurer.java       |  81 ++++-
 ...bernetesServiceAccountsComponentConfigurer.java |  25 +-
 ...ubernetesServiceAccountsEndpointConfigurer.java |  81 ++++-
 .../KubernetesServicesComponentConfigurer.java     |  28 +-
 .../KubernetesServicesEndpointConfigurer.java      | 104 +++++-
 .../OpenshiftBuildConfigsComponentConfigurer.java  |  25 +-
 .../OpenshiftBuildConfigsEndpointConfigurer.java   |  81 ++++-
 .../builds/OpenshiftBuildsComponentConfigurer.java |  25 +-
 .../builds/OpenshiftBuildsEndpointConfigurer.java  |  81 ++++-
 .../component/kudu/KuduComponentConfigurer.java    |  25 +-
 .../component/kudu/KuduEndpointConfigurer.java     |  29 +-
 .../language/LanguageComponentConfigurer.java      |  25 +-
 .../language/LanguageEndpointConfigurer.java       |  39 ++-
 .../component/ldap/LdapComponentConfigurer.java    |  25 +-
 .../component/ldap/LdapEndpointConfigurer.java     |  37 ++-
 .../component/ldif/LdifComponentConfigurer.java    |  25 +-
 .../component/ldif/LdifEndpointConfigurer.java     |  27 +-
 .../component/log/LogComponentConfigurer.java      |  28 +-
 .../camel/component/log/LogEndpointConfigurer.java |  98 +++++-
 .../lucene/LuceneComponentConfigurer.java          |  38 ++-
 .../component/lucene/LuceneEndpointConfigurer.java |  38 ++-
 .../lumberjack/LumberjackComponentConfigurer.java  |  31 +-
 .../lumberjack/LumberjackEndpointConfigurer.java   |  36 ++-
 .../component/mail/MailComponentConfigurer.java    | 129 +++++++-
 .../component/mail/MailEndpointConfigurer.java     | 200 +++++++++++-
 .../master/MasterComponentConfigurer.java          |  30 +-
 .../component/master/MasterEndpointConfigurer.java |  33 +-
 .../metrics/MetricsComponentConfigurer.java        |  28 +-
 .../metrics/MetricsEndpointConfigurer.java         |  39 ++-
 .../micrometer/MicrometerComponentConfigurer.java  |  28 +-
 .../micrometer/MicrometerEndpointConfigurer.java   |  35 +-
 .../MicroProfileMetricsComponentConfigurer.java    |  28 +-
 .../MicroProfileMetricsEndpointConfigurer.java     |  55 +++-
 .../milo/client/MiloClientComponentConfigurer.java |  87 ++++-
 .../milo/client/MiloClientEndpointConfigurer.java  | 103 +++++-
 .../milo/server/MiloServerComponentConfigurer.java |  82 ++++-
 .../milo/server/MiloServerEndpointConfigurer.java  |  36 ++-
 .../camel/component/milo/server/milo-server.json   |   4 +-
 .../src/main/docs/milo-server-component.adoc       |   4 +-
 .../component/milo/server/MiloServerComponent.java | 115 +++++--
 .../component/milo/AbstractMiloServerTest.java     |   2 +-
 .../component/milo/server/ServerLocalTest.java     |   2 +-
 .../component/mina/MinaComponentConfigurer.java    |  95 +++++-
 .../component/mina/MinaEndpointConfigurer.java     |  98 +++++-
 .../component/mock/MockComponentConfigurer.java    |  25 +-
 .../component/mock/MockEndpointConfigurer.java     |  57 +++-
 .../mongodb/gridfs/GridFsComponentConfigurer.java  |  28 +-
 .../mongodb/gridfs/GridFsEndpointConfigurer.java   |  67 +++-
 .../mongodb/MongoDbComponentConfigurer.java        |  31 +-
 .../mongodb/MongoDbEndpointConfigurer.java         |  92 +++++-
 .../validator/msv/MsvComponentConfigurer.java      |  22 +-
 .../validator/msv/MsvEndpointConfigurer.java       |   7 +-
 .../mustache/MustacheComponentConfigurer.java      |  28 +-
 .../mustache/MustacheEndpointConfigurer.java       |  38 ++-
 .../component/mvel/MvelComponentConfigurer.java    |  25 +-
 .../component/mvel/MvelEndpointConfigurer.java     |  32 +-
 .../mybatis/MyBatisBeanComponentConfigurer.java    |  31 +-
 .../mybatis/MyBatisBeanEndpointConfigurer.java     |  36 ++-
 .../mybatis/MyBatisComponentConfigurer.java        |  34 +-
 .../mybatis/MyBatisEndpointConfigurer.java         | 110 ++++++-
 .../nagios/NagiosComponentConfigurer.java          |  36 ++-
 .../component/nagios/NagiosEndpointConfigurer.java |  39 ++-
 .../component/nats/NatsComponentConfigurer.java    |  33 +-
 .../component/nats/NatsEndpointConfigurer.java     |  96 +++++-
 .../netty/http/NettyHttpComponentConfigurer.java   |  28 +-
 .../netty/http/NettyHttpEndpointConfigurer.java    |  89 +++++-
 .../component/netty/NettyComponentConfigurer.java  | 221 ++++++++++++-
 .../component/netty/NettyEndpointConfigurer.java   | 218 ++++++++++++-
 .../nitrite/NitriteComponentConfigurer.java        |  28 +-
 .../nitrite/NitriteEndpointConfigurer.java         |  48 ++-
 .../component/nsq/NsqComponentConfigurer.java      |  33 +-
 .../camel/component/nsq/NsqEndpointConfigurer.java |  68 +++-
 .../olingo2/Olingo2ComponentConfigurer.java        |  65 +++-
 .../olingo2/Olingo2EndpointConfigurer.java         | 116 ++++++-
 .../olingo4/Olingo4ComponentConfigurer.java        |  65 +++-
 .../olingo4/Olingo4EndpointConfigurer.java         | 116 ++++++-
 .../cinder/CinderComponentConfigurer.java          |  25 +-
 .../openstack/cinder/CinderEndpointConfigurer.java |  44 ++-
 .../glance/GlanceComponentConfigurer.java          |  25 +-
 .../openstack/glance/GlanceEndpointConfigurer.java |  42 ++-
 .../keystone/KeystoneComponentConfigurer.java      |  25 +-
 .../keystone/KeystoneEndpointConfigurer.java       |  41 ++-
 .../neutron/NeutronComponentConfigurer.java        |  25 +-
 .../neutron/NeutronEndpointConfigurer.java         |  44 ++-
 .../openstack/nova/NovaComponentConfigurer.java    |  25 +-
 .../openstack/nova/NovaEndpointConfigurer.java     |  44 ++-
 .../openstack/swift/SwiftComponentConfigurer.java  |  25 +-
 .../openstack/swift/SwiftEndpointConfigurer.java   |  44 ++-
 .../OptaPlannerComponentConfigurer.java            |  28 +-
 .../optaplanner/OptaPlannerEndpointConfigurer.java |  44 ++-
 .../component/paho/PahoComponentConfigurer.java    | 106 ++++++-
 .../component/paho/PahoEndpointConfigurer.java     | 112 ++++++-
 .../paxlogging/PaxLoggingComponentConfigurer.java  |  28 +-
 .../paxlogging/PaxLoggingEndpointConfigurer.java   |  33 +-
 .../component/pdf/PdfComponentConfigurer.java      |  25 +-
 .../camel/component/pdf/PdfEndpointConfigurer.java |  50 ++-
 .../slot/PgReplicationSlotComponentConfigurer.java |  25 +-
 .../slot/PgReplicationSlotEndpointConfigurer.java  |  91 +++++-
 .../pgevent/PgEventComponentConfigurer.java        |  28 +-
 .../pgevent/PgEventEndpointConfigurer.java         |  42 ++-
 .../http/PlatformHttpComponentConfigurer.java      |  27 +-
 .../http/PlatformHttpEndpointConfigurer.java       |  52 ++-
 .../platform/http/PlatformHttpEndpoint.java        |   2 +-
 .../printer/PrinterComponentConfigurer.java        |  25 +-
 .../printer/PrinterEndpointConfigurer.java         |  53 +++-
 .../pubnub/PubNubComponentConfigurer.java          |  28 +-
 .../component/pubnub/PubNubEndpointConfigurer.java |  62 +++-
 .../pulsar/PulsarComponentConfigurer.java          | 117 ++++++-
 .../component/pulsar/PulsarEndpointConfigurer.java | 114 ++++++-
 .../quartz/QuartzComponentConfigurer.java          |  56 +++-
 .../component/quartz/QuartzEndpointConfigurer.java |  76 ++++-
 .../camel/component/quartz/QuartzComponent.java    |   8 +-
 .../quickfixj/QuickfixjComponentConfigurer.java    |  40 ++-
 .../quickfixj/QuickfixjEndpointConfigurer.java     |  42 ++-
 .../component/quickfixj/QuickfixjComponent.java    |  12 +
 .../rabbitmq/RabbitMQComponentConfigurer.java      | 166 +++++++++-
 .../rabbitmq/RabbitMQEndpointConfigurer.java       | 194 +++++++++++-
 .../ReactiveStreamsComponentConfigurer.java        |  46 ++-
 .../streams/ReactiveStreamsEndpointConfigurer.java |  54 +++-
 .../component/ref/RefComponentConfigurer.java      |  28 +-
 .../camel/component/ref/RefEndpointConfigurer.java |  36 ++-
 .../openapi/RestOpenApiComponentConfigurer.java    |  46 ++-
 .../openapi/RestOpenApiEndpointConfigurer.java     |  39 ++-
 .../swagger/RestSwaggerComponentConfigurer.java    |  46 ++-
 .../swagger/RestSwaggerEndpointConfigurer.java     |  42 ++-
 .../component/rest/RestApiComponentConfigurer.java |  25 +-
 .../component/rest/RestApiEndpointConfigurer.java  |  39 ++-
 .../component/rest/RestComponentConfigurer.java    |  42 ++-
 .../component/rest/RestEndpointConfigurer.java     |  68 +++-
 .../RobotFrameworkComponentConfigurer.java         | 149 ++++++++-
 .../RobotFrameworkEndpointConfigurer.java          | 203 +++++++++++-
 .../component/rss/RssComponentConfigurer.java      |  25 +-
 .../camel/component/rss/RssEndpointConfigurer.java |  99 +++++-
 .../component/saga/SagaComponentConfigurer.java    |  25 +-
 .../component/saga/SagaEndpointConfigurer.java     |  27 +-
 .../salesforce/SalesforceComponentConfigurer.java  | 237 +++++++++++++-
 .../salesforce/SalesforceEndpointConfigurer.java   | 151 ++++++++-
 .../camel/component/salesforce/salesforce.json     |   4 +-
 .../src/main/docs/salesforce-component.adoc        |   4 +-
 .../component/salesforce/SalesforceComponent.java  |  20 +-
 .../salesforce/HttpProxyIntegrationTest.java       |   2 +-
 .../netweaver/NetWeaverComponentConfigurer.java    |  25 +-
 .../sap/netweaver/NetWeaverEndpointConfigurer.java |  39 ++-
 .../xquery/XQueryComponentConfigurer.java          |  36 ++-
 .../component/xquery/XQueryEndpointConfigurer.java | 114 ++++++-
 .../scheduler/SchedulerComponentConfigurer.java    |  28 +-
 .../scheduler/SchedulerEndpointConfigurer.java     |  81 ++++-
 .../schematron/SchematronComponentConfigurer.java  |  25 +-
 .../schematron/SchematronEndpointConfigurer.java   |  34 +-
 .../component/seda/SedaComponentConfigurer.java    |  46 ++-
 .../component/seda/SedaEndpointConfigurer.java     |  75 ++++-
 .../service/ServiceComponentConfigurer.java        |  30 +-
 .../service/ServiceEndpointConfigurer.java         |  33 +-
 .../servicenow/ServiceNowComponentConfigurer.java  | 152 ++++++++-
 .../servicenow/ServiceNowEndpointConfigurer.java   | 146 ++++++++-
 .../servlet/ServletComponentConfigurer.java        |  49 ++-
 .../servlet/ServletEndpointConfigurer.java         |  88 +++++-
 .../component/sip/SipComponentConfigurer.java      |  28 +-
 .../camel/component/sip/SipEndpointConfigurer.java | 154 ++++++++-
 .../component/sjms/SjmsComponentConfigurer.java    |  76 ++++-
 .../component/sjms/SjmsEndpointConfigurer.java     | 129 +++++++-
 .../sjms/batch/SjmsBatchComponentConfigurer.java   |  37 ++-
 .../sjms/batch/SjmsBatchEndpointConfigurer.java    |  90 +++++-
 .../component/sjms2/Sjms2ComponentConfigurer.java  |   7 +-
 .../component/sjms2/Sjms2EndpointConfigurer.java   |  26 +-
 .../component/slack/SlackComponentConfigurer.java  |  31 +-
 .../component/slack/SlackEndpointConfigurer.java   | 100 +++++-
 .../component/smpp/SmppComponentConfigurer.java    | 129 +++++++-
 .../component/smpp/SmppEndpointConfigurer.java     | 135 +++++++-
 .../component/snmp/SnmpComponentConfigurer.java    |  28 +-
 .../component/snmp/SnmpEndpointConfigurer.java     | 124 +++++++-
 .../component/solr/SolrComponentConfigurer.java    |  25 +-
 .../component/solr/SolrEndpointConfigurer.java     |  66 +++-
 .../component/SoroushBotComponentConfigurer.java   |  31 +-
 .../component/SoroushBotEndpointConfigurer.java    |  84 ++++-
 .../sparkrest/SparkRestComponentConfigurer.java    |  72 ++++-
 .../sparkrest/SparkRestEndpointConfigurer.java     |  53 +++-
 .../component/spark/SparkComponentConfigurer.java  |  30 +-
 .../component/spark/SparkEndpointConfigurer.java   |  40 ++-
 .../splunk/SplunkComponentConfigurer.java          |  31 +-
 .../component/splunk/SplunkEndpointConfigurer.java | 137 +++++++-
 .../batch/SpringBatchComponentConfigurer.java      |  31 +-
 .../batch/SpringBatchEndpointConfigurer.java       |  36 ++-
 .../SpringIntegrationComponentConfigurer.java      |  28 +-
 .../SpringIntegrationEndpointConfigurer.java       |  45 ++-
 .../springldap/SpringLdapComponentConfigurer.java  |  25 +-
 .../springldap/SpringLdapEndpointConfigurer.java   |  31 +-
 .../component/redis/RedisComponentConfigurer.java  |  28 +-
 .../component/redis/RedisEndpointConfigurer.java   |  51 ++-
 .../ws/SpringWebserviceComponentConfigurer.java    |  31 +-
 .../ws/SpringWebserviceEndpointConfigurer.java     |  86 ++++-
 .../component/event/EventComponentConfigurer.java  |  28 +-
 .../component/event/EventEndpointConfigurer.java   |  36 ++-
 .../component/sql/SqlComponentConfigurer.java      |  34 +-
 .../camel/component/sql/SqlEndpointConfigurer.java | 154 ++++++++-
 .../sql/stored/SqlStoredComponentConfigurer.java   |  28 +-
 .../sql/stored/SqlStoredEndpointConfigurer.java    |  42 ++-
 .../component/ssh/SshComponentConfigurer.java      |  66 +++-
 .../camel/component/ssh/SshEndpointConfigurer.java | 117 ++++++-
 .../component/stax/StAXComponentConfigurer.java    |  25 +-
 .../component/stax/StAXEndpointConfigurer.java     |  27 +-
 .../component/stomp/StompComponentConfigurer.java  |  53 +++-
 .../component/stomp/StompEndpointConfigurer.java   |  56 +++-
 .../stream/StreamComponentConfigurer.java          |  28 +-
 .../component/stream/StreamEndpointConfigurer.java |  78 ++++-
 .../StringTemplateComponentConfigurer.java         |  25 +-
 .../StringTemplateEndpointConfigurer.java          |  36 ++-
 .../component/stub/StubComponentConfigurer.java    |   7 +-
 .../component/stub/StubEndpointConfigurer.java     |   7 +-
 .../telegram/TelegramComponentConfigurer.java      |  39 ++-
 .../telegram/TelegramEndpointConfigurer.java       | 106 ++++++-
 .../thrift/ThriftComponentConfigurer.java          |  31 +-
 .../component/thrift/ThriftEndpointConfigurer.java |  59 +++-
 .../component/tika/TikaComponentConfigurer.java    |  25 +-
 .../component/tika/TikaEndpointConfigurer.java     |  39 ++-
 .../component/timer/TimerComponentConfigurer.java  |  25 +-
 .../component/timer/TimerEndpointConfigurer.java   |  54 +++-
 .../twilio/TwilioComponentConfigurer.java          |  40 ++-
 .../component/twilio/TwilioEndpointConfigurer.java |  84 ++++-
 .../TwitterDirectMessageComponentConfigurer.java   |  52 ++-
 .../TwitterDirectMessageEndpointConfigurer.java    | 140 +++++++-
 .../search/TwitterSearchComponentConfigurer.java   |  52 ++-
 .../search/TwitterSearchEndpointConfigurer.java    | 140 +++++++-
 .../TwitterTimelineComponentConfigurer.java        |  52 ++-
 .../TwitterTimelineEndpointConfigurer.java         | 142 ++++++++-
 .../undertow/UndertowComponentConfigurer.java      |  49 ++-
 .../undertow/UndertowEndpointConfigurer.java       | 106 ++++++-
 .../validator/ValidatorComponentConfigurer.java    |  28 +-
 .../validator/ValidatorEndpointConfigurer.java     |  54 +++-
 .../velocity/VelocityComponentConfigurer.java      |  28 +-
 .../velocity/VelocityEndpointConfigurer.java       |  38 ++-
 .../component/vertx/VertxComponentConfigurer.java  |  42 ++-
 .../component/vertx/VertxEndpointConfigurer.java   |  39 ++-
 .../camel/component/vm/VmComponentConfigurer.java  |   7 +-
 .../camel/component/vm/VmEndpointConfigurer.java   |   7 +-
 .../weather/WeatherComponentConfigurer.java        |  34 +-
 .../weather/WeatherEndpointConfigurer.java         | 147 ++++++++-
 .../component/web3j/Web3jComponentConfigurer.java  | 119 ++++++-
 .../component/web3j/Web3jEndpointConfigurer.java   | 125 +++++++-
 .../webhook/WebhookComponentConfigurer.java        |  42 ++-
 .../webhook/WebhookEndpointConfigurer.java         |  48 ++-
 .../websocket/jsr356/JSR356EndpointConfigurer.java |  39 ++-
 .../jsr356/JSR356WebSocketComponentConfigurer.java |  31 +-
 .../websocket/WebsocketComponentConfigurer.java    |  62 +++-
 .../websocket/WebsocketEndpointConfigurer.java     |  78 ++++-
 .../component/weka/WekaComponentConfigurer.java    |  25 +-
 .../component/weka/WekaEndpointConfigurer.java     |  47 ++-
 .../wordpress/WordpressComponentConfigurer.java    |  48 ++-
 .../wordpress/WordpressEndpointConfigurer.java     |  54 +++-
 .../workday/WorkdayComponentConfigurer.java        |  25 +-
 .../workday/WorkdayEndpointConfigurer.java         |  46 ++-
 .../xchange/XChangeComponentConfigurer.java        |  25 +-
 .../xchange/XChangeEndpointConfigurer.java         |  36 ++-
 .../camel/component/xj/XJComponentConfigurer.java  |   7 +-
 .../camel/component/xj/XJEndpointConfigurer.java   |  22 +-
 .../xmlsecurity/XmlSignerComponentConfigurer.java  | 105 +++++-
 .../xmlsecurity/XmlSignerEndpointConfigurer.java   | 104 +++++-
 .../XmlVerifierComponentConfigurer.java            |  76 ++++-
 .../xmlsecurity/XmlVerifierEndpointConfigurer.java |  75 ++++-
 .../component/xmpp/XmppComponentConfigurer.java    |  28 +-
 .../component/xmpp/XmppEndpointConfigurer.java     |  73 ++++-
 .../xslt/saxon/XsltSaxonComponentConfigurer.java   |  28 +-
 .../xslt/saxon/XsltSaxonEndpointConfigurer.java    |  28 +-
 .../component/xslt/XsltComponentConfigurer.java    |  40 ++-
 .../component/xslt/XsltEndpointConfigurer.java     |  62 +++-
 .../yammer/YammerComponentConfigurer.java          |  59 +++-
 .../component/yammer/YammerEndpointConfigurer.java | 108 ++++++-
 .../zendesk/ZendeskComponentConfigurer.java        |  32 +-
 .../zendesk/ZendeskEndpointConfigurer.java         |  96 +++++-
 .../zookeepermaster/MasterComponentConfigurer.java |  42 ++-
 .../zookeepermaster/MasterEndpointConfigurer.java  |  33 +-
 .../zookeeper/ZooKeeperComponentConfigurer.java    |  47 ++-
 .../zookeeper/ZooKeeperEndpointConfigurer.java     |  53 +++-
 .../dsl/MiloServerComponentBuilderFactory.java     |  30 +-
 .../dsl/SalesforceComponentBuilderFactory.java     |  38 +--
 677 files changed, 39616 insertions(+), 775 deletions(-)

diff --git a/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java b/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java
index ea1d8aa..e30db8a 100644
--- a/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java
+++ b/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.activemq;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.jms.JmsComponentConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ActiveMQComponentConfigurer extends JmsComponentConfigurer implements GeneratedPropertyConfigurer {
+public class ActiveMQComponentConfigurer extends JmsComponentConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -27,5 +31,30 @@ public class ActiveMQComponentConfigurer extends JmsComponentConfigurer implemen
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = super.getAllOptions(target);
+        answer.put("brokerURL", java.lang.String.class);
+        answer.put("trustAllPackages", boolean.class);
+        answer.put("usePooledConnection", boolean.class);
+        answer.put("useSingleConnection", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        ActiveMQComponent target = (ActiveMQComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "brokerurl":
+        case "brokerURL": target.getBrokerURL(); return true;
+        case "trustallpackages":
+        case "trustAllPackages": target.isTrustAllPackages(); return true;
+        case "usepooledconnection":
+        case "usePooledConnection": target.isUsePooledConnection(); return true;
+        case "usesingleconnection":
+        case "useSingleConnection": target.isUseSingleConnection(); return true;
+        default: return super.getOptionValue(obj, name, ignoreCase);
+        }
+    }
 }
 
diff --git a/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQEndpointConfigurer.java b/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQEndpointConfigurer.java
index 5fb6cac..5597f4e 100644
--- a/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQEndpointConfigurer.java
+++ b/components/camel-activemq/src/generated/java/org/apache/camel/component/activemq/ActiveMQEndpointConfigurer.java
@@ -1,16 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.activemq;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.jms.JmsEndpointConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ActiveMQEndpointConfigurer extends JmsEndpointConfigurer implements GeneratedPropertyConfigurer {
-
+public class ActiveMQEndpointConfigurer extends JmsEndpointConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
 }
 
diff --git a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java
index 8bc2f64..55e76b7 100644
--- a/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java
+++ b/components/camel-activemq/src/main/java/org/apache/camel/component/activemq/ActiveMQComponent.java
@@ -82,6 +82,13 @@ public class ActiveMQComponent extends JmsComponent {
         return answer;
     }
 
+    public String getBrokerURL() {
+        if (getConfiguration() instanceof ActiveMQConfiguration) {
+            return ((ActiveMQConfiguration) getConfiguration()).getBrokerURL();
+        }
+        return null;
+    }
+
     /**
      * Sets the broker URL to use to connect to ActiveMQ
      */
@@ -102,6 +109,13 @@ public class ActiveMQComponent extends JmsComponent {
         }
     }
 
+    public boolean isTrustAllPackages() {
+        if (getConfiguration() instanceof ActiveMQConfiguration) {
+            return ((ActiveMQConfiguration)getConfiguration()).isTrustAllPackages();
+        }
+        return false;
+    }
+
     /**
      * Enables or disables whether a PooledConnectionFactory will be used so
      * that when messages are sent to ActiveMQ from outside of a message
@@ -117,6 +131,13 @@ public class ActiveMQComponent extends JmsComponent {
         }
     }
 
+    public boolean isUsePooledConnection() {
+        if (getConfiguration() instanceof ActiveMQConfiguration) {
+            return ((ActiveMQConfiguration)getConfiguration()).isUsePooledConnection();
+        }
+        return true;
+    }
+
     /**
      * Enables or disables whether a Spring {@link SingleConnectionFactory} will
      * be used so that when messages are sent to ActiveMQ from outside of a
@@ -132,6 +153,13 @@ public class ActiveMQComponent extends JmsComponent {
         }
     }
 
+    public boolean isUseSingleConnection() {
+        if (getConfiguration() instanceof ActiveMQConfiguration) {
+            return ((ActiveMQConfiguration)getConfiguration()).isUseSingleConnection();
+        }
+        return false;
+    }
+
     @Override
     protected void setProperties(Endpoint bean, Map<String, Object> parameters) throws Exception {
         Object useSingleConnection = parameters.remove("useSingleConnection");
diff --git a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java
index 335998e..d9e5392 100644
--- a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java
+++ b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.ahc.ws;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.ahc.AhcComponentConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class WsComponentConfigurer extends AhcComponentConfigurer implements GeneratedPropertyConfigurer {
+public class WsComponentConfigurer extends AhcComponentConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -21,5 +25,21 @@ public class WsComponentConfigurer extends AhcComponentConfigurer implements Gen
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = super.getAllOptions(target);
+        answer.put("bridgeErrorHandler", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        WsComponent target = (WsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        default: return super.getOptionValue(obj, name, ignoreCase);
+        }
+    }
 }
 
diff --git a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java
index d23df29..a045b83 100644
--- a/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java
+++ b/components/camel-ahc-ws/src/generated/java/org/apache/camel/component/ahc/ws/WsEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.ahc.ws;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.ahc.AhcEndpointConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class WsEndpointConfigurer extends AhcEndpointConfigurer implements GeneratedPropertyConfigurer {
+public class WsEndpointConfigurer extends AhcEndpointConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -29,5 +33,33 @@ public class WsEndpointConfigurer extends AhcEndpointConfigurer implements Gener
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = super.getAllOptions(target);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("sendMessageOnError", boolean.class);
+        answer.put("useStreaming", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        WsEndpoint target = (WsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "sendmessageonerror":
+        case "sendMessageOnError": target.isSendMessageOnError(); return true;
+        case "usestreaming":
+        case "useStreaming": target.isUseStreaming(); return true;
+        default: return super.getOptionValue(obj, name, ignoreCase);
+        }
+    }
 }
 
diff --git a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java
index 839ddbd..df68745 100644
--- a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java
+++ b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.ahc;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AhcComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AhcComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -35,5 +39,43 @@ public class AhcComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("allowJavaSerializedObject", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("binding", org.apache.camel.component.ahc.AhcBinding.class);
+        answer.put("client", org.asynchttpclient.AsyncHttpClient.class);
+        answer.put("clientConfig", org.asynchttpclient.AsyncHttpClientConfig.class);
+        answer.put("headerFilterStrategy", org.apache.camel.spi.HeaderFilterStrategy.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("sslContextParameters", org.apache.camel.support.jsse.SSLContextParameters.class);
+        answer.put("useGlobalSslContextParameters", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AhcComponent target = (AhcComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "allowjavaserializedobject":
+        case "allowJavaSerializedObject": target.isAllowJavaSerializedObject(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "binding": target.getBinding(); return true;
+        case "client": target.getClient(); return true;
+        case "clientconfig":
+        case "clientConfig": target.getClientConfig(); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.getSslContextParameters(); return true;
+        case "useglobalsslcontextparameters":
+        case "useGlobalSslContextParameters": target.isUseGlobalSslContextParameters(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java
index 1116603..2343d59 100644
--- a/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java
+++ b/components/camel-ahc/src/generated/java/org/apache/camel/component/ahc/AhcEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.ahc;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AhcEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AhcEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -47,5 +51,61 @@ public class AhcEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("binding", org.apache.camel.component.ahc.AhcBinding.class);
+        answer.put("bridgeEndpoint", boolean.class);
+        answer.put("bufferSize", int.class);
+        answer.put("clientConfig", org.asynchttpclient.AsyncHttpClientConfig.class);
+        answer.put("clientConfigOptions", java.util.Map.class);
+        answer.put("clientConfigRealmOptions", java.util.Map.class);
+        answer.put("connectionClose", boolean.class);
+        answer.put("cookieHandler", org.apache.camel.http.base.cookie.CookieHandler.class);
+        answer.put("headerFilterStrategy", org.apache.camel.spi.HeaderFilterStrategy.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("sslContextParameters", org.apache.camel.support.jsse.SSLContextParameters.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("throwExceptionOnFailure", boolean.class);
+        answer.put("transferException", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AhcEndpoint target = (AhcEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "binding": target.getBinding(); return true;
+        case "bridgeendpoint":
+        case "bridgeEndpoint": target.isBridgeEndpoint(); return true;
+        case "buffersize":
+        case "bufferSize": target.getBufferSize(); return true;
+        case "clientconfig":
+        case "clientConfig": target.getClientConfig(); return true;
+        case "clientconfigoptions":
+        case "clientConfigOptions": target.getClientConfigOptions(); return true;
+        case "clientconfigrealmoptions":
+        case "clientConfigRealmOptions": target.getClientConfigRealmOptions(); return true;
+        case "connectionclose":
+        case "connectionClose": target.isConnectionClose(); return true;
+        case "cookiehandler":
+        case "cookieHandler": target.getCookieHandler(); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.getSslContextParameters(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "throwexceptiononfailure":
+        case "throwExceptionOnFailure": target.isThrowExceptionOnFailure(); return true;
+        case "transferexception":
+        case "transferException": target.isTransferException(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java b/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java
index 6fe882f..795079e 100644
--- a/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java
+++ b/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.amqp;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.jms.JmsComponentConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AMQPComponentConfigurer extends JmsComponentConfigurer implements GeneratedPropertyConfigurer {
+public class AMQPComponentConfigurer extends JmsComponentConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -21,5 +25,21 @@ public class AMQPComponentConfigurer extends JmsComponentConfigurer implements G
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = super.getAllOptions(target);
+        answer.put("includeAmqpAnnotations", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AMQPComponent target = (AMQPComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "includeamqpannotations":
+        case "includeAmqpAnnotations": target.isIncludeAmqpAnnotations(); return true;
+        default: return super.getOptionValue(obj, name, ignoreCase);
+        }
+    }
 }
 
diff --git a/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPEndpointConfigurer.java b/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPEndpointConfigurer.java
index 7ad3510..11004ff 100644
--- a/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPEndpointConfigurer.java
+++ b/components/camel-amqp/src/generated/java/org/apache/camel/component/amqp/AMQPEndpointConfigurer.java
@@ -1,16 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.amqp;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.jms.JmsEndpointConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AMQPEndpointConfigurer extends JmsEndpointConfigurer implements GeneratedPropertyConfigurer {
-
+public class AMQPEndpointConfigurer extends JmsEndpointConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
 }
 
diff --git a/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/AMQPComponent.java b/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/AMQPComponent.java
index 1658b52..d2ebf9f 100644
--- a/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/AMQPComponent.java
+++ b/components/camel-amqp/src/main/java/org/apache/camel/component/amqp/AMQPComponent.java
@@ -117,6 +117,13 @@ public class AMQPComponent extends JmsComponent {
         }
     }
 
+    public boolean isIncludeAmqpAnnotations() {
+        if (getConfiguration() instanceof AMQPConfiguration) {
+            return ((AMQPConfiguration) getConfiguration()).isIncludeAmqpAnnotations();
+        }
+        return false;
+    }
+
     @Override
     protected void setProperties(Endpoint bean, Map<String, Object> parameters) throws Exception {
         Object includeAmqpAnnotations = parameters.remove("includeAmqpAnnotations");
diff --git a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java
index df051b5..0ed5fe2 100644
--- a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java
+++ b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.apns;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ApnsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class ApnsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -27,5 +31,30 @@ public class ApnsComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("apnsService", com.notnoop.apns.ApnsService.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        ApnsComponent target = (ApnsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "apnsservice":
+        case "apnsService": target.getApnsService(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java
index ae446be..123f3d9 100644
--- a/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java
+++ b/components/camel-apns/src/generated/java/org/apache/camel/component/apns/ApnsEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.apns;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ApnsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class ApnsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -60,5 +64,82 @@ public class ApnsEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("greedy", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("tokens", java.lang.String.class);
+        answer.put("useFixedDelay", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        ApnsEndpoint target = (ApnsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "delay": target.getDelay(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "tokens": target.getTokens(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java
index aa12442..c25885c 100644
--- a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java
+++ b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.as2;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -26,5 +30,29 @@ public class AS2ComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.as2.AS2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AS2Component target = (AS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java
index c023ea9..91ca0fe 100644
--- a/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java
+++ b/components/camel-as2/camel-as2-component/src/generated/java/org/apache/camel/component/as2/AS2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.as2;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -110,5 +114,158 @@ public class AS2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("as2From", java.lang.String.class);
+        answer.put("as2MessageStructure", org.apache.camel.component.as2.api.AS2MessageStructure.class);
+        answer.put("as2To", java.lang.String.class);
+        answer.put("as2Version", java.lang.String.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("clientFqdn", java.lang.String.class);
+        answer.put("compressionAlgorithm", org.apache.camel.component.as2.api.AS2CompressionAlgorithm.class);
+        answer.put("decryptingPrivateKey", java.security.PrivateKey.class);
+        answer.put("delay", long.class);
+        answer.put("dispositionNotificationTo", java.lang.String.class);
+        answer.put("ediMessageTransferEncoding", java.lang.String.class);
+        answer.put("ediMessageType", org.apache.http.entity.ContentType.class);
+        answer.put("encryptingAlgorithm", org.apache.camel.component.as2.api.AS2EncryptionAlgorithm.class);
+        answer.put("encryptingCertificateChain", java.security.cert.Certificate[].class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("from", java.lang.String.class);
+        answer.put("greedy", boolean.class);
+        answer.put("inBody", java.lang.String.class);
+        answer.put("initialDelay", long.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("mdnMessageTemplate", java.lang.String.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("repeatCount", long.class);
+        answer.put("requestUri", java.lang.String.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("server", java.lang.String.class);
+        answer.put("serverFqdn", java.lang.String.class);
+        answer.put("serverPortNumber", java.lang.Integer.class);
+        answer.put("signedReceiptMicAlgorithms", java.lang.String[].class);
+        answer.put("signingAlgorithm", org.apache.camel.component.as2.api.AS2SignatureAlgorithm.class);
+        answer.put("signingCertificateChain", java.security.cert.Certificate[].class);
+        answer.put("signingPrivateKey", java.security.PrivateKey.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("targetHostname", java.lang.String.class);
+        answer.put("targetPortNumber", java.lang.Integer.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useFixedDelay", boolean.class);
+        answer.put("userAgent", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AS2Endpoint target = (AS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "as2from":
+        case "as2From": target.getConfiguration().getAs2From(); return true;
+        case "as2messagestructure":
+        case "as2MessageStructure": target.getConfiguration().getAs2MessageStructure(); return true;
+        case "as2to":
+        case "as2To": target.getConfiguration().getAs2To(); return true;
+        case "as2version":
+        case "as2Version": target.getConfiguration().getAs2Version(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "clientfqdn":
+        case "clientFqdn": target.getConfiguration().getClientFqdn(); return true;
+        case "compressionalgorithm":
+        case "compressionAlgorithm": target.getConfiguration().getCompressionAlgorithm(); return true;
+        case "decryptingprivatekey":
+        case "decryptingPrivateKey": target.getConfiguration().getDecryptingPrivateKey(); return true;
+        case "delay": target.getDelay(); return true;
+        case "dispositionnotificationto":
+        case "dispositionNotificationTo": target.getConfiguration().getDispositionNotificationTo(); return true;
+        case "edimessagetransferencoding":
+        case "ediMessageTransferEncoding": target.getConfiguration().getEdiMessageTransferEncoding(); return true;
+        case "edimessagetype":
+        case "ediMessageType": target.getConfiguration().getEdiMessageType(); return true;
+        case "encryptingalgorithm":
+        case "encryptingAlgorithm": target.getConfiguration().getEncryptingAlgorithm(); return true;
+        case "encryptingcertificatechain":
+        case "encryptingCertificateChain": target.getConfiguration().getEncryptingCertificateChain(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "from": target.getConfiguration().getFrom(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "inbody":
+        case "inBody": target.getInBody(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "mdnmessagetemplate":
+        case "mdnMessageTemplate": target.getConfiguration().getMdnMessageTemplate(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "requesturi":
+        case "requestUri": target.getConfiguration().getRequestUri(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "server": target.getConfiguration().getServer(); return true;
+        case "serverfqdn":
+        case "serverFqdn": target.getConfiguration().getServerFqdn(); return true;
+        case "serverportnumber":
+        case "serverPortNumber": target.getConfiguration().getServerPortNumber(); return true;
+        case "signedreceiptmicalgorithms":
+        case "signedReceiptMicAlgorithms": target.getConfiguration().getSignedReceiptMicAlgorithms(); return true;
+        case "signingalgorithm":
+        case "signingAlgorithm": target.getConfiguration().getSigningAlgorithm(); return true;
+        case "signingcertificatechain":
+        case "signingCertificateChain": target.getConfiguration().getSigningCertificateChain(); return true;
+        case "signingprivatekey":
+        case "signingPrivateKey": target.getConfiguration().getSigningPrivateKey(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "subject": target.getConfiguration().getSubject(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "targethostname":
+        case "targetHostname": target.getConfiguration().getTargetHostname(); return true;
+        case "targetportnumber":
+        case "targetPortNumber": target.getConfiguration().getTargetPortNumber(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useragent":
+        case "userAgent": target.getConfiguration().getUserAgent(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java
index 377a9f1..c43c730 100644
--- a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java
+++ b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.asterisk;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AsteriskComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AsteriskComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -25,5 +29,27 @@ public class AsteriskComponentConfigurer extends PropertyConfigurerSupport imple
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AsteriskComponent target = (AsteriskComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java
index 19c2353..bc11d69 100644
--- a/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java
+++ b/components/camel-asterisk/src/generated/java/org/apache/camel/component/asterisk/AsteriskEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.asterisk;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AsteriskEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AsteriskEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -34,5 +38,43 @@ public class AsteriskEndpointConfigurer extends PropertyConfigurerSupport implem
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("action", org.apache.camel.component.asterisk.AsteriskAction.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("hostname", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("password", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("username", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AsteriskEndpoint target = (AsteriskEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "action": target.getAction(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "hostname": target.getHostname(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "password": target.getPassword(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "username": target.getUsername(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java
index 959b088..e996507 100644
--- a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java
+++ b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atmos;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtmosComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtmosComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -32,5 +36,38 @@ public class AtmosComponentConfigurer extends PropertyConfigurerSupport implemen
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("fullTokenId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sslValidation", boolean.class);
+        answer.put("uri", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtmosComponent target = (AtmosComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "fulltokenid":
+        case "fullTokenId": target.getFullTokenId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "secretkey":
+        case "secretKey": target.getSecretKey(); return true;
+        case "sslvalidation":
+        case "sslValidation": target.isSslValidation(); return true;
+        case "uri": target.getUri(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java
index a030fd1..d067493 100644
--- a/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java
+++ b/components/camel-atmos/src/generated/java/org/apache/camel/component/atmos/AtmosEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atmos;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtmosEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtmosEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -44,5 +48,57 @@ public class AtmosEndpointConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("fullTokenId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("localPath", java.lang.String.class);
+        answer.put("newRemotePath", java.lang.String.class);
+        answer.put("query", java.lang.String.class);
+        answer.put("remotePath", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sslValidation", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("uri", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtmosEndpoint target = (AtmosEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "fulltokenid":
+        case "fullTokenId": target.getConfiguration().getFullTokenId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "localpath":
+        case "localPath": target.getConfiguration().getLocalPath(); return true;
+        case "newremotepath":
+        case "newRemotePath": target.getConfiguration().getNewRemotePath(); return true;
+        case "query": target.getConfiguration().getQuery(); return true;
+        case "remotepath":
+        case "remotePath": target.getConfiguration().getRemotePath(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sslvalidation":
+        case "sslValidation": target.getConfiguration().isSslValidation(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "uri": target.getConfiguration().getUri(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java
index 5c33bff..1e0f7ed 100644
--- a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java
+++ b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atmosphere.websocket;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.servlet.ServletComponentConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class WebsocketComponentConfigurer extends ServletComponentConfigurer implements GeneratedPropertyConfigurer {
+public class WebsocketComponentConfigurer extends ServletComponentConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -21,5 +25,21 @@ public class WebsocketComponentConfigurer extends ServletComponentConfigurer imp
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = super.getAllOptions(target);
+        answer.put("lazyStartProducer", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        WebsocketComponent target = (WebsocketComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        default: return super.getOptionValue(obj, name, ignoreCase);
+        }
+    }
 }
 
diff --git a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java
index c087dc7..c7629d9 100644
--- a/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java
+++ b/components/camel-atmosphere-websocket/src/generated/java/org/apache/camel/component/atmosphere/websocket/WebsocketEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atmosphere.websocket;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.component.servlet.ServletEndpointConfigurer;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class WebsocketEndpointConfigurer extends ServletEndpointConfigurer implements GeneratedPropertyConfigurer {
+public class WebsocketEndpointConfigurer extends ServletEndpointConfigurer implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -51,5 +55,66 @@ public class WebsocketEndpointConfigurer extends ServletEndpointConfigurer imple
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = super.getAllOptions(target);
+        answer.put("authHost", java.lang.String.class);
+        answer.put("bridgeEndpoint", boolean.class);
+        answer.put("connectionClose", boolean.class);
+        answer.put("cookieHandler", org.apache.camel.http.base.cookie.CookieHandler.class);
+        answer.put("copyHeaders", boolean.class);
+        answer.put("httpMethod", org.apache.camel.http.common.HttpMethods.class);
+        answer.put("ignoreResponseBody", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("okStatusCodeRange", java.lang.String.class);
+        answer.put("preserveHostHeader", boolean.class);
+        answer.put("proxyAuthScheme", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", int.class);
+        answer.put("sendToAll", boolean.class);
+        answer.put("throwExceptionOnFailure", boolean.class);
+        answer.put("useStreaming", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        WebsocketEndpoint target = (WebsocketEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "authhost":
+        case "authHost": target.getAuthHost(); return true;
+        case "bridgeendpoint":
+        case "bridgeEndpoint": target.isBridgeEndpoint(); return true;
+        case "connectionclose":
+        case "connectionClose": target.isConnectionClose(); return true;
+        case "cookiehandler":
+        case "cookieHandler": target.getCookieHandler(); return true;
+        case "copyheaders":
+        case "copyHeaders": target.isCopyHeaders(); return true;
+        case "httpmethod":
+        case "httpMethod": target.getHttpMethod(); return true;
+        case "ignoreresponsebody":
+        case "ignoreResponseBody": target.isIgnoreResponseBody(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "okstatuscoderange":
+        case "okStatusCodeRange": target.getOkStatusCodeRange(); return true;
+        case "preservehostheader":
+        case "preserveHostHeader": target.isPreserveHostHeader(); return true;
+        case "proxyauthscheme":
+        case "proxyAuthScheme": target.getProxyAuthScheme(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getProxyPort(); return true;
+        case "sendtoall":
+        case "sendToAll": target.isSendToAll(); return true;
+        case "throwexceptiononfailure":
+        case "throwExceptionOnFailure": target.isThrowExceptionOnFailure(); return true;
+        case "usestreaming":
+        case "useStreaming": target.isUseStreaming(); return true;
+        default: return super.getOptionValue(obj, name, ignoreCase);
+        }
+    }
 }
 
diff --git a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java
index 542c7c1..eae0d44 100644
--- a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java
+++ b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atom;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -23,5 +27,24 @@ public class AtomComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomComponent target = (AtomComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java
index e89460a..54fc5c3 100644
--- a/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java
+++ b/components/camel-atom/src/generated/java/org/apache/camel/component/atom/AtomEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atom;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -70,5 +74,98 @@ public class AtomEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("feedHeader", boolean.class);
+        answer.put("filter", boolean.class);
+        answer.put("greedy", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("lastUpdate", java.util.Date.class);
+        answer.put("password", java.lang.String.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("sortEntries", boolean.class);
+        answer.put("splitEntries", boolean.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("throttleEntries", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useFixedDelay", boolean.class);
+        answer.put("username", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomEndpoint target = (AtomEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "delay": target.getDelay(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "feedheader":
+        case "feedHeader": target.isFeedHeader(); return true;
+        case "filter": target.isFilter(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "lastupdate":
+        case "lastUpdate": target.getLastUpdate(); return true;
+        case "password": target.getPassword(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sortentries":
+        case "sortEntries": target.isSortEntries(); return true;
+        case "splitentries":
+        case "splitEntries": target.isSplitEntries(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "throttleentries":
+        case "throttleEntries": target.isThrottleEntries(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "username": target.getUsername(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java
index dfb181e..09bc976 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.map;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixMapComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixMapComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.atomix.client.map.AtomixMapConfiguration getOrCreateConfiguration(AtomixMapComponent target) {
         if (target.getConfiguration() == null) {
@@ -56,5 +60,66 @@ public class AtomixMapComponentConfigurer extends PropertyConfigurerSupport impl
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.atomix.client.map.AtomixMapConfiguration.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.map.AtomixMap.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("key", java.lang.Object.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.util.List.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixMapComponent target = (AtomixMapComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
+        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "key": getOrCreateConfiguration(target).getKey(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "transportclassname":
+        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java
index acf2f83c..6abaf51 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/map/AtomixMapEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.map;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixMapEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixMapEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -53,5 +57,72 @@ public class AtomixMapEndpointConfigurer extends PropertyConfigurerSupport imple
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.map.AtomixMap.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("key", java.lang.Object.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.lang.String.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixMapEndpoint target = (AtomixMapEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
+        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "key": target.getConfiguration().getKey(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        case "ttl": target.getConfiguration().getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java
index 51746c0..5e65abf 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.messaging;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixMessagingComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixMessagingComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.atomix.client.messaging.AtomixMessagingConfiguration getOrCreateConfiguration(AtomixMessagingComponent target) {
         if (target.getConfiguration() == null) {
@@ -60,5 +64,71 @@ public class AtomixMessagingComponentConfigurer extends PropertyConfigurerSuppor
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("broadcastType", org.apache.camel.component.atomix.client.messaging.AtomixMessaging.BroadcastType.class);
+        answer.put("channelName", java.lang.String.class);
+        answer.put("configuration", org.apache.camel.component.atomix.client.messaging.AtomixMessagingConfiguration.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.messaging.AtomixMessaging.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("memberName", java.lang.String.class);
+        answer.put("nodes", java.util.List.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("transportClassName", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixMessagingComponent target = (AtomixMessagingComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "broadcasttype":
+        case "broadcastType": getOrCreateConfiguration(target).getBroadcastType(); return true;
+        case "channelname":
+        case "channelName": getOrCreateConfiguration(target).getChannelName(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
+        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "membername":
+        case "memberName": getOrCreateConfiguration(target).getMemberName(); return true;
+        case "nodes": target.getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "transportclassname":
+        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java
index 43c4b27..c79eaf4 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/messaging/AtomixMessagingEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.messaging;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixMessagingEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixMessagingEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -57,5 +61,77 @@ public class AtomixMessagingEndpointConfigurer extends PropertyConfigurerSupport
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("broadcastType", org.apache.camel.component.atomix.client.messaging.AtomixMessaging.BroadcastType.class);
+        answer.put("channelName", java.lang.String.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.messaging.AtomixMessaging.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("memberName", java.lang.String.class);
+        answer.put("nodes", java.lang.String.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("transportClassName", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixMessagingEndpoint target = (AtomixMessagingEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "broadcasttype":
+        case "broadcastType": target.getConfiguration().getBroadcastType(); return true;
+        case "channelname":
+        case "channelName": target.getConfiguration().getChannelName(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
+        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "membername":
+        case "memberName": target.getConfiguration().getMemberName(); return true;
+        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java
index 24fe578..83802ef 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.multimap;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixMultiMapComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixMultiMapComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.atomix.client.multimap.AtomixMultiMapConfiguration getOrCreateConfiguration(AtomixMultiMapComponent target) {
         if (target.getConfiguration() == null) {
@@ -54,5 +58,63 @@ public class AtomixMultiMapComponentConfigurer extends PropertyConfigurerSupport
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.atomix.client.multimap.AtomixMultiMapConfiguration.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.multimap.AtomixMultiMap.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("key", java.lang.Object.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.util.List.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixMultiMapComponent target = (AtomixMultiMapComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
+        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "key": getOrCreateConfiguration(target).getKey(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "transportclassname":
+        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java
index c305df7..9c3c352 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/multimap/AtomixMultiMapEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.multimap;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixMultiMapEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixMultiMapEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -47,5 +51,63 @@ public class AtomixMultiMapEndpointConfigurer extends PropertyConfigurerSupport
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.multimap.AtomixMultiMap.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("key", java.lang.Object.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.lang.String.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixMultiMapEndpoint target = (AtomixMultiMapEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
+        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "key": target.getConfiguration().getKey(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        case "ttl": target.getConfiguration().getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java
index 6933fe9..2f02ca5 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.queue;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixQueueComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixQueueComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.atomix.client.queue.AtomixQueueConfiguration getOrCreateConfiguration(AtomixQueueComponent target) {
         if (target.getConfiguration() == null) {
@@ -54,5 +58,62 @@ public class AtomixQueueComponentConfigurer extends PropertyConfigurerSupport im
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.atomix.client.queue.AtomixQueueConfiguration.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.queue.AtomixQueue.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.util.List.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("transportClassName", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixQueueComponent target = (AtomixQueueComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
+        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "transportclassname":
+        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java
index eb9bc77..0750d5e 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/queue/AtomixQueueEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.queue;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixQueueEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixQueueEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -51,5 +55,68 @@ public class AtomixQueueEndpointConfigurer extends PropertyConfigurerSupport imp
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.queue.AtomixQueue.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.lang.String.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("transportClassName", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixQueueEndpoint target = (AtomixQueueEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
+        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java
index 8faf463..a8bf920 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.set;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixSetComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixSetComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.atomix.client.set.AtomixSetConfiguration getOrCreateConfiguration(AtomixSetComponent target) {
         if (target.getConfiguration() == null) {
@@ -55,5 +59,64 @@ public class AtomixSetComponentConfigurer extends PropertyConfigurerSupport impl
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.atomix.client.set.AtomixSetConfiguration.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.set.AtomixSet.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.util.List.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixSetComponent target = (AtomixSetComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
+        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "transportclassname":
+        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java
index 6fea91e..85c0c80 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/set/AtomixSetEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.set;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixSetEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixSetEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -52,5 +56,70 @@ public class AtomixSetEndpointConfigurer extends PropertyConfigurerSupport imple
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.set.AtomixSet.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.lang.String.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixSetEndpoint target = (AtomixSetEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
+        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        case "ttl": target.getConfiguration().getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java
index 1fa4dfb..83ddf7f 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.value;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixValueComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixValueComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.atomix.client.value.AtomixValueConfiguration getOrCreateConfiguration(AtomixValueComponent target) {
         if (target.getConfiguration() == null) {
@@ -55,5 +59,64 @@ public class AtomixValueComponentConfigurer extends PropertyConfigurerSupport im
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.atomix.client.value.AtomixValueConfiguration.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.value.AtomixValue.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.util.List.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixValueComponent target = (AtomixValueComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": getOrCreateConfiguration(target).getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": getOrCreateConfiguration(target).getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": getOrCreateConfiguration(target).getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": getOrCreateConfiguration(target).getDefaultResourceOptions(); return true;
+        case "ephemeral": getOrCreateConfiguration(target).isEphemeral(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": getOrCreateConfiguration(target).getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": getOrCreateConfiguration(target).getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": getOrCreateConfiguration(target).getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": getOrCreateConfiguration(target).getResultHeader(); return true;
+        case "transportclassname":
+        case "transportClassName": getOrCreateConfiguration(target).getTransportClassName(); return true;
+        case "ttl": getOrCreateConfiguration(target).getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java
index 46ba3ce..5fcffae 100644
--- a/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java
+++ b/components/camel-atomix/src/generated/java/org/apache/camel/component/atomix/client/value/AtomixValueEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.atomix.client.value;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AtomixValueEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AtomixValueEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -52,5 +56,70 @@ public class AtomixValueEndpointConfigurer extends PropertyConfigurerSupport imp
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("atomix", io.atomix.Atomix.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configurationUri", java.lang.String.class);
+        answer.put("defaultAction", org.apache.camel.component.atomix.client.value.AtomixValue.Action.class);
+        answer.put("defaultResourceConfig", java.util.Properties.class);
+        answer.put("defaultResourceOptions", java.util.Properties.class);
+        answer.put("ephemeral", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("nodes", java.lang.String.class);
+        answer.put("readConsistency", io.atomix.resource.ReadConsistency.class);
+        answer.put("resourceConfigs", java.util.Map.class);
+        answer.put("resourceOptions", java.util.Map.class);
+        answer.put("resultHeader", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("transportClassName", java.lang.String.class);
+        answer.put("ttl", long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AtomixValueEndpoint target = (AtomixValueEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().getAtomix(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().getConfigurationUri(); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().getDefaultAction(); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().getDefaultResourceConfig(); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().getDefaultResourceOptions(); return true;
+        case "ephemeral": target.getConfiguration().isEphemeral(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "nodes": target.getConfiguration().getNodes(); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().getReadConsistency(); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().getResourceConfigs(); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().getResourceOptions(); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().getResultHeader(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().getTransportClassName(); return true;
+        case "ttl": target.getConfiguration().getTtl(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java
index 01a1131..7333d18 100644
--- a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java
+++ b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.avro;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AvroComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AvroComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.avro.AvroConfiguration getOrCreateConfiguration(AvroComponent target) {
         if (target.getConfiguration() == null) {
@@ -44,5 +48,46 @@ public class AvroComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.avro.AvroConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("protocol", org.apache.avro.Protocol.class);
+        answer.put("protocolClassName", java.lang.String.class);
+        answer.put("protocolLocation", java.lang.String.class);
+        answer.put("reflectionProtocol", boolean.class);
+        answer.put("singleParameter", boolean.class);
+        answer.put("uriAuthority", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AvroComponent target = (AvroComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "protocol": getOrCreateConfiguration(target).getProtocol(); return true;
+        case "protocolclassname":
+        case "protocolClassName": getOrCreateConfiguration(target).getProtocolClassName(); return true;
+        case "protocollocation":
+        case "protocolLocation": getOrCreateConfiguration(target).getProtocolLocation(); return true;
+        case "reflectionprotocol":
+        case "reflectionProtocol": getOrCreateConfiguration(target).isReflectionProtocol(); return true;
+        case "singleparameter":
+        case "singleParameter": getOrCreateConfiguration(target).isSingleParameter(); return true;
+        case "uriauthority":
+        case "uriAuthority": getOrCreateConfiguration(target).getUriAuthority(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java
index 8cb856b..54f4226 100644
--- a/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java
+++ b/components/camel-avro/src/generated/java/org/apache/camel/component/avro/AvroEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.avro;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AvroEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AvroEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -41,5 +45,52 @@ public class AvroEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("protocol", org.apache.avro.Protocol.class);
+        answer.put("protocolClassName", java.lang.String.class);
+        answer.put("protocolLocation", java.lang.String.class);
+        answer.put("reflectionProtocol", boolean.class);
+        answer.put("singleParameter", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("uriAuthority", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AvroEndpoint target = (AvroEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "protocol": target.getConfiguration().getProtocol(); return true;
+        case "protocolclassname":
+        case "protocolClassName": target.getConfiguration().getProtocolClassName(); return true;
+        case "protocollocation":
+        case "protocolLocation": target.getConfiguration().getProtocolLocation(); return true;
+        case "reflectionprotocol":
+        case "reflectionProtocol": target.getConfiguration().isReflectionProtocol(); return true;
+        case "singleparameter":
+        case "singleParameter": target.getConfiguration().isSingleParameter(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "uriauthority":
+        case "uriAuthority": target.getConfiguration().getUriAuthority(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java
index 509ec59..32c8cd2 100644
--- a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java
+++ b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.cw;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class CwComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class CwComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.cw.CwConfiguration getOrCreateConfiguration(CwComponent target) {
         if (target.getConfiguration() == null) {
@@ -48,5 +52,54 @@ public class CwComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonCwClient", com.amazonaws.services.cloudwatch.AmazonCloudWatch.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.cw.CwConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("name", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("timestamp", java.util.Date.class);
+        answer.put("unit", java.lang.String.class);
+        answer.put("value", java.lang.Double.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        CwComponent target = (CwComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazoncwclient":
+        case "amazonCwClient": getOrCreateConfiguration(target).getAmazonCwClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "name": getOrCreateConfiguration(target).getName(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "timestamp": getOrCreateConfiguration(target).getTimestamp(); return true;
+        case "unit": getOrCreateConfiguration(target).getUnit(); return true;
+        case "value": getOrCreateConfiguration(target).getValue(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java
index de92fc6..2a2c640 100644
--- a/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java
+++ b/components/camel-aws-cw/src/generated/java/org/apache/camel/component/aws/cw/CwEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.cw;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class CwEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class CwEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -41,5 +45,54 @@ public class CwEndpointConfigurer extends PropertyConfigurerSupport implements G
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonCwClient", com.amazonaws.services.cloudwatch.AmazonCloudWatch.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("name", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timestamp", java.util.Date.class);
+        answer.put("unit", java.lang.String.class);
+        answer.put("value", java.lang.Double.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        CwEndpoint target = (CwEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazoncwclient":
+        case "amazonCwClient": target.getConfiguration().getAmazonCwClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "name": target.getConfiguration().getName(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timestamp": target.getConfiguration().getTimestamp(); return true;
+        case "unit": target.getConfiguration().getUnit(); return true;
+        case "value": target.getConfiguration().getValue(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java
index e5b0756..2d41f0f 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ddb;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class DdbComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class DdbComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.ddb.DdbConfiguration getOrCreateConfiguration(DdbComponent target) {
         if (target.getConfiguration() == null) {
@@ -55,5 +59,63 @@ public class DdbComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDDBClient", com.amazonaws.services.dynamodbv2.AmazonDynamoDB.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.ddb.DdbConfiguration.class);
+        answer.put("consistentRead", boolean.class);
+        answer.put("keyAttributeName", java.lang.String.class);
+        answer.put("keyAttributeType", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.ddb.DdbOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("readCapacity", java.lang.Long.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("writeCapacity", java.lang.Long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        DdbComponent target = (DdbComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonddbclient":
+        case "amazonDDBClient": getOrCreateConfiguration(target).getAmazonDDBClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "consistentread":
+        case "consistentRead": getOrCreateConfiguration(target).isConsistentRead(); return true;
+        case "keyattributename":
+        case "keyAttributeName": getOrCreateConfiguration(target).getKeyAttributeName(); return true;
+        case "keyattributetype":
+        case "keyAttributeType": getOrCreateConfiguration(target).getKeyAttributeType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "readcapacity":
+        case "readCapacity": getOrCreateConfiguration(target).getReadCapacity(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "writecapacity":
+        case "writeCapacity": getOrCreateConfiguration(target).getWriteCapacity(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java
index 613b5f9..acc244c 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddb/DdbEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ddb;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class DdbEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class DdbEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -48,5 +52,63 @@ public class DdbEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDDBClient", com.amazonaws.services.dynamodbv2.AmazonDynamoDB.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("consistentRead", boolean.class);
+        answer.put("keyAttributeName", java.lang.String.class);
+        answer.put("keyAttributeType", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.ddb.DdbOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("readCapacity", java.lang.Long.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("writeCapacity", java.lang.Long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        DdbEndpoint target = (DdbEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonddbclient":
+        case "amazonDDBClient": target.getConfiguration().getAmazonDDBClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "consistentread":
+        case "consistentRead": target.getConfiguration().isConsistentRead(); return true;
+        case "keyattributename":
+        case "keyAttributeName": target.getConfiguration().getKeyAttributeName(); return true;
+        case "keyattributetype":
+        case "keyAttributeType": target.getConfiguration().getKeyAttributeType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "readcapacity":
+        case "readCapacity": target.getConfiguration().getReadCapacity(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "writecapacity":
+        case "writeCapacity": target.getConfiguration().getWriteCapacity(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java
index c83c875..25bf78c 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ddbstream;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class DdbStreamComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class DdbStreamComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.ddbstream.DdbStreamConfiguration getOrCreateConfiguration(DdbStreamComponent target) {
         if (target.getConfiguration() == null) {
@@ -50,5 +54,55 @@ public class DdbStreamComponentConfigurer extends PropertyConfigurerSupport impl
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDynamoDbStreamsClient", com.amazonaws.services.dynamodbv2.AmazonDynamoDBStreams.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.ddbstream.DdbStreamConfiguration.class);
+        answer.put("iteratorType", com.amazonaws.services.dynamodbv2.model.ShardIteratorType.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sequenceNumberProvider", org.apache.camel.component.aws.ddbstream.SequenceNumberProvider.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        DdbStreamComponent target = (DdbStreamComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazondynamodbstreamsclient":
+        case "amazonDynamoDbStreamsClient": getOrCreateConfiguration(target).getAmazonDynamoDbStreamsClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "iteratortype":
+        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "sequencenumberprovider":
+        case "sequenceNumberProvider": getOrCreateConfiguration(target).getSequenceNumberProvider(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java
index 04b65d5..15c767e 100644
--- a/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java
+++ b/components/camel-aws-ddb/src/generated/java/org/apache/camel/component/aws/ddbstream/DdbStreamEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ddbstream;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class DdbStreamEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class DdbStreamEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -76,5 +80,106 @@ public class DdbStreamEndpointConfigurer extends PropertyConfigurerSupport imple
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDynamoDbStreamsClient", com.amazonaws.services.dynamodbv2.AmazonDynamoDBStreams.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("greedy", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("iteratorType", com.amazonaws.services.dynamodbv2.model.ShardIteratorType.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("sequenceNumberProvider", org.apache.camel.component.aws.ddbstream.SequenceNumberProvider.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useFixedDelay", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        DdbStreamEndpoint target = (DdbStreamEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazondynamodbstreamsclient":
+        case "amazonDynamoDbStreamsClient": target.getConfiguration().getAmazonDynamoDbStreamsClient(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "delay": target.getDelay(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "iteratortype":
+        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sequencenumberprovider":
+        case "sequenceNumberProvider": target.getConfiguration().getSequenceNumberProvider(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java
index 1572e22..1dcea65 100644
--- a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java
+++ b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ec2;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class EC2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class EC2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.ec2.EC2Configuration getOrCreateConfiguration(EC2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class EC2ComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonEc2Client", com.amazonaws.services.ec2.AmazonEC2.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.ec2.EC2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.ec2.EC2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        EC2Component target = (EC2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonec2client":
+        case "amazonEc2Client": getOrCreateConfiguration(target).getAmazonEc2Client(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java
index b5dc4d9..0a13970 100644
--- a/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java
+++ b/components/camel-aws-ec2/src/generated/java/org/apache/camel/component/aws/ec2/EC2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ec2;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class EC2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class EC2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class EC2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonEc2Client", com.amazonaws.services.ec2.AmazonEC2.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.ec2.EC2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        EC2Endpoint target = (EC2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonec2client":
+        case "amazonEc2Client": target.getConfiguration().getAmazonEc2Client(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java
index 6d5e566..371881c 100644
--- a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java
+++ b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ecs;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ECSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class ECSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.ecs.ECSConfiguration getOrCreateConfiguration(ECSComponent target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class ECSComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.ecs.ECSConfiguration.class);
+        answer.put("ecsClient", com.amazonaws.services.ecs.AmazonECS.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.ecs.ECSOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        ECSComponent target = (ECSComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "ecsclient":
+        case "ecsClient": getOrCreateConfiguration(target).getEcsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java
index 8574f50..9817e5b 100644
--- a/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java
+++ b/components/camel-aws-ecs/src/generated/java/org/apache/camel/component/aws/ecs/ECSEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ecs;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ECSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class ECSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class ECSEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("ecsClient", com.amazonaws.services.ecs.AmazonECS.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.ecs.ECSOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        ECSEndpoint target = (ECSEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "ecsclient":
+        case "ecsClient": target.getConfiguration().getEcsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java
index 109f16b..c84df26 100644
--- a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java
+++ b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.eks;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class EKSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class EKSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.eks.EKSConfiguration getOrCreateConfiguration(EKSComponent target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class EKSComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.eks.EKSConfiguration.class);
+        answer.put("eksClient", com.amazonaws.services.eks.AmazonEKS.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.eks.EKSOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        EKSComponent target = (EKSComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "eksclient":
+        case "eksClient": getOrCreateConfiguration(target).getEksClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java
index ea5f481..6e86b76 100644
--- a/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java
+++ b/components/camel-aws-eks/src/generated/java/org/apache/camel/component/aws/eks/EKSEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.eks;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class EKSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class EKSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class EKSEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("eksClient", com.amazonaws.services.eks.AmazonEKS.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.eks.EKSOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        EKSEndpoint target = (EKSEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "eksclient":
+        case "eksClient": target.getConfiguration().getEksClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java
index c9f0a2f..2236671 100644
--- a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java
+++ b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.iam;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class IAMComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class IAMComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.iam.IAMConfiguration getOrCreateConfiguration(IAMComponent target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class IAMComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.iam.IAMConfiguration.class);
+        answer.put("iamClient", com.amazonaws.services.identitymanagement.AmazonIdentityManagement.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.iam.IAMOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        IAMComponent target = (IAMComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "iamclient":
+        case "iamClient": getOrCreateConfiguration(target).getIamClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java
index d072548..dd9d3ef 100644
--- a/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java
+++ b/components/camel-aws-iam/src/generated/java/org/apache/camel/component/aws/iam/IAMEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.iam;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class IAMEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class IAMEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class IAMEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("iamClient", com.amazonaws.services.identitymanagement.AmazonIdentityManagement.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.iam.IAMOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        IAMEndpoint target = (IAMEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "iamclient":
+        case "iamClient": target.getConfiguration().getIamClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java
index d0eb098..b4320ce 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.firehose;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KinesisFirehoseComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KinesisFirehoseComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.firehose.KinesisFirehoseConfiguration getOrCreateConfiguration(KinesisFirehoseComponent target) {
         if (target.getConfiguration() == null) {
@@ -44,5 +48,46 @@ public class KinesisFirehoseComponentConfigurer extends PropertyConfigurerSuppor
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisFirehoseClient", com.amazonaws.services.kinesisfirehose.AmazonKinesisFirehose.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.firehose.KinesisFirehoseConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KinesisFirehoseComponent target = (KinesisFirehoseComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonkinesisfirehoseclient":
+        case "amazonKinesisFirehoseClient": getOrCreateConfiguration(target).getAmazonKinesisFirehoseClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java
index ba615b6..559ba22 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/firehose/KinesisFirehoseEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.firehose;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KinesisFirehoseEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KinesisFirehoseEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -37,5 +41,46 @@ public class KinesisFirehoseEndpointConfigurer extends PropertyConfigurerSupport
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisFirehoseClient", com.amazonaws.services.kinesisfirehose.AmazonKinesisFirehose.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KinesisFirehoseEndpoint target = (KinesisFirehoseEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonkinesisfirehoseclient":
+        case "amazonKinesisFirehoseClient": target.getConfiguration().getAmazonKinesisFirehoseClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java
index 0af992d..e7d6154 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.kinesis;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KinesisComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KinesisComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.kinesis.KinesisConfiguration getOrCreateConfiguration(KinesisComponent target) {
         if (target.getConfiguration() == null) {
@@ -56,5 +60,64 @@ public class KinesisComponentConfigurer extends PropertyConfigurerSupport implem
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisClient", com.amazonaws.services.kinesis.AmazonKinesis.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.kinesis.KinesisConfiguration.class);
+        answer.put("iteratorType", com.amazonaws.services.kinesis.model.ShardIteratorType.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sequenceNumber", java.lang.String.class);
+        answer.put("shardClosed", org.apache.camel.component.aws.kinesis.KinesisShardClosedStrategyEnum.class);
+        answer.put("shardId", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KinesisComponent target = (KinesisComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonkinesisclient":
+        case "amazonKinesisClient": getOrCreateConfiguration(target).getAmazonKinesisClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "iteratortype":
+        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "sequencenumber":
+        case "sequenceNumber": getOrCreateConfiguration(target).getSequenceNumber(); return true;
+        case "shardclosed":
+        case "shardClosed": getOrCreateConfiguration(target).getShardClosed(); return true;
+        case "shardid":
+        case "shardId": getOrCreateConfiguration(target).getShardId(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java
index dd9f21b..0e02de6 100644
--- a/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java
+++ b/components/camel-aws-kinesis/src/generated/java/org/apache/camel/component/aws/kinesis/KinesisEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.kinesis;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KinesisEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KinesisEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -82,5 +86,115 @@ public class KinesisEndpointConfigurer extends PropertyConfigurerSupport impleme
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisClient", com.amazonaws.services.kinesis.AmazonKinesis.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("greedy", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("iteratorType", com.amazonaws.services.kinesis.model.ShardIteratorType.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("sequenceNumber", java.lang.String.class);
+        answer.put("shardClosed", org.apache.camel.component.aws.kinesis.KinesisShardClosedStrategyEnum.class);
+        answer.put("shardId", java.lang.String.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useFixedDelay", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KinesisEndpoint target = (KinesisEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonkinesisclient":
+        case "amazonKinesisClient": target.getConfiguration().getAmazonKinesisClient(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "delay": target.getDelay(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "iteratortype":
+        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sequencenumber":
+        case "sequenceNumber": target.getConfiguration().getSequenceNumber(); return true;
+        case "shardclosed":
+        case "shardClosed": target.getConfiguration().getShardClosed(); return true;
+        case "shardid":
+        case "shardId": target.getConfiguration().getShardId(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java
index d760cde..17b49e8 100644
--- a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java
+++ b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.kms;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KMSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KMSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.kms.KMSConfiguration getOrCreateConfiguration(KMSComponent target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class KMSComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.kms.KMSConfiguration.class);
+        answer.put("kmsClient", com.amazonaws.services.kms.AWSKMS.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.kms.KMSOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KMSComponent target = (KMSComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "kmsclient":
+        case "kmsClient": getOrCreateConfiguration(target).getKmsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java
index 57e50ad..54f09ac 100644
--- a/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java
+++ b/components/camel-aws-kms/src/generated/java/org/apache/camel/component/aws/kms/KMSEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.kms;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KMSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KMSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class KMSEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("kmsClient", com.amazonaws.services.kms.AWSKMS.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.kms.KMSOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KMSEndpoint target = (KMSEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "kmsclient":
+        case "kmsClient": target.getConfiguration().getKmsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java
index 1bf6658..f2be92a 100644
--- a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java
+++ b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.lambda;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class LambdaComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class LambdaComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.lambda.LambdaConfiguration getOrCreateConfiguration(LambdaComponent target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class LambdaComponentConfigurer extends PropertyConfigurerSupport impleme
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("awsLambdaClient", com.amazonaws.services.lambda.AWSLambda.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.lambda.LambdaConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.lambda.LambdaOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        LambdaComponent target = (LambdaComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "awslambdaclient":
+        case "awsLambdaClient": getOrCreateConfiguration(target).getAwsLambdaClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java
index 89e2a91..a245ecd 100644
--- a/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java
+++ b/components/camel-aws-lambda/src/generated/java/org/apache/camel/component/aws/lambda/LambdaEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.lambda;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class LambdaEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class LambdaEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class LambdaEndpointConfigurer extends PropertyConfigurerSupport implemen
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("awsLambdaClient", com.amazonaws.services.lambda.AWSLambda.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.lambda.LambdaOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        LambdaEndpoint target = (LambdaEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "awslambdaclient":
+        case "awsLambdaClient": target.getConfiguration().getAwsLambdaClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java
index af59386..f90e0e3 100644
--- a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java
+++ b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.mq;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MQComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MQComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.mq.MQConfiguration getOrCreateConfiguration(MQComponent target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class MQComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonMqClient", com.amazonaws.services.mq.AmazonMQ.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.mq.MQConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.mq.MQOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MQComponent target = (MQComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonmqclient":
+        case "amazonMqClient": getOrCreateConfiguration(target).getAmazonMqClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java
index d843ad7..dbf8401 100644
--- a/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java
+++ b/components/camel-aws-mq/src/generated/java/org/apache/camel/component/aws/mq/MQEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.mq;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MQEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MQEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class MQEndpointConfigurer extends PropertyConfigurerSupport implements G
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonMqClient", com.amazonaws.services.mq.AmazonMQ.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.mq.MQOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MQEndpoint target = (MQEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonmqclient":
+        case "amazonMqClient": target.getConfiguration().getAmazonMqClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java
index 09735a7..6695d05 100644
--- a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java
+++ b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.msk;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MSKComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MSKComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.msk.MSKConfiguration getOrCreateConfiguration(MSKComponent target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class MSKComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.msk.MSKConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("mskClient", com.amazonaws.services.kafka.AWSKafka.class);
+        answer.put("operation", org.apache.camel.component.aws.msk.MSKOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MSKComponent target = (MSKComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "mskclient":
+        case "mskClient": getOrCreateConfiguration(target).getMskClient(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java
index a130f8e..3ca4a34 100644
--- a/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java
+++ b/components/camel-aws-msk/src/generated/java/org/apache/camel/component/aws/msk/MSKEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.msk;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MSKEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MSKEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class MSKEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("mskClient", com.amazonaws.services.kafka.AWSKafka.class);
+        answer.put("operation", org.apache.camel.component.aws.msk.MSKOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MSKEndpoint target = (MSKEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "mskclient":
+        case "mskClient": target.getConfiguration().getMskClient(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java
index 85451a2..896bdb0 100644
--- a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java
+++ b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.s3;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class S3ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class S3ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.s3.S3Configuration getOrCreateConfiguration(S3Component target) {
         if (target.getConfiguration() == null) {
@@ -96,5 +100,126 @@ public class S3ComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accelerateModeEnabled", boolean.class);
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonS3Client", com.amazonaws.services.s3.AmazonS3.class);
+        answer.put("autoCreateBucket", boolean.class);
+        answer.put("autocloseBody", boolean.class);
+        answer.put("awsKMSKeyId", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("chunkedEncodingDisabled", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.s3.S3Configuration.class);
+        answer.put("deleteAfterRead", boolean.class);
+        answer.put("deleteAfterWrite", boolean.class);
+        answer.put("delimiter", java.lang.String.class);
+        answer.put("dualstackEnabled", boolean.class);
+        answer.put("encryptionMaterials", com.amazonaws.services.s3.model.EncryptionMaterials.class);
+        answer.put("endpointConfiguration", com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration.class);
+        answer.put("fileName", java.lang.String.class);
+        answer.put("forceGlobalBucketAccessEnabled", boolean.class);
+        answer.put("includeBody", boolean.class);
+        answer.put("keyName", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("multiPartUpload", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.s3.S3Operations.class);
+        answer.put("partSize", long.class);
+        answer.put("pathStyleAccess", boolean.class);
+        answer.put("payloadSigningEnabled", boolean.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("prefix", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("serverSideEncryption", java.lang.String.class);
+        answer.put("storageClass", java.lang.String.class);
+        answer.put("useAwsKMS", boolean.class);
+        answer.put("useEncryption", boolean.class);
+        answer.put("useIAMCredentials", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        S3Component target = (S3Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "acceleratemodeenabled":
+        case "accelerateModeEnabled": getOrCreateConfiguration(target).isAccelerateModeEnabled(); return true;
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazons3client":
+        case "amazonS3Client": getOrCreateConfiguration(target).getAmazonS3Client(); return true;
+        case "autocreatebucket":
+        case "autoCreateBucket": getOrCreateConfiguration(target).isAutoCreateBucket(); return true;
+        case "autoclosebody":
+        case "autocloseBody": getOrCreateConfiguration(target).isAutocloseBody(); return true;
+        case "awskmskeyid":
+        case "awsKMSKeyId": getOrCreateConfiguration(target).getAwsKMSKeyId(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "chunkedencodingdisabled":
+        case "chunkedEncodingDisabled": getOrCreateConfiguration(target).isChunkedEncodingDisabled(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": getOrCreateConfiguration(target).isDeleteAfterRead(); return true;
+        case "deleteafterwrite":
+        case "deleteAfterWrite": getOrCreateConfiguration(target).isDeleteAfterWrite(); return true;
+        case "delimiter": getOrCreateConfiguration(target).getDelimiter(); return true;
+        case "dualstackenabled":
+        case "dualstackEnabled": getOrCreateConfiguration(target).isDualstackEnabled(); return true;
+        case "encryptionmaterials":
+        case "encryptionMaterials": getOrCreateConfiguration(target).getEncryptionMaterials(); return true;
+        case "endpointconfiguration":
+        case "endpointConfiguration": getOrCreateConfiguration(target).getEndpointConfiguration(); return true;
+        case "filename":
+        case "fileName": getOrCreateConfiguration(target).getFileName(); return true;
+        case "forceglobalbucketaccessenabled":
+        case "forceGlobalBucketAccessEnabled": getOrCreateConfiguration(target).isForceGlobalBucketAccessEnabled(); return true;
+        case "includebody":
+        case "includeBody": getOrCreateConfiguration(target).isIncludeBody(); return true;
+        case "keyname":
+        case "keyName": getOrCreateConfiguration(target).getKeyName(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "multipartupload":
+        case "multiPartUpload": getOrCreateConfiguration(target).isMultiPartUpload(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "partsize":
+        case "partSize": getOrCreateConfiguration(target).getPartSize(); return true;
+        case "pathstyleaccess":
+        case "pathStyleAccess": getOrCreateConfiguration(target).isPathStyleAccess(); return true;
+        case "payloadsigningenabled":
+        case "payloadSigningEnabled": getOrCreateConfiguration(target).isPayloadSigningEnabled(); return true;
+        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
+        case "prefix": getOrCreateConfiguration(target).getPrefix(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "serversideencryption":
+        case "serverSideEncryption": getOrCreateConfiguration(target).getServerSideEncryption(); return true;
+        case "storageclass":
+        case "storageClass": getOrCreateConfiguration(target).getStorageClass(); return true;
+        case "useawskms":
+        case "useAwsKMS": getOrCreateConfiguration(target).isUseAwsKMS(); return true;
+        case "useencryption":
+        case "useEncryption": getOrCreateConfiguration(target).isUseEncryption(); return true;
+        case "useiamcredentials":
+        case "useIAMCredentials": getOrCreateConfiguration(target).isUseIAMCredentials(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java
index b0a4309..4a02a84 100644
--- a/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java
+++ b/components/camel-aws-s3/src/generated/java/org/apache/camel/component/aws/s3/S3EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.s3;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class S3EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class S3EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -126,5 +130,183 @@ public class S3EndpointConfigurer extends PropertyConfigurerSupport implements G
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accelerateModeEnabled", boolean.class);
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonS3Client", com.amazonaws.services.s3.AmazonS3.class);
+        answer.put("autoCreateBucket", boolean.class);
+        answer.put("autocloseBody", boolean.class);
+        answer.put("awsKMSKeyId", java.lang.String.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("chunkedEncodingDisabled", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("deleteAfterRead", boolean.class);
+        answer.put("deleteAfterWrite", boolean.class);
+        answer.put("delimiter", java.lang.String.class);
+        answer.put("dualstackEnabled", boolean.class);
+        answer.put("encryptionMaterials", com.amazonaws.services.s3.model.EncryptionMaterials.class);
+        answer.put("endpointConfiguration", com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("fileName", java.lang.String.class);
+        answer.put("forceGlobalBucketAccessEnabled", boolean.class);
+        answer.put("greedy", boolean.class);
+        answer.put("includeBody", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("keyName", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxConnections", int.class);
+        answer.put("maxMessagesPerPoll", int.class);
+        answer.put("multiPartUpload", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.s3.S3Operations.class);
+        answer.put("partSize", long.class);
+        answer.put("pathStyleAccess", boolean.class);
+        answer.put("payloadSigningEnabled", boolean.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("prefix", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("serverSideEncryption", java.lang.String.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("storageClass", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useAwsKMS", boolean.class);
+        answer.put("useEncryption", boolean.class);
+        answer.put("useFixedDelay", boolean.class);
+        answer.put("useIAMCredentials", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        S3Endpoint target = (S3Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "acceleratemodeenabled":
+        case "accelerateModeEnabled": target.getConfiguration().isAccelerateModeEnabled(); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazons3client":
+        case "amazonS3Client": target.getConfiguration().getAmazonS3Client(); return true;
+        case "autocreatebucket":
+        case "autoCreateBucket": target.getConfiguration().isAutoCreateBucket(); return true;
+        case "autoclosebody":
+        case "autocloseBody": target.getConfiguration().isAutocloseBody(); return true;
+        case "awskmskeyid":
+        case "awsKMSKeyId": target.getConfiguration().getAwsKMSKeyId(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "chunkedencodingdisabled":
+        case "chunkedEncodingDisabled": target.getConfiguration().isChunkedEncodingDisabled(); return true;
+        case "delay": target.getDelay(); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": target.getConfiguration().isDeleteAfterRead(); return true;
+        case "deleteafterwrite":
+        case "deleteAfterWrite": target.getConfiguration().isDeleteAfterWrite(); return true;
+        case "delimiter": target.getConfiguration().getDelimiter(); return true;
+        case "dualstackenabled":
+        case "dualstackEnabled": target.getConfiguration().isDualstackEnabled(); return true;
+        case "encryptionmaterials":
+        case "encryptionMaterials": target.getConfiguration().getEncryptionMaterials(); return true;
+        case "endpointconfiguration":
+        case "endpointConfiguration": target.getConfiguration().getEndpointConfiguration(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "filename":
+        case "fileName": target.getConfiguration().getFileName(); return true;
+        case "forceglobalbucketaccessenabled":
+        case "forceGlobalBucketAccessEnabled": target.getConfiguration().isForceGlobalBucketAccessEnabled(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "includebody":
+        case "includeBody": target.getConfiguration().isIncludeBody(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "keyname":
+        case "keyName": target.getConfiguration().getKeyName(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxconnections":
+        case "maxConnections": target.getMaxConnections(); return true;
+        case "maxmessagesperpoll":
+        case "maxMessagesPerPoll": target.getMaxMessagesPerPoll(); return true;
+        case "multipartupload":
+        case "multiPartUpload": target.getConfiguration().isMultiPartUpload(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "partsize":
+        case "partSize": target.getConfiguration().getPartSize(); return true;
+        case "pathstyleaccess":
+        case "pathStyleAccess": target.getConfiguration().isPathStyleAccess(); return true;
+        case "payloadsigningenabled":
+        case "payloadSigningEnabled": target.getConfiguration().isPayloadSigningEnabled(); return true;
+        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "prefix": target.getConfiguration().getPrefix(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "serversideencryption":
+        case "serverSideEncryption": target.getConfiguration().getServerSideEncryption(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "storageclass":
+        case "storageClass": target.getConfiguration().getStorageClass(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "useawskms":
+        case "useAwsKMS": target.getConfiguration().isUseAwsKMS(); return true;
+        case "useencryption":
+        case "useEncryption": target.getConfiguration().isUseEncryption(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useiamcredentials":
+        case "useIAMCredentials": target.getConfiguration().isUseIAMCredentials(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java
index 61b0607..895888e 100644
--- a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java
+++ b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.sdb;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SdbComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SdbComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -23,5 +27,24 @@ public class SdbComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SdbComponent target = (SdbComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java
index 443d3bf..64af6c7 100644
--- a/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java
+++ b/components/camel-aws-sdb/src/generated/java/org/apache/camel/component/aws/sdb/SdbEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.sdb;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SdbEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SdbEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -42,5 +46,54 @@ public class SdbEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSDBClient", com.amazonaws.services.simpledb.AmazonSimpleDB.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("consistentRead", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxNumberOfDomains", java.lang.Integer.class);
+        answer.put("operation", org.apache.camel.component.aws.sdb.SdbOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SdbEndpoint target = (SdbEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonsdbclient":
+        case "amazonSDBClient": target.getConfiguration().getAmazonSDBClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "consistentread":
+        case "consistentRead": target.getConfiguration().isConsistentRead(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxnumberofdomains":
+        case "maxNumberOfDomains": target.getConfiguration().getMaxNumberOfDomains(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java
index c09d59a..d446f9a 100644
--- a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java
+++ b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ses;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SesComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SesComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.ses.SesConfiguration getOrCreateConfiguration(SesComponent target) {
         if (target.getConfiguration() == null) {
@@ -50,5 +54,56 @@ public class SesComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSESClient", com.amazonaws.services.simpleemail.AmazonSimpleEmailService.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.ses.SesConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("replyToAddresses", java.util.List.class);
+        answer.put("returnPath", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("to", java.util.List.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SesComponent target = (SesComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonsesclient":
+        case "amazonSESClient": getOrCreateConfiguration(target).getAmazonSESClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "replytoaddresses":
+        case "replyToAddresses": getOrCreateConfiguration(target).getReplyToAddresses(); return true;
+        case "returnpath":
+        case "returnPath": getOrCreateConfiguration(target).getReturnPath(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
+        case "to": getOrCreateConfiguration(target).getTo(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java
index 005dfd4..b9ba0ac 100644
--- a/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java
+++ b/components/camel-aws-ses/src/generated/java/org/apache/camel/component/aws/ses/SesEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.ses;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SesEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SesEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -43,5 +47,56 @@ public class SesEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSESClient", com.amazonaws.services.simpleemail.AmazonSimpleEmailService.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("replyToAddresses", java.util.List.class);
+        answer.put("returnPath", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("to", java.util.List.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SesEndpoint target = (SesEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonsesclient":
+        case "amazonSESClient": target.getConfiguration().getAmazonSESClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "replytoaddresses":
+        case "replyToAddresses": target.getConfiguration().getReplyToAddresses(); return true;
+        case "returnpath":
+        case "returnPath": target.getConfiguration().getReturnPath(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "subject": target.getConfiguration().getSubject(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "to": target.getConfiguration().getTo(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java
index 7f2b822..348e6a7 100644
--- a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java
+++ b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.sns;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SnsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SnsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.sns.SnsConfiguration getOrCreateConfiguration(SnsComponent target) {
         if (target.getConfiguration() == null) {
@@ -60,5 +64,71 @@ public class SnsComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSNSClient", com.amazonaws.services.sns.AmazonSNS.class);
+        answer.put("amazonSQSClient", com.amazonaws.services.sqs.AmazonSQS.class);
+        answer.put("autoCreateTopic", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.sns.SnsConfiguration.class);
+        answer.put("kmsMasterKeyId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("messageStructure", java.lang.String.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("queueUrl", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("serverSideEncryptionEnabled", boolean.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("subscribeSNStoSQS", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SnsComponent target = (SnsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonsnsclient":
+        case "amazonSNSClient": getOrCreateConfiguration(target).getAmazonSNSClient(); return true;
+        case "amazonsqsclient":
+        case "amazonSQSClient": getOrCreateConfiguration(target).getAmazonSQSClient(); return true;
+        case "autocreatetopic":
+        case "autoCreateTopic": getOrCreateConfiguration(target).isAutoCreateTopic(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": getOrCreateConfiguration(target).getKmsMasterKeyId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "messagestructure":
+        case "messageStructure": getOrCreateConfiguration(target).getMessageStructure(); return true;
+        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "queueurl":
+        case "queueUrl": getOrCreateConfiguration(target).getQueueUrl(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": getOrCreateConfiguration(target).isServerSideEncryptionEnabled(); return true;
+        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
+        case "subscribesnstosqs":
+        case "subscribeSNStoSQS": getOrCreateConfiguration(target).isSubscribeSNStoSQS(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java
index 51008cc..54786f3 100644
--- a/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java
+++ b/components/camel-aws-sns/src/generated/java/org/apache/camel/component/aws/sns/SnsEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.sns;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SnsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SnsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -55,5 +59,74 @@ public class SnsEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSNSClient", com.amazonaws.services.sns.AmazonSNS.class);
+        answer.put("amazonSQSClient", com.amazonaws.services.sqs.AmazonSQS.class);
+        answer.put("autoCreateTopic", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("headerFilterStrategy", org.apache.camel.spi.HeaderFilterStrategy.class);
+        answer.put("kmsMasterKeyId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("messageStructure", java.lang.String.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("queueUrl", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("serverSideEncryptionEnabled", boolean.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("subscribeSNStoSQS", boolean.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SnsEndpoint target = (SnsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonsnsclient":
+        case "amazonSNSClient": target.getConfiguration().getAmazonSNSClient(); return true;
+        case "amazonsqsclient":
+        case "amazonSQSClient": target.getConfiguration().getAmazonSQSClient(); return true;
+        case "autocreatetopic":
+        case "autoCreateTopic": target.getConfiguration().isAutoCreateTopic(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": target.getConfiguration().getKmsMasterKeyId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "messagestructure":
+        case "messageStructure": target.getConfiguration().getMessageStructure(); return true;
+        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "queueurl":
+        case "queueUrl": target.getConfiguration().getQueueUrl(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": target.getConfiguration().isServerSideEncryptionEnabled(); return true;
+        case "subject": target.getConfiguration().getSubject(); return true;
+        case "subscribesnstosqs":
+        case "subscribeSNStoSQS": target.getConfiguration().isSubscribeSNStoSQS(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java
index d3c5685..90f6ac6 100644
--- a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java
+++ b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.sqs;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SqsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SqsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.sqs.SqsConfiguration getOrCreateConfiguration(SqsComponent target) {
         if (target.getConfiguration() == null) {
@@ -97,5 +101,127 @@ public class SqsComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonAWSHost", java.lang.String.class);
+        answer.put("amazonSQSClient", com.amazonaws.services.sqs.AmazonSQS.class);
+        answer.put("attributeNames", java.lang.String.class);
+        answer.put("autoCreateQueue", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("concurrentConsumers", int.class);
+        answer.put("configuration", org.apache.camel.component.aws.sqs.SqsConfiguration.class);
+        answer.put("defaultVisibilityTimeout", java.lang.Integer.class);
+        answer.put("delayQueue", boolean.class);
+        answer.put("delaySeconds", java.lang.Integer.class);
+        answer.put("deleteAfterRead", boolean.class);
+        answer.put("deleteIfFiltered", boolean.class);
+        answer.put("extendMessageVisibility", boolean.class);
+        answer.put("kmsDataKeyReusePeriodSeconds", java.lang.Integer.class);
+        answer.put("kmsMasterKeyId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maximumMessageSize", java.lang.Integer.class);
+        answer.put("messageAttributeNames", java.lang.String.class);
+        answer.put("messageDeduplicationIdStrategy", java.lang.String.class);
+        answer.put("messageGroupIdStrategy", java.lang.String.class);
+        answer.put("messageRetentionPeriod", java.lang.Integer.class);
+        answer.put("operation", org.apache.camel.component.aws.sqs.SqsOperations.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("protocol", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("queueOwnerAWSAccountId", java.lang.String.class);
+        answer.put("queueUrl", java.lang.String.class);
+        answer.put("receiveMessageWaitTimeSeconds", java.lang.Integer.class);
+        answer.put("redrivePolicy", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("serverSideEncryptionEnabled", boolean.class);
+        answer.put("visibilityTimeout", java.lang.Integer.class);
+        answer.put("waitTimeSeconds", java.lang.Integer.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SqsComponent target = (SqsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonawshost":
+        case "amazonAWSHost": getOrCreateConfiguration(target).getAmazonAWSHost(); return true;
+        case "amazonsqsclient":
+        case "amazonSQSClient": getOrCreateConfiguration(target).getAmazonSQSClient(); return true;
+        case "attributenames":
+        case "attributeNames": getOrCreateConfiguration(target).getAttributeNames(); return true;
+        case "autocreatequeue":
+        case "autoCreateQueue": getOrCreateConfiguration(target).isAutoCreateQueue(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "concurrentconsumers":
+        case "concurrentConsumers": getOrCreateConfiguration(target).getConcurrentConsumers(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "defaultvisibilitytimeout":
+        case "defaultVisibilityTimeout": getOrCreateConfiguration(target).getDefaultVisibilityTimeout(); return true;
+        case "delayqueue":
+        case "delayQueue": getOrCreateConfiguration(target).isDelayQueue(); return true;
+        case "delayseconds":
+        case "delaySeconds": getOrCreateConfiguration(target).getDelaySeconds(); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": getOrCreateConfiguration(target).isDeleteAfterRead(); return true;
+        case "deleteiffiltered":
+        case "deleteIfFiltered": getOrCreateConfiguration(target).isDeleteIfFiltered(); return true;
+        case "extendmessagevisibility":
+        case "extendMessageVisibility": getOrCreateConfiguration(target).isExtendMessageVisibility(); return true;
+        case "kmsdatakeyreuseperiodseconds":
+        case "kmsDataKeyReusePeriodSeconds": getOrCreateConfiguration(target).getKmsDataKeyReusePeriodSeconds(); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": getOrCreateConfiguration(target).getKmsMasterKeyId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maximummessagesize":
+        case "maximumMessageSize": getOrCreateConfiguration(target).getMaximumMessageSize(); return true;
+        case "messageattributenames":
+        case "messageAttributeNames": getOrCreateConfiguration(target).getMessageAttributeNames(); return true;
+        case "messagededuplicationidstrategy":
+        case "messageDeduplicationIdStrategy": getOrCreateConfiguration(target).getMessageDeduplicationIdStrategy(); return true;
+        case "messagegroupidstrategy":
+        case "messageGroupIdStrategy": getOrCreateConfiguration(target).getMessageGroupIdStrategy(); return true;
+        case "messageretentionperiod":
+        case "messageRetentionPeriod": getOrCreateConfiguration(target).getMessageRetentionPeriod(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
+        case "protocol": getOrCreateConfiguration(target).getProtocol(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "queueownerawsaccountid":
+        case "queueOwnerAWSAccountId": getOrCreateConfiguration(target).getQueueOwnerAWSAccountId(); return true;
+        case "queueurl":
+        case "queueUrl": getOrCreateConfiguration(target).getQueueUrl(); return true;
+        case "receivemessagewaittimeseconds":
+        case "receiveMessageWaitTimeSeconds": getOrCreateConfiguration(target).getReceiveMessageWaitTimeSeconds(); return true;
+        case "redrivepolicy":
+        case "redrivePolicy": getOrCreateConfiguration(target).getRedrivePolicy(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": getOrCreateConfiguration(target).isServerSideEncryptionEnabled(); return true;
+        case "visibilitytimeout":
+        case "visibilityTimeout": getOrCreateConfiguration(target).getVisibilityTimeout(); return true;
+        case "waittimeseconds":
+        case "waitTimeSeconds": getOrCreateConfiguration(target).getWaitTimeSeconds(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java
index c0888d6..87bf267 100644
--- a/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java
+++ b/components/camel-aws-sqs/src/generated/java/org/apache/camel/component/aws/sqs/SqsEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.sqs;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SqsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SqsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -127,5 +131,184 @@ public class SqsEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonAWSHost", java.lang.String.class);
+        answer.put("amazonSQSClient", com.amazonaws.services.sqs.AmazonSQS.class);
+        answer.put("attributeNames", java.lang.String.class);
+        answer.put("autoCreateQueue", boolean.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("concurrentConsumers", int.class);
+        answer.put("defaultVisibilityTimeout", java.lang.Integer.class);
+        answer.put("delay", long.class);
+        answer.put("delayQueue", boolean.class);
+        answer.put("delaySeconds", java.lang.Integer.class);
+        answer.put("deleteAfterRead", boolean.class);
+        answer.put("deleteIfFiltered", boolean.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("extendMessageVisibility", boolean.class);
+        answer.put("greedy", boolean.class);
+        answer.put("headerFilterStrategy", org.apache.camel.spi.HeaderFilterStrategy.class);
+        answer.put("initialDelay", long.class);
+        answer.put("kmsDataKeyReusePeriodSeconds", java.lang.Integer.class);
+        answer.put("kmsMasterKeyId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxMessagesPerPoll", int.class);
+        answer.put("maximumMessageSize", java.lang.Integer.class);
+        answer.put("messageAttributeNames", java.lang.String.class);
+        answer.put("messageDeduplicationIdStrategy", java.lang.String.class);
+        answer.put("messageGroupIdStrategy", java.lang.String.class);
+        answer.put("messageRetentionPeriod", java.lang.Integer.class);
+        answer.put("operation", org.apache.camel.component.aws.sqs.SqsOperations.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("protocol", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("queueOwnerAWSAccountId", java.lang.String.class);
+        answer.put("queueUrl", java.lang.String.class);
+        answer.put("receiveMessageWaitTimeSeconds", java.lang.Integer.class);
+        answer.put("redrivePolicy", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("serverSideEncryptionEnabled", boolean.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useFixedDelay", boolean.class);
+        answer.put("visibilityTimeout", java.lang.Integer.class);
+        answer.put("waitTimeSeconds", java.lang.Integer.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SqsEndpoint target = (SqsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonawshost":
+        case "amazonAWSHost": target.getConfiguration().getAmazonAWSHost(); return true;
+        case "amazonsqsclient":
+        case "amazonSQSClient": target.getConfiguration().getAmazonSQSClient(); return true;
+        case "attributenames":
+        case "attributeNames": target.getConfiguration().getAttributeNames(); return true;
+        case "autocreatequeue":
+        case "autoCreateQueue": target.getConfiguration().isAutoCreateQueue(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "concurrentconsumers":
+        case "concurrentConsumers": target.getConfiguration().getConcurrentConsumers(); return true;
+        case "defaultvisibilitytimeout":
+        case "defaultVisibilityTimeout": target.getConfiguration().getDefaultVisibilityTimeout(); return true;
+        case "delay": target.getDelay(); return true;
+        case "delayqueue":
+        case "delayQueue": target.getConfiguration().isDelayQueue(); return true;
+        case "delayseconds":
+        case "delaySeconds": target.getConfiguration().getDelaySeconds(); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": target.getConfiguration().isDeleteAfterRead(); return true;
+        case "deleteiffiltered":
+        case "deleteIfFiltered": target.getConfiguration().isDeleteIfFiltered(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "extendmessagevisibility":
+        case "extendMessageVisibility": target.getConfiguration().isExtendMessageVisibility(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "kmsdatakeyreuseperiodseconds":
+        case "kmsDataKeyReusePeriodSeconds": target.getConfiguration().getKmsDataKeyReusePeriodSeconds(); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": target.getConfiguration().getKmsMasterKeyId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxmessagesperpoll":
+        case "maxMessagesPerPoll": target.getMaxMessagesPerPoll(); return true;
+        case "maximummessagesize":
+        case "maximumMessageSize": target.getConfiguration().getMaximumMessageSize(); return true;
+        case "messageattributenames":
+        case "messageAttributeNames": target.getConfiguration().getMessageAttributeNames(); return true;
+        case "messagededuplicationidstrategy":
+        case "messageDeduplicationIdStrategy": target.getConfiguration().getMessageDeduplicationIdStrategy(); return true;
+        case "messagegroupidstrategy":
+        case "messageGroupIdStrategy": target.getConfiguration().getMessageGroupIdStrategy(); return true;
+        case "messageretentionperiod":
+        case "messageRetentionPeriod": target.getConfiguration().getMessageRetentionPeriod(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "protocol": target.getConfiguration().getProtocol(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "queueownerawsaccountid":
+        case "queueOwnerAWSAccountId": target.getConfiguration().getQueueOwnerAWSAccountId(); return true;
+        case "queueurl":
+        case "queueUrl": target.getConfiguration().getQueueUrl(); return true;
+        case "receivemessagewaittimeseconds":
+        case "receiveMessageWaitTimeSeconds": target.getConfiguration().getReceiveMessageWaitTimeSeconds(); return true;
+        case "redrivepolicy":
+        case "redrivePolicy": target.getConfiguration().getRedrivePolicy(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": target.getConfiguration().isServerSideEncryptionEnabled(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "visibilitytimeout":
+        case "visibilityTimeout": target.getConfiguration().getVisibilityTimeout(); return true;
+        case "waittimeseconds":
+        case "waitTimeSeconds": target.getConfiguration().getWaitTimeSeconds(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java
index b307cf9..eebf212 100644
--- a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java
+++ b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.swf;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SWFComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SWFComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.swf.SWFConfiguration getOrCreateConfiguration(SWFComponent target) {
         if (target.getConfiguration() == null) {
@@ -82,5 +86,104 @@ public class SWFComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("activityList", java.lang.String.class);
+        answer.put("activitySchedulingOptions", com.amazonaws.services.simpleworkflow.flow.ActivitySchedulingOptions.class);
+        answer.put("activityThreadPoolSize", int.class);
+        answer.put("activityTypeExecutionOptions", com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeExecutionOptions.class);
+        answer.put("activityTypeRegistrationOptions", com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeRegistrationOptions.class);
+        answer.put("amazonSWClient", com.amazonaws.services.simpleworkflow.AmazonSimpleWorkflow.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("childPolicy", java.lang.String.class);
+        answer.put("clientConfigurationParameters", java.util.Map.class);
+        answer.put("configuration", org.apache.camel.component.aws.swf.SWFConfiguration.class);
+        answer.put("dataConverter", com.amazonaws.services.simpleworkflow.flow.DataConverter.class);
+        answer.put("domainName", java.lang.String.class);
+        answer.put("eventName", java.lang.String.class);
+        answer.put("executionStartToCloseTimeout", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("sWClientParameters", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("signalName", java.lang.String.class);
+        answer.put("startWorkflowOptionsParameters", java.util.Map.class);
+        answer.put("stateResultType", java.lang.String.class);
+        answer.put("taskStartToCloseTimeout", java.lang.String.class);
+        answer.put("terminationDetails", java.lang.String.class);
+        answer.put("terminationReason", java.lang.String.class);
+        answer.put("version", java.lang.String.class);
+        answer.put("workflowList", java.lang.String.class);
+        answer.put("workflowTypeRegistrationOptions", com.amazonaws.services.simpleworkflow.flow.WorkflowTypeRegistrationOptions.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SWFComponent target = (SWFComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "activitylist":
+        case "activityList": getOrCreateConfiguration(target).getActivityList(); return true;
+        case "activityschedulingoptions":
+        case "activitySchedulingOptions": getOrCreateConfiguration(target).getActivitySchedulingOptions(); return true;
+        case "activitythreadpoolsize":
+        case "activityThreadPoolSize": getOrCreateConfiguration(target).getActivityThreadPoolSize(); return true;
+        case "activitytypeexecutionoptions":
+        case "activityTypeExecutionOptions": getOrCreateConfiguration(target).getActivityTypeExecutionOptions(); return true;
+        case "activitytyperegistrationoptions":
+        case "activityTypeRegistrationOptions": getOrCreateConfiguration(target).getActivityTypeRegistrationOptions(); return true;
+        case "amazonswclient":
+        case "amazonSWClient": getOrCreateConfiguration(target).getAmazonSWClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "childpolicy":
+        case "childPolicy": getOrCreateConfiguration(target).getChildPolicy(); return true;
+        case "clientconfigurationparameters":
+        case "clientConfigurationParameters": getOrCreateConfiguration(target).getClientConfigurationParameters(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "dataconverter":
+        case "dataConverter": getOrCreateConfiguration(target).getDataConverter(); return true;
+        case "domainname":
+        case "domainName": getOrCreateConfiguration(target).getDomainName(); return true;
+        case "eventname":
+        case "eventName": getOrCreateConfiguration(target).getEventName(); return true;
+        case "executionstarttoclosetimeout":
+        case "executionStartToCloseTimeout": getOrCreateConfiguration(target).getExecutionStartToCloseTimeout(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "swclientparameters":
+        case "sWClientParameters": getOrCreateConfiguration(target).getSWClientParameters(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "signalname":
+        case "signalName": getOrCreateConfiguration(target).getSignalName(); return true;
+        case "startworkflowoptionsparameters":
+        case "startWorkflowOptionsParameters": getOrCreateConfiguration(target).getStartWorkflowOptionsParameters(); return true;
+        case "stateresulttype":
+        case "stateResultType": getOrCreateConfiguration(target).getStateResultType(); return true;
+        case "taskstarttoclosetimeout":
+        case "taskStartToCloseTimeout": getOrCreateConfiguration(target).getTaskStartToCloseTimeout(); return true;
+        case "terminationdetails":
+        case "terminationDetails": getOrCreateConfiguration(target).getTerminationDetails(); return true;
+        case "terminationreason":
+        case "terminationReason": getOrCreateConfiguration(target).getTerminationReason(); return true;
+        case "version": getOrCreateConfiguration(target).getVersion(); return true;
+        case "workflowlist":
+        case "workflowList": getOrCreateConfiguration(target).getWorkflowList(); return true;
+        case "workflowtyperegistrationoptions":
+        case "workflowTypeRegistrationOptions": getOrCreateConfiguration(target).getWorkflowTypeRegistrationOptions(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java
index 480eb35..3914a62 100644
--- a/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java
+++ b/components/camel-aws-swf/src/generated/java/org/apache/camel/component/aws/swf/SWFEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.swf;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class SWFEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class SWFEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -79,5 +83,110 @@ public class SWFEndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("activityList", java.lang.String.class);
+        answer.put("activitySchedulingOptions", com.amazonaws.services.simpleworkflow.flow.ActivitySchedulingOptions.class);
+        answer.put("activityThreadPoolSize", int.class);
+        answer.put("activityTypeExecutionOptions", com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeExecutionOptions.class);
+        answer.put("activityTypeRegistrationOptions", com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeRegistrationOptions.class);
+        answer.put("amazonSWClient", com.amazonaws.services.simpleworkflow.AmazonSimpleWorkflow.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("childPolicy", java.lang.String.class);
+        answer.put("clientConfigurationParameters", java.util.Map.class);
+        answer.put("dataConverter", com.amazonaws.services.simpleworkflow.flow.DataConverter.class);
+        answer.put("domainName", java.lang.String.class);
+        answer.put("eventName", java.lang.String.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("executionStartToCloseTimeout", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("sWClientParameters", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("signalName", java.lang.String.class);
+        answer.put("startWorkflowOptionsParameters", java.util.Map.class);
+        answer.put("stateResultType", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("taskStartToCloseTimeout", java.lang.String.class);
+        answer.put("terminationDetails", java.lang.String.class);
+        answer.put("terminationReason", java.lang.String.class);
+        answer.put("version", java.lang.String.class);
+        answer.put("workflowList", java.lang.String.class);
+        answer.put("workflowTypeRegistrationOptions", com.amazonaws.services.simpleworkflow.flow.WorkflowTypeRegistrationOptions.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        SWFEndpoint target = (SWFEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "activitylist":
+        case "activityList": target.getConfiguration().getActivityList(); return true;
+        case "activityschedulingoptions":
+        case "activitySchedulingOptions": target.getConfiguration().getActivitySchedulingOptions(); return true;
+        case "activitythreadpoolsize":
+        case "activityThreadPoolSize": target.getConfiguration().getActivityThreadPoolSize(); return true;
+        case "activitytypeexecutionoptions":
+        case "activityTypeExecutionOptions": target.getConfiguration().getActivityTypeExecutionOptions(); return true;
+        case "activitytyperegistrationoptions":
+        case "activityTypeRegistrationOptions": target.getConfiguration().getActivityTypeRegistrationOptions(); return true;
+        case "amazonswclient":
+        case "amazonSWClient": target.getConfiguration().getAmazonSWClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "childpolicy":
+        case "childPolicy": target.getConfiguration().getChildPolicy(); return true;
+        case "clientconfigurationparameters":
+        case "clientConfigurationParameters": target.getConfiguration().getClientConfigurationParameters(); return true;
+        case "dataconverter":
+        case "dataConverter": target.getConfiguration().getDataConverter(); return true;
+        case "domainname":
+        case "domainName": target.getConfiguration().getDomainName(); return true;
+        case "eventname":
+        case "eventName": target.getConfiguration().getEventName(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "executionstarttoclosetimeout":
+        case "executionStartToCloseTimeout": target.getConfiguration().getExecutionStartToCloseTimeout(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "swclientparameters":
+        case "sWClientParameters": target.getConfiguration().getSWClientParameters(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "signalname":
+        case "signalName": target.getConfiguration().getSignalName(); return true;
+        case "startworkflowoptionsparameters":
+        case "startWorkflowOptionsParameters": target.getConfiguration().getStartWorkflowOptionsParameters(); return true;
+        case "stateresulttype":
+        case "stateResultType": target.getConfiguration().getStateResultType(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "taskstarttoclosetimeout":
+        case "taskStartToCloseTimeout": target.getConfiguration().getTaskStartToCloseTimeout(); return true;
+        case "terminationdetails":
+        case "terminationDetails": target.getConfiguration().getTerminationDetails(); return true;
+        case "terminationreason":
+        case "terminationReason": target.getConfiguration().getTerminationReason(); return true;
+        case "version": target.getConfiguration().getVersion(); return true;
+        case "workflowlist":
+        case "workflowList": target.getConfiguration().getWorkflowList(); return true;
+        case "workflowtyperegistrationoptions":
+        case "workflowTypeRegistrationOptions": target.getConfiguration().getWorkflowTypeRegistrationOptions(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java
index 92db380..3892ccb 100644
--- a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java
+++ b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.translate;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class TranslateComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class TranslateComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws.translate.TranslateConfiguration getOrCreateConfiguration(TranslateComponent target) {
         if (target.getConfiguration() == null) {
@@ -51,5 +55,57 @@ public class TranslateComponentConfigurer extends PropertyConfigurerSupport impl
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("autodetectSourceLanguage", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws.translate.TranslateConfiguration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.translate.TranslateOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sourceLanguage", java.lang.String.class);
+        answer.put("targetLanguage", java.lang.String.class);
+        answer.put("translateClient", com.amazonaws.services.translate.AmazonTranslate.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        TranslateComponent target = (TranslateComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "autodetectsourcelanguage":
+        case "autodetectSourceLanguage": getOrCreateConfiguration(target).isAutodetectSourceLanguage(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "sourcelanguage":
+        case "sourceLanguage": getOrCreateConfiguration(target).getSourceLanguage(); return true;
+        case "targetlanguage":
+        case "targetLanguage": getOrCreateConfiguration(target).getTargetLanguage(); return true;
+        case "translateclient":
+        case "translateClient": getOrCreateConfiguration(target).getTranslateClient(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java
index c8047bb..5a66c68 100644
--- a/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java
+++ b/components/camel-aws-translate/src/generated/java/org/apache/camel/component/aws/translate/TranslateEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws.translate;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class TranslateEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class TranslateEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -44,5 +48,57 @@ public class TranslateEndpointConfigurer extends PropertyConfigurerSupport imple
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("autodetectSourceLanguage", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws.translate.TranslateOperations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", com.amazonaws.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sourceLanguage", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("targetLanguage", java.lang.String.class);
+        answer.put("translateClient", com.amazonaws.services.translate.AmazonTranslate.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        TranslateEndpoint target = (TranslateEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "autodetectsourcelanguage":
+        case "autodetectSourceLanguage": target.getConfiguration().isAutodetectSourceLanguage(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sourcelanguage":
+        case "sourceLanguage": target.getConfiguration().getSourceLanguage(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "targetlanguage":
+        case "targetLanguage": target.getConfiguration().getTargetLanguage(); return true;
+        case "translateclient":
+        case "translateClient": target.getConfiguration().getTranslateClient(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java
index 5f4e0b5..4ebd50c 100644
--- a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java
+++ b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.cw;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Cw2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Cw2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.cw.Cw2Configuration getOrCreateConfiguration(Cw2Component target) {
         if (target.getConfiguration() == null) {
@@ -48,5 +52,54 @@ public class Cw2ComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonCwClient", software.amazon.awssdk.services.cloudwatch.CloudWatchClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.cw.Cw2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("name", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("timestamp", java.time.Instant.class);
+        answer.put("unit", java.lang.String.class);
+        answer.put("value", java.lang.Double.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Cw2Component target = (Cw2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazoncwclient":
+        case "amazonCwClient": getOrCreateConfiguration(target).getAmazonCwClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "name": getOrCreateConfiguration(target).getName(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "timestamp": getOrCreateConfiguration(target).getTimestamp(); return true;
+        case "unit": getOrCreateConfiguration(target).getUnit(); return true;
+        case "value": getOrCreateConfiguration(target).getValue(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java
index d58af3a..ece6c1c 100644
--- a/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java
+++ b/components/camel-aws2-cw/src/generated/java/org/apache/camel/component/aws2/cw/Cw2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.cw;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Cw2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Cw2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -41,5 +45,54 @@ public class Cw2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonCwClient", software.amazon.awssdk.services.cloudwatch.CloudWatchClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("name", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timestamp", java.time.Instant.class);
+        answer.put("unit", java.lang.String.class);
+        answer.put("value", java.lang.Double.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Cw2Endpoint target = (Cw2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazoncwclient":
+        case "amazonCwClient": target.getConfiguration().getAmazonCwClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "name": target.getConfiguration().getName(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timestamp": target.getConfiguration().getTimestamp(); return true;
+        case "unit": target.getConfiguration().getUnit(); return true;
+        case "value": target.getConfiguration().getValue(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java
index b47717b..424f072 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ddb;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Ddb2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Ddb2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.ddb.Ddb2Configuration getOrCreateConfiguration(Ddb2Component target) {
         if (target.getConfiguration() == null) {
@@ -55,5 +59,63 @@ public class Ddb2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDDBClient", software.amazon.awssdk.services.dynamodb.DynamoDbClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.ddb.Ddb2Configuration.class);
+        answer.put("consistentRead", boolean.class);
+        answer.put("keyAttributeName", java.lang.String.class);
+        answer.put("keyAttributeType", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.ddb.Ddb2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("readCapacity", java.lang.Long.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("writeCapacity", java.lang.Long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Ddb2Component target = (Ddb2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonddbclient":
+        case "amazonDDBClient": getOrCreateConfiguration(target).getAmazonDDBClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "consistentread":
+        case "consistentRead": getOrCreateConfiguration(target).isConsistentRead(); return true;
+        case "keyattributename":
+        case "keyAttributeName": getOrCreateConfiguration(target).getKeyAttributeName(); return true;
+        case "keyattributetype":
+        case "keyAttributeType": getOrCreateConfiguration(target).getKeyAttributeType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "readcapacity":
+        case "readCapacity": getOrCreateConfiguration(target).getReadCapacity(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "writecapacity":
+        case "writeCapacity": getOrCreateConfiguration(target).getWriteCapacity(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java
index a7b78f3..9699fc9 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddb/Ddb2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ddb;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Ddb2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Ddb2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -48,5 +52,63 @@ public class Ddb2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDDBClient", software.amazon.awssdk.services.dynamodb.DynamoDbClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("consistentRead", boolean.class);
+        answer.put("keyAttributeName", java.lang.String.class);
+        answer.put("keyAttributeType", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.ddb.Ddb2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("readCapacity", java.lang.Long.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("writeCapacity", java.lang.Long.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Ddb2Endpoint target = (Ddb2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonddbclient":
+        case "amazonDDBClient": target.getConfiguration().getAmazonDDBClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "consistentread":
+        case "consistentRead": target.getConfiguration().isConsistentRead(); return true;
+        case "keyattributename":
+        case "keyAttributeName": target.getConfiguration().getKeyAttributeName(); return true;
+        case "keyattributetype":
+        case "keyAttributeType": target.getConfiguration().getKeyAttributeType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "readcapacity":
+        case "readCapacity": target.getConfiguration().getReadCapacity(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "writecapacity":
+        case "writeCapacity": target.getConfiguration().getWriteCapacity(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java
index 3315cd6..c485109 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ddbstream;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Ddb2StreamComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Ddb2StreamComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.ddbstream.Ddb2StreamConfiguration getOrCreateConfiguration(Ddb2StreamComponent target) {
         if (target.getConfiguration() == null) {
@@ -50,5 +54,55 @@ public class Ddb2StreamComponentConfigurer extends PropertyConfigurerSupport imp
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDynamoDbStreamsClient", software.amazon.awssdk.services.dynamodb.streams.DynamoDbStreamsClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.ddbstream.Ddb2StreamConfiguration.class);
+        answer.put("iteratorType", software.amazon.awssdk.services.dynamodb.model.ShardIteratorType.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sequenceNumberProvider", org.apache.camel.component.aws2.ddbstream.SequenceNumberProvider.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Ddb2StreamComponent target = (Ddb2StreamComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazondynamodbstreamsclient":
+        case "amazonDynamoDbStreamsClient": getOrCreateConfiguration(target).getAmazonDynamoDbStreamsClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "iteratortype":
+        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "sequencenumberprovider":
+        case "sequenceNumberProvider": getOrCreateConfiguration(target).getSequenceNumberProvider(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java
index 5aa3d92..0536860 100644
--- a/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java
+++ b/components/camel-aws2-ddb/src/generated/java/org/apache/camel/component/aws2/ddbstream/Ddb2StreamEndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ddbstream;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Ddb2StreamEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Ddb2StreamEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -76,5 +80,106 @@ public class Ddb2StreamEndpointConfigurer extends PropertyConfigurerSupport impl
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonDynamoDbStreamsClient", software.amazon.awssdk.services.dynamodb.streams.DynamoDbStreamsClient.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("greedy", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("iteratorType", software.amazon.awssdk.services.dynamodb.model.ShardIteratorType.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("sequenceNumberProvider", org.apache.camel.component.aws2.ddbstream.SequenceNumberProvider.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useFixedDelay", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Ddb2StreamEndpoint target = (Ddb2StreamEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazondynamodbstreamsclient":
+        case "amazonDynamoDbStreamsClient": target.getConfiguration().getAmazonDynamoDbStreamsClient(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "delay": target.getDelay(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "iteratortype":
+        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sequencenumberprovider":
+        case "sequenceNumberProvider": target.getConfiguration().getSequenceNumberProvider(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java
index 4b340be..12cab3f 100644
--- a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java
+++ b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ec2;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AWS2EC2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AWS2EC2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.ec2.AWS2EC2Configuration getOrCreateConfiguration(AWS2EC2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class AWS2EC2ComponentConfigurer extends PropertyConfigurerSupport implem
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonEc2Client", software.amazon.awssdk.services.ec2.Ec2Client.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.ec2.AWS2EC2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.ec2.AWS2EC2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AWS2EC2Component target = (AWS2EC2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonec2client":
+        case "amazonEc2Client": getOrCreateConfiguration(target).getAmazonEc2Client(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java
index 4c9ec82..4cbde54 100644
--- a/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java
+++ b/components/camel-aws2-ec2/src/generated/java/org/apache/camel/component/aws2/ec2/AWS2EC2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ec2;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AWS2EC2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AWS2EC2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class AWS2EC2EndpointConfigurer extends PropertyConfigurerSupport impleme
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonEc2Client", software.amazon.awssdk.services.ec2.Ec2Client.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.ec2.AWS2EC2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AWS2EC2Endpoint target = (AWS2EC2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonec2client":
+        case "amazonEc2Client": target.getConfiguration().getAmazonEc2Client(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java
index 372c11a..35db0ee 100644
--- a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java
+++ b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ecs;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ECS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class ECS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.ecs.ECS2Configuration getOrCreateConfiguration(ECS2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class ECS2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.ecs.ECS2Configuration.class);
+        answer.put("ecsClient", software.amazon.awssdk.services.ecs.EcsClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.ecs.ECS2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        ECS2Component target = (ECS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "ecsclient":
+        case "ecsClient": getOrCreateConfiguration(target).getEcsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java
index d6c2088..a43414b 100644
--- a/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java
+++ b/components/camel-aws2-ecs/src/generated/java/org/apache/camel/component/aws2/ecs/ECS2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ecs;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class ECS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class ECS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class ECS2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("ecsClient", software.amazon.awssdk.services.ecs.EcsClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.ecs.ECS2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        ECS2Endpoint target = (ECS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "ecsclient":
+        case "ecsClient": target.getConfiguration().getEcsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java
index c69ac01..176fb93 100644
--- a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java
+++ b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.eks;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class EKS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class EKS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.eks.EKS2Configuration getOrCreateConfiguration(EKS2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class EKS2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.eks.EKS2Configuration.class);
+        answer.put("eksClient", software.amazon.awssdk.services.eks.EksClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.eks.EKS2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        EKS2Component target = (EKS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "eksclient":
+        case "eksClient": getOrCreateConfiguration(target).getEksClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java
index f1c4bd1..c0c4e24 100644
--- a/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java
+++ b/components/camel-aws2-eks/src/generated/java/org/apache/camel/component/aws2/eks/EKS2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.eks;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class EKS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class EKS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class EKS2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("eksClient", software.amazon.awssdk.services.eks.EksClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.eks.EKS2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        EKS2Endpoint target = (EKS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "eksclient":
+        case "eksClient": target.getConfiguration().getEksClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java
index 5fe1056..964cc7d 100644
--- a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java
+++ b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.iam;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class IAM2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class IAM2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.iam.IAM2Configuration getOrCreateConfiguration(IAM2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class IAM2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.iam.IAM2Configuration.class);
+        answer.put("iamClient", software.amazon.awssdk.services.iam.IamClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.iam.IAM2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        IAM2Component target = (IAM2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "iamclient":
+        case "iamClient": getOrCreateConfiguration(target).getIamClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java
index bb6606c..cc069aa 100644
--- a/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java
+++ b/components/camel-aws2-iam/src/generated/java/org/apache/camel/component/aws2/iam/IAM2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.iam;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class IAM2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class IAM2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class IAM2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("iamClient", software.amazon.awssdk.services.iam.IamClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.iam.IAM2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        IAM2Endpoint target = (IAM2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "iamclient":
+        case "iamClient": target.getConfiguration().getIamClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java
index 4f0af2f..78f24db 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.firehose;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KinesisFirehose2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KinesisFirehose2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.firehose.KinesisFirehose2Configuration getOrCreateConfiguration(KinesisFirehose2Component target) {
         if (target.getConfiguration() == null) {
@@ -44,5 +48,46 @@ public class KinesisFirehose2ComponentConfigurer extends PropertyConfigurerSuppo
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisFirehoseClient", software.amazon.awssdk.services.firehose.FirehoseClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.firehose.KinesisFirehose2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KinesisFirehose2Component target = (KinesisFirehose2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonkinesisfirehoseclient":
+        case "amazonKinesisFirehoseClient": getOrCreateConfiguration(target).getAmazonKinesisFirehoseClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java
index 7a78a7a..b38615e 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/firehose/KinesisFirehose2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.firehose;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KinesisFirehose2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KinesisFirehose2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -37,5 +41,46 @@ public class KinesisFirehose2EndpointConfigurer extends PropertyConfigurerSuppor
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisFirehoseClient", software.amazon.awssdk.services.firehose.FirehoseClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KinesisFirehose2Endpoint target = (KinesisFirehose2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonkinesisfirehoseclient":
+        case "amazonKinesisFirehoseClient": target.getConfiguration().getAmazonKinesisFirehoseClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java
index 2679dec4..3129769 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.kinesis;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Kinesis2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Kinesis2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.kinesis.Kinesis2Configuration getOrCreateConfiguration(Kinesis2Component target) {
         if (target.getConfiguration() == null) {
@@ -56,5 +60,64 @@ public class Kinesis2ComponentConfigurer extends PropertyConfigurerSupport imple
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisClient", software.amazon.awssdk.services.kinesis.KinesisClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.kinesis.Kinesis2Configuration.class);
+        answer.put("iteratorType", software.amazon.awssdk.services.kinesis.model.ShardIteratorType.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sequenceNumber", java.lang.String.class);
+        answer.put("shardClosed", org.apache.camel.component.aws2.kinesis.Kinesis2ShardClosedStrategyEnum.class);
+        answer.put("shardId", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Kinesis2Component target = (Kinesis2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonkinesisclient":
+        case "amazonKinesisClient": getOrCreateConfiguration(target).getAmazonKinesisClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "iteratortype":
+        case "iteratorType": getOrCreateConfiguration(target).getIteratorType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": getOrCreateConfiguration(target).getMaxResultsPerRequest(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "sequencenumber":
+        case "sequenceNumber": getOrCreateConfiguration(target).getSequenceNumber(); return true;
+        case "shardclosed":
+        case "shardClosed": getOrCreateConfiguration(target).getShardClosed(); return true;
+        case "shardid":
+        case "shardId": getOrCreateConfiguration(target).getShardId(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java
index a0e0576..ab3f7f1 100644
--- a/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java
+++ b/components/camel-aws2-kinesis/src/generated/java/org/apache/camel/component/aws2/kinesis/Kinesis2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.kinesis;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Kinesis2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Kinesis2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -82,5 +86,115 @@ public class Kinesis2EndpointConfigurer extends PropertyConfigurerSupport implem
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonKinesisClient", software.amazon.awssdk.services.kinesis.KinesisClient.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("greedy", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("iteratorType", software.amazon.awssdk.services.kinesis.model.ShardIteratorType.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxResultsPerRequest", int.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("sequenceNumber", java.lang.String.class);
+        answer.put("shardClosed", org.apache.camel.component.aws2.kinesis.Kinesis2ShardClosedStrategyEnum.class);
+        answer.put("shardId", java.lang.String.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("useFixedDelay", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Kinesis2Endpoint target = (Kinesis2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonkinesisclient":
+        case "amazonKinesisClient": target.getConfiguration().getAmazonKinesisClient(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "delay": target.getDelay(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "iteratortype":
+        case "iteratorType": target.getConfiguration().getIteratorType(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": target.getConfiguration().getMaxResultsPerRequest(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "sequencenumber":
+        case "sequenceNumber": target.getConfiguration().getSequenceNumber(); return true;
+        case "shardclosed":
+        case "shardClosed": target.getConfiguration().getShardClosed(); return true;
+        case "shardid":
+        case "shardId": target.getConfiguration().getShardId(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java
index 2c50699..fd53ca5 100644
--- a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java
+++ b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.kms;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KMS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KMS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.kms.KMS2Configuration getOrCreateConfiguration(KMS2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class KMS2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.kms.KMS2Configuration.class);
+        answer.put("kmsClient", software.amazon.awssdk.services.kms.KmsClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.kms.KMS2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KMS2Component target = (KMS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "kmsclient":
+        case "kmsClient": getOrCreateConfiguration(target).getKmsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java
index f0dd544..95656fe 100644
--- a/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java
+++ b/components/camel-aws2-kms/src/generated/java/org/apache/camel/component/aws2/kms/KMS2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.kms;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class KMS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class KMS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class KMS2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("kmsClient", software.amazon.awssdk.services.kms.KmsClient.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.kms.KMS2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        KMS2Endpoint target = (KMS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "kmsclient":
+        case "kmsClient": target.getConfiguration().getKmsClient(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java
index 6eff5af..6ceae12 100644
--- a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java
+++ b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.lambda;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Lambda2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Lambda2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.lambda.Lambda2Configuration getOrCreateConfiguration(Lambda2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class Lambda2ComponentConfigurer extends PropertyConfigurerSupport implem
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("awsLambdaClient", software.amazon.awssdk.services.lambda.LambdaClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.lambda.Lambda2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.lambda.Lambda2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Lambda2Component target = (Lambda2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "awslambdaclient":
+        case "awsLambdaClient": getOrCreateConfiguration(target).getAwsLambdaClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java
index 907835d..d5a1891 100644
--- a/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java
+++ b/components/camel-aws2-lambda/src/generated/java/org/apache/camel/component/aws2/lambda/Lambda2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.lambda;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Lambda2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Lambda2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class Lambda2EndpointConfigurer extends PropertyConfigurerSupport impleme
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("awsLambdaClient", software.amazon.awssdk.services.lambda.LambdaClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.lambda.Lambda2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Lambda2Endpoint target = (Lambda2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "awslambdaclient":
+        case "awsLambdaClient": target.getConfiguration().getAwsLambdaClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java
index 0999072..67e2462 100644
--- a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java
+++ b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.mq;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MQ2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MQ2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.mq.MQ2Configuration getOrCreateConfiguration(MQ2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class MQ2ComponentConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonMqClient", software.amazon.awssdk.services.mq.MqClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.mq.MQ2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.mq.MQ2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MQ2Component target = (MQ2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonmqclient":
+        case "amazonMqClient": getOrCreateConfiguration(target).getAmazonMqClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java
index 6c1cfe3..2d9e1c6 100644
--- a/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java
+++ b/components/camel-aws2-mq/src/generated/java/org/apache/camel/component/aws2/mq/MQ2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.mq;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MQ2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MQ2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class MQ2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonMqClient", software.amazon.awssdk.services.mq.MqClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.mq.MQ2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MQ2Endpoint target = (MQ2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonmqclient":
+        case "amazonMqClient": target.getConfiguration().getAmazonMqClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java
index fa5d019..701fd54 100644
--- a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java
+++ b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.msk;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MSK2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MSK2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.msk.MSK2Configuration getOrCreateConfiguration(MSK2Component target) {
         if (target.getConfiguration() == null) {
@@ -45,5 +49,48 @@ public class MSK2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.msk.MSK2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("mskClient", software.amazon.awssdk.services.kafka.KafkaClient.class);
+        answer.put("operation", org.apache.camel.component.aws2.msk.MSK2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MSK2Component target = (MSK2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "mskclient":
+        case "mskClient": getOrCreateConfiguration(target).getMskClient(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java
index db39c68..022ae52 100644
--- a/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java
+++ b/components/camel-aws2-msk/src/generated/java/org/apache/camel/component/aws2/msk/MSK2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.msk;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class MSK2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class MSK2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -38,5 +42,48 @@ public class MSK2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("mskClient", software.amazon.awssdk.services.kafka.KafkaClient.class);
+        answer.put("operation", org.apache.camel.component.aws2.msk.MSK2Operations.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        MSK2Endpoint target = (MSK2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "mskclient":
+        case "mskClient": target.getConfiguration().getMskClient(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java
index 3a1c86a..41ba0de 100644
--- a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java
+++ b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.s3;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AWS2S3ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AWS2S3ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.s3.AWS2S3Configuration getOrCreateConfiguration(AWS2S3Component target) {
         if (target.getConfiguration() == null) {
@@ -80,5 +84,102 @@ public class AWS2S3ComponentConfigurer extends PropertyConfigurerSupport impleme
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonS3Client", software.amazon.awssdk.services.s3.S3Client.class);
+        answer.put("autoCreateBucket", boolean.class);
+        answer.put("autocloseBody", boolean.class);
+        answer.put("awsKMSKeyId", java.lang.String.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.s3.AWS2S3Configuration.class);
+        answer.put("deleteAfterRead", boolean.class);
+        answer.put("deleteAfterWrite", boolean.class);
+        answer.put("delimiter", java.lang.String.class);
+        answer.put("fileName", java.lang.String.class);
+        answer.put("includeBody", boolean.class);
+        answer.put("keyName", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("multiPartUpload", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.s3.AWS2S3Operations.class);
+        answer.put("overrideEndpoint", boolean.class);
+        answer.put("partSize", long.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("prefix", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("storageClass", java.lang.String.class);
+        answer.put("uriEndpointOverride", java.lang.String.class);
+        answer.put("useAwsKMS", boolean.class);
+        answer.put("useIAMCredentials", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AWS2S3Component target = (AWS2S3Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazons3client":
+        case "amazonS3Client": getOrCreateConfiguration(target).getAmazonS3Client(); return true;
+        case "autocreatebucket":
+        case "autoCreateBucket": getOrCreateConfiguration(target).isAutoCreateBucket(); return true;
+        case "autoclosebody":
+        case "autocloseBody": getOrCreateConfiguration(target).isAutocloseBody(); return true;
+        case "awskmskeyid":
+        case "awsKMSKeyId": getOrCreateConfiguration(target).getAwsKMSKeyId(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": getOrCreateConfiguration(target).isDeleteAfterRead(); return true;
+        case "deleteafterwrite":
+        case "deleteAfterWrite": getOrCreateConfiguration(target).isDeleteAfterWrite(); return true;
+        case "delimiter": getOrCreateConfiguration(target).getDelimiter(); return true;
+        case "filename":
+        case "fileName": getOrCreateConfiguration(target).getFileName(); return true;
+        case "includebody":
+        case "includeBody": getOrCreateConfiguration(target).isIncludeBody(); return true;
+        case "keyname":
+        case "keyName": getOrCreateConfiguration(target).getKeyName(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "multipartupload":
+        case "multiPartUpload": getOrCreateConfiguration(target).isMultiPartUpload(); return true;
+        case "operation": getOrCreateConfiguration(target).getOperation(); return true;
+        case "overrideendpoint":
+        case "overrideEndpoint": getOrCreateConfiguration(target).isOverrideEndpoint(); return true;
+        case "partsize":
+        case "partSize": getOrCreateConfiguration(target).getPartSize(); return true;
+        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
+        case "prefix": getOrCreateConfiguration(target).getPrefix(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "storageclass":
+        case "storageClass": getOrCreateConfiguration(target).getStorageClass(); return true;
+        case "uriendpointoverride":
+        case "uriEndpointOverride": getOrCreateConfiguration(target).getUriEndpointOverride(); return true;
+        case "useawskms":
+        case "useAwsKMS": getOrCreateConfiguration(target).isUseAwsKMS(); return true;
+        case "useiamcredentials":
+        case "useIAMCredentials": getOrCreateConfiguration(target).isUseIAMCredentials(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java
index f62ba82..acd5708 100644
--- a/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java
+++ b/components/camel-aws2-s3/src/generated/java/org/apache/camel/component/aws2/s3/AWS2S3EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.s3;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class AWS2S3EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class AWS2S3EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -110,5 +114,159 @@ public class AWS2S3EndpointConfigurer extends PropertyConfigurerSupport implemen
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonS3Client", software.amazon.awssdk.services.s3.S3Client.class);
+        answer.put("autoCreateBucket", boolean.class);
+        answer.put("autocloseBody", boolean.class);
+        answer.put("awsKMSKeyId", java.lang.String.class);
+        answer.put("backoffErrorThreshold", int.class);
+        answer.put("backoffIdleThreshold", int.class);
+        answer.put("backoffMultiplier", int.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("bridgeErrorHandler", boolean.class);
+        answer.put("delay", long.class);
+        answer.put("deleteAfterRead", boolean.class);
+        answer.put("deleteAfterWrite", boolean.class);
+        answer.put("delimiter", java.lang.String.class);
+        answer.put("exceptionHandler", org.apache.camel.spi.ExceptionHandler.class);
+        answer.put("exchangePattern", org.apache.camel.ExchangePattern.class);
+        answer.put("fileName", java.lang.String.class);
+        answer.put("greedy", boolean.class);
+        answer.put("includeBody", boolean.class);
+        answer.put("initialDelay", long.class);
+        answer.put("keyName", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("maxConnections", int.class);
+        answer.put("maxMessagesPerPoll", int.class);
+        answer.put("multiPartUpload", boolean.class);
+        answer.put("operation", org.apache.camel.component.aws2.s3.AWS2S3Operations.class);
+        answer.put("overrideEndpoint", boolean.class);
+        answer.put("partSize", long.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("pollStrategy", org.apache.camel.spi.PollingConsumerPollStrategy.class);
+        answer.put("prefix", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("repeatCount", long.class);
+        answer.put("runLoggingLevel", org.apache.camel.LoggingLevel.class);
+        answer.put("scheduledExecutorService", java.util.concurrent.ScheduledExecutorService.class);
+        answer.put("scheduler", java.lang.String.class);
+        answer.put("schedulerProperties", java.util.Map.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("sendEmptyMessageWhenIdle", boolean.class);
+        answer.put("startScheduler", boolean.class);
+        answer.put("storageClass", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("timeUnit", java.util.concurrent.TimeUnit.class);
+        answer.put("uriEndpointOverride", java.lang.String.class);
+        answer.put("useAwsKMS", boolean.class);
+        answer.put("useFixedDelay", boolean.class);
+        answer.put("useIAMCredentials", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        AWS2S3Endpoint target = (AWS2S3Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazons3client":
+        case "amazonS3Client": target.getConfiguration().getAmazonS3Client(); return true;
+        case "autocreatebucket":
+        case "autoCreateBucket": target.getConfiguration().isAutoCreateBucket(); return true;
+        case "autoclosebody":
+        case "autocloseBody": target.getConfiguration().isAutocloseBody(); return true;
+        case "awskmskeyid":
+        case "awsKMSKeyId": target.getConfiguration().getAwsKMSKeyId(); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.getBackoffErrorThreshold(); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.getBackoffIdleThreshold(); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.getBackoffMultiplier(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.isBridgeErrorHandler(); return true;
+        case "delay": target.getDelay(); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": target.getConfiguration().isDeleteAfterRead(); return true;
+        case "deleteafterwrite":
+        case "deleteAfterWrite": target.getConfiguration().isDeleteAfterWrite(); return true;
+        case "delimiter": target.getConfiguration().getDelimiter(); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.getExceptionHandler(); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.getExchangePattern(); return true;
+        case "filename":
+        case "fileName": target.getConfiguration().getFileName(); return true;
+        case "greedy": target.isGreedy(); return true;
+        case "includebody":
+        case "includeBody": target.getConfiguration().isIncludeBody(); return true;
+        case "initialdelay":
+        case "initialDelay": target.getInitialDelay(); return true;
+        case "keyname":
+        case "keyName": target.getConfiguration().getKeyName(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "maxconnections":
+        case "maxConnections": target.getMaxConnections(); return true;
+        case "maxmessagesperpoll":
+        case "maxMessagesPerPoll": target.getMaxMessagesPerPoll(); return true;
+        case "multipartupload":
+        case "multiPartUpload": target.getConfiguration().isMultiPartUpload(); return true;
+        case "operation": target.getConfiguration().getOperation(); return true;
+        case "overrideendpoint":
+        case "overrideEndpoint": target.getConfiguration().isOverrideEndpoint(); return true;
+        case "partsize":
+        case "partSize": target.getConfiguration().getPartSize(); return true;
+        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.getPollStrategy(); return true;
+        case "prefix": target.getConfiguration().getPrefix(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "repeatcount":
+        case "repeatCount": target.getRepeatCount(); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.getRunLoggingLevel(); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.getScheduledExecutorService(); return true;
+        case "scheduler": target.getScheduler(); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.getSchedulerProperties(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.isSendEmptyMessageWhenIdle(); return true;
+        case "startscheduler":
+        case "startScheduler": target.isStartScheduler(); return true;
+        case "storageclass":
+        case "storageClass": target.getConfiguration().getStorageClass(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "timeunit":
+        case "timeUnit": target.getTimeUnit(); return true;
+        case "uriendpointoverride":
+        case "uriEndpointOverride": target.getConfiguration().getUriEndpointOverride(); return true;
+        case "useawskms":
+        case "useAwsKMS": target.getConfiguration().isUseAwsKMS(); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.isUseFixedDelay(); return true;
+        case "useiamcredentials":
+        case "useIAMCredentials": target.getConfiguration().isUseIAMCredentials(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java
index 318b0ca..f5499e5 100644
--- a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java
+++ b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ses;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Ses2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Ses2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.ses.Ses2Configuration getOrCreateConfiguration(Ses2Component target) {
         if (target.getConfiguration() == null) {
@@ -50,5 +54,56 @@ public class Ses2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSESClient", software.amazon.awssdk.services.ses.SesClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.ses.Ses2Configuration.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("replyToAddresses", java.util.List.class);
+        answer.put("returnPath", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("to", java.util.List.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Ses2Component target = (Ses2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonsesclient":
+        case "amazonSESClient": getOrCreateConfiguration(target).getAmazonSESClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "replytoaddresses":
+        case "replyToAddresses": getOrCreateConfiguration(target).getReplyToAddresses(); return true;
+        case "returnpath":
+        case "returnPath": getOrCreateConfiguration(target).getReturnPath(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
+        case "to": getOrCreateConfiguration(target).getTo(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java
index 569a504..7805f9c 100644
--- a/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java
+++ b/components/camel-aws2-ses/src/generated/java/org/apache/camel/component/aws2/ses/Ses2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.ses;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Ses2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Ses2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -43,5 +47,56 @@ public class Ses2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSESClient", software.amazon.awssdk.services.ses.SesClient.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("replyToAddresses", java.util.List.class);
+        answer.put("returnPath", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("synchronous", boolean.class);
+        answer.put("to", java.util.List.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Ses2Endpoint target = (Ses2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonsesclient":
+        case "amazonSESClient": target.getConfiguration().getAmazonSESClient(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "replytoaddresses":
+        case "replyToAddresses": target.getConfiguration().getReplyToAddresses(); return true;
+        case "returnpath":
+        case "returnPath": target.getConfiguration().getReturnPath(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "subject": target.getConfiguration().getSubject(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        case "to": target.getConfiguration().getTo(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java
index cf2c91f..208b6f9 100644
--- a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java
+++ b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.sns;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Sns2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Sns2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.sns.Sns2Configuration getOrCreateConfiguration(Sns2Component target) {
         if (target.getConfiguration() == null) {
@@ -58,5 +62,68 @@ public class Sns2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSNSClient", software.amazon.awssdk.services.sns.SnsClient.class);
+        answer.put("autoCreateTopic", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("configuration", org.apache.camel.component.aws2.sns.Sns2Configuration.class);
+        answer.put("kmsMasterKeyId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("messageStructure", java.lang.String.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("queueUrl", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("serverSideEncryptionEnabled", boolean.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("subscribeSNStoSQS", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Sns2Component target = (Sns2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": getOrCreateConfiguration(target).getAccessKey(); return true;
+        case "amazonsnsclient":
+        case "amazonSNSClient": getOrCreateConfiguration(target).getAmazonSNSClient(); return true;
+        case "autocreatetopic":
+        case "autoCreateTopic": getOrCreateConfiguration(target).isAutoCreateTopic(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "configuration": target.getConfiguration(); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": getOrCreateConfiguration(target).getKmsMasterKeyId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "messagestructure":
+        case "messageStructure": getOrCreateConfiguration(target).getMessageStructure(); return true;
+        case "policy": getOrCreateConfiguration(target).getPolicy(); return true;
+        case "proxyhost":
+        case "proxyHost": getOrCreateConfiguration(target).getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": getOrCreateConfiguration(target).getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": getOrCreateConfiguration(target).getProxyProtocol(); return true;
+        case "queueurl":
+        case "queueUrl": getOrCreateConfiguration(target).getQueueUrl(); return true;
+        case "region": getOrCreateConfiguration(target).getRegion(); return true;
+        case "secretkey":
+        case "secretKey": getOrCreateConfiguration(target).getSecretKey(); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": getOrCreateConfiguration(target).isServerSideEncryptionEnabled(); return true;
+        case "subject": getOrCreateConfiguration(target).getSubject(); return true;
+        case "subscribesnstosqs":
+        case "subscribeSNStoSQS": getOrCreateConfiguration(target).isSubscribeSNStoSQS(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java
index c8b2e5a..37fac23 100644
--- a/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java
+++ b/components/camel-aws2-sns/src/generated/java/org/apache/camel/component/aws2/sns/Sns2EndpointConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.sns;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Sns2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Sns2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     @Override
     public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
@@ -53,5 +57,71 @@ public class Sns2EndpointConfigurer extends PropertyConfigurerSupport implements
         }
     }
 
+    @Override
+    public Map<String, Object> getAllOptions(Object target) {
+        Map<String, Object> answer = new CaseInsensitiveMap();
+        answer.put("accessKey", java.lang.String.class);
+        answer.put("amazonSNSClient", software.amazon.awssdk.services.sns.SnsClient.class);
+        answer.put("autoCreateTopic", boolean.class);
+        answer.put("basicPropertyBinding", boolean.class);
+        answer.put("headerFilterStrategy", org.apache.camel.spi.HeaderFilterStrategy.class);
+        answer.put("kmsMasterKeyId", java.lang.String.class);
+        answer.put("lazyStartProducer", boolean.class);
+        answer.put("messageStructure", java.lang.String.class);
+        answer.put("policy", java.lang.String.class);
+        answer.put("proxyHost", java.lang.String.class);
+        answer.put("proxyPort", java.lang.Integer.class);
+        answer.put("proxyProtocol", software.amazon.awssdk.core.Protocol.class);
+        answer.put("queueUrl", java.lang.String.class);
+        answer.put("region", java.lang.String.class);
+        answer.put("secretKey", java.lang.String.class);
+        answer.put("serverSideEncryptionEnabled", boolean.class);
+        answer.put("subject", java.lang.String.class);
+        answer.put("subscribeSNStoSQS", boolean.class);
+        answer.put("synchronous", boolean.class);
+        return answer;
+    }
+
+    @Override
+    public Object getOptionValue(Object obj, String name, boolean ignoreCase) {
+        Sns2Endpoint target = (Sns2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().getAccessKey(); return true;
+        case "amazonsnsclient":
+        case "amazonSNSClient": target.getConfiguration().getAmazonSNSClient(); return true;
+        case "autocreatetopic":
+        case "autoCreateTopic": target.getConfiguration().isAutoCreateTopic(); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.isBasicPropertyBinding(); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.getHeaderFilterStrategy(); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": target.getConfiguration().getKmsMasterKeyId(); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.isLazyStartProducer(); return true;
+        case "messagestructure":
+        case "messageStructure": target.getConfiguration().getMessageStructure(); return true;
+        case "policy": target.getConfiguration().getPolicy(); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().getProxyHost(); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().getProxyPort(); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().getProxyProtocol(); return true;
+        case "queueurl":
+        case "queueUrl": target.getConfiguration().getQueueUrl(); return true;
+        case "region": target.getConfiguration().getRegion(); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().getSecretKey(); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": target.getConfiguration().isServerSideEncryptionEnabled(); return true;
+        case "subject": target.getConfiguration().getSubject(); return true;
+        case "subscribesnstosqs":
+        case "subscribeSNStoSQS": target.getConfiguration().isSubscribeSNStoSQS(); return true;
+        case "synchronous": target.isSynchronous(); return true;
+        default: return null;
+        }
+    }
 }
 
diff --git a/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java b/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java
index 858af5a..654dd5f 100644
--- a/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java
+++ b/components/camel-aws2-sqs/src/generated/java/org/apache/camel/component/aws2/sqs/Sqs2ComponentConfigurer.java
@@ -1,15 +1,19 @@
 /* Generated by camel build tools - do NOT edit this file! */
 package org.apache.camel.component.aws2.sqs;
 
+import java.util.Map;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.spi.GeneratedPropertyConfigurer;
+import org.apache.camel.spi.PropertyConfigurerGetter;
+import org.apache.camel.util.CaseInsensitiveMap;
 import org.apache.camel.support.component.PropertyConfigurerSupport;
 
 /**
  * Generated by camel build tools - do NOT edit this file!
  */
 @SuppressWarnings("unchecked")
-public class Sqs2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
+public class Sqs2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer, PropertyConfigurerGetter {
 
     private org.apache.camel.component.aws2.sqs.Sqs2Configuration getOrCreateConfiguration(Sqs2Component target) {
         if (target.getConfiguration() == null) {
@@ -97,5 +101,127 @@ public class Sqs2ComponentConfigurer extends PropertyConfigurerSupport implement
         }
     }
... 47877 lines suppressed ...


[camel] 04/13: Make camel-debezium generate boolean getter with isXXX name instead of getXXX

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

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

commit 1bdfcfe3a0db366d961d89ac2fa0a80c7fb51cb6
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 00:59:28 2020 +0100

    Make camel-debezium generate boolean getter with isXXX name instead of getXXX
---
 .../org/apache/camel/maven/config/ConnectorConfigField.java    | 10 +++++++---
 1 file changed, 7 insertions(+), 3 deletions(-)

diff --git a/components/camel-debezium-common/camel-debezium-maven-plugin/src/main/java/org/apache/camel/maven/config/ConnectorConfigField.java b/components/camel-debezium-common/camel-debezium-maven-plugin/src/main/java/org/apache/camel/maven/config/ConnectorConfigField.java
index 8f06e95..30c6d8c 100644
--- a/components/camel-debezium-common/camel-debezium-maven-plugin/src/main/java/org/apache/camel/maven/config/ConnectorConfigField.java
+++ b/components/camel-debezium-common/camel-debezium-maven-plugin/src/main/java/org/apache/camel/maven/config/ConnectorConfigField.java
@@ -53,7 +53,7 @@ public class ConnectorConfigField {
     }
 
     public String getFieldGetterMethodName() {
-        return getGetterMethodName(fieldDef.name);
+        return getGetterMethodName(fieldDef.name, fieldDef.type);
     }
 
     public Class<?> getRawType() {
@@ -94,8 +94,12 @@ public class ConnectorConfigField {
         return getCamelCase("set." + name);
     }
 
-    private String getGetterMethodName(final String name) {
-        return getCamelCase("get." + name);
+    private String getGetterMethodName(final String name, ConfigDef.Type type) {
+        if (type == ConfigDef.Type.BOOLEAN) {
+            return getCamelCase("is." + name);
+        } else {
+            return getCamelCase("get." + name);
+        }
     }
 
     private String getCamelCase(final String name) {


[camel] 05/13: CAMEL-14762: camel-core - Configurer to include API for method name and type

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

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

commit 81fb703e430912f78616113b26008daafb86af35
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Sun Mar 22 01:07:23 2020 +0100

    CAMEL-14762: camel-core - Configurer to include API for method name and type
---
 .../org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java   | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
index 5a26889..a02d964 100644
--- a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
+++ b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/PropertyConfigurerGenerator.java
@@ -125,7 +125,7 @@ public final class PropertyConfigurerGenerator {
                     if (!option.getName().toLowerCase().equals(option.getName())) {
                         w.write(String.format("        case \"%s\":\n", option.getName().toLowerCase()));
                     }
-                    w.write(String.format("        case \"%s\": %s; return true;\n", option.getName(), getterLambda));
+                    w.write(String.format("        case \"%s\": return %s;\n", option.getName(), getterLambda));
                 }
                 if (hasSuper) {
                     w.write("        default: return super.getOptionValue(obj, name, ignoreCase);\n");