You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by gn...@apache.org on 2020/02/05 08:58:41 UTC

[camel] branch master updated (9991812 -> a4ef937)

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

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


    from 9991812  Upgrade Spring-Data-keyvalue to version 2.2.4.RELEASE_1
     new 519f5a5  Reduce the size of the generated component/endpoint configurers by using a single switch statement
     new c03c4ff  Keep the generated jaxb files in git
     new f5fd9ec  Fix components generation
     new a4ef937  Regen

The 4 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:
 .../component/ahc/ws/WsComponentConfigurer.java    |  59 +--
 .../component/ahc/ws/WsEndpointConfigurer.java     |  99 ++---
 .../component/ahc/AhcComponentConfigurer.java      |  55 +--
 .../camel/component/ahc/AhcEndpointConfigurer.java |  79 ++--
 .../component/apns/ApnsComponentConfigurer.java    |  37 +-
 .../component/apns/ApnsEndpointConfigurer.java     | 108 ++---
 .../component/as2/AS2ComponentConfigurer.java      |  36 +-
 .../camel/component/as2/AS2EndpointConfigurer.java | 210 +++++-----
 .../asterisk/AsteriskComponentConfigurer.java      |  33 +-
 .../asterisk/AsteriskEndpointConfigurer.java       |  56 +--
 .../component/atmos/AtmosComponentConfigurer.java  |  48 +--
 .../component/atmos/AtmosEndpointConfigurer.java   |  74 ++--
 .../websocket/WebsocketComponentConfigurer.java    |  65 ++-
 .../websocket/WebsocketEndpointConfigurer.java     | 178 ++++----
 .../component/atom/AtomComponentConfigurer.java    |  29 +-
 .../component/atom/AtomEndpointConfigurer.java     | 130 +++---
 .../client/map/AtomixMapComponentConfigurer.java   |  46 +-
 .../client/map/AtomixMapEndpointConfigurer.java    |  95 ++---
 .../AtomixMessagingComponentConfigurer.java        |  46 +-
 .../AtomixMessagingEndpointConfigurer.java         | 101 ++---
 .../AtomixMultiMapComponentConfigurer.java         |  42 +-
 .../multimap/AtomixMultiMapEndpointConfigurer.java |  83 ++--
 .../queue/AtomixQueueComponentConfigurer.java      |  46 +-
 .../queue/AtomixQueueEndpointConfigurer.java       |  89 ++--
 .../client/set/AtomixSetComponentConfigurer.java   |  46 +-
 .../client/set/AtomixSetEndpointConfigurer.java    |  92 ++--
 .../value/AtomixValueComponentConfigurer.java      |  46 +-
 .../value/AtomixValueEndpointConfigurer.java       |  92 ++--
 .../component/avro/AvroComponentConfigurer.java    |  36 +-
 .../component/avro/AvroEndpointConfigurer.java     |  67 ++-
 .../component/aws/cw/CwComponentConfigurer.java    |  43 +-
 .../component/aws/cw/CwEndpointConfigurer.java     |  71 ++--
 .../component/aws/ddb/DdbComponentConfigurer.java  |  43 +-
 .../component/aws/ddb/DdbEndpointConfigurer.java   |  82 ++--
 .../ddbstream/DdbStreamComponentConfigurer.java    |  43 +-
 .../aws/ddbstream/DdbStreamEndpointConfigurer.java | 140 +++----
 .../component/aws/ec2/EC2ComponentConfigurer.java  |  43 +-
 .../component/aws/ec2/EC2EndpointConfigurer.java   |  62 +--
 .../component/aws/ecs/ECSComponentConfigurer.java  |  43 +-
 .../component/aws/ecs/ECSEndpointConfigurer.java   |  62 +--
 .../component/aws/eks/EKSComponentConfigurer.java  |  43 +-
 .../component/aws/eks/EKSEndpointConfigurer.java   |  62 +--
 .../component/aws/iam/IAMComponentConfigurer.java  |  43 +-
 .../component/aws/iam/IAMEndpointConfigurer.java   |  62 +--
 .../KinesisFirehoseComponentConfigurer.java        |  43 +-
 .../KinesisFirehoseEndpointConfigurer.java         |  59 +--
 .../aws/kinesis/KinesisComponentConfigurer.java    |  47 +--
 .../aws/kinesis/KinesisEndpointConfigurer.java     | 152 +++----
 .../component/aws/kms/KMSComponentConfigurer.java  |  43 +-
 .../component/aws/kms/KMSEndpointConfigurer.java   |  62 +--
 .../aws/lambda/LambdaComponentConfigurer.java      |  43 +-
 .../aws/lambda/LambdaEndpointConfigurer.java       |  62 +--
 .../component/aws/mq/MQComponentConfigurer.java    |  43 +-
 .../component/aws/mq/MQEndpointConfigurer.java     |  62 +--
 .../component/aws/msk/MSKComponentConfigurer.java  |  43 +-
 .../component/aws/msk/MSKEndpointConfigurer.java   |  62 +--
 .../component/aws/s3/S3ComponentConfigurer.java    |  47 +--
 .../component/aws/s3/S3EndpointConfigurer.java     | 240 +++++------
 .../component/aws/sdb/SdbComponentConfigurer.java  |  29 +-
 .../component/aws/sdb/SdbEndpointConfigurer.java   |  70 ++--
 .../component/aws/ses/SesComponentConfigurer.java  |  43 +-
 .../component/aws/ses/SesEndpointConfigurer.java   |  73 ++--
 .../component/aws/sns/SnsComponentConfigurer.java  |  43 +-
 .../component/aws/sns/SnsEndpointConfigurer.java   |  97 ++---
 .../component/aws/sqs/SqsComponentConfigurer.java  |  47 +--
 .../component/aws/sqs/SqsEndpointConfigurer.java   | 245 +++++------
 .../component/aws/swf/SWFComponentConfigurer.java  |  47 +--
 .../component/aws/swf/SWFEndpointConfigurer.java   | 145 +++----
 .../translate/TranslateComponentConfigurer.java    |  43 +-
 .../aws/translate/TranslateEndpointConfigurer.java |  74 ++--
 .../aws2/ecs/ECS2ComponentConfigurer.java          |  43 +-
 .../component/aws2/ecs/ECS2EndpointConfigurer.java |  62 +--
 .../aws2/eks/EKS2ComponentConfigurer.java          |  43 +-
 .../component/aws2/eks/EKS2EndpointConfigurer.java |  62 +--
 .../aws2/kms/KMS2ComponentConfigurer.java          |  43 +-
 .../component/aws2/kms/KMS2EndpointConfigurer.java |  62 +--
 .../component/aws2/mq/MQ2ComponentConfigurer.java  |  43 +-
 .../component/aws2/mq/MQ2EndpointConfigurer.java   |  62 +--
 .../aws2/msk/MSK2ComponentConfigurer.java          |  43 +-
 .../component/aws2/msk/MSK2EndpointConfigurer.java |  62 +--
 .../translate/Translate2ComponentConfigurer.java   |  43 +-
 .../translate/Translate2EndpointConfigurer.java    |  74 ++--
 .../azure/blob/BlobServiceComponentConfigurer.java |  36 +-
 .../azure/blob/BlobServiceEndpointConfigurer.java  | 102 ++---
 .../queue/QueueServiceComponentConfigurer.java     |  36 +-
 .../queue/QueueServiceEndpointConfigurer.java      |  66 ++-
 .../BeanValidatorComponentConfigurer.java          |  49 +--
 .../validator/BeanValidatorEndpointConfigurer.java |  59 +--
 .../component/bean/BeanComponentConfigurer.java    |  35 +-
 .../component/bean/BeanEndpointConfigurer.java     |  44 +-
 .../beanclass/ClassComponentConfigurer.java        |  35 +-
 .../beanclass/ClassEndpointConfigurer.java         |  44 +-
 .../beanstalk/BeanstalkComponentConfigurer.java    |  37 +-
 .../beanstalk/BeanstalkEndpointConfigurer.java     | 132 +++---
 .../bonita/BonitaComponentConfigurer.java          |  29 +-
 .../component/bonita/BonitaEndpointConfigurer.java |  48 +--
 .../component/box/BoxComponentConfigurer.java      |  36 +-
 .../camel/component/box/BoxEndpointConfigurer.java | 169 ++++----
 .../braintree/BraintreeComponentConfigurer.java    |  40 +-
 .../braintree/BraintreeEndpointConfigurer.java     | 148 +++----
 .../browse/BrowseComponentConfigurer.java          |  33 +-
 .../component/browse/BrowseEndpointConfigurer.java |  44 +-
 .../cache/CaffeineCacheComponentConfigurer.java    |  32 +-
 .../cache/CaffeineCacheEndpointConfigurer.java     |  89 ++--
 .../load/CaffeineLoadCacheComponentConfigurer.java |  32 +-
 .../load/CaffeineLoadCacheEndpointConfigurer.java  |  89 ++--
 .../cassandra/CassandraComponentConfigurer.java    |  33 +-
 .../cassandra/CassandraEndpointConfigurer.java     | 140 +++----
 .../chatscript/ChatScriptComponentConfigurer.java  |  29 +-
 .../chatscript/ChatScriptEndpointConfigurer.java   |  40 +-
 .../component/chunk/ChunkComponentConfigurer.java  |  29 +-
 .../component/chunk/ChunkEndpointConfigurer.java   |  54 +--
 .../camel/component/cm/CMComponentConfigurer.java  |  29 +-
 .../camel/component/cm/CMEndpointConfigurer.java   |  48 +--
 .../component/cmis/CMISComponentConfigurer.java    |  37 +-
 .../component/cmis/CMISEndpointConfigurer.java     |  77 ++--
 .../apache/camel/coap/CoAPComponentConfigurer.java |  33 +-
 .../apache/camel/coap/CoAPEndpointConfigurer.java  |  83 ++--
 .../cometd/CometdComponentConfigurer.java          |  60 +--
 .../component/cometd/CometdEndpointConfigurer.java |  90 ++--
 .../consul/ConsulComponentConfigurer.java          |  61 +--
 .../component/consul/ConsulEndpointConfigurer.java | 121 +++---
 .../controlbus/ControlBusComponentConfigurer.java  |  29 +-
 .../controlbus/ControlBusEndpointConfigurer.java   |  50 +--
 .../component/corda/CordaComponentConfigurer.java  |  36 +-
 .../component/corda/CordaEndpointConfigurer.java   |  53 +--
 .../couchbase/CouchbaseComponentConfigurer.java    |  33 +-
 .../couchbase/CouchbaseEndpointConfigurer.java     | 209 ++++-----
 .../couchdb/CouchDbComponentConfigurer.java        |  33 +-
 .../couchdb/CouchDbEndpointConfigurer.java         |  69 ++-
 .../component/cron/CronComponentConfigurer.java    |  33 +-
 .../component/cron/CronEndpointConfigurer.java     |  43 +-
 .../crypto/cms/CryptoCmsComponentConfigurer.java   |  37 +-
 .../crypto/cms/CryptoCmsEndpointConfigurer.java    |  85 ++--
 .../DigitalSignatureComponentConfigurer.java       |  32 +-
 .../crypto/DigitalSignatureEndpointConfigurer.java |  98 ++---
 .../component/cxf/CxfComponentConfigurer.java      |  45 +-
 .../camel/component/cxf/CxfEndpointConfigurer.java | 159 ++++---
 .../cxf/jaxrs/CxfRsComponentConfigurer.java        |  41 +-
 .../cxf/jaxrs/CxfRsEndpointConfigurer.java         | 144 +++----
 .../dataformat/DataFormatComponentConfigurer.java  |  29 +-
 .../dataformat/DataFormatEndpointConfigurer.java   |  32 +-
 .../dataset/DataSetComponentConfigurer.java        |  33 +-
 .../dataset/DataSetEndpointConfigurer.java         | 108 +++--
 .../dataset/DataSetTestComponentConfigurer.java    |  29 +-
 .../dataset/DataSetTestEndpointConfigurer.java     |  85 ++--
 .../DebeziumMongodbComponentConfigurer.java        |  32 +-
 .../DebeziumMongodbEndpointConfigurer.java         | 196 ++++-----
 .../debezium/DebeziumMySqlComponentConfigurer.java |  32 +-
 .../debezium/DebeziumMySqlEndpointConfigurer.java  | 316 +++++++-------
 .../DebeziumPostgresComponentConfigurer.java       |  32 +-
 .../DebeziumPostgresEndpointConfigurer.java        | 284 ++++++-------
 .../DebeziumSqlserverComponentConfigurer.java      |  32 +-
 .../DebeziumSqlserverEndpointConfigurer.java       | 212 +++++-----
 .../DigitalOceanComponentConfigurer.java           |  29 +-
 .../DigitalOceanEndpointConfigurer.java            |  66 ++-
 .../direct/DirectComponentConfigurer.java          |  39 +-
 .../component/direct/DirectEndpointConfigurer.java |  54 +--
 .../directvm/DirectVmComponentConfigurer.java      |  47 +--
 .../directvm/DirectVmEndpointConfigurer.java       |  62 +--
 .../disruptor/DisruptorComponentConfigurer.java    |  61 ++-
 .../disruptor/DisruptorEndpointConfigurer.java     |  74 ++--
 .../component/dns/DnsComponentConfigurer.java      |  29 +-
 .../camel/component/dns/DnsEndpointConfigurer.java |  32 +-
 .../docker/DockerComponentConfigurer.java          |  36 +-
 .../component/docker/DockerEndpointConfigurer.java | 101 ++---
 .../component/dozer/DozerComponentConfigurer.java  |  29 +-
 .../component/dozer/DozerEndpointConfigurer.java   |  56 +--
 .../component/drill/DrillComponentConfigurer.java  |  29 +-
 .../component/drill/DrillEndpointConfigurer.java   |  45 +-
 .../dropbox/DropboxComponentConfigurer.java        |  33 +-
 .../dropbox/DropboxEndpointConfigurer.java         |  74 ++--
 .../ehcache/EhcacheComponentConfigurer.java        |  56 +--
 .../ehcache/EhcacheEndpointConfigurer.java         |  92 ++--
 .../ElasticsearchComponentConfigurer.java          |  70 ++--
 .../ElasticsearchEndpointConfigurer.java           |  86 ++--
 .../component/elsql/ElsqlComponentConfigurer.java  |  49 +--
 .../component/elsql/ElsqlEndpointConfigurer.java   | 212 +++++-----
 .../elytron/ElytronComponentConfigurer.java        |  65 ++-
 .../elytron/ElytronEndpointConfigurer.java         | 134 +++---
 .../AbstractEtcdPollingEndpointConfigurer.java     | 141 +++----
 .../component/etcd/EtcdComponentConfigurer.java    |  54 +--
 .../eventadmin/EventAdminComponentConfigurer.java  |  37 +-
 .../eventadmin/EventAdminEndpointConfigurer.java   |  47 +--
 .../component/exec/ExecComponentConfigurer.java    |  29 +-
 .../component/exec/ExecEndpointConfigurer.java     |  61 +--
 .../facebook/FacebookComponentConfigurer.java      |  36 +-
 .../facebook/FacebookEndpointConfigurer.java       | 419 +++++++++---------
 .../component/file/FileComponentConfigurer.java    |  33 +-
 .../component/file/FileEndpointConfigurer.java     | 372 ++++++++--------
 .../flatpack/FlatpackComponentConfigurer.java      |  33 +-
 .../flatpack/FlatpackEndpointConfigurer.java       | 128 +++---
 .../component/flink/FlinkComponentConfigurer.java  |  45 +-
 .../component/flink/FlinkEndpointConfigurer.java   |  51 +--
 .../component/fop/FopComponentConfigurer.java      |  29 +-
 .../camel/component/fop/FopEndpointConfigurer.java |  40 +-
 .../freemarker/FreemarkerComponentConfigurer.java  |  32 +-
 .../freemarker/FreemarkerEndpointConfigurer.java   |  46 +-
 .../file/remote/FtpComponentConfigurer.java        |  33 +-
 .../file/remote/FtpEndpointConfigurer.java         | 435 +++++++++----------
 .../file/remote/FtpsComponentConfigurer.java       |  37 +-
 .../file/remote/FtpsEndpointConfigurer.java        | 466 ++++++++++-----------
 .../file/remote/SftpComponentConfigurer.java       |  33 +-
 .../file/remote/SftpEndpointConfigurer.java        | 466 ++++++++++-----------
 .../ganglia/GangliaComponentConfigurer.java        |  32 +-
 .../ganglia/GangliaEndpointConfigurer.java         |  72 ++--
 .../geocoder/GeoCoderComponentConfigurer.java      |  29 +-
 .../geocoder/GeoCoderEndpointConfigurer.java       |  79 ++--
 .../component/git/GitComponentConfigurer.java      |  33 +-
 .../camel/component/git/GitEndpointConfigurer.java |  76 ++--
 .../github/GitHubComponentConfigurer.java          |  33 +-
 .../component/github/GitHubEndpointConfigurer.java |  72 ++--
 .../drive/GoogleDriveComponentConfigurer.java      |  40 +-
 .../drive/GoogleDriveEndpointConfigurer.java       | 136 +++---
 .../component/gora/GoraComponentConfigurer.java    |  33 +-
 .../component/gora/GoraEndpointConfigurer.java     | 109 ++---
 .../component/grape/GrapeComponentConfigurer.java  |  33 +-
 .../component/grape/GrapeEndpointConfigurer.java   |  32 +-
 .../graphql/GraphqlComponentConfigurer.java        |  29 +-
 .../graphql/GraphqlEndpointConfigurer.java         |  60 +--
 .../component/grpc/GrpcComponentConfigurer.java    |  33 +-
 .../component/grpc/GrpcEndpointConfigurer.java     | 127 +++---
 .../component/hbase/HBaseComponentConfigurer.java  |  40 +-
 .../component/hbase/HBaseEndpointConfigurer.java   |  89 ++--
 .../apache/camel/component/hbase/model}/jaxb.index |   3 +-
 .../component/hdfs/HdfsComponentConfigurer.java    |  41 +-
 .../component/hdfs/HdfsEndpointConfigurer.java     | 200 ++++-----
 .../hipchat/HipchatComponentConfigurer.java        |  33 +-
 .../hipchat/HipchatEndpointConfigurer.java         | 117 +++---
 .../component/http/HttpComponentConfigurer.java    |  97 ++---
 .../component/http/HttpEndpointConfigurer.java     | 227 +++++-----
 .../infinispan/InfinispanComponentConfigurer.java  |  40 +-
 .../infinispan/InfinispanEndpointConfigurer.java   |  99 ++---
 .../influxdb/InfluxDbComponentConfigurer.java      |  29 +-
 .../influxdb/InfluxDbEndpointConfigurer.java       |  49 +--
 .../component/iota/IOTAComponentConfigurer.java    |  29 +-
 .../component/iota/IOTAEndpointConfigurer.java     |  52 +--
 .../component/ipfs/IPFSComponentConfigurer.java    |  37 +-
 .../component/ipfs/IPFSEndpointConfigurer.java     |  35 +-
 .../component/irc/IrcComponentConfigurer.java      |  37 +-
 .../camel/component/irc/IrcEndpointConfigurer.java | 128 +++---
 .../ironmq/IronMQComponentConfigurer.java          |  33 +-
 .../component/ironmq/IronMQEndpointConfigurer.java | 145 +++----
 .../component/jbpm/JBPMComponentConfigurer.java    |  33 +-
 .../component/jbpm/JBPMEndpointConfigurer.java     | 137 +++---
 .../jcache/JCacheComponentConfigurer.java          |  53 +--
 .../component/jcache/JCacheEndpointConfigurer.java | 115 +++--
 .../jclouds/JcloudsComponentConfigurer.java        |  41 +-
 .../jclouds/JcloudsEndpointConfigurer.java         |  83 ++--
 .../component/jcr/JcrComponentConfigurer.java      |  33 +-
 .../camel/component/jcr/JcrEndpointConfigurer.java |  80 ++--
 .../component/jdbc/JdbcComponentConfigurer.java    |  33 +-
 .../component/jdbc/JdbcEndpointConfigurer.java     |  78 ++--
 .../jetty9/JettyHttpComponent9Configurer.java      | 148 +++----
 .../jetty9/JettyHttpEndpoint9Configurer.java       | 152 +++----
 .../jgroups/JGroupsComponentConfigurer.java        |  44 +-
 .../jgroups/JGroupsEndpointConfigurer.java         |  52 +--
 .../validator/jing/JingComponentConfigurer.java    |  29 +-
 .../validator/jing/JingEndpointConfigurer.java     |  36 +-
 .../component/jira/JiraComponentConfigurer.java    |  36 +-
 .../component/jira/JiraEndpointConfigurer.java     |  80 ++--
 .../component/jms/JmsComponentConfigurer.java      | 352 ++++++++--------
 .../camel/component/jms/JmsEndpointConfigurer.java | 387 ++++++++---------
 .../component/jmx/JMXComponentConfigurer.java      |  29 +-
 .../camel/component/jmx/JMXEndpointConfigurer.java | 138 +++---
 .../component/jolt/JoltComponentConfigurer.java    |  32 +-
 .../component/jolt/JoltEndpointConfigurer.java     |  48 +--
 .../component/jooq/JooqComponentConfigurer.java    |  36 +-
 .../component/jooq/JooqEndpointConfigurer.java     | 115 +++--
 .../component/jpa/JpaComponentConfigurer.java      |  49 +--
 .../camel/component/jpa/JpaEndpointConfigurer.java | 197 ++++-----
 .../component/scp/ScpComponentConfigurer.java      |  33 +-
 .../camel/component/scp/ScpEndpointConfigurer.java | 109 ++---
 .../component/jslt/JsltComponentConfigurer.java    |  32 +-
 .../component/jslt/JsltEndpointConfigurer.java     |  40 +-
 .../JsonValidatorComponentConfigurer.java          |  29 +-
 .../JsonValidatorEndpointConfigurer.java           |  56 +--
 .../component/jt400/Jt400ComponentConfigurer.java  |  37 +-
 .../component/jt400/Jt400EndpointConfigurer.java   | 145 +++----
 .../component/kafka/KafkaComponentConfigurer.java  |  59 +--
 .../component/kafka/KafkaEndpointConfigurer.java   | 400 +++++++++---------
 .../KubernetesConfigMapsComponentConfigurer.java   |  29 +-
 .../KubernetesConfigMapsEndpointConfigurer.java    | 105 ++---
 .../KubernetesDeploymentsComponentConfigurer.java  |  33 +-
 .../KubernetesDeploymentsEndpointConfigurer.java   | 136 +++---
 .../hpa/KubernetesHPAComponentConfigurer.java      |  33 +-
 .../hpa/KubernetesHPAEndpointConfigurer.java       | 136 +++---
 .../job/KubernetesJobComponentConfigurer.java      |  33 +-
 .../job/KubernetesJobEndpointConfigurer.java       | 136 +++---
 .../KubernetesNamespacesComponentConfigurer.java   |  33 +-
 .../KubernetesNamespacesEndpointConfigurer.java    | 136 +++---
 .../nodes/KubernetesNodesComponentConfigurer.java  |  33 +-
 .../nodes/KubernetesNodesEndpointConfigurer.java   | 136 +++---
 ...rnetesPersistentVolumesComponentConfigurer.java |  29 +-
 ...ernetesPersistentVolumesEndpointConfigurer.java | 105 ++---
 ...PersistentVolumesClaimsComponentConfigurer.java |  29 +-
 ...sPersistentVolumesClaimsEndpointConfigurer.java | 105 ++---
 .../pods/KubernetesPodsComponentConfigurer.java    |  33 +-
 .../pods/KubernetesPodsEndpointConfigurer.java     | 136 +++---
 ...sReplicationControllersComponentConfigurer.java |  33 +-
 ...esReplicationControllersEndpointConfigurer.java | 136 +++---
 ...ubernetesResourcesQuotaComponentConfigurer.java |  29 +-
 ...KubernetesResourcesQuotaEndpointConfigurer.java | 105 ++---
 .../KubernetesSecretsComponentConfigurer.java      |  29 +-
 .../KubernetesSecretsEndpointConfigurer.java       | 105 ++---
 ...bernetesServiceAccountsComponentConfigurer.java |  29 +-
 ...ubernetesServiceAccountsEndpointConfigurer.java | 105 ++---
 .../KubernetesServicesComponentConfigurer.java     |  33 +-
 .../KubernetesServicesEndpointConfigurer.java      | 136 +++---
 .../OpenshiftBuildConfigsComponentConfigurer.java  |  29 +-
 .../OpenshiftBuildConfigsEndpointConfigurer.java   | 105 ++---
 .../builds/OpenshiftBuildsComponentConfigurer.java |  29 +-
 .../builds/OpenshiftBuildsEndpointConfigurer.java  | 105 ++---
 .../component/kudu/KuduComponentConfigurer.java    |  29 +-
 .../component/kudu/KuduEndpointConfigurer.java     |  35 +-
 .../language/LanguageComponentConfigurer.java      |  29 +-
 .../language/LanguageEndpointConfigurer.java       |  49 +--
 .../component/ldap/LdapComponentConfigurer.java    |  29 +-
 .../component/ldap/LdapEndpointConfigurer.java     |  46 +-
 .../component/ldif/LdifComponentConfigurer.java    |  29 +-
 .../component/ldif/LdifEndpointConfigurer.java     |  32 +-
 .../component/log/LogComponentConfigurer.java      |  33 +-
 .../camel/component/log/LogEndpointConfigurer.java | 128 +++---
 .../lucene/LuceneComponentConfigurer.java          |  32 +-
 .../component/lucene/LuceneEndpointConfigurer.java |  47 +--
 .../lumberjack/LumberjackComponentConfigurer.java  |  37 +-
 .../lumberjack/LumberjackEndpointConfigurer.java   |  44 +-
 .../component/mail/MailComponentConfigurer.java    |  48 +--
 .../component/mail/MailEndpointConfigurer.java     | 260 +++++-------
 .../master/MasterComponentConfigurer.java          |  36 +-
 .../component/master/MasterEndpointConfigurer.java |  40 +-
 .../metrics/MetricsComponentConfigurer.java        |  33 +-
 .../metrics/MetricsEndpointConfigurer.java         |  50 +--
 .../micrometer/MicrometerComponentConfigurer.java  |  33 +-
 .../micrometer/MicrometerEndpointConfigurer.java   |  44 +-
 .../component/mina/MinaComponentConfigurer.java    |  40 +-
 .../component/mina/MinaEndpointConfigurer.java     | 129 +++---
 .../component/mock/MockComponentConfigurer.java    |  29 +-
 .../component/mock/MockEndpointConfigurer.java     |  72 ++--
 .../mongodb/gridfs/GridFsComponentConfigurer.java  |  33 +-
 .../mongodb/gridfs/GridFsEndpointConfigurer.java   |  87 ++--
 .../mongodb/MongoDbComponentConfigurer.java        |  37 +-
 .../mongodb/MongoDbEndpointConfigurer.java         | 120 +++---
 .../validator/msv/MsvComponentConfigurer.java      |  37 +-
 .../validator/msv/MsvEndpointConfigurer.java       |  68 ++-
 .../mustache/MustacheComponentConfigurer.java      |  33 +-
 .../mustache/MustacheEndpointConfigurer.java       |  47 +--
 .../component/mvel/MvelComponentConfigurer.java    |  29 +-
 .../component/mvel/MvelEndpointConfigurer.java     |  39 +-
 .../mybatis/MyBatisBeanComponentConfigurer.java    |  37 +-
 .../mybatis/MyBatisBeanEndpointConfigurer.java     |  44 +-
 .../mybatis/MyBatisComponentConfigurer.java        |  41 +-
 .../mybatis/MyBatisEndpointConfigurer.java         | 144 +++----
 .../nagios/NagiosComponentConfigurer.java          |  32 +-
 .../component/nagios/NagiosEndpointConfigurer.java |  49 +--
 .../component/nats/NatsComponentConfigurer.java    |  40 +-
 .../component/nats/NatsEndpointConfigurer.java     | 126 +++---
 .../netty/http/NettyHttpComponentConfigurer.java   |  64 ++-
 .../netty/http/NettyHttpEndpointConfigurer.java    | 330 +++++++--------
 .../component/netty/NettyComponentConfigurer.java  |  52 +--
 .../component/netty/NettyEndpointConfigurer.java   | 291 ++++++-------
 .../nitrite/NitriteComponentConfigurer.java        |  33 +-
 .../nitrite/NitriteEndpointConfigurer.java         |  61 +--
 .../component/nsq/NsqComponentConfigurer.java      |  40 +-
 .../camel/component/nsq/NsqEndpointConfigurer.java |  88 ++--
 .../olingo2/Olingo2ComponentConfigurer.java        |  40 +-
 .../olingo2/Olingo2EndpointConfigurer.java         | 152 +++----
 .../olingo4/Olingo4ComponentConfigurer.java        |  40 +-
 .../olingo4/Olingo4EndpointConfigurer.java         | 152 +++----
 .../OptaPlannerComponentConfigurer.java            |  33 +-
 .../optaplanner/OptaPlannerEndpointConfigurer.java |  55 +--
 .../component/paho/PahoComponentConfigurer.java    |  43 +-
 .../component/paho/PahoEndpointConfigurer.java     | 147 +++----
 .../paxlogging/PaxLoggingComponentConfigurer.java  |  33 +-
 .../paxlogging/PaxLoggingEndpointConfigurer.java   |  40 +-
 .../component/pdf/PdfComponentConfigurer.java      |  29 +-
 .../camel/component/pdf/PdfEndpointConfigurer.java |  63 ++-
 .../pgevent/PgEventComponentConfigurer.java        |  33 +-
 .../pgevent/PgEventEndpointConfigurer.java         |  53 +--
 .../printer/PrinterComponentConfigurer.java        |  29 +-
 .../printer/PrinterEndpointConfigurer.java         |  68 ++-
 .../pubnub/PubNubComponentConfigurer.java          |  33 +-
 .../component/pubnub/PubNubEndpointConfigurer.java |  80 ++--
 .../pulsar/PulsarComponentConfigurer.java          |  49 +--
 .../component/pulsar/PulsarEndpointConfigurer.java | 132 +++---
 .../quartz/QuartzComponentConfigurer.java          |  71 ++--
 .../component/quartz/QuartzEndpointConfigurer.java |  98 ++---
 .../quickfixj/QuickfixjComponentConfigurer.java    |  52 +--
 .../quickfixj/QuickfixjEndpointConfigurer.java     |  52 +--
 .../rabbitmq/RabbitMQComponentConfigurer.java      | 217 +++++-----
 .../rabbitmq/RabbitMQEndpointConfigurer.java       | 243 +++++------
 .../component/ref/RefComponentConfigurer.java      |  33 +-
 .../camel/component/ref/RefEndpointConfigurer.java |  44 +-
 .../swagger/RestSwaggerComponentConfigurer.java    |  58 +--
 .../swagger/RestSwaggerEndpointConfigurer.java     |  53 +--
 .../component/rest/RestApiComponentConfigurer.java |  29 +-
 .../component/rest/RestApiEndpointConfigurer.java  |  48 +--
 .../component/rest/RestComponentConfigurer.java    |  52 +--
 .../component/rest/RestEndpointConfigurer.java     |  88 ++--
 .../RobotFrameworkComponentConfigurer.java         |  36 +-
 .../RobotFrameworkEndpointConfigurer.java          | 273 ++++++------
 .../component/rss/RssComponentConfigurer.java      |  29 +-
 .../camel/component/rss/RssEndpointConfigurer.java | 130 +++---
 .../component/saga/SagaComponentConfigurer.java    |  29 +-
 .../component/saga/SagaEndpointConfigurer.java     |  32 +-
 .../salesforce/SalesforceComponentConfigurer.java  | 153 +++----
 .../salesforce/SalesforceEndpointConfigurer.java   | 198 ++++-----
 .../component/salesforce/api/dto/bulk/jaxb.index   |  17 +
 .../netweaver/NetWeaverComponentConfigurer.java    |  29 +-
 .../sap/netweaver/NetWeaverEndpointConfigurer.java |  49 +--
 .../xquery/XQueryComponentConfigurer.java          |  44 +-
 .../component/xquery/XQueryEndpointConfigurer.java | 150 +++----
 .../scheduler/SchedulerComponentConfigurer.java    |  33 +-
 .../scheduler/SchedulerEndpointConfigurer.java     | 105 ++---
 .../schematron/SchematronComponentConfigurer.java  |  29 +-
 .../schematron/SchematronEndpointConfigurer.java   |  42 +-
 .../component/seda/SedaComponentConfigurer.java    |  57 +--
 .../component/seda/SedaEndpointConfigurer.java     |  97 ++---
 .../service/ServiceComponentConfigurer.java        |  36 +-
 .../service/ServiceEndpointConfigurer.java         |  40 +-
 .../servlet/ServletComponentConfigurer.java        |  61 ++-
 .../servlet/ServletEndpointConfigurer.java         | 114 +++--
 .../component/sip/SipComponentConfigurer.java      |  33 +-
 .../camel/component/sip/SipEndpointConfigurer.java | 202 ++++-----
 .../component/sjms/SjmsComponentConfigurer.java    |  89 ++--
 .../component/sjms/SjmsEndpointConfigurer.java     | 161 ++++---
 .../sjms/batch/SjmsBatchComponentConfigurer.java   |  45 +-
 .../sjms/batch/SjmsBatchEndpointConfigurer.java    | 116 +++--
 .../component/sjms2/Sjms2ComponentConfigurer.java  |  89 ++--
 .../component/sjms2/Sjms2EndpointConfigurer.java   | 171 ++++----
 .../component/slack/SlackComponentConfigurer.java  |  37 +-
 .../component/slack/SlackEndpointConfigurer.java   | 131 +++---
 .../component/smpp/SmppComponentConfigurer.java    |  36 +-
 .../component/smpp/SmppEndpointConfigurer.java     | 177 ++++----
 .../component/snmp/SnmpComponentConfigurer.java    |  33 +-
 .../component/snmp/SnmpEndpointConfigurer.java     | 164 ++++----
 .../org/w3/_2003/_05/soap_envelope/jaxb.index      |  13 +
 .../org/xmlsoap/schemas/soap/envelope}/jaxb.index  |   6 +-
 .../component/solr/SolrComponentConfigurer.java    |  29 +-
 .../component/solr/SolrEndpointConfigurer.java     |  85 ++--
 .../sparkrest/SparkComponentConfigurer.java        |  72 ++--
 .../sparkrest/SparkEndpointConfigurer.java         |  67 ++-
 .../component/spark/SparkComponentConfigurer.java  |  36 +-
 .../component/spark/SparkEndpointConfigurer.java   |  50 +--
 .../splunk/SplunkComponentConfigurer.java          |  37 +-
 .../component/splunk/SplunkEndpointConfigurer.java | 184 ++++----
 .../SpringIntegrationComponentConfigurer.java      |  33 +-
 .../SpringIntegrationEndpointConfigurer.java       |  56 +--
 .../springldap/SpringLdapComponentConfigurer.java  |  29 +-
 .../springldap/SpringLdapEndpointConfigurer.java   |  38 +-
 .../component/redis/RedisComponentConfigurer.java  |  33 +-
 .../component/redis/RedisEndpointConfigurer.java   |  65 ++-
 .../ws/SpringWebserviceComponentConfigurer.java    |  37 +-
 .../ws/SpringWebserviceEndpointConfigurer.java     | 111 +++--
 .../component/event/EventComponentConfigurer.java  |  33 +-
 .../component/event/EventEndpointConfigurer.java   |  44 +-
 .../component/sql/SqlComponentConfigurer.java      |  41 +-
 .../camel/component/sql/SqlEndpointConfigurer.java | 204 ++++-----
 .../sql/stored/SqlStoredComponentConfigurer.java   |  33 +-
 .../sql/stored/SqlStoredEndpointConfigurer.java    |  53 +--
 .../component/ssh/SshComponentConfigurer.java      |  83 ++--
 .../camel/component/ssh/SshEndpointConfigurer.java | 154 +++----
 .../component/stax/StAXComponentConfigurer.java    |  29 +-
 .../component/stax/StAXEndpointConfigurer.java     |  32 +-
 .../component/stomp/StompComponentConfigurer.java  |  57 +--
 .../component/stomp/StompEndpointConfigurer.java   |  72 ++--
 .../stream/StreamComponentConfigurer.java          |  33 +-
 .../component/stream/StreamEndpointConfigurer.java | 101 ++---
 .../StringTemplateComponentConfigurer.java         |  29 +-
 .../StringTemplateEndpointConfigurer.java          |  44 +-
 .../component/stub/StubComponentConfigurer.java    |  57 +--
 .../component/stub/StubEndpointConfigurer.java     |  97 ++---
 .../telegram/TelegramComponentConfigurer.java      |  48 +--
 .../telegram/TelegramEndpointConfigurer.java       | 139 +++---
 .../thrift/ThriftComponentConfigurer.java          |  37 +-
 .../component/thrift/ThriftEndpointConfigurer.java |  75 ++--
 .../component/tika/TikaComponentConfigurer.java    |  29 +-
 .../component/tika/TikaEndpointConfigurer.java     |  48 +--
 .../component/timer/TimerComponentConfigurer.java  |  29 +-
 .../component/timer/TimerEndpointConfigurer.java   |  70 ++--
 .../twilio/TwilioComponentConfigurer.java          |  50 +--
 .../component/twilio/TwilioEndpointConfigurer.java | 109 ++---
 .../undertow/UndertowComponentConfigurer.java      |  53 +--
 .../undertow/UndertowEndpointConfigurer.java       | 130 +++---
 .../validator/ValidatorComponentConfigurer.java    |  33 +-
 .../validator/ValidatorEndpointConfigurer.java     |  68 ++-
 .../velocity/VelocityComponentConfigurer.java      |  33 +-
 .../velocity/VelocityEndpointConfigurer.java       |  47 +--
 .../component/vertx/VertxComponentConfigurer.java  |  53 +--
 .../component/vertx/VertxEndpointConfigurer.java   |  48 +--
 .../camel/component/vm/VmComponentConfigurer.java  |  57 +--
 .../camel/component/vm/VmEndpointConfigurer.java   |  97 ++---
 .../weather/WeatherComponentConfigurer.java        |  41 +-
 .../weather/WeatherEndpointConfigurer.java         | 197 ++++-----
 .../component/web3j/Web3jComponentConfigurer.java  |  36 +-
 .../component/web3j/Web3jEndpointConfigurer.java   | 167 ++++----
 .../webhook/WebhookComponentConfigurer.java        |  32 +-
 .../webhook/WebhookEndpointConfigurer.java         |  60 +--
 .../websocket/jsr356/JSR356EndpointConfigurer.java |  48 +--
 .../jsr356/JSR356WebSocketComponentConfigurer.java |  37 +-
 .../websocket/WebsocketComponentConfigurer.java    |  83 ++--
 .../websocket/WebsocketEndpointConfigurer.java     | 100 ++---
 .../component/weka/WekaComponentConfigurer.java    |  29 +-
 .../component/weka/WekaEndpointConfigurer.java     |  61 +--
 .../wordpress/WordpressComponentConfigurer.java    |  36 +-
 .../wordpress/WordpressEndpointConfigurer.java     |  70 ++--
 .../workday/WorkdayComponentConfigurer.java        |  29 +-
 .../workday/WorkdayEndpointConfigurer.java         |  58 +--
 .../xchange/XChangeComponentConfigurer.java        |  29 +-
 .../xchange/XChangeEndpointConfigurer.java         |  45 +-
 .../camel/component/xj/XJComponentConfigurer.java  |  61 ++-
 .../camel/component/xj/XJEndpointConfigurer.java   |  95 ++---
 .../XmlSignatureComponentConfigurer.java           |  37 +-
 .../XmlSignatureEndpointConfigurer.java            | 167 ++++----
 .../component/xmpp/XmppComponentConfigurer.java    |  33 +-
 .../component/xmpp/XmppEndpointConfigurer.java     |  96 ++---
 .../xslt/saxon/XsltSaxonComponentConfigurer.java   |  61 ++-
 .../xslt/saxon/XsltSaxonEndpointConfigurer.java    |  91 ++--
 .../component/xslt/XsltComponentConfigurer.java    |  49 +--
 .../component/xslt/XsltEndpointConfigurer.java     |  79 ++--
 .../yammer/YammerComponentConfigurer.java          |  48 +--
 .../component/yammer/YammerEndpointConfigurer.java | 139 +++---
 .../zendesk/ZendeskComponentConfigurer.java        |  39 +-
 .../zendesk/ZendeskEndpointConfigurer.java         | 126 +++---
 .../zookeepermaster/MasterComponentConfigurer.java |  52 +--
 .../zookeepermaster/MasterEndpointConfigurer.java  |  40 +-
 .../zookeeper/ZooKeeperComponentConfigurer.java    |  36 +-
 .../zookeeper/ZooKeeperEndpointConfigurer.java     |  68 ++-
 components/pom.xml                                 |   2 +
 .../packaging/PropertyConfigurerGenerator.java     |  36 +-
 .../camel/maven/packaging/SpiGeneratorMojo.java    |   4 +-
 531 files changed, 15518 insertions(+), 23724 deletions(-)
 copy {core/camel-util/src/generated/resources/org/apache/camel/util/concurrent => components/camel-hbase/src/generated/resources/org/apache/camel/component/hbase/model}/jaxb.index (69%)
 create mode 100644 components/camel-salesforce/camel-salesforce-component/src/generated/resources/org/apache/camel/component/salesforce/api/dto/bulk/jaxb.index
 create mode 100644 components/camel-soap/src/generated/resources/org/w3/_2003/_05/soap_envelope/jaxb.index
 copy {core/camel-util/src/generated/resources/org/apache/camel/util/concurrent => components/camel-soap/src/generated/resources/org/xmlsoap/schemas/soap/envelope}/jaxb.index (63%)


[camel] 04/04: Regen

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

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

commit a4ef9373aeef7c2a7dedbbea320a3359123831d3
Author: Guillaume Nodet <gn...@gmail.com>
AuthorDate: Wed Feb 5 09:58:09 2020 +0100

    Regen
---
 .../workday/WorkdayComponentConfigurer.java        | 29 +++--------
 .../workday/WorkdayEndpointConfigurer.java         | 58 ++++++++--------------
 2 files changed, 29 insertions(+), 58 deletions(-)

diff --git a/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayComponentConfigurer.java b/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayComponentConfigurer.java
index 325218b..eafe87c 100644
--- a/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayComponentConfigurer.java
+++ b/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayComponentConfigurer.java
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class WorkdayComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((WorkdayComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((WorkdayComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((WorkdayComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((WorkdayComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        WorkdayComponent target = (WorkdayComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
diff --git a/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayEndpointConfigurer.java b/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayEndpointConfigurer.java
index 9c489b6..9961cde 100644
--- a/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayEndpointConfigurer.java
+++ b/components/camel-workday/src/generated/java/org/apache/camel/component/workday/WorkdayEndpointConfigurer.java
@@ -12,43 +12,27 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class WorkdayEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "lazyStartProducer": ((WorkdayEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((WorkdayEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "httpConnectionManager": ((WorkdayEndpoint) target).getWorkdayConfiguration().setHttpConnectionManager(property(camelContext, org.apache.http.impl.conn.PoolingHttpClientConnectionManager.class, value)); return true;
-        case "synchronous": ((WorkdayEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "reportFormat": ((WorkdayEndpoint) target).getWorkdayConfiguration().setReportFormat(property(camelContext, java.lang.String.class, value)); return true;
-        case "host": ((WorkdayEndpoint) target).getWorkdayConfiguration().setHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientId": ((WorkdayEndpoint) target).getWorkdayConfiguration().setClientId(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientSecret": ((WorkdayEndpoint) target).getWorkdayConfiguration().setClientSecret(property(camelContext, java.lang.String.class, value)); return true;
-        case "tokenRefresh": ((WorkdayEndpoint) target).getWorkdayConfiguration().setTokenRefresh(property(camelContext, java.lang.String.class, value)); return true;
-        case "tenant": ((WorkdayEndpoint) target).getWorkdayConfiguration().setTenant(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "lazystartproducer": ((WorkdayEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((WorkdayEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "httpconnectionmanager": ((WorkdayEndpoint) target).getWorkdayConfiguration().setHttpConnectionManager(property(camelContext, org.apache.http.impl.conn.PoolingHttpClientConnectionManager.class, value)); return true;
-        case "synchronous": ((WorkdayEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "reportformat": ((WorkdayEndpoint) target).getWorkdayConfiguration().setReportFormat(property(camelContext, java.lang.String.class, value)); return true;
-        case "host": ((WorkdayEndpoint) target).getWorkdayConfiguration().setHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientid": ((WorkdayEndpoint) target).getWorkdayConfiguration().setClientId(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientsecret": ((WorkdayEndpoint) target).getWorkdayConfiguration().setClientSecret(property(camelContext, java.lang.String.class, value)); return true;
-        case "tokenrefresh": ((WorkdayEndpoint) target).getWorkdayConfiguration().setTokenRefresh(property(camelContext, java.lang.String.class, value)); return true;
-        case "tenant": ((WorkdayEndpoint) target).getWorkdayConfiguration().setTenant(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        WorkdayEndpoint target = (WorkdayEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "httpconnectionmanager":
+        case "httpConnectionManager": target.getWorkdayConfiguration().setHttpConnectionManager(property(camelContext, org.apache.http.impl.conn.PoolingHttpClientConnectionManager.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "reportformat":
+        case "reportFormat": target.getWorkdayConfiguration().setReportFormat(property(camelContext, java.lang.String.class, value)); return true;
+        case "host": target.getWorkdayConfiguration().setHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "clientid":
+        case "clientId": target.getWorkdayConfiguration().setClientId(property(camelContext, java.lang.String.class, value)); return true;
+        case "clientsecret":
+        case "clientSecret": target.getWorkdayConfiguration().setClientSecret(property(camelContext, java.lang.String.class, value)); return true;
+        case "tokenrefresh":
+        case "tokenRefresh": target.getWorkdayConfiguration().setTokenRefresh(property(camelContext, java.lang.String.class, value)); return true;
+        case "tenant": target.getWorkdayConfiguration().setTenant(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 


[camel] 02/04: Keep the generated jaxb files in git

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

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

commit c03c4ff980937c1a81eb8bbdbeac554cd66f6c10
Author: Guillaume Nodet <gn...@gmail.com>
AuthorDate: Wed Feb 5 09:20:08 2020 +0100

    Keep the generated jaxb files in git
---
 .../org/apache/camel/component/hbase/model/jaxb.index   |  3 +++
 .../camel/component/salesforce/api/dto/bulk/jaxb.index  | 17 +++++++++++++++++
 .../resources/org/w3/_2003/_05/soap_envelope/jaxb.index | 13 +++++++++++++
 .../org/xmlsoap/schemas/soap/envelope/jaxb.index        |  6 ++++++
 4 files changed, 39 insertions(+)

diff --git a/components/camel-hbase/src/generated/resources/org/apache/camel/component/hbase/model/jaxb.index b/components/camel-hbase/src/generated/resources/org/apache/camel/component/hbase/model/jaxb.index
new file mode 100644
index 0000000..f190274
--- /dev/null
+++ b/components/camel-hbase/src/generated/resources/org/apache/camel/component/hbase/model/jaxb.index
@@ -0,0 +1,3 @@
+# Generated by camel build tools - do NOT edit this file!
+HBaseData
+HBaseRow
diff --git a/components/camel-salesforce/camel-salesforce-component/src/generated/resources/org/apache/camel/component/salesforce/api/dto/bulk/jaxb.index b/components/camel-salesforce/camel-salesforce-component/src/generated/resources/org/apache/camel/component/salesforce/api/dto/bulk/jaxb.index
new file mode 100644
index 0000000..4790830
--- /dev/null
+++ b/components/camel-salesforce/camel-salesforce-component/src/generated/resources/org/apache/camel/component/salesforce/api/dto/bulk/jaxb.index
@@ -0,0 +1,17 @@
+# Generated by camel build tools - do NOT edit this file!
+BatchInfo
+BatchInfoList
+BatchResult
+BatchStateEnum
+ConcurrencyModeEnum
+ContentType
+Error
+JobInfo
+JobStateEnum
+OperationEnum
+QueryResult
+QueryResultList
+Result
+ResultError
+SObject
+StatusCode
diff --git a/components/camel-soap/src/generated/resources/org/w3/_2003/_05/soap_envelope/jaxb.index b/components/camel-soap/src/generated/resources/org/w3/_2003/_05/soap_envelope/jaxb.index
new file mode 100644
index 0000000..f55a889
--- /dev/null
+++ b/components/camel-soap/src/generated/resources/org/w3/_2003/_05/soap_envelope/jaxb.index
@@ -0,0 +1,13 @@
+# Generated by camel build tools - do NOT edit this file!
+Body
+Detail
+Envelope
+Fault
+Faultcode
+Faultreason
+Header
+NotUnderstoodType
+Reasontext
+Subcode
+SupportedEnvType
+UpgradeType
diff --git a/components/camel-soap/src/generated/resources/org/xmlsoap/schemas/soap/envelope/jaxb.index b/components/camel-soap/src/generated/resources/org/xmlsoap/schemas/soap/envelope/jaxb.index
new file mode 100644
index 0000000..388b897
--- /dev/null
+++ b/components/camel-soap/src/generated/resources/org/xmlsoap/schemas/soap/envelope/jaxb.index
@@ -0,0 +1,6 @@
+# Generated by camel build tools - do NOT edit this file!
+Body
+Detail
+Envelope
+Fault
+Header


[camel] 03/04: Fix components generation

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

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

commit f5fd9ec9da8e23ba9d79cea49211032867a86d30
Author: Guillaume Nodet <gn...@gmail.com>
AuthorDate: Wed Feb 5 09:55:59 2020 +0100

    Fix components generation
---
 components/pom.xml                                                    | 2 ++
 .../main/java/org/apache/camel/maven/packaging/SpiGeneratorMojo.java  | 4 ++--
 2 files changed, 4 insertions(+), 2 deletions(-)

diff --git a/components/pom.xml b/components/pom.xml
index 154ca5d..4007cf8 100644
--- a/components/pom.xml
+++ b/components/pom.xml
@@ -373,6 +373,8 @@
 
     <properties>
         <camel.osgi.manifest>${project.build.outputDirectory}/META-INF/MANIFEST.MF</camel.osgi.manifest>
+
+        <camel-prepare-component>true</camel-prepare-component>
     </properties>
 
     <build>
diff --git a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/SpiGeneratorMojo.java b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/SpiGeneratorMojo.java
index d1a4077..a2fb53c 100644
--- a/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/SpiGeneratorMojo.java
+++ b/tooling/maven/camel-package-maven-plugin/src/main/java/org/apache/camel/maven/packaging/SpiGeneratorMojo.java
@@ -193,9 +193,9 @@ public class SpiGeneratorMojo extends AbstractGeneratorMojo {
                 indices.add(new IndexReader(is).read());
             }
             for (String cpe : project.getCompileClasspathElements()) {
-                if (cpe.matches("/camel-[^/]+.jar")) {
+                if (cpe.matches(".*/(camel|spi-annotations)-[^/]+.jar")) {
                     try (JarFile jf = new JarFile(cpe)) {
-                        JarEntry indexEntry = jf.getJarEntry("MANIFEST/jandex.idx");
+                        JarEntry indexEntry = jf.getJarEntry("META-INF/jandex.idx");
                         if (indexEntry != null) {
                             try (InputStream is = jf.getInputStream(indexEntry)) {
                                 indices.add(new IndexReader(is).read());


[camel] 01/04: Reduce the size of the generated component/endpoint configurers by using a single switch statement

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

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

commit 519f5a5379bda78d60c75d6828763eb31f946451
Author: Guillaume Nodet <gn...@gmail.com>
AuthorDate: Wed Feb 5 09:10:02 2020 +0100

    Reduce the size of the generated component/endpoint configurers by using a single switch statement
---
 .../component/ahc/ws/WsComponentConfigurer.java    |  59 +--
 .../component/ahc/ws/WsEndpointConfigurer.java     |  99 ++---
 .../component/ahc/AhcComponentConfigurer.java      |  55 +--
 .../camel/component/ahc/AhcEndpointConfigurer.java |  79 ++--
 .../component/apns/ApnsComponentConfigurer.java    |  37 +-
 .../component/apns/ApnsEndpointConfigurer.java     | 108 ++---
 .../component/as2/AS2ComponentConfigurer.java      |  36 +-
 .../camel/component/as2/AS2EndpointConfigurer.java | 210 +++++-----
 .../asterisk/AsteriskComponentConfigurer.java      |  33 +-
 .../asterisk/AsteriskEndpointConfigurer.java       |  56 +--
 .../component/atmos/AtmosComponentConfigurer.java  |  48 +--
 .../component/atmos/AtmosEndpointConfigurer.java   |  74 ++--
 .../websocket/WebsocketComponentConfigurer.java    |  65 ++-
 .../websocket/WebsocketEndpointConfigurer.java     | 178 ++++----
 .../component/atom/AtomComponentConfigurer.java    |  29 +-
 .../component/atom/AtomEndpointConfigurer.java     | 130 +++---
 .../client/map/AtomixMapComponentConfigurer.java   |  46 +-
 .../client/map/AtomixMapEndpointConfigurer.java    |  95 ++---
 .../AtomixMessagingComponentConfigurer.java        |  46 +-
 .../AtomixMessagingEndpointConfigurer.java         | 101 ++---
 .../AtomixMultiMapComponentConfigurer.java         |  42 +-
 .../multimap/AtomixMultiMapEndpointConfigurer.java |  83 ++--
 .../queue/AtomixQueueComponentConfigurer.java      |  46 +-
 .../queue/AtomixQueueEndpointConfigurer.java       |  89 ++--
 .../client/set/AtomixSetComponentConfigurer.java   |  46 +-
 .../client/set/AtomixSetEndpointConfigurer.java    |  92 ++--
 .../value/AtomixValueComponentConfigurer.java      |  46 +-
 .../value/AtomixValueEndpointConfigurer.java       |  92 ++--
 .../component/avro/AvroComponentConfigurer.java    |  36 +-
 .../component/avro/AvroEndpointConfigurer.java     |  67 ++-
 .../component/aws/cw/CwComponentConfigurer.java    |  43 +-
 .../component/aws/cw/CwEndpointConfigurer.java     |  71 ++--
 .../component/aws/ddb/DdbComponentConfigurer.java  |  43 +-
 .../component/aws/ddb/DdbEndpointConfigurer.java   |  82 ++--
 .../ddbstream/DdbStreamComponentConfigurer.java    |  43 +-
 .../aws/ddbstream/DdbStreamEndpointConfigurer.java | 140 +++----
 .../component/aws/ec2/EC2ComponentConfigurer.java  |  43 +-
 .../component/aws/ec2/EC2EndpointConfigurer.java   |  62 +--
 .../component/aws/ecs/ECSComponentConfigurer.java  |  43 +-
 .../component/aws/ecs/ECSEndpointConfigurer.java   |  62 +--
 .../component/aws/eks/EKSComponentConfigurer.java  |  43 +-
 .../component/aws/eks/EKSEndpointConfigurer.java   |  62 +--
 .../component/aws/iam/IAMComponentConfigurer.java  |  43 +-
 .../component/aws/iam/IAMEndpointConfigurer.java   |  62 +--
 .../KinesisFirehoseComponentConfigurer.java        |  43 +-
 .../KinesisFirehoseEndpointConfigurer.java         |  59 +--
 .../aws/kinesis/KinesisComponentConfigurer.java    |  47 +--
 .../aws/kinesis/KinesisEndpointConfigurer.java     | 152 +++----
 .../component/aws/kms/KMSComponentConfigurer.java  |  43 +-
 .../component/aws/kms/KMSEndpointConfigurer.java   |  62 +--
 .../aws/lambda/LambdaComponentConfigurer.java      |  43 +-
 .../aws/lambda/LambdaEndpointConfigurer.java       |  62 +--
 .../component/aws/mq/MQComponentConfigurer.java    |  43 +-
 .../component/aws/mq/MQEndpointConfigurer.java     |  62 +--
 .../component/aws/msk/MSKComponentConfigurer.java  |  43 +-
 .../component/aws/msk/MSKEndpointConfigurer.java   |  62 +--
 .../component/aws/s3/S3ComponentConfigurer.java    |  47 +--
 .../component/aws/s3/S3EndpointConfigurer.java     | 240 +++++------
 .../component/aws/sdb/SdbComponentConfigurer.java  |  29 +-
 .../component/aws/sdb/SdbEndpointConfigurer.java   |  70 ++--
 .../component/aws/ses/SesComponentConfigurer.java  |  43 +-
 .../component/aws/ses/SesEndpointConfigurer.java   |  73 ++--
 .../component/aws/sns/SnsComponentConfigurer.java  |  43 +-
 .../component/aws/sns/SnsEndpointConfigurer.java   |  97 ++---
 .../component/aws/sqs/SqsComponentConfigurer.java  |  47 +--
 .../component/aws/sqs/SqsEndpointConfigurer.java   | 245 +++++------
 .../component/aws/swf/SWFComponentConfigurer.java  |  47 +--
 .../component/aws/swf/SWFEndpointConfigurer.java   | 145 +++----
 .../translate/TranslateComponentConfigurer.java    |  43 +-
 .../aws/translate/TranslateEndpointConfigurer.java |  74 ++--
 .../aws2/ecs/ECS2ComponentConfigurer.java          |  43 +-
 .../component/aws2/ecs/ECS2EndpointConfigurer.java |  62 +--
 .../aws2/eks/EKS2ComponentConfigurer.java          |  43 +-
 .../component/aws2/eks/EKS2EndpointConfigurer.java |  62 +--
 .../aws2/kms/KMS2ComponentConfigurer.java          |  43 +-
 .../component/aws2/kms/KMS2EndpointConfigurer.java |  62 +--
 .../component/aws2/mq/MQ2ComponentConfigurer.java  |  43 +-
 .../component/aws2/mq/MQ2EndpointConfigurer.java   |  62 +--
 .../aws2/msk/MSK2ComponentConfigurer.java          |  43 +-
 .../component/aws2/msk/MSK2EndpointConfigurer.java |  62 +--
 .../translate/Translate2ComponentConfigurer.java   |  43 +-
 .../translate/Translate2EndpointConfigurer.java    |  74 ++--
 .../azure/blob/BlobServiceComponentConfigurer.java |  36 +-
 .../azure/blob/BlobServiceEndpointConfigurer.java  | 102 ++---
 .../queue/QueueServiceComponentConfigurer.java     |  36 +-
 .../queue/QueueServiceEndpointConfigurer.java      |  66 ++-
 .../BeanValidatorComponentConfigurer.java          |  49 +--
 .../validator/BeanValidatorEndpointConfigurer.java |  59 +--
 .../component/bean/BeanComponentConfigurer.java    |  35 +-
 .../component/bean/BeanEndpointConfigurer.java     |  44 +-
 .../beanclass/ClassComponentConfigurer.java        |  35 +-
 .../beanclass/ClassEndpointConfigurer.java         |  44 +-
 .../beanstalk/BeanstalkComponentConfigurer.java    |  37 +-
 .../beanstalk/BeanstalkEndpointConfigurer.java     | 132 +++---
 .../bonita/BonitaComponentConfigurer.java          |  29 +-
 .../component/bonita/BonitaEndpointConfigurer.java |  48 +--
 .../component/box/BoxComponentConfigurer.java      |  36 +-
 .../camel/component/box/BoxEndpointConfigurer.java | 169 ++++----
 .../braintree/BraintreeComponentConfigurer.java    |  40 +-
 .../braintree/BraintreeEndpointConfigurer.java     | 148 +++----
 .../browse/BrowseComponentConfigurer.java          |  33 +-
 .../component/browse/BrowseEndpointConfigurer.java |  44 +-
 .../cache/CaffeineCacheComponentConfigurer.java    |  32 +-
 .../cache/CaffeineCacheEndpointConfigurer.java     |  89 ++--
 .../load/CaffeineLoadCacheComponentConfigurer.java |  32 +-
 .../load/CaffeineLoadCacheEndpointConfigurer.java  |  89 ++--
 .../cassandra/CassandraComponentConfigurer.java    |  33 +-
 .../cassandra/CassandraEndpointConfigurer.java     | 140 +++----
 .../chatscript/ChatScriptComponentConfigurer.java  |  29 +-
 .../chatscript/ChatScriptEndpointConfigurer.java   |  40 +-
 .../component/chunk/ChunkComponentConfigurer.java  |  29 +-
 .../component/chunk/ChunkEndpointConfigurer.java   |  54 +--
 .../camel/component/cm/CMComponentConfigurer.java  |  29 +-
 .../camel/component/cm/CMEndpointConfigurer.java   |  48 +--
 .../component/cmis/CMISComponentConfigurer.java    |  37 +-
 .../component/cmis/CMISEndpointConfigurer.java     |  77 ++--
 .../apache/camel/coap/CoAPComponentConfigurer.java |  33 +-
 .../apache/camel/coap/CoAPEndpointConfigurer.java  |  83 ++--
 .../cometd/CometdComponentConfigurer.java          |  60 +--
 .../component/cometd/CometdEndpointConfigurer.java |  90 ++--
 .../consul/ConsulComponentConfigurer.java          |  61 +--
 .../component/consul/ConsulEndpointConfigurer.java | 121 +++---
 .../controlbus/ControlBusComponentConfigurer.java  |  29 +-
 .../controlbus/ControlBusEndpointConfigurer.java   |  50 +--
 .../component/corda/CordaComponentConfigurer.java  |  36 +-
 .../component/corda/CordaEndpointConfigurer.java   |  53 +--
 .../couchbase/CouchbaseComponentConfigurer.java    |  33 +-
 .../couchbase/CouchbaseEndpointConfigurer.java     | 209 ++++-----
 .../couchdb/CouchDbComponentConfigurer.java        |  33 +-
 .../couchdb/CouchDbEndpointConfigurer.java         |  69 ++-
 .../component/cron/CronComponentConfigurer.java    |  33 +-
 .../component/cron/CronEndpointConfigurer.java     |  43 +-
 .../crypto/cms/CryptoCmsComponentConfigurer.java   |  37 +-
 .../crypto/cms/CryptoCmsEndpointConfigurer.java    |  85 ++--
 .../DigitalSignatureComponentConfigurer.java       |  32 +-
 .../crypto/DigitalSignatureEndpointConfigurer.java |  98 ++---
 .../component/cxf/CxfComponentConfigurer.java      |  45 +-
 .../camel/component/cxf/CxfEndpointConfigurer.java | 159 ++++---
 .../cxf/jaxrs/CxfRsComponentConfigurer.java        |  41 +-
 .../cxf/jaxrs/CxfRsEndpointConfigurer.java         | 144 +++----
 .../dataformat/DataFormatComponentConfigurer.java  |  29 +-
 .../dataformat/DataFormatEndpointConfigurer.java   |  32 +-
 .../dataset/DataSetComponentConfigurer.java        |  33 +-
 .../dataset/DataSetEndpointConfigurer.java         | 108 +++--
 .../dataset/DataSetTestComponentConfigurer.java    |  29 +-
 .../dataset/DataSetTestEndpointConfigurer.java     |  85 ++--
 .../DebeziumMongodbComponentConfigurer.java        |  32 +-
 .../DebeziumMongodbEndpointConfigurer.java         | 196 ++++-----
 .../debezium/DebeziumMySqlComponentConfigurer.java |  32 +-
 .../debezium/DebeziumMySqlEndpointConfigurer.java  | 316 +++++++-------
 .../DebeziumPostgresComponentConfigurer.java       |  32 +-
 .../DebeziumPostgresEndpointConfigurer.java        | 284 ++++++-------
 .../DebeziumSqlserverComponentConfigurer.java      |  32 +-
 .../DebeziumSqlserverEndpointConfigurer.java       | 212 +++++-----
 .../DigitalOceanComponentConfigurer.java           |  29 +-
 .../DigitalOceanEndpointConfigurer.java            |  66 ++-
 .../direct/DirectComponentConfigurer.java          |  39 +-
 .../component/direct/DirectEndpointConfigurer.java |  54 +--
 .../directvm/DirectVmComponentConfigurer.java      |  47 +--
 .../directvm/DirectVmEndpointConfigurer.java       |  62 +--
 .../disruptor/DisruptorComponentConfigurer.java    |  61 ++-
 .../disruptor/DisruptorEndpointConfigurer.java     |  74 ++--
 .../component/dns/DnsComponentConfigurer.java      |  29 +-
 .../camel/component/dns/DnsEndpointConfigurer.java |  32 +-
 .../docker/DockerComponentConfigurer.java          |  36 +-
 .../component/docker/DockerEndpointConfigurer.java | 101 ++---
 .../component/dozer/DozerComponentConfigurer.java  |  29 +-
 .../component/dozer/DozerEndpointConfigurer.java   |  56 +--
 .../component/drill/DrillComponentConfigurer.java  |  29 +-
 .../component/drill/DrillEndpointConfigurer.java   |  45 +-
 .../dropbox/DropboxComponentConfigurer.java        |  33 +-
 .../dropbox/DropboxEndpointConfigurer.java         |  74 ++--
 .../ehcache/EhcacheComponentConfigurer.java        |  56 +--
 .../ehcache/EhcacheEndpointConfigurer.java         |  92 ++--
 .../ElasticsearchComponentConfigurer.java          |  70 ++--
 .../ElasticsearchEndpointConfigurer.java           |  86 ++--
 .../component/elsql/ElsqlComponentConfigurer.java  |  49 +--
 .../component/elsql/ElsqlEndpointConfigurer.java   | 212 +++++-----
 .../elytron/ElytronComponentConfigurer.java        |  65 ++-
 .../elytron/ElytronEndpointConfigurer.java         | 134 +++---
 .../AbstractEtcdPollingEndpointConfigurer.java     | 141 +++----
 .../component/etcd/EtcdComponentConfigurer.java    |  54 +--
 .../eventadmin/EventAdminComponentConfigurer.java  |  37 +-
 .../eventadmin/EventAdminEndpointConfigurer.java   |  47 +--
 .../component/exec/ExecComponentConfigurer.java    |  29 +-
 .../component/exec/ExecEndpointConfigurer.java     |  61 +--
 .../facebook/FacebookComponentConfigurer.java      |  36 +-
 .../facebook/FacebookEndpointConfigurer.java       | 419 +++++++++---------
 .../component/file/FileComponentConfigurer.java    |  33 +-
 .../component/file/FileEndpointConfigurer.java     | 372 ++++++++--------
 .../flatpack/FlatpackComponentConfigurer.java      |  33 +-
 .../flatpack/FlatpackEndpointConfigurer.java       | 128 +++---
 .../component/flink/FlinkComponentConfigurer.java  |  45 +-
 .../component/flink/FlinkEndpointConfigurer.java   |  51 +--
 .../component/fop/FopComponentConfigurer.java      |  29 +-
 .../camel/component/fop/FopEndpointConfigurer.java |  40 +-
 .../freemarker/FreemarkerComponentConfigurer.java  |  32 +-
 .../freemarker/FreemarkerEndpointConfigurer.java   |  46 +-
 .../file/remote/FtpComponentConfigurer.java        |  33 +-
 .../file/remote/FtpEndpointConfigurer.java         | 435 +++++++++----------
 .../file/remote/FtpsComponentConfigurer.java       |  37 +-
 .../file/remote/FtpsEndpointConfigurer.java        | 466 ++++++++++-----------
 .../file/remote/SftpComponentConfigurer.java       |  33 +-
 .../file/remote/SftpEndpointConfigurer.java        | 466 ++++++++++-----------
 .../ganglia/GangliaComponentConfigurer.java        |  32 +-
 .../ganglia/GangliaEndpointConfigurer.java         |  72 ++--
 .../geocoder/GeoCoderComponentConfigurer.java      |  29 +-
 .../geocoder/GeoCoderEndpointConfigurer.java       |  79 ++--
 .../component/git/GitComponentConfigurer.java      |  33 +-
 .../camel/component/git/GitEndpointConfigurer.java |  76 ++--
 .../github/GitHubComponentConfigurer.java          |  33 +-
 .../component/github/GitHubEndpointConfigurer.java |  72 ++--
 .../drive/GoogleDriveComponentConfigurer.java      |  40 +-
 .../drive/GoogleDriveEndpointConfigurer.java       | 136 +++---
 .../component/gora/GoraComponentConfigurer.java    |  33 +-
 .../component/gora/GoraEndpointConfigurer.java     | 109 ++---
 .../component/grape/GrapeComponentConfigurer.java  |  33 +-
 .../component/grape/GrapeEndpointConfigurer.java   |  32 +-
 .../graphql/GraphqlComponentConfigurer.java        |  29 +-
 .../graphql/GraphqlEndpointConfigurer.java         |  60 +--
 .../component/grpc/GrpcComponentConfigurer.java    |  33 +-
 .../component/grpc/GrpcEndpointConfigurer.java     | 127 +++---
 .../component/hbase/HBaseComponentConfigurer.java  |  40 +-
 .../component/hbase/HBaseEndpointConfigurer.java   |  89 ++--
 .../component/hdfs/HdfsComponentConfigurer.java    |  41 +-
 .../component/hdfs/HdfsEndpointConfigurer.java     | 200 ++++-----
 .../hipchat/HipchatComponentConfigurer.java        |  33 +-
 .../hipchat/HipchatEndpointConfigurer.java         | 117 +++---
 .../component/http/HttpComponentConfigurer.java    |  97 ++---
 .../component/http/HttpEndpointConfigurer.java     | 227 +++++-----
 .../infinispan/InfinispanComponentConfigurer.java  |  40 +-
 .../infinispan/InfinispanEndpointConfigurer.java   |  99 ++---
 .../influxdb/InfluxDbComponentConfigurer.java      |  29 +-
 .../influxdb/InfluxDbEndpointConfigurer.java       |  49 +--
 .../component/iota/IOTAComponentConfigurer.java    |  29 +-
 .../component/iota/IOTAEndpointConfigurer.java     |  52 +--
 .../component/ipfs/IPFSComponentConfigurer.java    |  37 +-
 .../component/ipfs/IPFSEndpointConfigurer.java     |  35 +-
 .../component/irc/IrcComponentConfigurer.java      |  37 +-
 .../camel/component/irc/IrcEndpointConfigurer.java | 128 +++---
 .../ironmq/IronMQComponentConfigurer.java          |  33 +-
 .../component/ironmq/IronMQEndpointConfigurer.java | 145 +++----
 .../component/jbpm/JBPMComponentConfigurer.java    |  33 +-
 .../component/jbpm/JBPMEndpointConfigurer.java     | 137 +++---
 .../jcache/JCacheComponentConfigurer.java          |  53 +--
 .../component/jcache/JCacheEndpointConfigurer.java | 115 +++--
 .../jclouds/JcloudsComponentConfigurer.java        |  41 +-
 .../jclouds/JcloudsEndpointConfigurer.java         |  83 ++--
 .../component/jcr/JcrComponentConfigurer.java      |  33 +-
 .../camel/component/jcr/JcrEndpointConfigurer.java |  80 ++--
 .../component/jdbc/JdbcComponentConfigurer.java    |  33 +-
 .../component/jdbc/JdbcEndpointConfigurer.java     |  78 ++--
 .../jetty9/JettyHttpComponent9Configurer.java      | 148 +++----
 .../jetty9/JettyHttpEndpoint9Configurer.java       | 152 +++----
 .../jgroups/JGroupsComponentConfigurer.java        |  44 +-
 .../jgroups/JGroupsEndpointConfigurer.java         |  52 +--
 .../validator/jing/JingComponentConfigurer.java    |  29 +-
 .../validator/jing/JingEndpointConfigurer.java     |  36 +-
 .../component/jira/JiraComponentConfigurer.java    |  36 +-
 .../component/jira/JiraEndpointConfigurer.java     |  80 ++--
 .../component/jms/JmsComponentConfigurer.java      | 352 ++++++++--------
 .../camel/component/jms/JmsEndpointConfigurer.java | 387 ++++++++---------
 .../component/jmx/JMXComponentConfigurer.java      |  29 +-
 .../camel/component/jmx/JMXEndpointConfigurer.java | 138 +++---
 .../component/jolt/JoltComponentConfigurer.java    |  32 +-
 .../component/jolt/JoltEndpointConfigurer.java     |  48 +--
 .../component/jooq/JooqComponentConfigurer.java    |  36 +-
 .../component/jooq/JooqEndpointConfigurer.java     | 115 +++--
 .../component/jpa/JpaComponentConfigurer.java      |  49 +--
 .../camel/component/jpa/JpaEndpointConfigurer.java | 197 ++++-----
 .../component/scp/ScpComponentConfigurer.java      |  33 +-
 .../camel/component/scp/ScpEndpointConfigurer.java | 109 ++---
 .../component/jslt/JsltComponentConfigurer.java    |  32 +-
 .../component/jslt/JsltEndpointConfigurer.java     |  40 +-
 .../JsonValidatorComponentConfigurer.java          |  29 +-
 .../JsonValidatorEndpointConfigurer.java           |  56 +--
 .../component/jt400/Jt400ComponentConfigurer.java  |  37 +-
 .../component/jt400/Jt400EndpointConfigurer.java   | 145 +++----
 .../component/kafka/KafkaComponentConfigurer.java  |  59 +--
 .../component/kafka/KafkaEndpointConfigurer.java   | 400 +++++++++---------
 .../KubernetesConfigMapsComponentConfigurer.java   |  29 +-
 .../KubernetesConfigMapsEndpointConfigurer.java    | 105 ++---
 .../KubernetesDeploymentsComponentConfigurer.java  |  33 +-
 .../KubernetesDeploymentsEndpointConfigurer.java   | 136 +++---
 .../hpa/KubernetesHPAComponentConfigurer.java      |  33 +-
 .../hpa/KubernetesHPAEndpointConfigurer.java       | 136 +++---
 .../job/KubernetesJobComponentConfigurer.java      |  33 +-
 .../job/KubernetesJobEndpointConfigurer.java       | 136 +++---
 .../KubernetesNamespacesComponentConfigurer.java   |  33 +-
 .../KubernetesNamespacesEndpointConfigurer.java    | 136 +++---
 .../nodes/KubernetesNodesComponentConfigurer.java  |  33 +-
 .../nodes/KubernetesNodesEndpointConfigurer.java   | 136 +++---
 ...rnetesPersistentVolumesComponentConfigurer.java |  29 +-
 ...ernetesPersistentVolumesEndpointConfigurer.java | 105 ++---
 ...PersistentVolumesClaimsComponentConfigurer.java |  29 +-
 ...sPersistentVolumesClaimsEndpointConfigurer.java | 105 ++---
 .../pods/KubernetesPodsComponentConfigurer.java    |  33 +-
 .../pods/KubernetesPodsEndpointConfigurer.java     | 136 +++---
 ...sReplicationControllersComponentConfigurer.java |  33 +-
 ...esReplicationControllersEndpointConfigurer.java | 136 +++---
 ...ubernetesResourcesQuotaComponentConfigurer.java |  29 +-
 ...KubernetesResourcesQuotaEndpointConfigurer.java | 105 ++---
 .../KubernetesSecretsComponentConfigurer.java      |  29 +-
 .../KubernetesSecretsEndpointConfigurer.java       | 105 ++---
 ...bernetesServiceAccountsComponentConfigurer.java |  29 +-
 ...ubernetesServiceAccountsEndpointConfigurer.java | 105 ++---
 .../KubernetesServicesComponentConfigurer.java     |  33 +-
 .../KubernetesServicesEndpointConfigurer.java      | 136 +++---
 .../OpenshiftBuildConfigsComponentConfigurer.java  |  29 +-
 .../OpenshiftBuildConfigsEndpointConfigurer.java   | 105 ++---
 .../builds/OpenshiftBuildsComponentConfigurer.java |  29 +-
 .../builds/OpenshiftBuildsEndpointConfigurer.java  | 105 ++---
 .../component/kudu/KuduComponentConfigurer.java    |  29 +-
 .../component/kudu/KuduEndpointConfigurer.java     |  35 +-
 .../language/LanguageComponentConfigurer.java      |  29 +-
 .../language/LanguageEndpointConfigurer.java       |  49 +--
 .../component/ldap/LdapComponentConfigurer.java    |  29 +-
 .../component/ldap/LdapEndpointConfigurer.java     |  46 +-
 .../component/ldif/LdifComponentConfigurer.java    |  29 +-
 .../component/ldif/LdifEndpointConfigurer.java     |  32 +-
 .../component/log/LogComponentConfigurer.java      |  33 +-
 .../camel/component/log/LogEndpointConfigurer.java | 128 +++---
 .../lucene/LuceneComponentConfigurer.java          |  32 +-
 .../component/lucene/LuceneEndpointConfigurer.java |  47 +--
 .../lumberjack/LumberjackComponentConfigurer.java  |  37 +-
 .../lumberjack/LumberjackEndpointConfigurer.java   |  44 +-
 .../component/mail/MailComponentConfigurer.java    |  48 +--
 .../component/mail/MailEndpointConfigurer.java     | 260 +++++-------
 .../master/MasterComponentConfigurer.java          |  36 +-
 .../component/master/MasterEndpointConfigurer.java |  40 +-
 .../metrics/MetricsComponentConfigurer.java        |  33 +-
 .../metrics/MetricsEndpointConfigurer.java         |  50 +--
 .../micrometer/MicrometerComponentConfigurer.java  |  33 +-
 .../micrometer/MicrometerEndpointConfigurer.java   |  44 +-
 .../component/mina/MinaComponentConfigurer.java    |  40 +-
 .../component/mina/MinaEndpointConfigurer.java     | 129 +++---
 .../component/mock/MockComponentConfigurer.java    |  29 +-
 .../component/mock/MockEndpointConfigurer.java     |  72 ++--
 .../mongodb/gridfs/GridFsComponentConfigurer.java  |  33 +-
 .../mongodb/gridfs/GridFsEndpointConfigurer.java   |  87 ++--
 .../mongodb/MongoDbComponentConfigurer.java        |  37 +-
 .../mongodb/MongoDbEndpointConfigurer.java         | 120 +++---
 .../validator/msv/MsvComponentConfigurer.java      |  37 +-
 .../validator/msv/MsvEndpointConfigurer.java       |  68 ++-
 .../mustache/MustacheComponentConfigurer.java      |  33 +-
 .../mustache/MustacheEndpointConfigurer.java       |  47 +--
 .../component/mvel/MvelComponentConfigurer.java    |  29 +-
 .../component/mvel/MvelEndpointConfigurer.java     |  39 +-
 .../mybatis/MyBatisBeanComponentConfigurer.java    |  37 +-
 .../mybatis/MyBatisBeanEndpointConfigurer.java     |  44 +-
 .../mybatis/MyBatisComponentConfigurer.java        |  41 +-
 .../mybatis/MyBatisEndpointConfigurer.java         | 144 +++----
 .../nagios/NagiosComponentConfigurer.java          |  32 +-
 .../component/nagios/NagiosEndpointConfigurer.java |  49 +--
 .../component/nats/NatsComponentConfigurer.java    |  40 +-
 .../component/nats/NatsEndpointConfigurer.java     | 126 +++---
 .../netty/http/NettyHttpComponentConfigurer.java   |  64 ++-
 .../netty/http/NettyHttpEndpointConfigurer.java    | 330 +++++++--------
 .../component/netty/NettyComponentConfigurer.java  |  52 +--
 .../component/netty/NettyEndpointConfigurer.java   | 291 ++++++-------
 .../nitrite/NitriteComponentConfigurer.java        |  33 +-
 .../nitrite/NitriteEndpointConfigurer.java         |  61 +--
 .../component/nsq/NsqComponentConfigurer.java      |  40 +-
 .../camel/component/nsq/NsqEndpointConfigurer.java |  88 ++--
 .../olingo2/Olingo2ComponentConfigurer.java        |  40 +-
 .../olingo2/Olingo2EndpointConfigurer.java         | 152 +++----
 .../olingo4/Olingo4ComponentConfigurer.java        |  40 +-
 .../olingo4/Olingo4EndpointConfigurer.java         | 152 +++----
 .../OptaPlannerComponentConfigurer.java            |  33 +-
 .../optaplanner/OptaPlannerEndpointConfigurer.java |  55 +--
 .../component/paho/PahoComponentConfigurer.java    |  43 +-
 .../component/paho/PahoEndpointConfigurer.java     | 147 +++----
 .../paxlogging/PaxLoggingComponentConfigurer.java  |  33 +-
 .../paxlogging/PaxLoggingEndpointConfigurer.java   |  40 +-
 .../component/pdf/PdfComponentConfigurer.java      |  29 +-
 .../camel/component/pdf/PdfEndpointConfigurer.java |  63 ++-
 .../pgevent/PgEventComponentConfigurer.java        |  33 +-
 .../pgevent/PgEventEndpointConfigurer.java         |  53 +--
 .../printer/PrinterComponentConfigurer.java        |  29 +-
 .../printer/PrinterEndpointConfigurer.java         |  68 ++-
 .../pubnub/PubNubComponentConfigurer.java          |  33 +-
 .../component/pubnub/PubNubEndpointConfigurer.java |  80 ++--
 .../pulsar/PulsarComponentConfigurer.java          |  49 +--
 .../component/pulsar/PulsarEndpointConfigurer.java | 132 +++---
 .../quartz/QuartzComponentConfigurer.java          |  71 ++--
 .../component/quartz/QuartzEndpointConfigurer.java |  98 ++---
 .../quickfixj/QuickfixjComponentConfigurer.java    |  52 +--
 .../quickfixj/QuickfixjEndpointConfigurer.java     |  52 +--
 .../rabbitmq/RabbitMQComponentConfigurer.java      | 217 +++++-----
 .../rabbitmq/RabbitMQEndpointConfigurer.java       | 243 +++++------
 .../component/ref/RefComponentConfigurer.java      |  33 +-
 .../camel/component/ref/RefEndpointConfigurer.java |  44 +-
 .../swagger/RestSwaggerComponentConfigurer.java    |  58 +--
 .../swagger/RestSwaggerEndpointConfigurer.java     |  53 +--
 .../component/rest/RestApiComponentConfigurer.java |  29 +-
 .../component/rest/RestApiEndpointConfigurer.java  |  48 +--
 .../component/rest/RestComponentConfigurer.java    |  52 +--
 .../component/rest/RestEndpointConfigurer.java     |  88 ++--
 .../RobotFrameworkComponentConfigurer.java         |  36 +-
 .../RobotFrameworkEndpointConfigurer.java          | 273 ++++++------
 .../component/rss/RssComponentConfigurer.java      |  29 +-
 .../camel/component/rss/RssEndpointConfigurer.java | 130 +++---
 .../component/saga/SagaComponentConfigurer.java    |  29 +-
 .../component/saga/SagaEndpointConfigurer.java     |  32 +-
 .../salesforce/SalesforceComponentConfigurer.java  | 153 +++----
 .../salesforce/SalesforceEndpointConfigurer.java   | 198 ++++-----
 .../netweaver/NetWeaverComponentConfigurer.java    |  29 +-
 .../sap/netweaver/NetWeaverEndpointConfigurer.java |  49 +--
 .../xquery/XQueryComponentConfigurer.java          |  44 +-
 .../component/xquery/XQueryEndpointConfigurer.java | 150 +++----
 .../scheduler/SchedulerComponentConfigurer.java    |  33 +-
 .../scheduler/SchedulerEndpointConfigurer.java     | 105 ++---
 .../schematron/SchematronComponentConfigurer.java  |  29 +-
 .../schematron/SchematronEndpointConfigurer.java   |  42 +-
 .../component/seda/SedaComponentConfigurer.java    |  57 +--
 .../component/seda/SedaEndpointConfigurer.java     |  97 ++---
 .../service/ServiceComponentConfigurer.java        |  36 +-
 .../service/ServiceEndpointConfigurer.java         |  40 +-
 .../servlet/ServletComponentConfigurer.java        |  61 ++-
 .../servlet/ServletEndpointConfigurer.java         | 114 +++--
 .../component/sip/SipComponentConfigurer.java      |  33 +-
 .../camel/component/sip/SipEndpointConfigurer.java | 202 ++++-----
 .../component/sjms/SjmsComponentConfigurer.java    |  89 ++--
 .../component/sjms/SjmsEndpointConfigurer.java     | 161 ++++---
 .../sjms/batch/SjmsBatchComponentConfigurer.java   |  45 +-
 .../sjms/batch/SjmsBatchEndpointConfigurer.java    | 116 +++--
 .../component/sjms2/Sjms2ComponentConfigurer.java  |  89 ++--
 .../component/sjms2/Sjms2EndpointConfigurer.java   | 171 ++++----
 .../component/slack/SlackComponentConfigurer.java  |  37 +-
 .../component/slack/SlackEndpointConfigurer.java   | 131 +++---
 .../component/smpp/SmppComponentConfigurer.java    |  36 +-
 .../component/smpp/SmppEndpointConfigurer.java     | 177 ++++----
 .../component/snmp/SnmpComponentConfigurer.java    |  33 +-
 .../component/snmp/SnmpEndpointConfigurer.java     | 164 ++++----
 .../component/solr/SolrComponentConfigurer.java    |  29 +-
 .../component/solr/SolrEndpointConfigurer.java     |  85 ++--
 .../sparkrest/SparkComponentConfigurer.java        |  72 ++--
 .../sparkrest/SparkEndpointConfigurer.java         |  67 ++-
 .../component/spark/SparkComponentConfigurer.java  |  36 +-
 .../component/spark/SparkEndpointConfigurer.java   |  50 +--
 .../splunk/SplunkComponentConfigurer.java          |  37 +-
 .../component/splunk/SplunkEndpointConfigurer.java | 184 ++++----
 .../SpringIntegrationComponentConfigurer.java      |  33 +-
 .../SpringIntegrationEndpointConfigurer.java       |  56 +--
 .../springldap/SpringLdapComponentConfigurer.java  |  29 +-
 .../springldap/SpringLdapEndpointConfigurer.java   |  38 +-
 .../component/redis/RedisComponentConfigurer.java  |  33 +-
 .../component/redis/RedisEndpointConfigurer.java   |  65 ++-
 .../ws/SpringWebserviceComponentConfigurer.java    |  37 +-
 .../ws/SpringWebserviceEndpointConfigurer.java     | 111 +++--
 .../component/event/EventComponentConfigurer.java  |  33 +-
 .../component/event/EventEndpointConfigurer.java   |  44 +-
 .../component/sql/SqlComponentConfigurer.java      |  41 +-
 .../camel/component/sql/SqlEndpointConfigurer.java | 204 ++++-----
 .../sql/stored/SqlStoredComponentConfigurer.java   |  33 +-
 .../sql/stored/SqlStoredEndpointConfigurer.java    |  53 +--
 .../component/ssh/SshComponentConfigurer.java      |  83 ++--
 .../camel/component/ssh/SshEndpointConfigurer.java | 154 +++----
 .../component/stax/StAXComponentConfigurer.java    |  29 +-
 .../component/stax/StAXEndpointConfigurer.java     |  32 +-
 .../component/stomp/StompComponentConfigurer.java  |  57 +--
 .../component/stomp/StompEndpointConfigurer.java   |  72 ++--
 .../stream/StreamComponentConfigurer.java          |  33 +-
 .../component/stream/StreamEndpointConfigurer.java | 101 ++---
 .../StringTemplateComponentConfigurer.java         |  29 +-
 .../StringTemplateEndpointConfigurer.java          |  44 +-
 .../component/stub/StubComponentConfigurer.java    |  57 +--
 .../component/stub/StubEndpointConfigurer.java     |  97 ++---
 .../telegram/TelegramComponentConfigurer.java      |  48 +--
 .../telegram/TelegramEndpointConfigurer.java       | 139 +++---
 .../thrift/ThriftComponentConfigurer.java          |  37 +-
 .../component/thrift/ThriftEndpointConfigurer.java |  75 ++--
 .../component/tika/TikaComponentConfigurer.java    |  29 +-
 .../component/tika/TikaEndpointConfigurer.java     |  48 +--
 .../component/timer/TimerComponentConfigurer.java  |  29 +-
 .../component/timer/TimerEndpointConfigurer.java   |  70 ++--
 .../twilio/TwilioComponentConfigurer.java          |  50 +--
 .../component/twilio/TwilioEndpointConfigurer.java | 109 ++---
 .../undertow/UndertowComponentConfigurer.java      |  53 +--
 .../undertow/UndertowEndpointConfigurer.java       | 130 +++---
 .../validator/ValidatorComponentConfigurer.java    |  33 +-
 .../validator/ValidatorEndpointConfigurer.java     |  68 ++-
 .../velocity/VelocityComponentConfigurer.java      |  33 +-
 .../velocity/VelocityEndpointConfigurer.java       |  47 +--
 .../component/vertx/VertxComponentConfigurer.java  |  53 +--
 .../component/vertx/VertxEndpointConfigurer.java   |  48 +--
 .../camel/component/vm/VmComponentConfigurer.java  |  57 +--
 .../camel/component/vm/VmEndpointConfigurer.java   |  97 ++---
 .../weather/WeatherComponentConfigurer.java        |  41 +-
 .../weather/WeatherEndpointConfigurer.java         | 197 ++++-----
 .../component/web3j/Web3jComponentConfigurer.java  |  36 +-
 .../component/web3j/Web3jEndpointConfigurer.java   | 167 ++++----
 .../webhook/WebhookComponentConfigurer.java        |  32 +-
 .../webhook/WebhookEndpointConfigurer.java         |  60 +--
 .../websocket/jsr356/JSR356EndpointConfigurer.java |  48 +--
 .../jsr356/JSR356WebSocketComponentConfigurer.java |  37 +-
 .../websocket/WebsocketComponentConfigurer.java    |  83 ++--
 .../websocket/WebsocketEndpointConfigurer.java     | 100 ++---
 .../component/weka/WekaComponentConfigurer.java    |  29 +-
 .../component/weka/WekaEndpointConfigurer.java     |  61 +--
 .../wordpress/WordpressComponentConfigurer.java    |  36 +-
 .../wordpress/WordpressEndpointConfigurer.java     |  70 ++--
 .../xchange/XChangeComponentConfigurer.java        |  29 +-
 .../xchange/XChangeEndpointConfigurer.java         |  45 +-
 .../camel/component/xj/XJComponentConfigurer.java  |  61 ++-
 .../camel/component/xj/XJEndpointConfigurer.java   |  95 ++---
 .../XmlSignatureComponentConfigurer.java           |  37 +-
 .../XmlSignatureEndpointConfigurer.java            | 167 ++++----
 .../component/xmpp/XmppComponentConfigurer.java    |  33 +-
 .../component/xmpp/XmppEndpointConfigurer.java     |  96 ++---
 .../xslt/saxon/XsltSaxonComponentConfigurer.java   |  61 ++-
 .../xslt/saxon/XsltSaxonEndpointConfigurer.java    |  91 ++--
 .../component/xslt/XsltComponentConfigurer.java    |  49 +--
 .../component/xslt/XsltEndpointConfigurer.java     |  79 ++--
 .../yammer/YammerComponentConfigurer.java          |  48 +--
 .../component/yammer/YammerEndpointConfigurer.java | 139 +++---
 .../zendesk/ZendeskComponentConfigurer.java        |  39 +-
 .../zendesk/ZendeskEndpointConfigurer.java         | 126 +++---
 .../zookeepermaster/MasterComponentConfigurer.java |  52 +--
 .../zookeepermaster/MasterEndpointConfigurer.java  |  40 +-
 .../zookeeper/ZooKeeperComponentConfigurer.java    |  36 +-
 .../zookeeper/ZooKeeperEndpointConfigurer.java     |  68 ++-
 .../packaging/PropertyConfigurerGenerator.java     |  36 +-
 523 files changed, 15448 insertions(+), 23662 deletions(-)

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 225e52c..55ea9b2 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
@@ -12,43 +12,28 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class WsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "client": ((WsComponent) target).setClient(property(camelContext, org.asynchttpclient.AsyncHttpClient.class, value)); return true;
-        case "binding": ((WsComponent) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientConfig": ((WsComponent) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "sslContextParameters": ((WsComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "allowJavaSerializedObject": ((WsComponent) target).setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
-        case "useGlobalSslContextParameters": ((WsComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "headerFilterStrategy": ((WsComponent) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "basicPropertyBinding": ((WsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((WsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((WsComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "client": ((WsComponent) target).setClient(property(camelContext, org.asynchttpclient.AsyncHttpClient.class, value)); return true;
-        case "binding": ((WsComponent) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientconfig": ((WsComponent) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "sslcontextparameters": ((WsComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "allowjavaserializedobject": ((WsComponent) target).setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
-        case "useglobalsslcontextparameters": ((WsComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "headerfilterstrategy": ((WsComponent) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "basicpropertybinding": ((WsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((WsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((WsComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        WsComponent target = (WsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "client": target.setClient(property(camelContext, org.asynchttpclient.AsyncHttpClient.class, value)); return true;
+        case "binding": target.setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
+        case "clientconfig":
+        case "clientConfig": target.setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        case "allowjavaserializedobject":
+        case "allowJavaSerializedObject": target.setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
+        case "useglobalsslcontextparameters":
+        case "useGlobalSslContextParameters": target.setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 a0f3f35..0b25b2b 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
@@ -12,63 +12,48 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class WsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "bridgeEndpoint": ((WsEndpoint) target).setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
-        case "bufferSize": ((WsEndpoint) target).setBufferSize(property(camelContext, int.class, value)); return true;
-        case "headerFilterStrategy": ((WsEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "throwExceptionOnFailure": ((WsEndpoint) target).setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
-        case "transferException": ((WsEndpoint) target).setTransferException(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((WsEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendMessageOnError": ((WsEndpoint) target).setSendMessageOnError(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((WsEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((WsEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "connectionClose": ((WsEndpoint) target).setConnectionClose(property(camelContext, boolean.class, value)); return true;
-        case "cookieHandler": ((WsEndpoint) target).setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
-        case "lazyStartProducer": ((WsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "useStreaming": ((WsEndpoint) target).setUseStreaming(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((WsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "binding": ((WsEndpoint) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientConfig": ((WsEndpoint) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "clientConfigOptions": ((WsEndpoint) target).setClientConfigOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((WsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "clientConfigRealmOptions": ((WsEndpoint) target).setClientConfigRealmOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "sslContextParameters": ((WsEndpoint) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "bridgeendpoint": ((WsEndpoint) target).setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
-        case "buffersize": ((WsEndpoint) target).setBufferSize(property(camelContext, int.class, value)); return true;
-        case "headerfilterstrategy": ((WsEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "throwexceptiononfailure": ((WsEndpoint) target).setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
-        case "transferexception": ((WsEndpoint) target).setTransferException(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((WsEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendmessageonerror": ((WsEndpoint) target).setSendMessageOnError(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((WsEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((WsEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "connectionclose": ((WsEndpoint) target).setConnectionClose(property(camelContext, boolean.class, value)); return true;
-        case "cookiehandler": ((WsEndpoint) target).setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
-        case "lazystartproducer": ((WsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "usestreaming": ((WsEndpoint) target).setUseStreaming(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((WsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "binding": ((WsEndpoint) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientconfig": ((WsEndpoint) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "clientconfigoptions": ((WsEndpoint) target).setClientConfigOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((WsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "clientconfigrealmoptions": ((WsEndpoint) target).setClientConfigRealmOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "sslcontextparameters": ((WsEndpoint) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        WsEndpoint target = (WsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "bridgeendpoint":
+        case "bridgeEndpoint": target.setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
+        case "buffersize":
+        case "bufferSize": target.setBufferSize(property(camelContext, int.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "throwexceptiononfailure":
+        case "throwExceptionOnFailure": target.setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
+        case "transferexception":
+        case "transferException": target.setTransferException(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "sendmessageonerror":
+        case "sendMessageOnError": target.setSendMessageOnError(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "connectionclose":
+        case "connectionClose": target.setConnectionClose(property(camelContext, boolean.class, value)); return true;
+        case "cookiehandler":
+        case "cookieHandler": target.setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "usestreaming":
+        case "useStreaming": target.setUseStreaming(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "binding": target.setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
+        case "clientconfig":
+        case "clientConfig": target.setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
+        case "clientconfigoptions":
+        case "clientConfigOptions": target.setClientConfigOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "clientconfigrealmoptions":
+        case "clientConfigRealmOptions": target.setClientConfigRealmOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        default: return false;
         }
     }
 
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 137d00c..13609c7 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
@@ -12,41 +12,26 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AhcComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "client": ((AhcComponent) target).setClient(property(camelContext, org.asynchttpclient.AsyncHttpClient.class, value)); return true;
-        case "binding": ((AhcComponent) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientConfig": ((AhcComponent) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "sslContextParameters": ((AhcComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "allowJavaSerializedObject": ((AhcComponent) target).setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
-        case "useGlobalSslContextParameters": ((AhcComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "headerFilterStrategy": ((AhcComponent) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "basicPropertyBinding": ((AhcComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AhcComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "client": ((AhcComponent) target).setClient(property(camelContext, org.asynchttpclient.AsyncHttpClient.class, value)); return true;
-        case "binding": ((AhcComponent) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientconfig": ((AhcComponent) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "sslcontextparameters": ((AhcComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "allowjavaserializedobject": ((AhcComponent) target).setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
-        case "useglobalsslcontextparameters": ((AhcComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "headerfilterstrategy": ((AhcComponent) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "basicpropertybinding": ((AhcComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AhcComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AhcComponent target = (AhcComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "client": target.setClient(property(camelContext, org.asynchttpclient.AsyncHttpClient.class, value)); return true;
+        case "binding": target.setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
+        case "clientconfig":
+        case "clientConfig": target.setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        case "allowjavaserializedobject":
+        case "allowJavaSerializedObject": target.setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
+        case "useglobalsslcontextparameters":
+        case "useGlobalSslContextParameters": target.setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 52e5139..7b256bb 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
@@ -12,53 +12,38 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AhcEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "bridgeEndpoint": ((AhcEndpoint) target).setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
-        case "bufferSize": ((AhcEndpoint) target).setBufferSize(property(camelContext, int.class, value)); return true;
-        case "connectionClose": ((AhcEndpoint) target).setConnectionClose(property(camelContext, boolean.class, value)); return true;
-        case "cookieHandler": ((AhcEndpoint) target).setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
-        case "headerFilterStrategy": ((AhcEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "lazyStartProducer": ((AhcEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "throwExceptionOnFailure": ((AhcEndpoint) target).setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
-        case "transferException": ((AhcEndpoint) target).setTransferException(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AhcEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "binding": ((AhcEndpoint) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientConfig": ((AhcEndpoint) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "clientConfigOptions": ((AhcEndpoint) target).setClientConfigOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AhcEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "clientConfigRealmOptions": ((AhcEndpoint) target).setClientConfigRealmOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "sslContextParameters": ((AhcEndpoint) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "bridgeendpoint": ((AhcEndpoint) target).setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
-        case "buffersize": ((AhcEndpoint) target).setBufferSize(property(camelContext, int.class, value)); return true;
-        case "connectionclose": ((AhcEndpoint) target).setConnectionClose(property(camelContext, boolean.class, value)); return true;
-        case "cookiehandler": ((AhcEndpoint) target).setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
-        case "headerfilterstrategy": ((AhcEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "lazystartproducer": ((AhcEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "throwexceptiononfailure": ((AhcEndpoint) target).setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
-        case "transferexception": ((AhcEndpoint) target).setTransferException(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AhcEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "binding": ((AhcEndpoint) target).setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
-        case "clientconfig": ((AhcEndpoint) target).setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
-        case "clientconfigoptions": ((AhcEndpoint) target).setClientConfigOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AhcEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "clientconfigrealmoptions": ((AhcEndpoint) target).setClientConfigRealmOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "sslcontextparameters": ((AhcEndpoint) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AhcEndpoint target = (AhcEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "bridgeendpoint":
+        case "bridgeEndpoint": target.setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
+        case "buffersize":
+        case "bufferSize": target.setBufferSize(property(camelContext, int.class, value)); return true;
+        case "connectionclose":
+        case "connectionClose": target.setConnectionClose(property(camelContext, boolean.class, value)); return true;
+        case "cookiehandler":
+        case "cookieHandler": target.setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "throwexceptiononfailure":
+        case "throwExceptionOnFailure": target.setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
+        case "transferexception":
+        case "transferException": target.setTransferException(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "binding": target.setBinding(property(camelContext, org.apache.camel.component.ahc.AhcBinding.class, value)); return true;
+        case "clientconfig":
+        case "clientConfig": target.setClientConfig(property(camelContext, org.asynchttpclient.AsyncHttpClientConfig.class, value)); return true;
+        case "clientconfigoptions":
+        case "clientConfigOptions": target.setClientConfigOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "clientconfigrealmoptions":
+        case "clientConfigRealmOptions": target.setClientConfigRealmOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        default: return false;
         }
     }
 
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 e3798df..becc0c6 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
@@ -12,31 +12,18 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ApnsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "apnsService": ((ApnsComponent) target).setApnsService(property(camelContext, com.notnoop.apns.ApnsService.class, value)); return true;
-        case "basicPropertyBinding": ((ApnsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ApnsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((ApnsComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "apnsservice": ((ApnsComponent) target).setApnsService(property(camelContext, com.notnoop.apns.ApnsService.class, value)); return true;
-        case "basicpropertybinding": ((ApnsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ApnsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((ApnsComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ApnsComponent target = (ApnsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "apnsservice":
+        case "apnsService": target.setApnsService(property(camelContext, com.notnoop.apns.ApnsService.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 8a50a96..792c472 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
@@ -12,69 +12,51 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ApnsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "tokens": ((ApnsEndpoint) target).setTokens(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((ApnsEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((ApnsEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((ApnsEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((ApnsEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((ApnsEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazyStartProducer": ((ApnsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((ApnsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ApnsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((ApnsEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((ApnsEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((ApnsEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((ApnsEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((ApnsEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((ApnsEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((ApnsEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((ApnsEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((ApnsEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((ApnsEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((ApnsEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((ApnsEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((ApnsEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((ApnsEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "tokens": ((ApnsEndpoint) target).setTokens(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((ApnsEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendemptymessagewhenidle": ((ApnsEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((ApnsEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((ApnsEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((ApnsEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazystartproducer": ((ApnsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((ApnsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ApnsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((ApnsEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((ApnsEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((ApnsEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((ApnsEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((ApnsEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((ApnsEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((ApnsEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((ApnsEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((ApnsEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((ApnsEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((ApnsEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((ApnsEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((ApnsEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((ApnsEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ApnsEndpoint target = (ApnsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "tokens": target.setTokens(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 9565981..a8e9ce5 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
@@ -12,31 +12,17 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.as2.AS2Configuration.class, value)); return true;
-        case "basicPropertyBinding": ((AS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AS2Component) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.as2.AS2Configuration.class, value)); return true;
-        case "basicpropertybinding": ((AS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AS2Component) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AS2Component target = (AS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.as2.AS2Configuration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 58009a5..f0a226a 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
@@ -12,121 +12,101 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "as2From": ((AS2Endpoint) target).getConfiguration().setAs2From(property(camelContext, java.lang.String.class, value)); return true;
-        case "as2MessageStructure": ((AS2Endpoint) target).getConfiguration().setAs2MessageStructure(property(camelContext, org.apache.camel.component.as2.api.AS2MessageStructure.class, value)); return true;
-        case "as2To": ((AS2Endpoint) target).getConfiguration().setAs2To(property(camelContext, java.lang.String.class, value)); return true;
-        case "as2Version": ((AS2Endpoint) target).getConfiguration().setAs2Version(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientFqdn": ((AS2Endpoint) target).getConfiguration().setClientFqdn(property(camelContext, java.lang.String.class, value)); return true;
-        case "compressionAlgorithm": ((AS2Endpoint) target).getConfiguration().setCompressionAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2CompressionAlgorithm.class, value)); return true;
-        case "decryptingPrivateKey": ((AS2Endpoint) target).getConfiguration().setDecryptingPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
-        case "dispositionNotificationTo": ((AS2Endpoint) target).getConfiguration().setDispositionNotificationTo(property(camelContext, java.lang.String.class, value)); return true;
-        case "ediMessageTransferEncoding": ((AS2Endpoint) target).getConfiguration().setEdiMessageTransferEncoding(property(camelContext, java.lang.String.class, value)); return true;
-        case "ediMessageType": ((AS2Endpoint) target).getConfiguration().setEdiMessageType(property(camelContext, org.apache.http.entity.ContentType.class, value)); return true;
-        case "encryptingAlgorithm": ((AS2Endpoint) target).getConfiguration().setEncryptingAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2EncryptionAlgorithm.class, value)); return true;
-        case "encryptingCertificateChain": ((AS2Endpoint) target).getConfiguration().setEncryptingCertificateChain(property(camelContext, java.security.cert.Certificate[].class, value)); return true;
-        case "from": ((AS2Endpoint) target).getConfiguration().setFrom(property(camelContext, java.lang.String.class, value)); return true;
-        case "inBody": ((AS2Endpoint) target).setInBody(property(camelContext, java.lang.String.class, value)); return true;
-        case "mdnMessageTemplate": ((AS2Endpoint) target).getConfiguration().setMdnMessageTemplate(property(camelContext, java.lang.String.class, value)); return true;
-        case "requestUri": ((AS2Endpoint) target).getConfiguration().setRequestUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "server": ((AS2Endpoint) target).getConfiguration().setServer(property(camelContext, java.lang.String.class, value)); return true;
-        case "serverFqdn": ((AS2Endpoint) target).getConfiguration().setServerFqdn(property(camelContext, java.lang.String.class, value)); return true;
-        case "serverPortNumber": ((AS2Endpoint) target).getConfiguration().setServerPortNumber(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "signedReceiptMicAlgorithms": ((AS2Endpoint) target).getConfiguration().setSignedReceiptMicAlgorithms(property(camelContext, java.lang.String[].class, value)); return true;
-        case "signingAlgorithm": ((AS2Endpoint) target).getConfiguration().setSigningAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2SignatureAlgorithm.class, value)); return true;
-        case "signingCertificateChain": ((AS2Endpoint) target).getConfiguration().setSigningCertificateChain(property(camelContext, java.security.cert.Certificate[].class, value)); return true;
-        case "signingPrivateKey": ((AS2Endpoint) target).getConfiguration().setSigningPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
-        case "subject": ((AS2Endpoint) target).getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
-        case "targetHostname": ((AS2Endpoint) target).getConfiguration().setTargetHostname(property(camelContext, java.lang.String.class, value)); return true;
-        case "targetPortNumber": ((AS2Endpoint) target).getConfiguration().setTargetPortNumber(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "userAgent": ((AS2Endpoint) target).getConfiguration().setUserAgent(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((AS2Endpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((AS2Endpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AS2Endpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AS2Endpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((AS2Endpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazyStartProducer": ((AS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((AS2Endpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((AS2Endpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((AS2Endpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((AS2Endpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((AS2Endpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((AS2Endpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((AS2Endpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((AS2Endpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((AS2Endpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((AS2Endpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((AS2Endpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((AS2Endpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((AS2Endpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((AS2Endpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "as2from": ((AS2Endpoint) target).getConfiguration().setAs2From(property(camelContext, java.lang.String.class, value)); return true;
-        case "as2messagestructure": ((AS2Endpoint) target).getConfiguration().setAs2MessageStructure(property(camelContext, org.apache.camel.component.as2.api.AS2MessageStructure.class, value)); return true;
-        case "as2to": ((AS2Endpoint) target).getConfiguration().setAs2To(property(camelContext, java.lang.String.class, value)); return true;
-        case "as2version": ((AS2Endpoint) target).getConfiguration().setAs2Version(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientfqdn": ((AS2Endpoint) target).getConfiguration().setClientFqdn(property(camelContext, java.lang.String.class, value)); return true;
-        case "compressionalgorithm": ((AS2Endpoint) target).getConfiguration().setCompressionAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2CompressionAlgorithm.class, value)); return true;
-        case "decryptingprivatekey": ((AS2Endpoint) target).getConfiguration().setDecryptingPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
-        case "dispositionnotificationto": ((AS2Endpoint) target).getConfiguration().setDispositionNotificationTo(property(camelContext, java.lang.String.class, value)); return true;
-        case "edimessagetransferencoding": ((AS2Endpoint) target).getConfiguration().setEdiMessageTransferEncoding(property(camelContext, java.lang.String.class, value)); return true;
-        case "edimessagetype": ((AS2Endpoint) target).getConfiguration().setEdiMessageType(property(camelContext, org.apache.http.entity.ContentType.class, value)); return true;
-        case "encryptingalgorithm": ((AS2Endpoint) target).getConfiguration().setEncryptingAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2EncryptionAlgorithm.class, value)); return true;
-        case "encryptingcertificatechain": ((AS2Endpoint) target).getConfiguration().setEncryptingCertificateChain(property(camelContext, java.security.cert.Certificate[].class, value)); return true;
-        case "from": ((AS2Endpoint) target).getConfiguration().setFrom(property(camelContext, java.lang.String.class, value)); return true;
-        case "inbody": ((AS2Endpoint) target).setInBody(property(camelContext, java.lang.String.class, value)); return true;
-        case "mdnmessagetemplate": ((AS2Endpoint) target).getConfiguration().setMdnMessageTemplate(property(camelContext, java.lang.String.class, value)); return true;
-        case "requesturi": ((AS2Endpoint) target).getConfiguration().setRequestUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "server": ((AS2Endpoint) target).getConfiguration().setServer(property(camelContext, java.lang.String.class, value)); return true;
-        case "serverfqdn": ((AS2Endpoint) target).getConfiguration().setServerFqdn(property(camelContext, java.lang.String.class, value)); return true;
-        case "serverportnumber": ((AS2Endpoint) target).getConfiguration().setServerPortNumber(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "signedreceiptmicalgorithms": ((AS2Endpoint) target).getConfiguration().setSignedReceiptMicAlgorithms(property(camelContext, java.lang.String[].class, value)); return true;
-        case "signingalgorithm": ((AS2Endpoint) target).getConfiguration().setSigningAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2SignatureAlgorithm.class, value)); return true;
-        case "signingcertificatechain": ((AS2Endpoint) target).getConfiguration().setSigningCertificateChain(property(camelContext, java.security.cert.Certificate[].class, value)); return true;
-        case "signingprivatekey": ((AS2Endpoint) target).getConfiguration().setSigningPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
-        case "subject": ((AS2Endpoint) target).getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
-        case "targethostname": ((AS2Endpoint) target).getConfiguration().setTargetHostname(property(camelContext, java.lang.String.class, value)); return true;
-        case "targetportnumber": ((AS2Endpoint) target).getConfiguration().setTargetPortNumber(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "useragent": ((AS2Endpoint) target).getConfiguration().setUserAgent(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((AS2Endpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendemptymessagewhenidle": ((AS2Endpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AS2Endpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AS2Endpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((AS2Endpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazystartproducer": ((AS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((AS2Endpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((AS2Endpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((AS2Endpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((AS2Endpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((AS2Endpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((AS2Endpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((AS2Endpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((AS2Endpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((AS2Endpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((AS2Endpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((AS2Endpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((AS2Endpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((AS2Endpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((AS2Endpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AS2Endpoint target = (AS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "as2from":
+        case "as2From": target.getConfiguration().setAs2From(property(camelContext, java.lang.String.class, value)); return true;
+        case "as2messagestructure":
+        case "as2MessageStructure": target.getConfiguration().setAs2MessageStructure(property(camelContext, org.apache.camel.component.as2.api.AS2MessageStructure.class, value)); return true;
+        case "as2to":
+        case "as2To": target.getConfiguration().setAs2To(property(camelContext, java.lang.String.class, value)); return true;
+        case "as2version":
+        case "as2Version": target.getConfiguration().setAs2Version(property(camelContext, java.lang.String.class, value)); return true;
+        case "clientfqdn":
+        case "clientFqdn": target.getConfiguration().setClientFqdn(property(camelContext, java.lang.String.class, value)); return true;
+        case "compressionalgorithm":
+        case "compressionAlgorithm": target.getConfiguration().setCompressionAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2CompressionAlgorithm.class, value)); return true;
+        case "decryptingprivatekey":
+        case "decryptingPrivateKey": target.getConfiguration().setDecryptingPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
+        case "dispositionnotificationto":
+        case "dispositionNotificationTo": target.getConfiguration().setDispositionNotificationTo(property(camelContext, java.lang.String.class, value)); return true;
+        case "edimessagetransferencoding":
+        case "ediMessageTransferEncoding": target.getConfiguration().setEdiMessageTransferEncoding(property(camelContext, java.lang.String.class, value)); return true;
+        case "edimessagetype":
+        case "ediMessageType": target.getConfiguration().setEdiMessageType(property(camelContext, org.apache.http.entity.ContentType.class, value)); return true;
+        case "encryptingalgorithm":
+        case "encryptingAlgorithm": target.getConfiguration().setEncryptingAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2EncryptionAlgorithm.class, value)); return true;
+        case "encryptingcertificatechain":
+        case "encryptingCertificateChain": target.getConfiguration().setEncryptingCertificateChain(property(camelContext, java.security.cert.Certificate[].class, value)); return true;
+        case "from": target.getConfiguration().setFrom(property(camelContext, java.lang.String.class, value)); return true;
+        case "inbody":
+        case "inBody": target.setInBody(property(camelContext, java.lang.String.class, value)); return true;
+        case "mdnmessagetemplate":
+        case "mdnMessageTemplate": target.getConfiguration().setMdnMessageTemplate(property(camelContext, java.lang.String.class, value)); return true;
+        case "requesturi":
+        case "requestUri": target.getConfiguration().setRequestUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "server": target.getConfiguration().setServer(property(camelContext, java.lang.String.class, value)); return true;
+        case "serverfqdn":
+        case "serverFqdn": target.getConfiguration().setServerFqdn(property(camelContext, java.lang.String.class, value)); return true;
+        case "serverportnumber":
+        case "serverPortNumber": target.getConfiguration().setServerPortNumber(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "signedreceiptmicalgorithms":
+        case "signedReceiptMicAlgorithms": target.getConfiguration().setSignedReceiptMicAlgorithms(property(camelContext, java.lang.String[].class, value)); return true;
+        case "signingalgorithm":
+        case "signingAlgorithm": target.getConfiguration().setSigningAlgorithm(property(camelContext, org.apache.camel.component.as2.api.AS2SignatureAlgorithm.class, value)); return true;
+        case "signingcertificatechain":
+        case "signingCertificateChain": target.getConfiguration().setSigningCertificateChain(property(camelContext, java.security.cert.Certificate[].class, value)); return true;
+        case "signingprivatekey":
+        case "signingPrivateKey": target.getConfiguration().setSigningPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
+        case "subject": target.getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
+        case "targethostname":
+        case "targetHostname": target.getConfiguration().setTargetHostname(property(camelContext, java.lang.String.class, value)); return true;
+        case "targetportnumber":
+        case "targetPortNumber": target.getConfiguration().setTargetPortNumber(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "useragent":
+        case "userAgent": target.getConfiguration().setUserAgent(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 2b7935e..cb3f4ff 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
@@ -12,29 +12,16 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AsteriskComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((AsteriskComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AsteriskComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AsteriskComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((AsteriskComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AsteriskComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AsteriskComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AsteriskComponent target = (AsteriskComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 f22a488..5904d56 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
@@ -12,43 +12,25 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AsteriskEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "hostname": ((AsteriskEndpoint) target).setHostname(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((AsteriskEndpoint) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "username": ((AsteriskEndpoint) target).setUsername(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((AsteriskEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AsteriskEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AsteriskEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "action": ((AsteriskEndpoint) target).setAction(property(camelContext, org.apache.camel.component.asterisk.AsteriskAction.class, value)); return true;
-        case "lazyStartProducer": ((AsteriskEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AsteriskEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AsteriskEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "hostname": ((AsteriskEndpoint) target).setHostname(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((AsteriskEndpoint) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "username": ((AsteriskEndpoint) target).setUsername(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((AsteriskEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AsteriskEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AsteriskEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "action": ((AsteriskEndpoint) target).setAction(property(camelContext, org.apache.camel.component.asterisk.AsteriskAction.class, value)); return true;
-        case "lazystartproducer": ((AsteriskEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AsteriskEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AsteriskEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AsteriskEndpoint target = (AsteriskEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "hostname": target.setHostname(property(camelContext, java.lang.String.class, value)); return true;
+        case "password": target.setPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "username": target.setUsername(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "action": target.setAction(property(camelContext, org.apache.camel.component.asterisk.AsteriskAction.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 bbee3c8..2343562 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
@@ -12,37 +12,23 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtmosComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "fullTokenId": ((AtmosComponent) target).setFullTokenId(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((AtmosComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "uri": ((AtmosComponent) target).setUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslValidation": ((AtmosComponent) target).setSslValidation(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AtmosComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AtmosComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AtmosComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "fulltokenid": ((AtmosComponent) target).setFullTokenId(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((AtmosComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "uri": ((AtmosComponent) target).setUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslvalidation": ((AtmosComponent) target).setSslValidation(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AtmosComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AtmosComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AtmosComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtmosComponent target = (AtmosComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "fulltokenid":
+        case "fullTokenId": target.setFullTokenId(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "uri": target.setUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "sslvalidation":
+        case "sslValidation": target.setSslValidation(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 037adb5..86cdeb3 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
@@ -12,51 +12,35 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtmosEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "localPath": ((AtmosEndpoint) target).getConfiguration().setLocalPath(property(camelContext, java.lang.String.class, value)); return true;
-        case "newRemotePath": ((AtmosEndpoint) target).getConfiguration().setNewRemotePath(property(camelContext, java.lang.String.class, value)); return true;
-        case "query": ((AtmosEndpoint) target).getConfiguration().setQuery(property(camelContext, java.lang.String.class, value)); return true;
-        case "remotePath": ((AtmosEndpoint) target).getConfiguration().setRemotePath(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((AtmosEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AtmosEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AtmosEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((AtmosEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AtmosEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AtmosEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "uri": ((AtmosEndpoint) target).getConfiguration().setUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "fullTokenId": ((AtmosEndpoint) target).getConfiguration().setFullTokenId(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((AtmosEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslValidation": ((AtmosEndpoint) target).getConfiguration().setSslValidation(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "localpath": ((AtmosEndpoint) target).getConfiguration().setLocalPath(property(camelContext, java.lang.String.class, value)); return true;
-        case "newremotepath": ((AtmosEndpoint) target).getConfiguration().setNewRemotePath(property(camelContext, java.lang.String.class, value)); return true;
-        case "query": ((AtmosEndpoint) target).getConfiguration().setQuery(property(camelContext, java.lang.String.class, value)); return true;
-        case "remotepath": ((AtmosEndpoint) target).getConfiguration().setRemotePath(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((AtmosEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AtmosEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AtmosEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((AtmosEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AtmosEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AtmosEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "uri": ((AtmosEndpoint) target).getConfiguration().setUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "fulltokenid": ((AtmosEndpoint) target).getConfiguration().setFullTokenId(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((AtmosEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslvalidation": ((AtmosEndpoint) target).getConfiguration().setSslValidation(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtmosEndpoint target = (AtmosEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "localpath":
+        case "localPath": target.getConfiguration().setLocalPath(property(camelContext, java.lang.String.class, value)); return true;
+        case "newremotepath":
+        case "newRemotePath": target.getConfiguration().setNewRemotePath(property(camelContext, java.lang.String.class, value)); return true;
+        case "query": target.getConfiguration().setQuery(property(camelContext, java.lang.String.class, value)); return true;
+        case "remotepath":
+        case "remotePath": target.getConfiguration().setRemotePath(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "uri": target.getConfiguration().setUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "fulltokenid":
+        case "fullTokenId": target.getConfiguration().setFullTokenId(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "sslvalidation":
+        case "sslValidation": target.getConfiguration().setSslValidation(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 d09c144..511c5a8 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
@@ -12,45 +12,32 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class WebsocketComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "servletName": ((WebsocketComponent) target).setServletName(property(camelContext, java.lang.String.class, value)); return true;
-        case "httpRegistry": ((WebsocketComponent) target).setHttpRegistry(property(camelContext, org.apache.camel.component.servlet.HttpRegistry.class, value)); return true;
-        case "attachmentMultipartBinding": ((WebsocketComponent) target).setAttachmentMultipartBinding(property(camelContext, boolean.class, value)); return true;
-        case "fileNameExtWhitelist": ((WebsocketComponent) target).setFileNameExtWhitelist(property(camelContext, java.lang.String.class, value)); return true;
-        case "httpBinding": ((WebsocketComponent) target).setHttpBinding(property(camelContext, org.apache.camel.http.common.HttpBinding.class, value)); return true;
-        case "httpConfiguration": ((WebsocketComponent) target).setHttpConfiguration(property(camelContext, org.apache.camel.http.common.HttpConfiguration.class, value)); return true;
-        case "allowJavaSerializedObject": ((WebsocketComponent) target).setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
-        case "headerFilterStrategy": ((WebsocketComponent) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "basicPropertyBinding": ((WebsocketComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((WebsocketComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((WebsocketComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "servletname": ((WebsocketComponent) target).setServletName(property(camelContext, java.lang.String.class, value)); return true;
-        case "httpregistry": ((WebsocketComponent) target).setHttpRegistry(property(camelContext, org.apache.camel.component.servlet.HttpRegistry.class, value)); return true;
-        case "attachmentmultipartbinding": ((WebsocketComponent) target).setAttachmentMultipartBinding(property(camelContext, boolean.class, value)); return true;
-        case "filenameextwhitelist": ((WebsocketComponent) target).setFileNameExtWhitelist(property(camelContext, java.lang.String.class, value)); return true;
-        case "httpbinding": ((WebsocketComponent) target).setHttpBinding(property(camelContext, org.apache.camel.http.common.HttpBinding.class, value)); return true;
-        case "httpconfiguration": ((WebsocketComponent) target).setHttpConfiguration(property(camelContext, org.apache.camel.http.common.HttpConfiguration.class, value)); return true;
-        case "allowjavaserializedobject": ((WebsocketComponent) target).setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
-        case "headerfilterstrategy": ((WebsocketComponent) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "basicpropertybinding": ((WebsocketComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((WebsocketComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((WebsocketComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        WebsocketComponent target = (WebsocketComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "servletname":
+        case "servletName": target.setServletName(property(camelContext, java.lang.String.class, value)); return true;
+        case "httpregistry":
+        case "httpRegistry": target.setHttpRegistry(property(camelContext, org.apache.camel.component.servlet.HttpRegistry.class, value)); return true;
+        case "attachmentmultipartbinding":
+        case "attachmentMultipartBinding": target.setAttachmentMultipartBinding(property(camelContext, boolean.class, value)); return true;
+        case "filenameextwhitelist":
+        case "fileNameExtWhitelist": target.setFileNameExtWhitelist(property(camelContext, java.lang.String.class, value)); return true;
+        case "httpbinding":
+        case "httpBinding": target.setHttpBinding(property(camelContext, org.apache.camel.http.common.HttpBinding.class, value)); return true;
+        case "httpconfiguration":
+        case "httpConfiguration": target.setHttpConfiguration(property(camelContext, org.apache.camel.http.common.HttpConfiguration.class, value)); return true;
+        case "allowjavaserializedobject":
+        case "allowJavaSerializedObject": target.setAllowJavaSerializedObject(property(camelContext, boolean.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 0174577..a07e1f4 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
@@ -12,103 +12,87 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class WebsocketEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "chunked": ((WebsocketEndpoint) target).setChunked(property(camelContext, boolean.class, value)); return true;
-        case "disableStreamCache": ((WebsocketEndpoint) target).setDisableStreamCache(property(camelContext, boolean.class, value)); return true;
-        case "headerFilterStrategy": ((WebsocketEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "sendToAll": ((WebsocketEndpoint) target).setSendToAll(property(camelContext, boolean.class, value)); return true;
-        case "transferException": ((WebsocketEndpoint) target).setTransferException(property(camelContext, boolean.class, value)); return true;
-        case "useStreaming": ((WebsocketEndpoint) target).setUseStreaming(property(camelContext, boolean.class, value)); return true;
-        case "httpBinding": ((WebsocketEndpoint) target).setHttpBinding(property(camelContext, org.apache.camel.http.common.HttpBinding.class, value)); return true;
-        case "async": ((WebsocketEndpoint) target).setAsync(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((WebsocketEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "httpMethodRestrict": ((WebsocketEndpoint) target).setHttpMethodRestrict(property(camelContext, java.lang.String.class, value)); return true;
-        case "matchOnUriPrefix": ((WebsocketEndpoint) target).setMatchOnUriPrefix(property(camelContext, boolean.class, value)); return true;
-        case "muteException": ((WebsocketEndpoint) target).setMuteException(property(camelContext, boolean.class, value)); return true;
-        case "responseBufferSize": ((WebsocketEndpoint) target).setResponseBufferSize(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "servletName": ((WebsocketEndpoint) target).setServletName(property(camelContext, java.lang.String.class, value)); return true;
-        case "attachmentMultipartBinding": ((WebsocketEndpoint) target).setAttachmentMultipartBinding(property(camelContext, boolean.class, value)); return true;
-        case "eagerCheckContentAvailable": ((WebsocketEndpoint) target).setEagerCheckContentAvailable(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((WebsocketEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((WebsocketEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "fileNameExtWhitelist": ((WebsocketEndpoint) target).setFileNameExtWhitelist(property(camelContext, java.lang.String.class, value)); return true;
-        case "optionsEnabled": ((WebsocketEndpoint) target).setOptionsEnabled(property(camelContext, boolean.class, value)); return true;
-        case "traceEnabled": ((WebsocketEndpoint) target).setTraceEnabled(property(camelContext, boolean.class, value)); return true;
-        case "bridgeEndpoint": ((WebsocketEndpoint) target).setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
-        case "connectionClose": ((WebsocketEndpoint) target).setConnectionClose(property(camelContext, boolean.class, value)); return true;
-        case "copyHeaders": ((WebsocketEndpoint) target).setCopyHeaders(property(camelContext, boolean.class, value)); return true;
-        case "httpMethod": ((WebsocketEndpoint) target).setHttpMethod(property(camelContext, org.apache.camel.http.common.HttpMethods.class, value)); return true;
-        case "ignoreResponseBody": ((WebsocketEndpoint) target).setIgnoreResponseBody(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((WebsocketEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "preserveHostHeader": ((WebsocketEndpoint) target).setPreserveHostHeader(property(camelContext, boolean.class, value)); return true;
-        case "throwExceptionOnFailure": ((WebsocketEndpoint) target).setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
-        case "cookieHandler": ((WebsocketEndpoint) target).setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
-        case "okStatusCodeRange": ((WebsocketEndpoint) target).setOkStatusCodeRange(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((WebsocketEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "mapHttpMessageBody": ((WebsocketEndpoint) target).setMapHttpMessageBody(property(camelContext, boolean.class, value)); return true;
-        case "mapHttpMessageFormUrlEncodedBody": ((WebsocketEndpoint) target).setMapHttpMessageFormUrlEncodedBody(property(camelContext, boolean.class, value)); return true;
-        case "mapHttpMessageHeaders": ((WebsocketEndpoint) target).setMapHttpMessageHeaders(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((WebsocketEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "proxyAuthScheme": ((WebsocketEndpoint) target).setProxyAuthScheme(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyHost": ((WebsocketEndpoint) target).setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((WebsocketEndpoint) target).setProxyPort(property(camelContext, int.class, value)); return true;
-        case "authHost": ((WebsocketEndpoint) target).setAuthHost(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "chunked": ((WebsocketEndpoint) target).setChunked(property(camelContext, boolean.class, value)); return true;
-        case "disablestreamcache": ((WebsocketEndpoint) target).setDisableStreamCache(property(camelContext, boolean.class, value)); return true;
-        case "headerfilterstrategy": ((WebsocketEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "sendtoall": ((WebsocketEndpoint) target).setSendToAll(property(camelContext, boolean.class, value)); return true;
-        case "transferexception": ((WebsocketEndpoint) target).setTransferException(property(camelContext, boolean.class, value)); return true;
-        case "usestreaming": ((WebsocketEndpoint) target).setUseStreaming(property(camelContext, boolean.class, value)); return true;
-        case "httpbinding": ((WebsocketEndpoint) target).setHttpBinding(property(camelContext, org.apache.camel.http.common.HttpBinding.class, value)); return true;
-        case "async": ((WebsocketEndpoint) target).setAsync(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((WebsocketEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "httpmethodrestrict": ((WebsocketEndpoint) target).setHttpMethodRestrict(property(camelContext, java.lang.String.class, value)); return true;
-        case "matchonuriprefix": ((WebsocketEndpoint) target).setMatchOnUriPrefix(property(camelContext, boolean.class, value)); return true;
-        case "muteexception": ((WebsocketEndpoint) target).setMuteException(property(camelContext, boolean.class, value)); return true;
-        case "responsebuffersize": ((WebsocketEndpoint) target).setResponseBufferSize(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "servletname": ((WebsocketEndpoint) target).setServletName(property(camelContext, java.lang.String.class, value)); return true;
-        case "attachmentmultipartbinding": ((WebsocketEndpoint) target).setAttachmentMultipartBinding(property(camelContext, boolean.class, value)); return true;
-        case "eagercheckcontentavailable": ((WebsocketEndpoint) target).setEagerCheckContentAvailable(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((WebsocketEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((WebsocketEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "filenameextwhitelist": ((WebsocketEndpoint) target).setFileNameExtWhitelist(property(camelContext, java.lang.String.class, value)); return true;
-        case "optionsenabled": ((WebsocketEndpoint) target).setOptionsEnabled(property(camelContext, boolean.class, value)); return true;
-        case "traceenabled": ((WebsocketEndpoint) target).setTraceEnabled(property(camelContext, boolean.class, value)); return true;
-        case "bridgeendpoint": ((WebsocketEndpoint) target).setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
-        case "connectionclose": ((WebsocketEndpoint) target).setConnectionClose(property(camelContext, boolean.class, value)); return true;
-        case "copyheaders": ((WebsocketEndpoint) target).setCopyHeaders(property(camelContext, boolean.class, value)); return true;
-        case "httpmethod": ((WebsocketEndpoint) target).setHttpMethod(property(camelContext, org.apache.camel.http.common.HttpMethods.class, value)); return true;
-        case "ignoreresponsebody": ((WebsocketEndpoint) target).setIgnoreResponseBody(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((WebsocketEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "preservehostheader": ((WebsocketEndpoint) target).setPreserveHostHeader(property(camelContext, boolean.class, value)); return true;
-        case "throwexceptiononfailure": ((WebsocketEndpoint) target).setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
-        case "cookiehandler": ((WebsocketEndpoint) target).setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
-        case "okstatuscoderange": ((WebsocketEndpoint) target).setOkStatusCodeRange(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((WebsocketEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "maphttpmessagebody": ((WebsocketEndpoint) target).setMapHttpMessageBody(property(camelContext, boolean.class, value)); return true;
-        case "maphttpmessageformurlencodedbody": ((WebsocketEndpoint) target).setMapHttpMessageFormUrlEncodedBody(property(camelContext, boolean.class, value)); return true;
-        case "maphttpmessageheaders": ((WebsocketEndpoint) target).setMapHttpMessageHeaders(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((WebsocketEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "proxyauthscheme": ((WebsocketEndpoint) target).setProxyAuthScheme(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyhost": ((WebsocketEndpoint) target).setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((WebsocketEndpoint) target).setProxyPort(property(camelContext, int.class, value)); return true;
-        case "authhost": ((WebsocketEndpoint) target).setAuthHost(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        WebsocketEndpoint target = (WebsocketEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "chunked": target.setChunked(property(camelContext, boolean.class, value)); return true;
+        case "disablestreamcache":
+        case "disableStreamCache": target.setDisableStreamCache(property(camelContext, boolean.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "sendtoall":
+        case "sendToAll": target.setSendToAll(property(camelContext, boolean.class, value)); return true;
+        case "transferexception":
+        case "transferException": target.setTransferException(property(camelContext, boolean.class, value)); return true;
+        case "usestreaming":
+        case "useStreaming": target.setUseStreaming(property(camelContext, boolean.class, value)); return true;
+        case "httpbinding":
+        case "httpBinding": target.setHttpBinding(property(camelContext, org.apache.camel.http.common.HttpBinding.class, value)); return true;
+        case "async": target.setAsync(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "httpmethodrestrict":
+        case "httpMethodRestrict": target.setHttpMethodRestrict(property(camelContext, java.lang.String.class, value)); return true;
+        case "matchonuriprefix":
+        case "matchOnUriPrefix": target.setMatchOnUriPrefix(property(camelContext, boolean.class, value)); return true;
+        case "muteexception":
+        case "muteException": target.setMuteException(property(camelContext, boolean.class, value)); return true;
+        case "responsebuffersize":
+        case "responseBufferSize": target.setResponseBufferSize(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "servletname":
+        case "servletName": target.setServletName(property(camelContext, java.lang.String.class, value)); return true;
+        case "attachmentmultipartbinding":
+        case "attachmentMultipartBinding": target.setAttachmentMultipartBinding(property(camelContext, boolean.class, value)); return true;
+        case "eagercheckcontentavailable":
+        case "eagerCheckContentAvailable": target.setEagerCheckContentAvailable(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "filenameextwhitelist":
+        case "fileNameExtWhitelist": target.setFileNameExtWhitelist(property(camelContext, java.lang.String.class, value)); return true;
+        case "optionsenabled":
+        case "optionsEnabled": target.setOptionsEnabled(property(camelContext, boolean.class, value)); return true;
+        case "traceenabled":
+        case "traceEnabled": target.setTraceEnabled(property(camelContext, boolean.class, value)); return true;
+        case "bridgeendpoint":
+        case "bridgeEndpoint": target.setBridgeEndpoint(property(camelContext, boolean.class, value)); return true;
+        case "connectionclose":
+        case "connectionClose": target.setConnectionClose(property(camelContext, boolean.class, value)); return true;
+        case "copyheaders":
+        case "copyHeaders": target.setCopyHeaders(property(camelContext, boolean.class, value)); return true;
+        case "httpmethod":
+        case "httpMethod": target.setHttpMethod(property(camelContext, org.apache.camel.http.common.HttpMethods.class, value)); return true;
+        case "ignoreresponsebody":
+        case "ignoreResponseBody": target.setIgnoreResponseBody(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "preservehostheader":
+        case "preserveHostHeader": target.setPreserveHostHeader(property(camelContext, boolean.class, value)); return true;
+        case "throwexceptiononfailure":
+        case "throwExceptionOnFailure": target.setThrowExceptionOnFailure(property(camelContext, boolean.class, value)); return true;
+        case "cookiehandler":
+        case "cookieHandler": target.setCookieHandler(property(camelContext, org.apache.camel.http.base.cookie.CookieHandler.class, value)); return true;
+        case "okstatuscoderange":
+        case "okStatusCodeRange": target.setOkStatusCodeRange(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "maphttpmessagebody":
+        case "mapHttpMessageBody": target.setMapHttpMessageBody(property(camelContext, boolean.class, value)); return true;
+        case "maphttpmessageformurlencodedbody":
+        case "mapHttpMessageFormUrlEncodedBody": target.setMapHttpMessageFormUrlEncodedBody(property(camelContext, boolean.class, value)); return true;
+        case "maphttpmessageheaders":
+        case "mapHttpMessageHeaders": target.setMapHttpMessageHeaders(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "proxyauthscheme":
+        case "proxyAuthScheme": target.setProxyAuthScheme(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.setProxyPort(property(camelContext, int.class, value)); return true;
+        case "authhost":
+        case "authHost": target.setAuthHost(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 1be4b7a..542c7c1 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
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((AtomComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((AtomComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomComponent target = (AtomComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 baa5cd9..4b3c488 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
@@ -12,81 +12,61 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "bridgeErrorHandler": ((AtomEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "feedHeader": ((AtomEndpoint) target).setFeedHeader(property(camelContext, boolean.class, value)); return true;
-        case "filter": ((AtomEndpoint) target).setFilter(property(camelContext, boolean.class, value)); return true;
-        case "lastUpdate": ((AtomEndpoint) target).setLastUpdate(property(camelContext, java.util.Date.class, value)); return true;
-        case "password": ((AtomEndpoint) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((AtomEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "sortEntries": ((AtomEndpoint) target).setSortEntries(property(camelContext, boolean.class, value)); return true;
-        case "splitEntries": ((AtomEndpoint) target).setSplitEntries(property(camelContext, boolean.class, value)); return true;
-        case "throttleEntries": ((AtomEndpoint) target).setThrottleEntries(property(camelContext, boolean.class, value)); return true;
-        case "username": ((AtomEndpoint) target).setUsername(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionHandler": ((AtomEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AtomEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((AtomEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "basicPropertyBinding": ((AtomEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AtomEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((AtomEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((AtomEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((AtomEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((AtomEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((AtomEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((AtomEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((AtomEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((AtomEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((AtomEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((AtomEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((AtomEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((AtomEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((AtomEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((AtomEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "bridgeerrorhandler": ((AtomEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "feedheader": ((AtomEndpoint) target).setFeedHeader(property(camelContext, boolean.class, value)); return true;
-        case "filter": ((AtomEndpoint) target).setFilter(property(camelContext, boolean.class, value)); return true;
-        case "lastupdate": ((AtomEndpoint) target).setLastUpdate(property(camelContext, java.util.Date.class, value)); return true;
-        case "password": ((AtomEndpoint) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendemptymessagewhenidle": ((AtomEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "sortentries": ((AtomEndpoint) target).setSortEntries(property(camelContext, boolean.class, value)); return true;
-        case "splitentries": ((AtomEndpoint) target).setSplitEntries(property(camelContext, boolean.class, value)); return true;
-        case "throttleentries": ((AtomEndpoint) target).setThrottleEntries(property(camelContext, boolean.class, value)); return true;
-        case "username": ((AtomEndpoint) target).setUsername(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionhandler": ((AtomEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AtomEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((AtomEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "basicpropertybinding": ((AtomEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AtomEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((AtomEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((AtomEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((AtomEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((AtomEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((AtomEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((AtomEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((AtomEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((AtomEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((AtomEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((AtomEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((AtomEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((AtomEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((AtomEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((AtomEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomEndpoint target = (AtomEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "feedheader":
+        case "feedHeader": target.setFeedHeader(property(camelContext, boolean.class, value)); return true;
+        case "filter": target.setFilter(property(camelContext, boolean.class, value)); return true;
+        case "lastupdate":
+        case "lastUpdate": target.setLastUpdate(property(camelContext, java.util.Date.class, value)); return true;
+        case "password": target.setPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "sortentries":
+        case "sortEntries": target.setSortEntries(property(camelContext, boolean.class, value)); return true;
+        case "splitentries":
+        case "splitEntries": target.setSplitEntries(property(camelContext, boolean.class, value)); return true;
+        case "throttleentries":
+        case "throttleEntries": target.setThrottleEntries(property(camelContext, boolean.class, value)); return true;
+        case "username": target.setUsername(property(camelContext, java.lang.String.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 c22d84c..7c4128e 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
@@ -12,37 +12,21 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixMapComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AtomixMapComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.map.AtomixMapConfiguration.class, value)); return true;
-        case "atomix": ((AtomixMapComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixMapComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationUri": ((AtomixMapComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixMapComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AtomixMapComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixMapComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AtomixMapComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.map.AtomixMapConfiguration.class, value)); return true;
-        case "atomix": ((AtomixMapComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixMapComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationuri": ((AtomixMapComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((AtomixMapComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AtomixMapComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixMapComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixMapComponent target = (AtomixMapComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.map.AtomixMapConfiguration.class, value)); return true;
+        case "atomix": target.setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
+        case "nodes": target.setNodes(property(camelContext, java.util.List.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 02f07cd..9b7b127 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
@@ -12,63 +12,44 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixMapEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "atomix": ((AtomixMapEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationUri": ((AtomixMapEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultAction": ((AtomixMapEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.map.AtomixMap.Action.class, value)); return true;
-        case "key": ((AtomixMapEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "nodes": ((AtomixMapEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultHeader": ((AtomixMapEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportClassName": ((AtomixMapEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixMapEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixMapEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AtomixMapEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AtomixMapEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((AtomixMapEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixMapEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultResourceConfig": ((AtomixMapEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultResourceOptions": ((AtomixMapEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixMapEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readConsistency": ((AtomixMapEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceConfigs": ((AtomixMapEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceOptions": ((AtomixMapEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixMapEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "atomix": ((AtomixMapEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationuri": ((AtomixMapEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultaction": ((AtomixMapEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.map.AtomixMap.Action.class, value)); return true;
-        case "key": ((AtomixMapEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "nodes": ((AtomixMapEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultheader": ((AtomixMapEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportclassname": ((AtomixMapEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixMapEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixMapEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AtomixMapEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AtomixMapEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((AtomixMapEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AtomixMapEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultresourceconfig": ((AtomixMapEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultresourceoptions": ((AtomixMapEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixMapEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readconsistency": ((AtomixMapEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceconfigs": ((AtomixMapEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceoptions": ((AtomixMapEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixMapEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixMapEndpoint target = (AtomixMapEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.map.AtomixMap.Action.class, value)); return true;
+        case "key": target.getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
+        case "nodes": target.getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
+        case "ttl": target.getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
+        case "ephemeral": target.getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 ba63e7d..007d7a3 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
@@ -12,37 +12,21 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixMessagingComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AtomixMessagingComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessagingConfiguration.class, value)); return true;
-        case "atomix": ((AtomixMessagingComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixMessagingComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationUri": ((AtomixMessagingComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixMessagingComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AtomixMessagingComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixMessagingComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AtomixMessagingComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessagingConfiguration.class, value)); return true;
-        case "atomix": ((AtomixMessagingComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixMessagingComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationuri": ((AtomixMessagingComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((AtomixMessagingComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AtomixMessagingComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixMessagingComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixMessagingComponent target = (AtomixMessagingComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessagingConfiguration.class, value)); return true;
+        case "atomix": target.setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
+        case "nodes": target.setNodes(property(camelContext, java.util.List.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 d7310f5..4d783f5 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
@@ -12,65 +12,48 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixMessagingEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "atomix": ((AtomixMessagingEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "broadcastType": ((AtomixMessagingEndpoint) target).getConfiguration().setBroadcastType(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessaging.BroadcastType.class, value)); return true;
-        case "channelName": ((AtomixMessagingEndpoint) target).getConfiguration().setChannelName(property(camelContext, java.lang.String.class, value)); return true;
-        case "configurationUri": ((AtomixMessagingEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultAction": ((AtomixMessagingEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessaging.Action.class, value)); return true;
-        case "memberName": ((AtomixMessagingEndpoint) target).getConfiguration().setMemberName(property(camelContext, java.lang.String.class, value)); return true;
-        case "nodes": ((AtomixMessagingEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultHeader": ((AtomixMessagingEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportClassName": ((AtomixMessagingEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixMessagingEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AtomixMessagingEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AtomixMessagingEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((AtomixMessagingEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixMessagingEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultResourceConfig": ((AtomixMessagingEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultResourceOptions": ((AtomixMessagingEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixMessagingEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readConsistency": ((AtomixMessagingEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceConfigs": ((AtomixMessagingEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceOptions": ((AtomixMessagingEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixMessagingEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "atomix": ((AtomixMessagingEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "broadcasttype": ((AtomixMessagingEndpoint) target).getConfiguration().setBroadcastType(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessaging.BroadcastType.class, value)); return true;
-        case "channelname": ((AtomixMessagingEndpoint) target).getConfiguration().setChannelName(property(camelContext, java.lang.String.class, value)); return true;
-        case "configurationuri": ((AtomixMessagingEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultaction": ((AtomixMessagingEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessaging.Action.class, value)); return true;
-        case "membername": ((AtomixMessagingEndpoint) target).getConfiguration().setMemberName(property(camelContext, java.lang.String.class, value)); return true;
-        case "nodes": ((AtomixMessagingEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultheader": ((AtomixMessagingEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportclassname": ((AtomixMessagingEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixMessagingEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AtomixMessagingEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AtomixMessagingEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((AtomixMessagingEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AtomixMessagingEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultresourceconfig": ((AtomixMessagingEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultresourceoptions": ((AtomixMessagingEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixMessagingEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readconsistency": ((AtomixMessagingEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceconfigs": ((AtomixMessagingEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceoptions": ((AtomixMessagingEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixMessagingEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixMessagingEndpoint target = (AtomixMessagingEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
+        case "broadcasttype":
+        case "broadcastType": target.getConfiguration().setBroadcastType(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessaging.BroadcastType.class, value)); return true;
+        case "channelname":
+        case "channelName": target.getConfiguration().setChannelName(property(camelContext, java.lang.String.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.messaging.AtomixMessaging.Action.class, value)); return true;
+        case "membername":
+        case "memberName": target.getConfiguration().setMemberName(property(camelContext, java.lang.String.class, value)); return true;
+        case "nodes": target.getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
+        case "ephemeral": target.getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6da0d26..d6f8c2d 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
@@ -12,35 +12,19 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixMultiMapComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AtomixMultiMapComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.multimap.AtomixMultiMapConfiguration.class, value)); return true;
-        case "atomix": ((AtomixMultiMapComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixMultiMapComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationUri": ((AtomixMultiMapComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixMultiMapComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AtomixMultiMapComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AtomixMultiMapComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.multimap.AtomixMultiMapConfiguration.class, value)); return true;
-        case "atomix": ((AtomixMultiMapComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixMultiMapComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationuri": ((AtomixMultiMapComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((AtomixMultiMapComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AtomixMultiMapComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixMultiMapComponent target = (AtomixMultiMapComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.multimap.AtomixMultiMapConfiguration.class, value)); return true;
+        case "atomix": target.setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
+        case "nodes": target.setNodes(property(camelContext, java.util.List.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 5838fc5..e0c375c 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
@@ -12,57 +12,38 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixMultiMapEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "atomix": ((AtomixMultiMapEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationUri": ((AtomixMultiMapEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultAction": ((AtomixMultiMapEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.multimap.AtomixMultiMap.Action.class, value)); return true;
-        case "key": ((AtomixMultiMapEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "lazyStartProducer": ((AtomixMultiMapEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "nodes": ((AtomixMultiMapEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultHeader": ((AtomixMultiMapEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportClassName": ((AtomixMultiMapEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixMultiMapEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixMultiMapEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultResourceConfig": ((AtomixMultiMapEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultResourceOptions": ((AtomixMultiMapEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixMultiMapEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readConsistency": ((AtomixMultiMapEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceConfigs": ((AtomixMultiMapEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceOptions": ((AtomixMultiMapEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixMultiMapEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "atomix": ((AtomixMultiMapEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationuri": ((AtomixMultiMapEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultaction": ((AtomixMultiMapEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.multimap.AtomixMultiMap.Action.class, value)); return true;
-        case "key": ((AtomixMultiMapEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "lazystartproducer": ((AtomixMultiMapEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "nodes": ((AtomixMultiMapEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultheader": ((AtomixMultiMapEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportclassname": ((AtomixMultiMapEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixMultiMapEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "basicpropertybinding": ((AtomixMultiMapEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultresourceconfig": ((AtomixMultiMapEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultresourceoptions": ((AtomixMultiMapEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixMultiMapEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readconsistency": ((AtomixMultiMapEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceconfigs": ((AtomixMultiMapEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceoptions": ((AtomixMultiMapEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixMultiMapEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixMultiMapEndpoint target = (AtomixMultiMapEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.multimap.AtomixMultiMap.Action.class, value)); return true;
+        case "key": target.getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "nodes": target.getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
+        case "ttl": target.getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
+        case "ephemeral": target.getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6dc323c..370e9ca 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
@@ -12,37 +12,21 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixQueueComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AtomixQueueComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.queue.AtomixQueueConfiguration.class, value)); return true;
-        case "atomix": ((AtomixQueueComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixQueueComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationUri": ((AtomixQueueComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixQueueComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AtomixQueueComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixQueueComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AtomixQueueComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.queue.AtomixQueueConfiguration.class, value)); return true;
-        case "atomix": ((AtomixQueueComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixQueueComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationuri": ((AtomixQueueComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((AtomixQueueComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AtomixQueueComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixQueueComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixQueueComponent target = (AtomixQueueComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.queue.AtomixQueueConfiguration.class, value)); return true;
+        case "atomix": target.setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
+        case "nodes": target.setNodes(property(camelContext, java.util.List.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 cf863fb..0e65e75 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
@@ -12,59 +12,42 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixQueueEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "atomix": ((AtomixQueueEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationUri": ((AtomixQueueEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultAction": ((AtomixQueueEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.queue.AtomixQueue.Action.class, value)); return true;
-        case "nodes": ((AtomixQueueEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultHeader": ((AtomixQueueEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportClassName": ((AtomixQueueEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixQueueEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AtomixQueueEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AtomixQueueEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((AtomixQueueEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixQueueEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultResourceConfig": ((AtomixQueueEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultResourceOptions": ((AtomixQueueEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixQueueEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readConsistency": ((AtomixQueueEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceConfigs": ((AtomixQueueEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceOptions": ((AtomixQueueEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixQueueEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "atomix": ((AtomixQueueEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationuri": ((AtomixQueueEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultaction": ((AtomixQueueEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.queue.AtomixQueue.Action.class, value)); return true;
-        case "nodes": ((AtomixQueueEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultheader": ((AtomixQueueEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportclassname": ((AtomixQueueEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixQueueEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AtomixQueueEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AtomixQueueEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((AtomixQueueEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AtomixQueueEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultresourceconfig": ((AtomixQueueEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultresourceoptions": ((AtomixQueueEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixQueueEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readconsistency": ((AtomixQueueEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceconfigs": ((AtomixQueueEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceoptions": ((AtomixQueueEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixQueueEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixQueueEndpoint target = (AtomixQueueEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.queue.AtomixQueue.Action.class, value)); return true;
+        case "nodes": target.getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
+        case "ephemeral": target.getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 7ba0d28..f7e90e2 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
@@ -12,37 +12,21 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixSetComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AtomixSetComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.set.AtomixSetConfiguration.class, value)); return true;
-        case "atomix": ((AtomixSetComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixSetComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationUri": ((AtomixSetComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixSetComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AtomixSetComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixSetComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AtomixSetComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.set.AtomixSetConfiguration.class, value)); return true;
-        case "atomix": ((AtomixSetComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixSetComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationuri": ((AtomixSetComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((AtomixSetComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AtomixSetComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixSetComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixSetComponent target = (AtomixSetComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.set.AtomixSetConfiguration.class, value)); return true;
+        case "atomix": target.setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
+        case "nodes": target.setNodes(property(camelContext, java.util.List.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6bd284c..34988ff 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
@@ -12,61 +12,43 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixSetEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "atomix": ((AtomixSetEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationUri": ((AtomixSetEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultAction": ((AtomixSetEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.set.AtomixSet.Action.class, value)); return true;
-        case "nodes": ((AtomixSetEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultHeader": ((AtomixSetEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportClassName": ((AtomixSetEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixSetEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixSetEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AtomixSetEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AtomixSetEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((AtomixSetEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixSetEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultResourceConfig": ((AtomixSetEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultResourceOptions": ((AtomixSetEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixSetEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readConsistency": ((AtomixSetEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceConfigs": ((AtomixSetEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceOptions": ((AtomixSetEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixSetEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "atomix": ((AtomixSetEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationuri": ((AtomixSetEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultaction": ((AtomixSetEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.set.AtomixSet.Action.class, value)); return true;
-        case "nodes": ((AtomixSetEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultheader": ((AtomixSetEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportclassname": ((AtomixSetEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixSetEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixSetEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AtomixSetEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AtomixSetEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((AtomixSetEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AtomixSetEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultresourceconfig": ((AtomixSetEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultresourceoptions": ((AtomixSetEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixSetEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readconsistency": ((AtomixSetEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceconfigs": ((AtomixSetEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceoptions": ((AtomixSetEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixSetEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixSetEndpoint target = (AtomixSetEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.set.AtomixSet.Action.class, value)); return true;
+        case "nodes": target.getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
+        case "ttl": target.getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
+        case "ephemeral": target.getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 bccd058..d04aabc 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
@@ -12,37 +12,21 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixValueComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AtomixValueComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.value.AtomixValueConfiguration.class, value)); return true;
-        case "atomix": ((AtomixValueComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixValueComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationUri": ((AtomixValueComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixValueComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AtomixValueComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixValueComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AtomixValueComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.value.AtomixValueConfiguration.class, value)); return true;
-        case "atomix": ((AtomixValueComponent) target).setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
-        case "nodes": ((AtomixValueComponent) target).setNodes(property(camelContext, java.util.List.class, value)); return true;
-        case "configurationuri": ((AtomixValueComponent) target).setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((AtomixValueComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AtomixValueComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixValueComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixValueComponent target = (AtomixValueComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.atomix.client.value.AtomixValueConfiguration.class, value)); return true;
+        case "atomix": target.setAtomix(property(camelContext, io.atomix.AtomixClient.class, value)); return true;
+        case "nodes": target.setNodes(property(camelContext, java.util.List.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 e57bd9c..4c9078f 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
@@ -12,61 +12,43 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AtomixValueEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "atomix": ((AtomixValueEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationUri": ((AtomixValueEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultAction": ((AtomixValueEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.value.AtomixValue.Action.class, value)); return true;
-        case "nodes": ((AtomixValueEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultHeader": ((AtomixValueEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportClassName": ((AtomixValueEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixValueEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "bridgeErrorHandler": ((AtomixValueEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AtomixValueEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AtomixValueEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((AtomixValueEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AtomixValueEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultResourceConfig": ((AtomixValueEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultResourceOptions": ((AtomixValueEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixValueEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readConsistency": ((AtomixValueEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceConfigs": ((AtomixValueEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceOptions": ((AtomixValueEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixValueEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "atomix": ((AtomixValueEndpoint) target).getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
-        case "configurationuri": ((AtomixValueEndpoint) target).getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultaction": ((AtomixValueEndpoint) target).getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.value.AtomixValue.Action.class, value)); return true;
-        case "nodes": ((AtomixValueEndpoint) target).getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
-        case "resultheader": ((AtomixValueEndpoint) target).getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
-        case "transportclassname": ((AtomixValueEndpoint) target).getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "ttl": ((AtomixValueEndpoint) target).getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
-        case "bridgeerrorhandler": ((AtomixValueEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AtomixValueEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AtomixValueEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((AtomixValueEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AtomixValueEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "defaultresourceconfig": ((AtomixValueEndpoint) target).getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
-        case "defaultresourceoptions": ((AtomixValueEndpoint) target).getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
-        case "ephemeral": ((AtomixValueEndpoint) target).getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
-        case "readconsistency": ((AtomixValueEndpoint) target).getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
-        case "resourceconfigs": ((AtomixValueEndpoint) target).getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
-        case "resourceoptions": ((AtomixValueEndpoint) target).getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((AtomixValueEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AtomixValueEndpoint target = (AtomixValueEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "atomix": target.getConfiguration().setAtomix(property(camelContext, io.atomix.Atomix.class, value)); return true;
+        case "configurationuri":
+        case "configurationUri": target.getConfiguration().setConfigurationUri(property(camelContext, java.lang.String.class, value)); return true;
+        case "defaultaction":
+        case "defaultAction": target.getConfiguration().setDefaultAction(property(camelContext, org.apache.camel.component.atomix.client.value.AtomixValue.Action.class, value)); return true;
+        case "nodes": target.getConfiguration().setNodes(property(camelContext, java.lang.String.class, value)); return true;
+        case "resultheader":
+        case "resultHeader": target.getConfiguration().setResultHeader(property(camelContext, java.lang.String.class, value)); return true;
+        case "transportclassname":
+        case "transportClassName": target.getConfiguration().setTransportClassName(property(camelContext, java.lang.String.class, value)); return true;
+        case "ttl": target.getConfiguration().setTtl(property(camelContext, long.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "defaultresourceconfig":
+        case "defaultResourceConfig": target.getConfiguration().setDefaultResourceConfig(property(camelContext, java.util.Properties.class, value)); return true;
+        case "defaultresourceoptions":
+        case "defaultResourceOptions": target.getConfiguration().setDefaultResourceOptions(property(camelContext, java.util.Properties.class, value)); return true;
+        case "ephemeral": target.getConfiguration().setEphemeral(property(camelContext, boolean.class, value)); return true;
+        case "readconsistency":
+        case "readConsistency": target.getConfiguration().setReadConsistency(property(camelContext, io.atomix.resource.ReadConsistency.class, value)); return true;
+        case "resourceconfigs":
+        case "resourceConfigs": target.getConfiguration().setResourceConfigs(property(camelContext, java.util.Map.class, value)); return true;
+        case "resourceoptions":
+        case "resourceOptions": target.getConfiguration().setResourceOptions(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 3f4ad24..a31f77b 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
@@ -12,31 +12,17 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AvroComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((AvroComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.avro.AvroConfiguration.class, value)); return true;
-        case "basicPropertyBinding": ((AvroComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((AvroComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((AvroComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((AvroComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.avro.AvroConfiguration.class, value)); return true;
-        case "basicpropertybinding": ((AvroComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((AvroComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((AvroComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AvroComponent target = (AvroComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.avro.AvroConfiguration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6e9b3cb..250cb44 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
@@ -12,47 +12,32 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class AvroEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "protocol": ((AvroEndpoint) target).getConfiguration().setProtocol(property(camelContext, org.apache.avro.Protocol.class, value)); return true;
-        case "protocolClassName": ((AvroEndpoint) target).getConfiguration().setProtocolClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "protocolLocation": ((AvroEndpoint) target).getConfiguration().setProtocolLocation(property(camelContext, java.lang.String.class, value)); return true;
-        case "reflectionProtocol": ((AvroEndpoint) target).getConfiguration().setReflectionProtocol(property(camelContext, boolean.class, value)); return true;
-        case "singleParameter": ((AvroEndpoint) target).getConfiguration().setSingleParameter(property(camelContext, boolean.class, value)); return true;
-        case "uriAuthority": ((AvroEndpoint) target).getConfiguration().setUriAuthority(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((AvroEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((AvroEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((AvroEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((AvroEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((AvroEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AvroEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "protocol": ((AvroEndpoint) target).getConfiguration().setProtocol(property(camelContext, org.apache.avro.Protocol.class, value)); return true;
-        case "protocolclassname": ((AvroEndpoint) target).getConfiguration().setProtocolClassName(property(camelContext, java.lang.String.class, value)); return true;
-        case "protocollocation": ((AvroEndpoint) target).getConfiguration().setProtocolLocation(property(camelContext, java.lang.String.class, value)); return true;
-        case "reflectionprotocol": ((AvroEndpoint) target).getConfiguration().setReflectionProtocol(property(camelContext, boolean.class, value)); return true;
-        case "singleparameter": ((AvroEndpoint) target).getConfiguration().setSingleParameter(property(camelContext, boolean.class, value)); return true;
-        case "uriauthority": ((AvroEndpoint) target).getConfiguration().setUriAuthority(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((AvroEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((AvroEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((AvroEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((AvroEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((AvroEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((AvroEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        AvroEndpoint target = (AvroEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "protocol": target.getConfiguration().setProtocol(property(camelContext, org.apache.avro.Protocol.class, value)); return true;
+        case "protocolclassname":
+        case "protocolClassName": target.getConfiguration().setProtocolClassName(property(camelContext, java.lang.String.class, value)); return true;
+        case "protocollocation":
+        case "protocolLocation": target.getConfiguration().setProtocolLocation(property(camelContext, java.lang.String.class, value)); return true;
+        case "reflectionprotocol":
+        case "reflectionProtocol": target.getConfiguration().setReflectionProtocol(property(camelContext, boolean.class, value)); return true;
+        case "singleparameter":
+        case "singleParameter": target.getConfiguration().setSingleParameter(property(camelContext, boolean.class, value)); return true;
+        case "uriauthority":
+        case "uriAuthority": target.getConfiguration().setUriAuthority(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 12c6f31..1fee35a 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CwComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((CwComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.cw.CwConfiguration.class, value)); return true;
-        case "accessKey": ((CwComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((CwComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((CwComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((CwComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CwComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((CwComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.cw.CwConfiguration.class, value)); return true;
-        case "accesskey": ((CwComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((CwComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((CwComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((CwComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CwComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CwComponent target = (CwComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.cw.CwConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 3fa1eff..70f9934 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
@@ -12,51 +12,32 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CwEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonCwClient": ((CwEndpoint) target).getConfiguration().setAmazonCwClient(property(camelContext, com.amazonaws.services.cloudwatch.AmazonCloudWatch.class, value)); return true;
-        case "lazyStartProducer": ((CwEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "name": ((CwEndpoint) target).getConfiguration().setName(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyHost": ((CwEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((CwEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((CwEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((CwEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "timestamp": ((CwEndpoint) target).getConfiguration().setTimestamp(property(camelContext, java.util.Date.class, value)); return true;
-        case "unit": ((CwEndpoint) target).getConfiguration().setUnit(property(camelContext, java.lang.String.class, value)); return true;
-        case "value": ((CwEndpoint) target).getConfiguration().setValue(property(camelContext, java.lang.Double.class, value)); return true;
-        case "basicPropertyBinding": ((CwEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CwEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((CwEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((CwEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazoncwclient": ((CwEndpoint) target).getConfiguration().setAmazonCwClient(property(camelContext, com.amazonaws.services.cloudwatch.AmazonCloudWatch.class, value)); return true;
-        case "lazystartproducer": ((CwEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "name": ((CwEndpoint) target).getConfiguration().setName(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyhost": ((CwEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((CwEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((CwEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((CwEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "timestamp": ((CwEndpoint) target).getConfiguration().setTimestamp(property(camelContext, java.util.Date.class, value)); return true;
-        case "unit": ((CwEndpoint) target).getConfiguration().setUnit(property(camelContext, java.lang.String.class, value)); return true;
-        case "value": ((CwEndpoint) target).getConfiguration().setValue(property(camelContext, java.lang.Double.class, value)); return true;
-        case "basicpropertybinding": ((CwEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CwEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((CwEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((CwEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CwEndpoint target = (CwEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazoncwclient":
+        case "amazonCwClient": target.getConfiguration().setAmazonCwClient(property(camelContext, com.amazonaws.services.cloudwatch.AmazonCloudWatch.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "name": target.getConfiguration().setName(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "timestamp": target.getConfiguration().setTimestamp(property(camelContext, java.util.Date.class, value)); return true;
+        case "unit": target.getConfiguration().setUnit(property(camelContext, java.lang.String.class, value)); return true;
+        case "value": target.getConfiguration().setValue(property(camelContext, java.lang.Double.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 8d9b10d..3fae2a1 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class DdbComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((DdbComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ddb.DdbConfiguration.class, value)); return true;
-        case "accessKey": ((DdbComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((DdbComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((DdbComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((DdbComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((DdbComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((DdbComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ddb.DdbConfiguration.class, value)); return true;
-        case "accesskey": ((DdbComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((DdbComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((DdbComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((DdbComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((DdbComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        DdbComponent target = (DdbComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.ddb.DdbConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 ee840d2..42987d3 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
@@ -12,55 +12,39 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class DdbEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonDDBClient": ((DdbEndpoint) target).getConfiguration().setAmazonDDBClient(property(camelContext, com.amazonaws.services.dynamodbv2.AmazonDynamoDB.class, value)); return true;
-        case "consistentRead": ((DdbEndpoint) target).getConfiguration().setConsistentRead(property(camelContext, boolean.class, value)); return true;
-        case "keyAttributeName": ((DdbEndpoint) target).getConfiguration().setKeyAttributeName(property(camelContext, java.lang.String.class, value)); return true;
-        case "keyAttributeType": ((DdbEndpoint) target).getConfiguration().setKeyAttributeType(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((DdbEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((DdbEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ddb.DdbOperations.class, value)); return true;
-        case "proxyHost": ((DdbEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((DdbEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((DdbEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "readCapacity": ((DdbEndpoint) target).getConfiguration().setReadCapacity(property(camelContext, java.lang.Long.class, value)); return true;
-        case "region": ((DdbEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "writeCapacity": ((DdbEndpoint) target).getConfiguration().setWriteCapacity(property(camelContext, java.lang.Long.class, value)); return true;
-        case "basicPropertyBinding": ((DdbEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((DdbEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((DdbEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((DdbEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazonddbclient": ((DdbEndpoint) target).getConfiguration().setAmazonDDBClient(property(camelContext, com.amazonaws.services.dynamodbv2.AmazonDynamoDB.class, value)); return true;
-        case "consistentread": ((DdbEndpoint) target).getConfiguration().setConsistentRead(property(camelContext, boolean.class, value)); return true;
-        case "keyattributename": ((DdbEndpoint) target).getConfiguration().setKeyAttributeName(property(camelContext, java.lang.String.class, value)); return true;
-        case "keyattributetype": ((DdbEndpoint) target).getConfiguration().setKeyAttributeType(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((DdbEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((DdbEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ddb.DdbOperations.class, value)); return true;
-        case "proxyhost": ((DdbEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((DdbEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((DdbEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "readcapacity": ((DdbEndpoint) target).getConfiguration().setReadCapacity(property(camelContext, java.lang.Long.class, value)); return true;
-        case "region": ((DdbEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "writecapacity": ((DdbEndpoint) target).getConfiguration().setWriteCapacity(property(camelContext, java.lang.Long.class, value)); return true;
-        case "basicpropertybinding": ((DdbEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((DdbEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((DdbEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((DdbEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        DdbEndpoint target = (DdbEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazonddbclient":
+        case "amazonDDBClient": target.getConfiguration().setAmazonDDBClient(property(camelContext, com.amazonaws.services.dynamodbv2.AmazonDynamoDB.class, value)); return true;
+        case "consistentread":
+        case "consistentRead": target.getConfiguration().setConsistentRead(property(camelContext, boolean.class, value)); return true;
+        case "keyattributename":
+        case "keyAttributeName": target.getConfiguration().setKeyAttributeName(property(camelContext, java.lang.String.class, value)); return true;
+        case "keyattributetype":
+        case "keyAttributeType": target.getConfiguration().setKeyAttributeType(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ddb.DdbOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "readcapacity":
+        case "readCapacity": target.getConfiguration().setReadCapacity(property(camelContext, java.lang.Long.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "writecapacity":
+        case "writeCapacity": target.getConfiguration().setWriteCapacity(property(camelContext, java.lang.Long.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 08b1907..9e19b30 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class DdbStreamComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((DdbStreamComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ddbstream.DdbStreamConfiguration.class, value)); return true;
-        case "accessKey": ((DdbStreamComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((DdbStreamComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((DdbStreamComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((DdbStreamComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((DdbStreamComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((DdbStreamComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ddbstream.DdbStreamConfiguration.class, value)); return true;
-        case "accesskey": ((DdbStreamComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((DdbStreamComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((DdbStreamComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((DdbStreamComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((DdbStreamComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        DdbStreamComponent target = (DdbStreamComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.ddbstream.DdbStreamConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 102c84e..b329350 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
@@ -12,85 +12,67 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class DdbStreamEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonDynamoDbStreamsClient": ((DdbStreamEndpoint) target).getConfiguration().setAmazonDynamoDbStreamsClient(property(camelContext, com.amazonaws.services.dynamodbv2.AmazonDynamoDBStreams.class, value)); return true;
-        case "bridgeErrorHandler": ((DdbStreamEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "iteratorType": ((DdbStreamEndpoint) target).getConfiguration().setIteratorType(property(camelContext, com.amazonaws.services.dynamodbv2.model.ShardIteratorType.class, value)); return true;
-        case "maxResultsPerRequest": ((DdbStreamEndpoint) target).getConfiguration().setMaxResultsPerRequest(property(camelContext, int.class, value)); return true;
-        case "proxyHost": ((DdbStreamEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((DdbStreamEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((DdbStreamEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((DdbStreamEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((DdbStreamEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "sequenceNumberProvider": ((DdbStreamEndpoint) target).getConfiguration().setSequenceNumberProvider(property(camelContext, org.apache.camel.component.aws.ddbstream.SequenceNumberProvider.class, value)); return true;
-        case "exceptionHandler": ((DdbStreamEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((DdbStreamEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((DdbStreamEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "basicPropertyBinding": ((DdbStreamEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((DdbStreamEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((DdbStreamEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((DdbStreamEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((DdbStreamEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((DdbStreamEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((DdbStreamEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((DdbStreamEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((DdbStreamEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((DdbStreamEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((DdbStreamEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((DdbStreamEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((DdbStreamEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((DdbStreamEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((DdbStreamEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((DdbStreamEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((DdbStreamEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((DdbStreamEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazondynamodbstreamsclient": ((DdbStreamEndpoint) target).getConfiguration().setAmazonDynamoDbStreamsClient(property(camelContext, com.amazonaws.services.dynamodbv2.AmazonDynamoDBStreams.class, value)); return true;
-        case "bridgeerrorhandler": ((DdbStreamEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "iteratortype": ((DdbStreamEndpoint) target).getConfiguration().setIteratorType(property(camelContext, com.amazonaws.services.dynamodbv2.model.ShardIteratorType.class, value)); return true;
-        case "maxresultsperrequest": ((DdbStreamEndpoint) target).getConfiguration().setMaxResultsPerRequest(property(camelContext, int.class, value)); return true;
-        case "proxyhost": ((DdbStreamEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((DdbStreamEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((DdbStreamEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((DdbStreamEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendemptymessagewhenidle": ((DdbStreamEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "sequencenumberprovider": ((DdbStreamEndpoint) target).getConfiguration().setSequenceNumberProvider(property(camelContext, org.apache.camel.component.aws.ddbstream.SequenceNumberProvider.class, value)); return true;
-        case "exceptionhandler": ((DdbStreamEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((DdbStreamEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((DdbStreamEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "basicpropertybinding": ((DdbStreamEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((DdbStreamEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((DdbStreamEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((DdbStreamEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((DdbStreamEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((DdbStreamEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((DdbStreamEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((DdbStreamEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((DdbStreamEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((DdbStreamEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((DdbStreamEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((DdbStreamEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((DdbStreamEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((DdbStreamEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((DdbStreamEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((DdbStreamEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((DdbStreamEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((DdbStreamEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        DdbStreamEndpoint target = (DdbStreamEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazondynamodbstreamsclient":
+        case "amazonDynamoDbStreamsClient": target.getConfiguration().setAmazonDynamoDbStreamsClient(property(camelContext, com.amazonaws.services.dynamodbv2.AmazonDynamoDBStreams.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "iteratortype":
+        case "iteratorType": target.getConfiguration().setIteratorType(property(camelContext, com.amazonaws.services.dynamodbv2.model.ShardIteratorType.class, value)); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": target.getConfiguration().setMaxResultsPerRequest(property(camelContext, int.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "sequencenumberprovider":
+        case "sequenceNumberProvider": target.getConfiguration().setSequenceNumberProvider(property(camelContext, org.apache.camel.component.aws.ddbstream.SequenceNumberProvider.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 1d9da4f..a842183 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class EC2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((EC2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ec2.EC2Configuration.class, value)); return true;
-        case "region": ((EC2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "accessKey": ((EC2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((EC2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((EC2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((EC2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((EC2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ec2.EC2Configuration.class, value)); return true;
-        case "region": ((EC2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "accesskey": ((EC2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((EC2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((EC2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((EC2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        EC2Component target = (EC2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.ec2.EC2Configuration.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 f04428b..60a2bc3 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class EC2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((EC2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonEc2Client": ((EC2Endpoint) target).getConfiguration().setAmazonEc2Client(property(camelContext, com.amazonaws.services.ec2.AmazonEC2.class, value)); return true;
-        case "lazyStartProducer": ((EC2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((EC2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ec2.EC2Operations.class, value)); return true;
-        case "proxyHost": ((EC2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((EC2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((EC2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((EC2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((EC2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((EC2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((EC2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((EC2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonec2client": ((EC2Endpoint) target).getConfiguration().setAmazonEc2Client(property(camelContext, com.amazonaws.services.ec2.AmazonEC2.class, value)); return true;
-        case "lazystartproducer": ((EC2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((EC2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ec2.EC2Operations.class, value)); return true;
-        case "proxyhost": ((EC2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((EC2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((EC2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((EC2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((EC2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((EC2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((EC2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        EC2Endpoint target = (EC2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "amazonec2client":
+        case "amazonEc2Client": target.getConfiguration().setAmazonEc2Client(property(camelContext, com.amazonaws.services.ec2.AmazonEC2.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ec2.EC2Operations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 3129078..f9a0e28 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ECSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((ECSComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ecs.ECSConfiguration.class, value)); return true;
-        case "accessKey": ((ECSComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((ECSComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((ECSComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((ECSComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ECSComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((ECSComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ecs.ECSConfiguration.class, value)); return true;
-        case "accesskey": ((ECSComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((ECSComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((ECSComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((ECSComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ECSComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ECSComponent target = (ECSComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.ecs.ECSConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 628be1b..fab08ec 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ECSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((ECSEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "ecsClient": ((ECSEndpoint) target).getConfiguration().setEcsClient(property(camelContext, com.amazonaws.services.ecs.AmazonECS.class, value)); return true;
-        case "lazyStartProducer": ((ECSEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((ECSEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ecs.ECSOperations.class, value)); return true;
-        case "proxyHost": ((ECSEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((ECSEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((ECSEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((ECSEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((ECSEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((ECSEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ECSEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((ECSEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "ecsclient": ((ECSEndpoint) target).getConfiguration().setEcsClient(property(camelContext, com.amazonaws.services.ecs.AmazonECS.class, value)); return true;
-        case "lazystartproducer": ((ECSEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((ECSEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ecs.ECSOperations.class, value)); return true;
-        case "proxyhost": ((ECSEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((ECSEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((ECSEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((ECSEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((ECSEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((ECSEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ECSEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ECSEndpoint target = (ECSEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "ecsclient":
+        case "ecsClient": target.getConfiguration().setEcsClient(property(camelContext, com.amazonaws.services.ecs.AmazonECS.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.ecs.ECSOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 e8b2c06..4dabc12 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class EKSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((EKSComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.eks.EKSConfiguration.class, value)); return true;
-        case "accessKey": ((EKSComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((EKSComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((EKSComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((EKSComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((EKSComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((EKSComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.eks.EKSConfiguration.class, value)); return true;
-        case "accesskey": ((EKSComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((EKSComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((EKSComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((EKSComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((EKSComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        EKSComponent target = (EKSComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.eks.EKSConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 3272ea5..c702ef3 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class EKSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((EKSEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "eksClient": ((EKSEndpoint) target).getConfiguration().setEksClient(property(camelContext, com.amazonaws.services.eks.AmazonEKS.class, value)); return true;
-        case "lazyStartProducer": ((EKSEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((EKSEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.eks.EKSOperations.class, value)); return true;
-        case "proxyHost": ((EKSEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((EKSEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((EKSEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((EKSEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((EKSEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((EKSEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((EKSEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((EKSEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "eksclient": ((EKSEndpoint) target).getConfiguration().setEksClient(property(camelContext, com.amazonaws.services.eks.AmazonEKS.class, value)); return true;
-        case "lazystartproducer": ((EKSEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((EKSEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.eks.EKSOperations.class, value)); return true;
-        case "proxyhost": ((EKSEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((EKSEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((EKSEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((EKSEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((EKSEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((EKSEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((EKSEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        EKSEndpoint target = (EKSEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "eksclient":
+        case "eksClient": target.getConfiguration().setEksClient(property(camelContext, com.amazonaws.services.eks.AmazonEKS.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.eks.EKSOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 a1795a7..fff9b55 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class IAMComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((IAMComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.iam.IAMConfiguration.class, value)); return true;
-        case "accessKey": ((IAMComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((IAMComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((IAMComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((IAMComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((IAMComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((IAMComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.iam.IAMConfiguration.class, value)); return true;
-        case "accesskey": ((IAMComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((IAMComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((IAMComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((IAMComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((IAMComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        IAMComponent target = (IAMComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.iam.IAMConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6c7f078..7d73380 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class IAMEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((IAMEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "iamClient": ((IAMEndpoint) target).getConfiguration().setIamClient(property(camelContext, com.amazonaws.services.identitymanagement.AmazonIdentityManagement.class, value)); return true;
-        case "lazyStartProducer": ((IAMEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((IAMEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.iam.IAMOperations.class, value)); return true;
-        case "proxyHost": ((IAMEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((IAMEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((IAMEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((IAMEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((IAMEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((IAMEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((IAMEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((IAMEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "iamclient": ((IAMEndpoint) target).getConfiguration().setIamClient(property(camelContext, com.amazonaws.services.identitymanagement.AmazonIdentityManagement.class, value)); return true;
-        case "lazystartproducer": ((IAMEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((IAMEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.iam.IAMOperations.class, value)); return true;
-        case "proxyhost": ((IAMEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((IAMEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((IAMEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((IAMEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((IAMEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((IAMEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((IAMEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        IAMEndpoint target = (IAMEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "iamclient":
+        case "iamClient": target.getConfiguration().setIamClient(property(camelContext, com.amazonaws.services.identitymanagement.AmazonIdentityManagement.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.iam.IAMOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 272590f..61a1862 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KinesisFirehoseComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((KinesisFirehoseComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.firehose.KinesisFirehoseConfiguration.class, value)); return true;
-        case "accessKey": ((KinesisFirehoseComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KinesisFirehoseComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KinesisFirehoseComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((KinesisFirehoseComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((KinesisFirehoseComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((KinesisFirehoseComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.firehose.KinesisFirehoseConfiguration.class, value)); return true;
-        case "accesskey": ((KinesisFirehoseComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KinesisFirehoseComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KinesisFirehoseComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((KinesisFirehoseComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((KinesisFirehoseComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KinesisFirehoseComponent target = (KinesisFirehoseComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.firehose.KinesisFirehoseConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6fc45a0..2b5bb91 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
@@ -12,43 +12,28 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KinesisFirehoseEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonKinesisFirehoseClient": ((KinesisFirehoseEndpoint) target).getConfiguration().setAmazonKinesisFirehoseClient(property(camelContext, com.amazonaws.services.kinesisfirehose.AmazonKinesisFirehose.class, value)); return true;
-        case "lazyStartProducer": ((KinesisFirehoseEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "proxyHost": ((KinesisFirehoseEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((KinesisFirehoseEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((KinesisFirehoseEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((KinesisFirehoseEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((KinesisFirehoseEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KinesisFirehoseEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((KinesisFirehoseEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KinesisFirehoseEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazonkinesisfirehoseclient": ((KinesisFirehoseEndpoint) target).getConfiguration().setAmazonKinesisFirehoseClient(property(camelContext, com.amazonaws.services.kinesisfirehose.AmazonKinesisFirehose.class, value)); return true;
-        case "lazystartproducer": ((KinesisFirehoseEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "proxyhost": ((KinesisFirehoseEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((KinesisFirehoseEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((KinesisFirehoseEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((KinesisFirehoseEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((KinesisFirehoseEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KinesisFirehoseEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((KinesisFirehoseEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KinesisFirehoseEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KinesisFirehoseEndpoint target = (KinesisFirehoseEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazonkinesisfirehoseclient":
+        case "amazonKinesisFirehoseClient": target.getConfiguration().setAmazonKinesisFirehoseClient(property(camelContext, com.amazonaws.services.kinesisfirehose.AmazonKinesisFirehose.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 6edca63..711e0b94 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
@@ -12,37 +12,22 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KinesisComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((KinesisComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.kinesis.KinesisConfiguration.class, value)); return true;
-        case "accessKey": ((KinesisComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KinesisComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KinesisComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((KinesisComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((KinesisComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((KinesisComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((KinesisComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.kinesis.KinesisConfiguration.class, value)); return true;
-        case "accesskey": ((KinesisComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KinesisComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KinesisComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((KinesisComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((KinesisComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((KinesisComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KinesisComponent target = (KinesisComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.kinesis.KinesisConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 56b9a7a..f4743fe 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
@@ -12,91 +12,73 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KinesisEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonKinesisClient": ((KinesisEndpoint) target).getConfiguration().setAmazonKinesisClient(property(camelContext, com.amazonaws.services.kinesis.AmazonKinesis.class, value)); return true;
-        case "proxyHost": ((KinesisEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((KinesisEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((KinesisEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((KinesisEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((KinesisEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "iteratorType": ((KinesisEndpoint) target).getConfiguration().setIteratorType(property(camelContext, com.amazonaws.services.kinesis.model.ShardIteratorType.class, value)); return true;
-        case "maxResultsPerRequest": ((KinesisEndpoint) target).getConfiguration().setMaxResultsPerRequest(property(camelContext, int.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((KinesisEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "sequenceNumber": ((KinesisEndpoint) target).getConfiguration().setSequenceNumber(property(camelContext, java.lang.String.class, value)); return true;
-        case "shardClosed": ((KinesisEndpoint) target).getConfiguration().setShardClosed(property(camelContext, org.apache.camel.component.aws.kinesis.KinesisShardClosedStrategyEnum.class, value)); return true;
-        case "shardId": ((KinesisEndpoint) target).getConfiguration().setShardId(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionHandler": ((KinesisEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((KinesisEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((KinesisEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazyStartProducer": ((KinesisEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((KinesisEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KinesisEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((KinesisEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((KinesisEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((KinesisEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((KinesisEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((KinesisEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((KinesisEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((KinesisEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((KinesisEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((KinesisEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((KinesisEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((KinesisEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((KinesisEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((KinesisEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((KinesisEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((KinesisEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KinesisEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazonkinesisclient": ((KinesisEndpoint) target).getConfiguration().setAmazonKinesisClient(property(camelContext, com.amazonaws.services.kinesis.AmazonKinesis.class, value)); return true;
-        case "proxyhost": ((KinesisEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((KinesisEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((KinesisEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((KinesisEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((KinesisEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "iteratortype": ((KinesisEndpoint) target).getConfiguration().setIteratorType(property(camelContext, com.amazonaws.services.kinesis.model.ShardIteratorType.class, value)); return true;
-        case "maxresultsperrequest": ((KinesisEndpoint) target).getConfiguration().setMaxResultsPerRequest(property(camelContext, int.class, value)); return true;
-        case "sendemptymessagewhenidle": ((KinesisEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "sequencenumber": ((KinesisEndpoint) target).getConfiguration().setSequenceNumber(property(camelContext, java.lang.String.class, value)); return true;
-        case "shardclosed": ((KinesisEndpoint) target).getConfiguration().setShardClosed(property(camelContext, org.apache.camel.component.aws.kinesis.KinesisShardClosedStrategyEnum.class, value)); return true;
-        case "shardid": ((KinesisEndpoint) target).getConfiguration().setShardId(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionhandler": ((KinesisEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((KinesisEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((KinesisEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazystartproducer": ((KinesisEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((KinesisEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KinesisEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((KinesisEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((KinesisEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((KinesisEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((KinesisEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((KinesisEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((KinesisEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((KinesisEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((KinesisEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((KinesisEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((KinesisEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((KinesisEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((KinesisEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((KinesisEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((KinesisEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((KinesisEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KinesisEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KinesisEndpoint target = (KinesisEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazonkinesisclient":
+        case "amazonKinesisClient": target.getConfiguration().setAmazonKinesisClient(property(camelContext, com.amazonaws.services.kinesis.AmazonKinesis.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "iteratortype":
+        case "iteratorType": target.getConfiguration().setIteratorType(property(camelContext, com.amazonaws.services.kinesis.model.ShardIteratorType.class, value)); return true;
+        case "maxresultsperrequest":
+        case "maxResultsPerRequest": target.getConfiguration().setMaxResultsPerRequest(property(camelContext, int.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "sequencenumber":
+        case "sequenceNumber": target.getConfiguration().setSequenceNumber(property(camelContext, java.lang.String.class, value)); return true;
+        case "shardclosed":
+        case "shardClosed": target.getConfiguration().setShardClosed(property(camelContext, org.apache.camel.component.aws.kinesis.KinesisShardClosedStrategyEnum.class, value)); return true;
+        case "shardid":
+        case "shardId": target.getConfiguration().setShardId(property(camelContext, java.lang.String.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 7ff2011..964ee17 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KMSComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((KMSComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.kms.KMSConfiguration.class, value)); return true;
-        case "accessKey": ((KMSComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KMSComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KMSComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((KMSComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((KMSComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((KMSComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.kms.KMSConfiguration.class, value)); return true;
-        case "accesskey": ((KMSComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KMSComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KMSComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((KMSComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((KMSComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KMSComponent target = (KMSComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.kms.KMSConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 897fe1d..680a5fe 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KMSEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((KMSEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "kmsClient": ((KMSEndpoint) target).getConfiguration().setKmsClient(property(camelContext, com.amazonaws.services.kms.AWSKMS.class, value)); return true;
-        case "lazyStartProducer": ((KMSEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((KMSEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.kms.KMSOperations.class, value)); return true;
-        case "proxyHost": ((KMSEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((KMSEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((KMSEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((KMSEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KMSEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((KMSEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KMSEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((KMSEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "kmsclient": ((KMSEndpoint) target).getConfiguration().setKmsClient(property(camelContext, com.amazonaws.services.kms.AWSKMS.class, value)); return true;
-        case "lazystartproducer": ((KMSEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((KMSEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.kms.KMSOperations.class, value)); return true;
-        case "proxyhost": ((KMSEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((KMSEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((KMSEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((KMSEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KMSEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((KMSEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KMSEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KMSEndpoint target = (KMSEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "kmsclient":
+        case "kmsClient": target.getConfiguration().setKmsClient(property(camelContext, com.amazonaws.services.kms.AWSKMS.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.kms.KMSOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 3af2d08..ff7ef44 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class LambdaComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((LambdaComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.lambda.LambdaConfiguration.class, value)); return true;
-        case "accessKey": ((LambdaComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((LambdaComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((LambdaComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((LambdaComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((LambdaComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((LambdaComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.lambda.LambdaConfiguration.class, value)); return true;
-        case "accesskey": ((LambdaComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((LambdaComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((LambdaComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((LambdaComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((LambdaComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        LambdaComponent target = (LambdaComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.lambda.LambdaConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 919856a..ff350f1 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class LambdaEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "lazyStartProducer": ((LambdaEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((LambdaEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.lambda.LambdaOperations.class, value)); return true;
-        case "region": ((LambdaEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "awsLambdaClient": ((LambdaEndpoint) target).getConfiguration().setAwsLambdaClient(property(camelContext, com.amazonaws.services.lambda.AWSLambda.class, value)); return true;
-        case "basicPropertyBinding": ((LambdaEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((LambdaEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "proxyHost": ((LambdaEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((LambdaEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((LambdaEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "accessKey": ((LambdaEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((LambdaEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "lazystartproducer": ((LambdaEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((LambdaEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.lambda.LambdaOperations.class, value)); return true;
-        case "region": ((LambdaEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "awslambdaclient": ((LambdaEndpoint) target).getConfiguration().setAwsLambdaClient(property(camelContext, com.amazonaws.services.lambda.AWSLambda.class, value)); return true;
-        case "basicpropertybinding": ((LambdaEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((LambdaEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "proxyhost": ((LambdaEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((LambdaEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((LambdaEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "accesskey": ((LambdaEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((LambdaEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        LambdaEndpoint target = (LambdaEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.lambda.LambdaOperations.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "awslambdaclient":
+        case "awsLambdaClient": target.getConfiguration().setAwsLambdaClient(property(camelContext, com.amazonaws.services.lambda.AWSLambda.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 647ddbf..af46080 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MQComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((MQComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.mq.MQConfiguration.class, value)); return true;
-        case "accessKey": ((MQComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MQComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MQComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MQComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((MQComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((MQComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.mq.MQConfiguration.class, value)); return true;
-        case "accesskey": ((MQComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MQComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MQComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MQComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((MQComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MQComponent target = (MQComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.mq.MQConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 bb1d8d4..e020a7d 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MQEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((MQEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonMqClient": ((MQEndpoint) target).getConfiguration().setAmazonMqClient(property(camelContext, com.amazonaws.services.mq.AmazonMQ.class, value)); return true;
-        case "lazyStartProducer": ((MQEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((MQEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.mq.MQOperations.class, value)); return true;
-        case "proxyHost": ((MQEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((MQEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((MQEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((MQEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MQEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MQEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MQEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((MQEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonmqclient": ((MQEndpoint) target).getConfiguration().setAmazonMqClient(property(camelContext, com.amazonaws.services.mq.AmazonMQ.class, value)); return true;
-        case "lazystartproducer": ((MQEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((MQEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.mq.MQOperations.class, value)); return true;
-        case "proxyhost": ((MQEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((MQEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((MQEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((MQEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MQEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MQEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MQEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MQEndpoint target = (MQEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "amazonmqclient":
+        case "amazonMqClient": target.getConfiguration().setAmazonMqClient(property(camelContext, com.amazonaws.services.mq.AmazonMQ.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.mq.MQOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 07432c2..b87288c 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MSKComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((MSKComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.msk.MSKConfiguration.class, value)); return true;
-        case "accessKey": ((MSKComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MSKComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MSKComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MSKComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((MSKComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((MSKComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.msk.MSKConfiguration.class, value)); return true;
-        case "accesskey": ((MSKComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MSKComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MSKComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MSKComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((MSKComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MSKComponent target = (MSKComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.msk.MSKConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 5149076..baf11fa 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MSKEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((MSKEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((MSKEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "mskClient": ((MSKEndpoint) target).getConfiguration().setMskClient(property(camelContext, com.amazonaws.services.kafka.AWSKafka.class, value)); return true;
-        case "operation": ((MSKEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.msk.MSKOperations.class, value)); return true;
-        case "proxyHost": ((MSKEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((MSKEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((MSKEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((MSKEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MSKEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MSKEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MSKEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((MSKEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((MSKEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "mskclient": ((MSKEndpoint) target).getConfiguration().setMskClient(property(camelContext, com.amazonaws.services.kafka.AWSKafka.class, value)); return true;
-        case "operation": ((MSKEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.msk.MSKOperations.class, value)); return true;
-        case "proxyhost": ((MSKEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((MSKEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((MSKEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((MSKEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MSKEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MSKEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MSKEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MSKEndpoint target = (MSKEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "mskclient":
+        case "mskClient": target.getConfiguration().setMskClient(property(camelContext, com.amazonaws.services.kafka.AWSKafka.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.msk.MSKOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 db55fe1..afeed73 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
@@ -12,37 +12,22 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class S3ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((S3Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.s3.S3Configuration.class, value)); return true;
-        case "accessKey": ((S3Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((S3Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((S3Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((S3Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((S3Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((S3Component) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((S3Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.s3.S3Configuration.class, value)); return true;
-        case "accesskey": ((S3Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((S3Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((S3Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((S3Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((S3Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((S3Component) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        S3Component target = (S3Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.s3.S3Configuration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 64bdac9..e7e3c49 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
@@ -12,137 +12,115 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class S3EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonS3Client": ((S3Endpoint) target).getConfiguration().setAmazonS3Client(property(camelContext, com.amazonaws.services.s3.AmazonS3.class, value)); return true;
-        case "autoCreateBucket": ((S3Endpoint) target).getConfiguration().setAutoCreateBucket(property(camelContext, boolean.class, value)); return true;
-        case "pathStyleAccess": ((S3Endpoint) target).getConfiguration().setPathStyleAccess(property(camelContext, boolean.class, value)); return true;
-        case "policy": ((S3Endpoint) target).getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyHost": ((S3Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((S3Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((S3Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((S3Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "useIAMCredentials": ((S3Endpoint) target).getConfiguration().setUseIAMCredentials(property(camelContext, boolean.class, value)); return true;
-        case "encryptionMaterials": ((S3Endpoint) target).getConfiguration().setEncryptionMaterials(property(camelContext, com.amazonaws.services.s3.model.EncryptionMaterials.class, value)); return true;
-        case "useEncryption": ((S3Endpoint) target).getConfiguration().setUseEncryption(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((S3Endpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "deleteAfterRead": ((S3Endpoint) target).getConfiguration().setDeleteAfterRead(property(camelContext, boolean.class, value)); return true;
-        case "delimiter": ((S3Endpoint) target).getConfiguration().setDelimiter(property(camelContext, java.lang.String.class, value)); return true;
-        case "fileName": ((S3Endpoint) target).getConfiguration().setFileName(property(camelContext, java.lang.String.class, value)); return true;
-        case "includeBody": ((S3Endpoint) target).getConfiguration().setIncludeBody(property(camelContext, boolean.class, value)); return true;
-        case "maxConnections": ((S3Endpoint) target).setMaxConnections(property(camelContext, int.class, value)); return true;
-        case "maxMessagesPerPoll": ((S3Endpoint) target).setMaxMessagesPerPoll(property(camelContext, int.class, value)); return true;
-        case "prefix": ((S3Endpoint) target).getConfiguration().setPrefix(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((S3Endpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "autocloseBody": ((S3Endpoint) target).getConfiguration().setAutocloseBody(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((S3Endpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((S3Endpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((S3Endpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "deleteAfterWrite": ((S3Endpoint) target).getConfiguration().setDeleteAfterWrite(property(camelContext, boolean.class, value)); return true;
-        case "keyName": ((S3Endpoint) target).getConfiguration().setKeyName(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((S3Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "multiPartUpload": ((S3Endpoint) target).getConfiguration().setMultiPartUpload(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((S3Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.s3.S3Operations.class, value)); return true;
-        case "partSize": ((S3Endpoint) target).getConfiguration().setPartSize(property(camelContext, long.class, value)); return true;
-        case "serverSideEncryption": ((S3Endpoint) target).getConfiguration().setServerSideEncryption(property(camelContext, java.lang.String.class, value)); return true;
-        case "storageClass": ((S3Endpoint) target).getConfiguration().setStorageClass(property(camelContext, java.lang.String.class, value)); return true;
-        case "awsKMSKeyId": ((S3Endpoint) target).getConfiguration().setAwsKMSKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "useAwsKMS": ((S3Endpoint) target).getConfiguration().setUseAwsKMS(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((S3Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((S3Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accelerateModeEnabled": ((S3Endpoint) target).getConfiguration().setAccelerateModeEnabled(property(camelContext, boolean.class, value)); return true;
-        case "chunkedEncodingDisabled": ((S3Endpoint) target).getConfiguration().setChunkedEncodingDisabled(property(camelContext, boolean.class, value)); return true;
-        case "dualstackEnabled": ((S3Endpoint) target).getConfiguration().setDualstackEnabled(property(camelContext, boolean.class, value)); return true;
-        case "forceGlobalBucketAccessEnabled": ((S3Endpoint) target).getConfiguration().setForceGlobalBucketAccessEnabled(property(camelContext, boolean.class, value)); return true;
-        case "payloadSigningEnabled": ((S3Endpoint) target).getConfiguration().setPayloadSigningEnabled(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((S3Endpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((S3Endpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((S3Endpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((S3Endpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((S3Endpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((S3Endpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((S3Endpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((S3Endpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((S3Endpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((S3Endpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((S3Endpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((S3Endpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((S3Endpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((S3Endpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((S3Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((S3Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazons3client": ((S3Endpoint) target).getConfiguration().setAmazonS3Client(property(camelContext, com.amazonaws.services.s3.AmazonS3.class, value)); return true;
-        case "autocreatebucket": ((S3Endpoint) target).getConfiguration().setAutoCreateBucket(property(camelContext, boolean.class, value)); return true;
-        case "pathstyleaccess": ((S3Endpoint) target).getConfiguration().setPathStyleAccess(property(camelContext, boolean.class, value)); return true;
-        case "policy": ((S3Endpoint) target).getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyhost": ((S3Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((S3Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((S3Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((S3Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "useiamcredentials": ((S3Endpoint) target).getConfiguration().setUseIAMCredentials(property(camelContext, boolean.class, value)); return true;
-        case "encryptionmaterials": ((S3Endpoint) target).getConfiguration().setEncryptionMaterials(property(camelContext, com.amazonaws.services.s3.model.EncryptionMaterials.class, value)); return true;
-        case "useencryption": ((S3Endpoint) target).getConfiguration().setUseEncryption(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((S3Endpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "deleteafterread": ((S3Endpoint) target).getConfiguration().setDeleteAfterRead(property(camelContext, boolean.class, value)); return true;
-        case "delimiter": ((S3Endpoint) target).getConfiguration().setDelimiter(property(camelContext, java.lang.String.class, value)); return true;
-        case "filename": ((S3Endpoint) target).getConfiguration().setFileName(property(camelContext, java.lang.String.class, value)); return true;
-        case "includebody": ((S3Endpoint) target).getConfiguration().setIncludeBody(property(camelContext, boolean.class, value)); return true;
-        case "maxconnections": ((S3Endpoint) target).setMaxConnections(property(camelContext, int.class, value)); return true;
-        case "maxmessagesperpoll": ((S3Endpoint) target).setMaxMessagesPerPoll(property(camelContext, int.class, value)); return true;
-        case "prefix": ((S3Endpoint) target).getConfiguration().setPrefix(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendemptymessagewhenidle": ((S3Endpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "autoclosebody": ((S3Endpoint) target).getConfiguration().setAutocloseBody(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((S3Endpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((S3Endpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((S3Endpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "deleteafterwrite": ((S3Endpoint) target).getConfiguration().setDeleteAfterWrite(property(camelContext, boolean.class, value)); return true;
-        case "keyname": ((S3Endpoint) target).getConfiguration().setKeyName(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((S3Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "multipartupload": ((S3Endpoint) target).getConfiguration().setMultiPartUpload(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((S3Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.s3.S3Operations.class, value)); return true;
-        case "partsize": ((S3Endpoint) target).getConfiguration().setPartSize(property(camelContext, long.class, value)); return true;
-        case "serversideencryption": ((S3Endpoint) target).getConfiguration().setServerSideEncryption(property(camelContext, java.lang.String.class, value)); return true;
-        case "storageclass": ((S3Endpoint) target).getConfiguration().setStorageClass(property(camelContext, java.lang.String.class, value)); return true;
-        case "awskmskeyid": ((S3Endpoint) target).getConfiguration().setAwsKMSKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "useawskms": ((S3Endpoint) target).getConfiguration().setUseAwsKMS(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((S3Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((S3Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "acceleratemodeenabled": ((S3Endpoint) target).getConfiguration().setAccelerateModeEnabled(property(camelContext, boolean.class, value)); return true;
-        case "chunkedencodingdisabled": ((S3Endpoint) target).getConfiguration().setChunkedEncodingDisabled(property(camelContext, boolean.class, value)); return true;
-        case "dualstackenabled": ((S3Endpoint) target).getConfiguration().setDualstackEnabled(property(camelContext, boolean.class, value)); return true;
-        case "forceglobalbucketaccessenabled": ((S3Endpoint) target).getConfiguration().setForceGlobalBucketAccessEnabled(property(camelContext, boolean.class, value)); return true;
-        case "payloadsigningenabled": ((S3Endpoint) target).getConfiguration().setPayloadSigningEnabled(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((S3Endpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((S3Endpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((S3Endpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((S3Endpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((S3Endpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((S3Endpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((S3Endpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((S3Endpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((S3Endpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((S3Endpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((S3Endpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((S3Endpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((S3Endpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((S3Endpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((S3Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((S3Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        S3Endpoint target = (S3Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazons3client":
+        case "amazonS3Client": target.getConfiguration().setAmazonS3Client(property(camelContext, com.amazonaws.services.s3.AmazonS3.class, value)); return true;
+        case "autocreatebucket":
+        case "autoCreateBucket": target.getConfiguration().setAutoCreateBucket(property(camelContext, boolean.class, value)); return true;
+        case "pathstyleaccess":
+        case "pathStyleAccess": target.getConfiguration().setPathStyleAccess(property(camelContext, boolean.class, value)); return true;
+        case "policy": target.getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "useiamcredentials":
+        case "useIAMCredentials": target.getConfiguration().setUseIAMCredentials(property(camelContext, boolean.class, value)); return true;
+        case "encryptionmaterials":
+        case "encryptionMaterials": target.getConfiguration().setEncryptionMaterials(property(camelContext, com.amazonaws.services.s3.model.EncryptionMaterials.class, value)); return true;
+        case "useencryption":
+        case "useEncryption": target.getConfiguration().setUseEncryption(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": target.getConfiguration().setDeleteAfterRead(property(camelContext, boolean.class, value)); return true;
+        case "delimiter": target.getConfiguration().setDelimiter(property(camelContext, java.lang.String.class, value)); return true;
+        case "filename":
+        case "fileName": target.getConfiguration().setFileName(property(camelContext, java.lang.String.class, value)); return true;
+        case "includebody":
+        case "includeBody": target.getConfiguration().setIncludeBody(property(camelContext, boolean.class, value)); return true;
+        case "maxconnections":
+        case "maxConnections": target.setMaxConnections(property(camelContext, int.class, value)); return true;
+        case "maxmessagesperpoll":
+        case "maxMessagesPerPoll": target.setMaxMessagesPerPoll(property(camelContext, int.class, value)); return true;
+        case "prefix": target.getConfiguration().setPrefix(property(camelContext, java.lang.String.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "autoclosebody":
+        case "autocloseBody": target.getConfiguration().setAutocloseBody(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "deleteafterwrite":
+        case "deleteAfterWrite": target.getConfiguration().setDeleteAfterWrite(property(camelContext, boolean.class, value)); return true;
+        case "keyname":
+        case "keyName": target.getConfiguration().setKeyName(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "multipartupload":
+        case "multiPartUpload": target.getConfiguration().setMultiPartUpload(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.s3.S3Operations.class, value)); return true;
+        case "partsize":
+        case "partSize": target.getConfiguration().setPartSize(property(camelContext, long.class, value)); return true;
+        case "serversideencryption":
+        case "serverSideEncryption": target.getConfiguration().setServerSideEncryption(property(camelContext, java.lang.String.class, value)); return true;
+        case "storageclass":
+        case "storageClass": target.getConfiguration().setStorageClass(property(camelContext, java.lang.String.class, value)); return true;
+        case "awskmskeyid":
+        case "awsKMSKeyId": target.getConfiguration().setAwsKMSKeyId(property(camelContext, java.lang.String.class, value)); return true;
+        case "useawskms":
+        case "useAwsKMS": target.getConfiguration().setUseAwsKMS(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "acceleratemodeenabled":
+        case "accelerateModeEnabled": target.getConfiguration().setAccelerateModeEnabled(property(camelContext, boolean.class, value)); return true;
+        case "chunkedencodingdisabled":
+        case "chunkedEncodingDisabled": target.getConfiguration().setChunkedEncodingDisabled(property(camelContext, boolean.class, value)); return true;
+        case "dualstackenabled":
+        case "dualstackEnabled": target.getConfiguration().setDualstackEnabled(property(camelContext, boolean.class, value)); return true;
+        case "forceglobalbucketaccessenabled":
+        case "forceGlobalBucketAccessEnabled": target.getConfiguration().setForceGlobalBucketAccessEnabled(property(camelContext, boolean.class, value)); return true;
+        case "payloadsigningenabled":
+        case "payloadSigningEnabled": target.getConfiguration().setPayloadSigningEnabled(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 0b500d6..61b0607 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
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SdbComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((SdbComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((SdbComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((SdbComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((SdbComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SdbComponent target = (SdbComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 e5ce267..8e03587 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
@@ -12,49 +12,33 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SdbEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((SdbEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonSDBClient": ((SdbEndpoint) target).getConfiguration().setAmazonSDBClient(property(camelContext, com.amazonaws.services.simpledb.AmazonSimpleDB.class, value)); return true;
-        case "consistentRead": ((SdbEndpoint) target).getConfiguration().setConsistentRead(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((SdbEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "maxNumberOfDomains": ((SdbEndpoint) target).getConfiguration().setMaxNumberOfDomains(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "operation": ((SdbEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.sdb.SdbOperations.class, value)); return true;
-        case "proxyHost": ((SdbEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((SdbEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((SdbEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((SdbEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SdbEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((SdbEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((SdbEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((SdbEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonsdbclient": ((SdbEndpoint) target).getConfiguration().setAmazonSDBClient(property(camelContext, com.amazonaws.services.simpledb.AmazonSimpleDB.class, value)); return true;
-        case "consistentread": ((SdbEndpoint) target).getConfiguration().setConsistentRead(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((SdbEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "maxnumberofdomains": ((SdbEndpoint) target).getConfiguration().setMaxNumberOfDomains(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "operation": ((SdbEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.sdb.SdbOperations.class, value)); return true;
-        case "proxyhost": ((SdbEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((SdbEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((SdbEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((SdbEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SdbEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((SdbEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((SdbEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SdbEndpoint target = (SdbEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "amazonsdbclient":
+        case "amazonSDBClient": target.getConfiguration().setAmazonSDBClient(property(camelContext, com.amazonaws.services.simpledb.AmazonSimpleDB.class, value)); return true;
+        case "consistentread":
+        case "consistentRead": target.getConfiguration().setConsistentRead(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "maxnumberofdomains":
+        case "maxNumberOfDomains": target.getConfiguration().setMaxNumberOfDomains(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.sdb.SdbOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 fa5d04f..a233a64 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SesComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((SesComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ses.SesConfiguration.class, value)); return true;
-        case "accessKey": ((SesComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SesComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SesComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((SesComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((SesComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((SesComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.ses.SesConfiguration.class, value)); return true;
-        case "accesskey": ((SesComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SesComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SesComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((SesComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((SesComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SesComponent target = (SesComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.ses.SesConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 2d3ca78..13fb1f3 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
@@ -12,51 +12,34 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SesEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonSESClient": ((SesEndpoint) target).getConfiguration().setAmazonSESClient(property(camelContext, com.amazonaws.services.simpleemail.AmazonSimpleEmailService.class, value)); return true;
-        case "lazyStartProducer": ((SesEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "proxyHost": ((SesEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((SesEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((SesEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((SesEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "replyToAddresses": ((SesEndpoint) target).getConfiguration().setReplyToAddresses(property(camelContext, java.util.List.class, value)); return true;
-        case "returnPath": ((SesEndpoint) target).getConfiguration().setReturnPath(property(camelContext, java.lang.String.class, value)); return true;
-        case "subject": ((SesEndpoint) target).getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
-        case "to": ((SesEndpoint) target).getConfiguration().setTo(property(camelContext, java.util.List.class, value)); return true;
-        case "basicPropertyBinding": ((SesEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((SesEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((SesEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SesEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazonsesclient": ((SesEndpoint) target).getConfiguration().setAmazonSESClient(property(camelContext, com.amazonaws.services.simpleemail.AmazonSimpleEmailService.class, value)); return true;
-        case "lazystartproducer": ((SesEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "proxyhost": ((SesEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((SesEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((SesEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((SesEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "replytoaddresses": ((SesEndpoint) target).getConfiguration().setReplyToAddresses(property(camelContext, java.util.List.class, value)); return true;
-        case "returnpath": ((SesEndpoint) target).getConfiguration().setReturnPath(property(camelContext, java.lang.String.class, value)); return true;
-        case "subject": ((SesEndpoint) target).getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
-        case "to": ((SesEndpoint) target).getConfiguration().setTo(property(camelContext, java.util.List.class, value)); return true;
-        case "basicpropertybinding": ((SesEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((SesEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((SesEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SesEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SesEndpoint target = (SesEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazonsesclient":
+        case "amazonSESClient": target.getConfiguration().setAmazonSESClient(property(camelContext, com.amazonaws.services.simpleemail.AmazonSimpleEmailService.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "replytoaddresses":
+        case "replyToAddresses": target.getConfiguration().setReplyToAddresses(property(camelContext, java.util.List.class, value)); return true;
+        case "returnpath":
+        case "returnPath": target.getConfiguration().setReturnPath(property(camelContext, java.lang.String.class, value)); return true;
+        case "subject": target.getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
+        case "to": target.getConfiguration().setTo(property(camelContext, java.util.List.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 46504a0..810b3e5 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SnsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((SnsComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.sns.SnsConfiguration.class, value)); return true;
-        case "accessKey": ((SnsComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SnsComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SnsComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((SnsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((SnsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((SnsComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.sns.SnsConfiguration.class, value)); return true;
-        case "accesskey": ((SnsComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SnsComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SnsComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((SnsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((SnsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SnsComponent target = (SnsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.sns.SnsConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 07ff396..26a7a28 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
@@ -12,63 +12,46 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SnsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonSNSClient": ((SnsEndpoint) target).getConfiguration().setAmazonSNSClient(property(camelContext, com.amazonaws.services.sns.AmazonSNS.class, value)); return true;
-        case "amazonSQSClient": ((SnsEndpoint) target).getConfiguration().setAmazonSQSClient(property(camelContext, com.amazonaws.services.sqs.AmazonSQS.class, value)); return true;
-        case "autoCreateTopic": ((SnsEndpoint) target).getConfiguration().setAutoCreateTopic(property(camelContext, boolean.class, value)); return true;
-        case "headerFilterStrategy": ((SnsEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "kmsMasterKeyId": ((SnsEndpoint) target).getConfiguration().setKmsMasterKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((SnsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "messageStructure": ((SnsEndpoint) target).getConfiguration().setMessageStructure(property(camelContext, java.lang.String.class, value)); return true;
-        case "policy": ((SnsEndpoint) target).getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyHost": ((SnsEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((SnsEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((SnsEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "queueUrl": ((SnsEndpoint) target).getConfiguration().setQueueUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SnsEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "serverSideEncryptionEnabled": ((SnsEndpoint) target).getConfiguration().setServerSideEncryptionEnabled(property(camelContext, boolean.class, value)); return true;
-        case "subject": ((SnsEndpoint) target).getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
-        case "subscribeSNStoSQS": ((SnsEndpoint) target).getConfiguration().setSubscribeSNStoSQS(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((SnsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((SnsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accessKey": ((SnsEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SnsEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazonsnsclient": ((SnsEndpoint) target).getConfiguration().setAmazonSNSClient(property(camelContext, com.amazonaws.services.sns.AmazonSNS.class, value)); return true;
-        case "amazonsqsclient": ((SnsEndpoint) target).getConfiguration().setAmazonSQSClient(property(camelContext, com.amazonaws.services.sqs.AmazonSQS.class, value)); return true;
-        case "autocreatetopic": ((SnsEndpoint) target).getConfiguration().setAutoCreateTopic(property(camelContext, boolean.class, value)); return true;
-        case "headerfilterstrategy": ((SnsEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "kmsmasterkeyid": ((SnsEndpoint) target).getConfiguration().setKmsMasterKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((SnsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "messagestructure": ((SnsEndpoint) target).getConfiguration().setMessageStructure(property(camelContext, java.lang.String.class, value)); return true;
-        case "policy": ((SnsEndpoint) target).getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyhost": ((SnsEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((SnsEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((SnsEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "queueurl": ((SnsEndpoint) target).getConfiguration().setQueueUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SnsEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "serversideencryptionenabled": ((SnsEndpoint) target).getConfiguration().setServerSideEncryptionEnabled(property(camelContext, boolean.class, value)); return true;
-        case "subject": ((SnsEndpoint) target).getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
-        case "subscribesnstosqs": ((SnsEndpoint) target).getConfiguration().setSubscribeSNStoSQS(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((SnsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((SnsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accesskey": ((SnsEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SnsEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SnsEndpoint target = (SnsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazonsnsclient":
+        case "amazonSNSClient": target.getConfiguration().setAmazonSNSClient(property(camelContext, com.amazonaws.services.sns.AmazonSNS.class, value)); return true;
+        case "amazonsqsclient":
+        case "amazonSQSClient": target.getConfiguration().setAmazonSQSClient(property(camelContext, com.amazonaws.services.sqs.AmazonSQS.class, value)); return true;
+        case "autocreatetopic":
+        case "autoCreateTopic": target.getConfiguration().setAutoCreateTopic(property(camelContext, boolean.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": target.getConfiguration().setKmsMasterKeyId(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "messagestructure":
+        case "messageStructure": target.getConfiguration().setMessageStructure(property(camelContext, java.lang.String.class, value)); return true;
+        case "policy": target.getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "queueurl":
+        case "queueUrl": target.getConfiguration().setQueueUrl(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": target.getConfiguration().setServerSideEncryptionEnabled(property(camelContext, boolean.class, value)); return true;
+        case "subject": target.getConfiguration().setSubject(property(camelContext, java.lang.String.class, value)); return true;
+        case "subscribesnstosqs":
+        case "subscribeSNStoSQS": target.getConfiguration().setSubscribeSNStoSQS(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 080671e..9c23633 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
@@ -12,37 +12,22 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SqsComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((SqsComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.sqs.SqsConfiguration.class, value)); return true;
-        case "accessKey": ((SqsComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SqsComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SqsComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((SqsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((SqsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((SqsComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((SqsComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.sqs.SqsConfiguration.class, value)); return true;
-        case "accesskey": ((SqsComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SqsComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SqsComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((SqsComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((SqsComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((SqsComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SqsComponent target = (SqsComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.sqs.SqsConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 c9962c9..79c86ac 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
@@ -12,139 +12,118 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SqsEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonAWSHost": ((SqsEndpoint) target).getConfiguration().setAmazonAWSHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonSQSClient": ((SqsEndpoint) target).getConfiguration().setAmazonSQSClient(property(camelContext, com.amazonaws.services.sqs.AmazonSQS.class, value)); return true;
-        case "autoCreateQueue": ((SqsEndpoint) target).getConfiguration().setAutoCreateQueue(property(camelContext, boolean.class, value)); return true;
-        case "headerFilterStrategy": ((SqsEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "protocol": ((SqsEndpoint) target).getConfiguration().setProtocol(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyProtocol": ((SqsEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "queueOwnerAWSAccountId": ((SqsEndpoint) target).getConfiguration().setQueueOwnerAWSAccountId(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SqsEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "attributeNames": ((SqsEndpoint) target).getConfiguration().setAttributeNames(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((SqsEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "concurrentConsumers": ((SqsEndpoint) target).getConfiguration().setConcurrentConsumers(property(camelContext, int.class, value)); return true;
-        case "defaultVisibilityTimeout": ((SqsEndpoint) target).getConfiguration().setDefaultVisibilityTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "deleteAfterRead": ((SqsEndpoint) target).getConfiguration().setDeleteAfterRead(property(camelContext, boolean.class, value)); return true;
-        case "deleteIfFiltered": ((SqsEndpoint) target).getConfiguration().setDeleteIfFiltered(property(camelContext, boolean.class, value)); return true;
-        case "extendMessageVisibility": ((SqsEndpoint) target).getConfiguration().setExtendMessageVisibility(property(camelContext, boolean.class, value)); return true;
-        case "kmsDataKeyReusePeriodSeconds": ((SqsEndpoint) target).getConfiguration().setKmsDataKeyReusePeriodSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "kmsMasterKeyId": ((SqsEndpoint) target).getConfiguration().setKmsMasterKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "maxMessagesPerPoll": ((SqsEndpoint) target).setMaxMessagesPerPoll(property(camelContext, int.class, value)); return true;
-        case "messageAttributeNames": ((SqsEndpoint) target).getConfiguration().setMessageAttributeNames(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((SqsEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "serverSideEncryptionEnabled": ((SqsEndpoint) target).getConfiguration().setServerSideEncryptionEnabled(property(camelContext, boolean.class, value)); return true;
-        case "visibilityTimeout": ((SqsEndpoint) target).getConfiguration().setVisibilityTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "waitTimeSeconds": ((SqsEndpoint) target).getConfiguration().setWaitTimeSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "exceptionHandler": ((SqsEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((SqsEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((SqsEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "delaySeconds": ((SqsEndpoint) target).getConfiguration().setDelaySeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "lazyStartProducer": ((SqsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "messageDeduplicationIdStrategy": ((SqsEndpoint) target).getConfiguration().setMessageDeduplicationIdStrategy(property(camelContext, org.apache.camel.component.aws.sqs.MessageDeduplicationIdStrategy.class, value)); return true;
-        case "messageGroupIdStrategy": ((SqsEndpoint) target).getConfiguration().setMessageGroupIdStrategy(property(camelContext, org.apache.camel.component.aws.sqs.MessageGroupIdStrategy.class, value)); return true;
-        case "operation": ((SqsEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.sqs.SqsOperations.class, value)); return true;
-        case "basicPropertyBinding": ((SqsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "delayQueue": ((SqsEndpoint) target).getConfiguration().setDelayQueue(property(camelContext, boolean.class, value)); return true;
-        case "queueUrl": ((SqsEndpoint) target).getConfiguration().setQueueUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "synchronous": ((SqsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((SqsEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((SqsEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((SqsEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((SqsEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((SqsEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((SqsEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((SqsEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((SqsEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((SqsEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((SqsEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((SqsEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((SqsEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((SqsEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((SqsEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "proxyHost": ((SqsEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((SqsEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "maximumMessageSize": ((SqsEndpoint) target).getConfiguration().setMaximumMessageSize(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "messageRetentionPeriod": ((SqsEndpoint) target).getConfiguration().setMessageRetentionPeriod(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "policy": ((SqsEndpoint) target).getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "receiveMessageWaitTimeSeconds": ((SqsEndpoint) target).getConfiguration().setReceiveMessageWaitTimeSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "redrivePolicy": ((SqsEndpoint) target).getConfiguration().setRedrivePolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "accessKey": ((SqsEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SqsEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazonawshost": ((SqsEndpoint) target).getConfiguration().setAmazonAWSHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonsqsclient": ((SqsEndpoint) target).getConfiguration().setAmazonSQSClient(property(camelContext, com.amazonaws.services.sqs.AmazonSQS.class, value)); return true;
-        case "autocreatequeue": ((SqsEndpoint) target).getConfiguration().setAutoCreateQueue(property(camelContext, boolean.class, value)); return true;
-        case "headerfilterstrategy": ((SqsEndpoint) target).setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
-        case "protocol": ((SqsEndpoint) target).getConfiguration().setProtocol(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyprotocol": ((SqsEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "queueownerawsaccountid": ((SqsEndpoint) target).getConfiguration().setQueueOwnerAWSAccountId(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SqsEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "attributenames": ((SqsEndpoint) target).getConfiguration().setAttributeNames(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((SqsEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "concurrentconsumers": ((SqsEndpoint) target).getConfiguration().setConcurrentConsumers(property(camelContext, int.class, value)); return true;
-        case "defaultvisibilitytimeout": ((SqsEndpoint) target).getConfiguration().setDefaultVisibilityTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "deleteafterread": ((SqsEndpoint) target).getConfiguration().setDeleteAfterRead(property(camelContext, boolean.class, value)); return true;
-        case "deleteiffiltered": ((SqsEndpoint) target).getConfiguration().setDeleteIfFiltered(property(camelContext, boolean.class, value)); return true;
-        case "extendmessagevisibility": ((SqsEndpoint) target).getConfiguration().setExtendMessageVisibility(property(camelContext, boolean.class, value)); return true;
-        case "kmsdatakeyreuseperiodseconds": ((SqsEndpoint) target).getConfiguration().setKmsDataKeyReusePeriodSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "kmsmasterkeyid": ((SqsEndpoint) target).getConfiguration().setKmsMasterKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "maxmessagesperpoll": ((SqsEndpoint) target).setMaxMessagesPerPoll(property(camelContext, int.class, value)); return true;
-        case "messageattributenames": ((SqsEndpoint) target).getConfiguration().setMessageAttributeNames(property(camelContext, java.lang.String.class, value)); return true;
-        case "sendemptymessagewhenidle": ((SqsEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "serversideencryptionenabled": ((SqsEndpoint) target).getConfiguration().setServerSideEncryptionEnabled(property(camelContext, boolean.class, value)); return true;
-        case "visibilitytimeout": ((SqsEndpoint) target).getConfiguration().setVisibilityTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "waittimeseconds": ((SqsEndpoint) target).getConfiguration().setWaitTimeSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "exceptionhandler": ((SqsEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((SqsEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((SqsEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "delayseconds": ((SqsEndpoint) target).getConfiguration().setDelaySeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "lazystartproducer": ((SqsEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "messagededuplicationidstrategy": ((SqsEndpoint) target).getConfiguration().setMessageDeduplicationIdStrategy(property(camelContext, org.apache.camel.component.aws.sqs.MessageDeduplicationIdStrategy.class, value)); return true;
-        case "messagegroupidstrategy": ((SqsEndpoint) target).getConfiguration().setMessageGroupIdStrategy(property(camelContext, org.apache.camel.component.aws.sqs.MessageGroupIdStrategy.class, value)); return true;
-        case "operation": ((SqsEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.sqs.SqsOperations.class, value)); return true;
-        case "basicpropertybinding": ((SqsEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "delayqueue": ((SqsEndpoint) target).getConfiguration().setDelayQueue(property(camelContext, boolean.class, value)); return true;
-        case "queueurl": ((SqsEndpoint) target).getConfiguration().setQueueUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "synchronous": ((SqsEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((SqsEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((SqsEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((SqsEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((SqsEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((SqsEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((SqsEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((SqsEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((SqsEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((SqsEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((SqsEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((SqsEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((SqsEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((SqsEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((SqsEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "proxyhost": ((SqsEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((SqsEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "maximummessagesize": ((SqsEndpoint) target).getConfiguration().setMaximumMessageSize(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "messageretentionperiod": ((SqsEndpoint) target).getConfiguration().setMessageRetentionPeriod(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "policy": ((SqsEndpoint) target).getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "receivemessagewaittimeseconds": ((SqsEndpoint) target).getConfiguration().setReceiveMessageWaitTimeSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "redrivepolicy": ((SqsEndpoint) target).getConfiguration().setRedrivePolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "accesskey": ((SqsEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SqsEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SqsEndpoint target = (SqsEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazonawshost":
+        case "amazonAWSHost": target.getConfiguration().setAmazonAWSHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "amazonsqsclient":
+        case "amazonSQSClient": target.getConfiguration().setAmazonSQSClient(property(camelContext, com.amazonaws.services.sqs.AmazonSQS.class, value)); return true;
+        case "autocreatequeue":
+        case "autoCreateQueue": target.getConfiguration().setAutoCreateQueue(property(camelContext, boolean.class, value)); return true;
+        case "headerfilterstrategy":
+        case "headerFilterStrategy": target.setHeaderFilterStrategy(property(camelContext, org.apache.camel.spi.HeaderFilterStrategy.class, value)); return true;
+        case "protocol": target.getConfiguration().setProtocol(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "queueownerawsaccountid":
+        case "queueOwnerAWSAccountId": target.getConfiguration().setQueueOwnerAWSAccountId(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "attributenames":
+        case "attributeNames": target.getConfiguration().setAttributeNames(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "concurrentconsumers":
+        case "concurrentConsumers": target.getConfiguration().setConcurrentConsumers(property(camelContext, int.class, value)); return true;
+        case "defaultvisibilitytimeout":
+        case "defaultVisibilityTimeout": target.getConfiguration().setDefaultVisibilityTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "deleteafterread":
+        case "deleteAfterRead": target.getConfiguration().setDeleteAfterRead(property(camelContext, boolean.class, value)); return true;
+        case "deleteiffiltered":
+        case "deleteIfFiltered": target.getConfiguration().setDeleteIfFiltered(property(camelContext, boolean.class, value)); return true;
+        case "extendmessagevisibility":
+        case "extendMessageVisibility": target.getConfiguration().setExtendMessageVisibility(property(camelContext, boolean.class, value)); return true;
+        case "kmsdatakeyreuseperiodseconds":
+        case "kmsDataKeyReusePeriodSeconds": target.getConfiguration().setKmsDataKeyReusePeriodSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "kmsmasterkeyid":
+        case "kmsMasterKeyId": target.getConfiguration().setKmsMasterKeyId(property(camelContext, java.lang.String.class, value)); return true;
+        case "maxmessagesperpoll":
+        case "maxMessagesPerPoll": target.setMaxMessagesPerPoll(property(camelContext, int.class, value)); return true;
+        case "messageattributenames":
+        case "messageAttributeNames": target.getConfiguration().setMessageAttributeNames(property(camelContext, java.lang.String.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "serversideencryptionenabled":
+        case "serverSideEncryptionEnabled": target.getConfiguration().setServerSideEncryptionEnabled(property(camelContext, boolean.class, value)); return true;
+        case "visibilitytimeout":
+        case "visibilityTimeout": target.getConfiguration().setVisibilityTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "waittimeseconds":
+        case "waitTimeSeconds": target.getConfiguration().setWaitTimeSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "delayseconds":
+        case "delaySeconds": target.getConfiguration().setDelaySeconds(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "messagededuplicationidstrategy":
+        case "messageDeduplicationIdStrategy": target.getConfiguration().setMessageDeduplicationIdStrategy(property(camelContext, org.apache.camel.component.aws.sqs.MessageDeduplicationIdStrategy.class, value)); return true;
+        case "messagegroupidstrategy":
+        case "messageGroupIdStrategy": target.getConfiguration().setMessageGroupIdStrategy(property(camelContext, org.apache.camel.component.aws.sqs.MessageGroupIdStrategy.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.sqs.SqsOperations.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "delayqueue":
+        case "delayQueue": target.getConfiguration().setDelayQueue(property(camelContext, boolean.class, value)); return true;
+        case "queueurl":
+        case "queueUrl": target.getConfiguration().setQueueUrl(property(camelContext, java.lang.String.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "maximummessagesize":
+        case "maximumMessageSize": target.getConfiguration().setMaximumMessageSize(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "messageretentionperiod":
+        case "messageRetentionPeriod": target.getConfiguration().setMessageRetentionPeriod(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "policy": target.getConfiguration().setPolicy(property(camelContext, java.lang.String.class, value)); return true;
+        case "receivemessagewaittimeseconds":
+        case "receiveMessageWaitTimeSeconds": target.getConfiguration().setReceiveMessageWaitTimeSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "redrivepolicy":
+        case "redrivePolicy": target.getConfiguration().setRedrivePolicy(property(camelContext, java.lang.String.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 a613697..00b3568 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
@@ -12,37 +12,22 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SWFComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((SWFComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.swf.SWFConfiguration.class, value)); return true;
-        case "accessKey": ((SWFComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SWFComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SWFComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((SWFComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((SWFComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((SWFComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((SWFComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.swf.SWFConfiguration.class, value)); return true;
-        case "accesskey": ((SWFComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SWFComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SWFComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((SWFComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((SWFComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((SWFComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SWFComponent target = (SWFComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.swf.SWFConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 4b0b585..33d5bb7 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
@@ -12,87 +12,70 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class SWFEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "amazonSWClient": ((SWFEndpoint) target).getConfiguration().setAmazonSWClient(property(camelContext, com.amazonaws.services.simpleworkflow.AmazonSimpleWorkflow.class, value)); return true;
-        case "dataConverter": ((SWFEndpoint) target).getConfiguration().setDataConverter(property(camelContext, com.amazonaws.services.simpleworkflow.flow.DataConverter.class, value)); return true;
-        case "domainName": ((SWFEndpoint) target).getConfiguration().setDomainName(property(camelContext, java.lang.String.class, value)); return true;
-        case "eventName": ((SWFEndpoint) target).getConfiguration().setEventName(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SWFEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "version": ((SWFEndpoint) target).getConfiguration().setVersion(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((SWFEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((SWFEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((SWFEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((SWFEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((SWFEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "clientConfigurationParameters": ((SWFEndpoint) target).getConfiguration().setClientConfigurationParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "startWorkflowOptionsParameters": ((SWFEndpoint) target).getConfiguration().setStartWorkflowOptionsParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "sWClientParameters": ((SWFEndpoint) target).getConfiguration().setSWClientParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((SWFEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "activityList": ((SWFEndpoint) target).getConfiguration().setActivityList(property(camelContext, java.lang.String.class, value)); return true;
-        case "activitySchedulingOptions": ((SWFEndpoint) target).getConfiguration().setActivitySchedulingOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.ActivitySchedulingOptions.class, value)); return true;
-        case "activityThreadPoolSize": ((SWFEndpoint) target).getConfiguration().setActivityThreadPoolSize(property(camelContext, int.class, value)); return true;
-        case "activityTypeExecutionOptions": ((SWFEndpoint) target).getConfiguration().setActivityTypeExecutionOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeExecutionOptions.class, value)); return true;
-        case "activityTypeRegistrationOptions": ((SWFEndpoint) target).getConfiguration().setActivityTypeRegistrationOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeRegistrationOptions.class, value)); return true;
-        case "childPolicy": ((SWFEndpoint) target).getConfiguration().setChildPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "executionStartToCloseTimeout": ((SWFEndpoint) target).getConfiguration().setExecutionStartToCloseTimeout(property(camelContext, java.lang.String.class, value)); return true;
-        case "operation": ((SWFEndpoint) target).getConfiguration().setOperation(property(camelContext, java.lang.String.class, value)); return true;
-        case "signalName": ((SWFEndpoint) target).getConfiguration().setSignalName(property(camelContext, java.lang.String.class, value)); return true;
-        case "stateResultType": ((SWFEndpoint) target).getConfiguration().setStateResultType(property(camelContext, java.lang.String.class, value)); return true;
-        case "taskStartToCloseTimeout": ((SWFEndpoint) target).getConfiguration().setTaskStartToCloseTimeout(property(camelContext, java.lang.String.class, value)); return true;
-        case "terminationDetails": ((SWFEndpoint) target).getConfiguration().setTerminationDetails(property(camelContext, java.lang.String.class, value)); return true;
-        case "terminationReason": ((SWFEndpoint) target).getConfiguration().setTerminationReason(property(camelContext, java.lang.String.class, value)); return true;
-        case "workflowList": ((SWFEndpoint) target).getConfiguration().setWorkflowList(property(camelContext, java.lang.String.class, value)); return true;
-        case "workflowTypeRegistrationOptions": ((SWFEndpoint) target).getConfiguration().setWorkflowTypeRegistrationOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.WorkflowTypeRegistrationOptions.class, value)); return true;
-        case "accessKey": ((SWFEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((SWFEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "amazonswclient": ((SWFEndpoint) target).getConfiguration().setAmazonSWClient(property(camelContext, com.amazonaws.services.simpleworkflow.AmazonSimpleWorkflow.class, value)); return true;
-        case "dataconverter": ((SWFEndpoint) target).getConfiguration().setDataConverter(property(camelContext, com.amazonaws.services.simpleworkflow.flow.DataConverter.class, value)); return true;
-        case "domainname": ((SWFEndpoint) target).getConfiguration().setDomainName(property(camelContext, java.lang.String.class, value)); return true;
-        case "eventname": ((SWFEndpoint) target).getConfiguration().setEventName(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((SWFEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "version": ((SWFEndpoint) target).getConfiguration().setVersion(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((SWFEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((SWFEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((SWFEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((SWFEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((SWFEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "clientconfigurationparameters": ((SWFEndpoint) target).getConfiguration().setClientConfigurationParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "startworkflowoptionsparameters": ((SWFEndpoint) target).getConfiguration().setStartWorkflowOptionsParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "swclientparameters": ((SWFEndpoint) target).getConfiguration().setSWClientParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((SWFEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "activitylist": ((SWFEndpoint) target).getConfiguration().setActivityList(property(camelContext, java.lang.String.class, value)); return true;
-        case "activityschedulingoptions": ((SWFEndpoint) target).getConfiguration().setActivitySchedulingOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.ActivitySchedulingOptions.class, value)); return true;
-        case "activitythreadpoolsize": ((SWFEndpoint) target).getConfiguration().setActivityThreadPoolSize(property(camelContext, int.class, value)); return true;
-        case "activitytypeexecutionoptions": ((SWFEndpoint) target).getConfiguration().setActivityTypeExecutionOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeExecutionOptions.class, value)); return true;
-        case "activitytyperegistrationoptions": ((SWFEndpoint) target).getConfiguration().setActivityTypeRegistrationOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeRegistrationOptions.class, value)); return true;
-        case "childpolicy": ((SWFEndpoint) target).getConfiguration().setChildPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "executionstarttoclosetimeout": ((SWFEndpoint) target).getConfiguration().setExecutionStartToCloseTimeout(property(camelContext, java.lang.String.class, value)); return true;
-        case "operation": ((SWFEndpoint) target).getConfiguration().setOperation(property(camelContext, java.lang.String.class, value)); return true;
-        case "signalname": ((SWFEndpoint) target).getConfiguration().setSignalName(property(camelContext, java.lang.String.class, value)); return true;
-        case "stateresulttype": ((SWFEndpoint) target).getConfiguration().setStateResultType(property(camelContext, java.lang.String.class, value)); return true;
-        case "taskstarttoclosetimeout": ((SWFEndpoint) target).getConfiguration().setTaskStartToCloseTimeout(property(camelContext, java.lang.String.class, value)); return true;
-        case "terminationdetails": ((SWFEndpoint) target).getConfiguration().setTerminationDetails(property(camelContext, java.lang.String.class, value)); return true;
-        case "terminationreason": ((SWFEndpoint) target).getConfiguration().setTerminationReason(property(camelContext, java.lang.String.class, value)); return true;
-        case "workflowlist": ((SWFEndpoint) target).getConfiguration().setWorkflowList(property(camelContext, java.lang.String.class, value)); return true;
-        case "workflowtyperegistrationoptions": ((SWFEndpoint) target).getConfiguration().setWorkflowTypeRegistrationOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.WorkflowTypeRegistrationOptions.class, value)); return true;
-        case "accesskey": ((SWFEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((SWFEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        SWFEndpoint target = (SWFEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "amazonswclient":
+        case "amazonSWClient": target.getConfiguration().setAmazonSWClient(property(camelContext, com.amazonaws.services.simpleworkflow.AmazonSimpleWorkflow.class, value)); return true;
+        case "dataconverter":
+        case "dataConverter": target.getConfiguration().setDataConverter(property(camelContext, com.amazonaws.services.simpleworkflow.flow.DataConverter.class, value)); return true;
+        case "domainname":
+        case "domainName": target.getConfiguration().setDomainName(property(camelContext, java.lang.String.class, value)); return true;
+        case "eventname":
+        case "eventName": target.getConfiguration().setEventName(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "version": target.getConfiguration().setVersion(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "clientconfigurationparameters":
+        case "clientConfigurationParameters": target.getConfiguration().setClientConfigurationParameters(property(camelContext, java.util.Map.class, value)); return true;
+        case "startworkflowoptionsparameters":
+        case "startWorkflowOptionsParameters": target.getConfiguration().setStartWorkflowOptionsParameters(property(camelContext, java.util.Map.class, value)); return true;
+        case "swclientparameters":
+        case "sWClientParameters": target.getConfiguration().setSWClientParameters(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "activitylist":
+        case "activityList": target.getConfiguration().setActivityList(property(camelContext, java.lang.String.class, value)); return true;
+        case "activityschedulingoptions":
+        case "activitySchedulingOptions": target.getConfiguration().setActivitySchedulingOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.ActivitySchedulingOptions.class, value)); return true;
+        case "activitythreadpoolsize":
+        case "activityThreadPoolSize": target.getConfiguration().setActivityThreadPoolSize(property(camelContext, int.class, value)); return true;
+        case "activitytypeexecutionoptions":
+        case "activityTypeExecutionOptions": target.getConfiguration().setActivityTypeExecutionOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeExecutionOptions.class, value)); return true;
+        case "activitytyperegistrationoptions":
+        case "activityTypeRegistrationOptions": target.getConfiguration().setActivityTypeRegistrationOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.worker.ActivityTypeRegistrationOptions.class, value)); return true;
+        case "childpolicy":
+        case "childPolicy": target.getConfiguration().setChildPolicy(property(camelContext, java.lang.String.class, value)); return true;
+        case "executionstarttoclosetimeout":
+        case "executionStartToCloseTimeout": target.getConfiguration().setExecutionStartToCloseTimeout(property(camelContext, java.lang.String.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, java.lang.String.class, value)); return true;
+        case "signalname":
+        case "signalName": target.getConfiguration().setSignalName(property(camelContext, java.lang.String.class, value)); return true;
+        case "stateresulttype":
+        case "stateResultType": target.getConfiguration().setStateResultType(property(camelContext, java.lang.String.class, value)); return true;
+        case "taskstarttoclosetimeout":
+        case "taskStartToCloseTimeout": target.getConfiguration().setTaskStartToCloseTimeout(property(camelContext, java.lang.String.class, value)); return true;
+        case "terminationdetails":
+        case "terminationDetails": target.getConfiguration().setTerminationDetails(property(camelContext, java.lang.String.class, value)); return true;
+        case "terminationreason":
+        case "terminationReason": target.getConfiguration().setTerminationReason(property(camelContext, java.lang.String.class, value)); return true;
+        case "workflowlist":
+        case "workflowList": target.getConfiguration().setWorkflowList(property(camelContext, java.lang.String.class, value)); return true;
+        case "workflowtyperegistrationoptions":
+        case "workflowTypeRegistrationOptions": target.getConfiguration().setWorkflowTypeRegistrationOptions(property(camelContext, com.amazonaws.services.simpleworkflow.flow.WorkflowTypeRegistrationOptions.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 039c841..c3c5c3f 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class TranslateComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((TranslateComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.translate.TranslateConfiguration.class, value)); return true;
-        case "accessKey": ((TranslateComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((TranslateComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((TranslateComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((TranslateComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((TranslateComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((TranslateComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.aws.translate.TranslateConfiguration.class, value)); return true;
-        case "accesskey": ((TranslateComponent) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((TranslateComponent) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((TranslateComponent) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((TranslateComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((TranslateComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        TranslateComponent target = (TranslateComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws.translate.TranslateConfiguration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 a5c8d69..f083ab1 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
@@ -12,51 +12,35 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class TranslateEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((TranslateEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "autodetectSourceLanguage": ((TranslateEndpoint) target).getConfiguration().setAutodetectSourceLanguage(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((TranslateEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((TranslateEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.translate.TranslateOperations.class, value)); return true;
-        case "proxyHost": ((TranslateEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((TranslateEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((TranslateEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((TranslateEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((TranslateEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "sourceLanguage": ((TranslateEndpoint) target).getConfiguration().setSourceLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "targetLanguage": ((TranslateEndpoint) target).getConfiguration().setTargetLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "translateClient": ((TranslateEndpoint) target).getConfiguration().setTranslateClient(property(camelContext, com.amazonaws.services.translate.AmazonTranslate.class, value)); return true;
-        case "basicPropertyBinding": ((TranslateEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((TranslateEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((TranslateEndpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "autodetectsourcelanguage": ((TranslateEndpoint) target).getConfiguration().setAutodetectSourceLanguage(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((TranslateEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((TranslateEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.translate.TranslateOperations.class, value)); return true;
-        case "proxyhost": ((TranslateEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((TranslateEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((TranslateEndpoint) target).getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
-        case "region": ((TranslateEndpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((TranslateEndpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "sourcelanguage": ((TranslateEndpoint) target).getConfiguration().setSourceLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "targetlanguage": ((TranslateEndpoint) target).getConfiguration().setTargetLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "translateclient": ((TranslateEndpoint) target).getConfiguration().setTranslateClient(property(camelContext, com.amazonaws.services.translate.AmazonTranslate.class, value)); return true;
-        case "basicpropertybinding": ((TranslateEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((TranslateEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        TranslateEndpoint target = (TranslateEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "autodetectsourcelanguage":
+        case "autodetectSourceLanguage": target.getConfiguration().setAutodetectSourceLanguage(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws.translate.TranslateOperations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, com.amazonaws.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "sourcelanguage":
+        case "sourceLanguage": target.getConfiguration().setSourceLanguage(property(camelContext, java.lang.String.class, value)); return true;
+        case "targetlanguage":
+        case "targetLanguage": target.getConfiguration().setTargetLanguage(property(camelContext, java.lang.String.class, value)); return true;
+        case "translateclient":
+        case "translateClient": target.getConfiguration().setTranslateClient(property(camelContext, com.amazonaws.services.translate.AmazonTranslate.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 89afcd0..8e97d16 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ECS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((ECS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.ecs.ECS2Configuration.class, value)); return true;
-        case "accessKey": ((ECS2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((ECS2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((ECS2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((ECS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ECS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((ECS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.ecs.ECS2Configuration.class, value)); return true;
-        case "accesskey": ((ECS2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((ECS2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((ECS2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((ECS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ECS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ECS2Component target = (ECS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws2.ecs.ECS2Configuration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 f6225f0..755dd74 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ECS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((ECS2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "ecsClient": ((ECS2Endpoint) target).getConfiguration().setEcsClient(property(camelContext, software.amazon.awssdk.services.ecs.EcsClient.class, value)); return true;
-        case "lazyStartProducer": ((ECS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((ECS2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.ecs.ECS2Operations.class, value)); return true;
-        case "proxyHost": ((ECS2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((ECS2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((ECS2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((ECS2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((ECS2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((ECS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ECS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((ECS2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "ecsclient": ((ECS2Endpoint) target).getConfiguration().setEcsClient(property(camelContext, software.amazon.awssdk.services.ecs.EcsClient.class, value)); return true;
-        case "lazystartproducer": ((ECS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((ECS2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.ecs.ECS2Operations.class, value)); return true;
-        case "proxyhost": ((ECS2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((ECS2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((ECS2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((ECS2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((ECS2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((ECS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ECS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ECS2Endpoint target = (ECS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "ecsclient":
+        case "ecsClient": target.getConfiguration().setEcsClient(property(camelContext, software.amazon.awssdk.services.ecs.EcsClient.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.ecs.ECS2Operations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 1cc2860..e532292 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class EKS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((EKS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.eks.EKS2Configuration.class, value)); return true;
-        case "accessKey": ((EKS2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((EKS2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((EKS2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((EKS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((EKS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((EKS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.eks.EKS2Configuration.class, value)); return true;
-        case "accesskey": ((EKS2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((EKS2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((EKS2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((EKS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((EKS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        EKS2Component target = (EKS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws2.eks.EKS2Configuration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 bbd10d0..71b6959 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class EKS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((EKS2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "eksClient": ((EKS2Endpoint) target).getConfiguration().setEksClient(property(camelContext, software.amazon.awssdk.services.eks.EksClient.class, value)); return true;
-        case "lazyStartProducer": ((EKS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((EKS2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.eks.EKS2Operations.class, value)); return true;
-        case "proxyHost": ((EKS2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((EKS2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((EKS2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((EKS2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((EKS2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((EKS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((EKS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((EKS2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "eksclient": ((EKS2Endpoint) target).getConfiguration().setEksClient(property(camelContext, software.amazon.awssdk.services.eks.EksClient.class, value)); return true;
-        case "lazystartproducer": ((EKS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((EKS2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.eks.EKS2Operations.class, value)); return true;
-        case "proxyhost": ((EKS2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((EKS2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((EKS2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((EKS2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((EKS2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((EKS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((EKS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        EKS2Endpoint target = (EKS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "eksclient":
+        case "eksClient": target.getConfiguration().setEksClient(property(camelContext, software.amazon.awssdk.services.eks.EksClient.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.eks.EKS2Operations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 d3a6f00..256f224 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KMS2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((KMS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.kms.KMS2Configuration.class, value)); return true;
-        case "accessKey": ((KMS2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KMS2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KMS2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((KMS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((KMS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((KMS2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.kms.KMS2Configuration.class, value)); return true;
-        case "accesskey": ((KMS2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KMS2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((KMS2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((KMS2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((KMS2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KMS2Component target = (KMS2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws2.kms.KMS2Configuration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 7ad17d4..4ff346f 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class KMS2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((KMS2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "kmsClient": ((KMS2Endpoint) target).getConfiguration().setKmsClient(property(camelContext, software.amazon.awssdk.services.kms.KmsClient.class, value)); return true;
-        case "lazyStartProducer": ((KMS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((KMS2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.kms.KMS2Operations.class, value)); return true;
-        case "proxyHost": ((KMS2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((KMS2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((KMS2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((KMS2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((KMS2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((KMS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KMS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((KMS2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "kmsclient": ((KMS2Endpoint) target).getConfiguration().setKmsClient(property(camelContext, software.amazon.awssdk.services.kms.KmsClient.class, value)); return true;
-        case "lazystartproducer": ((KMS2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((KMS2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.kms.KMS2Operations.class, value)); return true;
-        case "proxyhost": ((KMS2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((KMS2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((KMS2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((KMS2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((KMS2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((KMS2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((KMS2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        KMS2Endpoint target = (KMS2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "kmsclient":
+        case "kmsClient": target.getConfiguration().setKmsClient(property(camelContext, software.amazon.awssdk.services.kms.KmsClient.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.kms.KMS2Operations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 71544b1..04544e3 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MQ2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((MQ2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.mq.MQ2Configuration.class, value)); return true;
-        case "accessKey": ((MQ2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MQ2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MQ2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MQ2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((MQ2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((MQ2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.mq.MQ2Configuration.class, value)); return true;
-        case "accesskey": ((MQ2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MQ2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MQ2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MQ2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((MQ2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MQ2Component target = (MQ2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws2.mq.MQ2Configuration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 0ae25dc..a7dee5a 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MQ2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((MQ2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonMqClient": ((MQ2Endpoint) target).getConfiguration().setAmazonMqClient(property(camelContext, software.amazon.awssdk.services.mq.MqClient.class, value)); return true;
-        case "lazyStartProducer": ((MQ2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((MQ2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.mq.MQ2Operations.class, value)); return true;
-        case "proxyHost": ((MQ2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((MQ2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((MQ2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((MQ2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MQ2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MQ2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MQ2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((MQ2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "amazonmqclient": ((MQ2Endpoint) target).getConfiguration().setAmazonMqClient(property(camelContext, software.amazon.awssdk.services.mq.MqClient.class, value)); return true;
-        case "lazystartproducer": ((MQ2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((MQ2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.mq.MQ2Operations.class, value)); return true;
-        case "proxyhost": ((MQ2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((MQ2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((MQ2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((MQ2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MQ2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MQ2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MQ2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MQ2Endpoint target = (MQ2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "amazonmqclient":
+        case "amazonMqClient": target.getConfiguration().setAmazonMqClient(property(camelContext, software.amazon.awssdk.services.mq.MqClient.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.mq.MQ2Operations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 ec2357c..07e93af 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MSK2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((MSK2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.msk.MSK2Configuration.class, value)); return true;
-        case "accessKey": ((MSK2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MSK2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MSK2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MSK2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((MSK2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((MSK2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.msk.MSK2Configuration.class, value)); return true;
-        case "accesskey": ((MSK2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MSK2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((MSK2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MSK2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((MSK2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MSK2Component target = (MSK2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws2.msk.MSK2Configuration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 100413f..34095f9 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
@@ -12,45 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class MSK2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((MSK2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((MSK2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "mskClient": ((MSK2Endpoint) target).getConfiguration().setMskClient(property(camelContext, software.amazon.awssdk.services.kafka.KafkaClient.class, value)); return true;
-        case "operation": ((MSK2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.msk.MSK2Operations.class, value)); return true;
-        case "proxyHost": ((MSK2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((MSK2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((MSK2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((MSK2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((MSK2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((MSK2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MSK2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((MSK2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((MSK2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "mskclient": ((MSK2Endpoint) target).getConfiguration().setMskClient(property(camelContext, software.amazon.awssdk.services.kafka.KafkaClient.class, value)); return true;
-        case "operation": ((MSK2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.msk.MSK2Operations.class, value)); return true;
-        case "proxyhost": ((MSK2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((MSK2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((MSK2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((MSK2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((MSK2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((MSK2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((MSK2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        MSK2Endpoint target = (MSK2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "mskclient":
+        case "mskClient": target.getConfiguration().setMskClient(property(camelContext, software.amazon.awssdk.services.kafka.KafkaClient.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.msk.MSK2Operations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 ae2e05b..d559ed3 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
@@ -12,35 +12,20 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class Translate2ComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((Translate2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.translate.Translate2Configuration.class, value)); return true;
-        case "accessKey": ((Translate2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((Translate2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((Translate2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((Translate2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((Translate2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((Translate2Component) target).setConfiguration(property(camelContext, org.apache.camel.component.aws2.translate.Translate2Configuration.class, value)); return true;
-        case "accesskey": ((Translate2Component) target).setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((Translate2Component) target).setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "region": ((Translate2Component) target).setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((Translate2Component) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((Translate2Component) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        Translate2Component target = (Translate2Component) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.aws2.translate.Translate2Configuration.class, value)); return true;
+        case "accesskey":
+        case "accessKey": target.setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "region": target.setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6b8a5ed..73f9d07 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
@@ -12,51 +12,35 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class Translate2EndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "accessKey": ((Translate2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "autodetectSourceLanguage": ((Translate2Endpoint) target).getConfiguration().setAutodetectSourceLanguage(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((Translate2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((Translate2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.translate.Translate2Operations.class, value)); return true;
-        case "proxyHost": ((Translate2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((Translate2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyProtocol": ((Translate2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((Translate2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretKey": ((Translate2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "sourceLanguage": ((Translate2Endpoint) target).getConfiguration().setSourceLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "targetLanguage": ((Translate2Endpoint) target).getConfiguration().setTargetLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "translateClient": ((Translate2Endpoint) target).getConfiguration().setTranslateClient(property(camelContext, software.amazon.awssdk.services.translate.TranslateClient.class, value)); return true;
-        case "basicPropertyBinding": ((Translate2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((Translate2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "accesskey": ((Translate2Endpoint) target).getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "autodetectsourcelanguage": ((Translate2Endpoint) target).getConfiguration().setAutodetectSourceLanguage(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((Translate2Endpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((Translate2Endpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.translate.Translate2Operations.class, value)); return true;
-        case "proxyhost": ((Translate2Endpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((Translate2Endpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "proxyprotocol": ((Translate2Endpoint) target).getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
-        case "region": ((Translate2Endpoint) target).getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
-        case "secretkey": ((Translate2Endpoint) target).getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "sourcelanguage": ((Translate2Endpoint) target).getConfiguration().setSourceLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "targetlanguage": ((Translate2Endpoint) target).getConfiguration().setTargetLanguage(property(camelContext, java.lang.String.class, value)); return true;
-        case "translateclient": ((Translate2Endpoint) target).getConfiguration().setTranslateClient(property(camelContext, software.amazon.awssdk.services.translate.TranslateClient.class, value)); return true;
-        case "basicpropertybinding": ((Translate2Endpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((Translate2Endpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        Translate2Endpoint target = (Translate2Endpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "accesskey":
+        case "accessKey": target.getConfiguration().setAccessKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "autodetectsourcelanguage":
+        case "autodetectSourceLanguage": target.getConfiguration().setAutodetectSourceLanguage(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.aws2.translate.Translate2Operations.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "proxyprotocol":
+        case "proxyProtocol": target.getConfiguration().setProxyProtocol(property(camelContext, software.amazon.awssdk.core.Protocol.class, value)); return true;
+        case "region": target.getConfiguration().setRegion(property(camelContext, java.lang.String.class, value)); return true;
+        case "secretkey":
+        case "secretKey": target.getConfiguration().setSecretKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "sourcelanguage":
+        case "sourceLanguage": target.getConfiguration().setSourceLanguage(property(camelContext, java.lang.String.class, value)); return true;
+        case "targetlanguage":
+        case "targetLanguage": target.getConfiguration().setTargetLanguage(property(camelContext, java.lang.String.class, value)); return true;
+        case "translateclient":
+        case "translateClient": target.getConfiguration().setTranslateClient(property(camelContext, software.amazon.awssdk.services.translate.TranslateClient.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 8c29117..ccc7f13 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
@@ -12,31 +12,17 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BlobServiceComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((BlobServiceComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.azure.blob.BlobServiceConfiguration.class, value)); return true;
-        case "basicPropertyBinding": ((BlobServiceComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BlobServiceComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((BlobServiceComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((BlobServiceComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.azure.blob.BlobServiceConfiguration.class, value)); return true;
-        case "basicpropertybinding": ((BlobServiceComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BlobServiceComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((BlobServiceComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BlobServiceComponent target = (BlobServiceComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.azure.blob.BlobServiceConfiguration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 e6fccb4..95f914c 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
@@ -12,65 +12,49 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BlobServiceEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "azureBlobClient": ((BlobServiceEndpoint) target).getConfiguration().setAzureBlobClient(property(camelContext, com.microsoft.azure.storage.blob.CloudBlob.class, value)); return true;
-        case "blobOffset": ((BlobServiceEndpoint) target).getConfiguration().setBlobOffset(property(camelContext, java.lang.Long.class, value)); return true;
-        case "blobType": ((BlobServiceEndpoint) target).getConfiguration().setBlobType(property(camelContext, org.apache.camel.component.azure.blob.BlobType.class, value)); return true;
-        case "closeStreamAfterRead": ((BlobServiceEndpoint) target).getConfiguration().setCloseStreamAfterRead(property(camelContext, boolean.class, value)); return true;
-        case "credentials": ((BlobServiceEndpoint) target).getConfiguration().setCredentials(property(camelContext, com.microsoft.azure.storage.StorageCredentials.class, value)); return true;
-        case "dataLength": ((BlobServiceEndpoint) target).getConfiguration().setDataLength(property(camelContext, java.lang.Long.class, value)); return true;
-        case "fileDir": ((BlobServiceEndpoint) target).getConfiguration().setFileDir(property(camelContext, java.lang.String.class, value)); return true;
-        case "publicForRead": ((BlobServiceEndpoint) target).getConfiguration().setPublicForRead(property(camelContext, boolean.class, value)); return true;
-        case "streamReadSize": ((BlobServiceEndpoint) target).getConfiguration().setStreamReadSize(property(camelContext, int.class, value)); return true;
-        case "bridgeErrorHandler": ((BlobServiceEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((BlobServiceEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((BlobServiceEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "blobMetadata": ((BlobServiceEndpoint) target).getConfiguration().setBlobMetadata(property(camelContext, java.util.Map.class, value)); return true;
-        case "blobPrefix": ((BlobServiceEndpoint) target).getConfiguration().setBlobPrefix(property(camelContext, java.lang.String.class, value)); return true;
-        case "closeStreamAfterWrite": ((BlobServiceEndpoint) target).getConfiguration().setCloseStreamAfterWrite(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BlobServiceEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((BlobServiceEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.azure.blob.BlobServiceOperations.class, value)); return true;
-        case "streamWriteSize": ((BlobServiceEndpoint) target).getConfiguration().setStreamWriteSize(property(camelContext, int.class, value)); return true;
-        case "useFlatListing": ((BlobServiceEndpoint) target).getConfiguration().setUseFlatListing(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((BlobServiceEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BlobServiceEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "azureblobclient": ((BlobServiceEndpoint) target).getConfiguration().setAzureBlobClient(property(camelContext, com.microsoft.azure.storage.blob.CloudBlob.class, value)); return true;
-        case "bloboffset": ((BlobServiceEndpoint) target).getConfiguration().setBlobOffset(property(camelContext, java.lang.Long.class, value)); return true;
-        case "blobtype": ((BlobServiceEndpoint) target).getConfiguration().setBlobType(property(camelContext, org.apache.camel.component.azure.blob.BlobType.class, value)); return true;
-        case "closestreamafterread": ((BlobServiceEndpoint) target).getConfiguration().setCloseStreamAfterRead(property(camelContext, boolean.class, value)); return true;
-        case "credentials": ((BlobServiceEndpoint) target).getConfiguration().setCredentials(property(camelContext, com.microsoft.azure.storage.StorageCredentials.class, value)); return true;
-        case "datalength": ((BlobServiceEndpoint) target).getConfiguration().setDataLength(property(camelContext, java.lang.Long.class, value)); return true;
-        case "filedir": ((BlobServiceEndpoint) target).getConfiguration().setFileDir(property(camelContext, java.lang.String.class, value)); return true;
-        case "publicforread": ((BlobServiceEndpoint) target).getConfiguration().setPublicForRead(property(camelContext, boolean.class, value)); return true;
-        case "streamreadsize": ((BlobServiceEndpoint) target).getConfiguration().setStreamReadSize(property(camelContext, int.class, value)); return true;
-        case "bridgeerrorhandler": ((BlobServiceEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((BlobServiceEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((BlobServiceEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "blobmetadata": ((BlobServiceEndpoint) target).getConfiguration().setBlobMetadata(property(camelContext, java.util.Map.class, value)); return true;
-        case "blobprefix": ((BlobServiceEndpoint) target).getConfiguration().setBlobPrefix(property(camelContext, java.lang.String.class, value)); return true;
-        case "closestreamafterwrite": ((BlobServiceEndpoint) target).getConfiguration().setCloseStreamAfterWrite(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BlobServiceEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "operation": ((BlobServiceEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.azure.blob.BlobServiceOperations.class, value)); return true;
-        case "streamwritesize": ((BlobServiceEndpoint) target).getConfiguration().setStreamWriteSize(property(camelContext, int.class, value)); return true;
-        case "useflatlisting": ((BlobServiceEndpoint) target).getConfiguration().setUseFlatListing(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((BlobServiceEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BlobServiceEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BlobServiceEndpoint target = (BlobServiceEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "azureblobclient":
+        case "azureBlobClient": target.getConfiguration().setAzureBlobClient(property(camelContext, com.microsoft.azure.storage.blob.CloudBlob.class, value)); return true;
+        case "bloboffset":
+        case "blobOffset": target.getConfiguration().setBlobOffset(property(camelContext, java.lang.Long.class, value)); return true;
+        case "blobtype":
+        case "blobType": target.getConfiguration().setBlobType(property(camelContext, org.apache.camel.component.azure.blob.BlobType.class, value)); return true;
+        case "closestreamafterread":
+        case "closeStreamAfterRead": target.getConfiguration().setCloseStreamAfterRead(property(camelContext, boolean.class, value)); return true;
+        case "credentials": target.getConfiguration().setCredentials(property(camelContext, com.microsoft.azure.storage.StorageCredentials.class, value)); return true;
+        case "datalength":
+        case "dataLength": target.getConfiguration().setDataLength(property(camelContext, java.lang.Long.class, value)); return true;
+        case "filedir":
+        case "fileDir": target.getConfiguration().setFileDir(property(camelContext, java.lang.String.class, value)); return true;
+        case "publicforread":
+        case "publicForRead": target.getConfiguration().setPublicForRead(property(camelContext, boolean.class, value)); return true;
+        case "streamreadsize":
+        case "streamReadSize": target.getConfiguration().setStreamReadSize(property(camelContext, int.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "blobmetadata":
+        case "blobMetadata": target.getConfiguration().setBlobMetadata(property(camelContext, java.util.Map.class, value)); return true;
+        case "blobprefix":
+        case "blobPrefix": target.getConfiguration().setBlobPrefix(property(camelContext, java.lang.String.class, value)); return true;
+        case "closestreamafterwrite":
+        case "closeStreamAfterWrite": target.getConfiguration().setCloseStreamAfterWrite(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.azure.blob.BlobServiceOperations.class, value)); return true;
+        case "streamwritesize":
+        case "streamWriteSize": target.getConfiguration().setStreamWriteSize(property(camelContext, int.class, value)); return true;
+        case "useflatlisting":
+        case "useFlatListing": target.getConfiguration().setUseFlatListing(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 5d1ab97..b95ec3a 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
@@ -12,31 +12,17 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class QueueServiceComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((QueueServiceComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.azure.queue.QueueServiceConfiguration.class, value)); return true;
-        case "basicPropertyBinding": ((QueueServiceComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((QueueServiceComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((QueueServiceComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((QueueServiceComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.azure.queue.QueueServiceConfiguration.class, value)); return true;
-        case "basicpropertybinding": ((QueueServiceComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((QueueServiceComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((QueueServiceComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        QueueServiceComponent target = (QueueServiceComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.azure.queue.QueueServiceConfiguration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 86cad9d..315c41a 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
@@ -12,47 +12,31 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class QueueServiceEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "azureQueueClient": ((QueueServiceEndpoint) target).getConfiguration().setAzureQueueClient(property(camelContext, com.microsoft.azure.storage.queue.CloudQueue.class, value)); return true;
-        case "credentials": ((QueueServiceEndpoint) target).getConfiguration().setCredentials(property(camelContext, com.microsoft.azure.storage.StorageCredentials.class, value)); return true;
-        case "bridgeErrorHandler": ((QueueServiceEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((QueueServiceEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((QueueServiceEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((QueueServiceEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "messageTimeToLive": ((QueueServiceEndpoint) target).getConfiguration().setMessageTimeToLive(property(camelContext, int.class, value)); return true;
-        case "messageVisibilityDelay": ((QueueServiceEndpoint) target).getConfiguration().setMessageVisibilityDelay(property(camelContext, int.class, value)); return true;
-        case "operation": ((QueueServiceEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.azure.queue.QueueServiceOperations.class, value)); return true;
-        case "queuePrefix": ((QueueServiceEndpoint) target).getConfiguration().setQueuePrefix(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((QueueServiceEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((QueueServiceEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "azurequeueclient": ((QueueServiceEndpoint) target).getConfiguration().setAzureQueueClient(property(camelContext, com.microsoft.azure.storage.queue.CloudQueue.class, value)); return true;
-        case "credentials": ((QueueServiceEndpoint) target).getConfiguration().setCredentials(property(camelContext, com.microsoft.azure.storage.StorageCredentials.class, value)); return true;
-        case "bridgeerrorhandler": ((QueueServiceEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((QueueServiceEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((QueueServiceEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((QueueServiceEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "messagetimetolive": ((QueueServiceEndpoint) target).getConfiguration().setMessageTimeToLive(property(camelContext, int.class, value)); return true;
-        case "messagevisibilitydelay": ((QueueServiceEndpoint) target).getConfiguration().setMessageVisibilityDelay(property(camelContext, int.class, value)); return true;
-        case "operation": ((QueueServiceEndpoint) target).getConfiguration().setOperation(property(camelContext, org.apache.camel.component.azure.queue.QueueServiceOperations.class, value)); return true;
-        case "queueprefix": ((QueueServiceEndpoint) target).getConfiguration().setQueuePrefix(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((QueueServiceEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((QueueServiceEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        QueueServiceEndpoint target = (QueueServiceEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "azurequeueclient":
+        case "azureQueueClient": target.getConfiguration().setAzureQueueClient(property(camelContext, com.microsoft.azure.storage.queue.CloudQueue.class, value)); return true;
+        case "credentials": target.getConfiguration().setCredentials(property(camelContext, com.microsoft.azure.storage.StorageCredentials.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "messagetimetolive":
+        case "messageTimeToLive": target.getConfiguration().setMessageTimeToLive(property(camelContext, int.class, value)); return true;
+        case "messagevisibilitydelay":
+        case "messageVisibilityDelay": target.getConfiguration().setMessageVisibilityDelay(property(camelContext, int.class, value)); return true;
+        case "operation": target.getConfiguration().setOperation(property(camelContext, org.apache.camel.component.azure.queue.QueueServiceOperations.class, value)); return true;
+        case "queueprefix":
+        case "queuePrefix": target.getConfiguration().setQueuePrefix(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 e72983c..a436731 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
@@ -12,37 +12,24 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BeanValidatorComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "ignoreXmlConfiguration": ((BeanValidatorComponent) target).setIgnoreXmlConfiguration(property(camelContext, boolean.class, value)); return true;
-        case "validationProviderResolver": ((BeanValidatorComponent) target).setValidationProviderResolver(property(camelContext, javax.validation.ValidationProviderResolver.class, value)); return true;
-        case "messageInterpolator": ((BeanValidatorComponent) target).setMessageInterpolator(property(camelContext, javax.validation.MessageInterpolator.class, value)); return true;
-        case "traversableResolver": ((BeanValidatorComponent) target).setTraversableResolver(property(camelContext, javax.validation.TraversableResolver.class, value)); return true;
-        case "constraintValidatorFactory": ((BeanValidatorComponent) target).setConstraintValidatorFactory(property(camelContext, javax.validation.ConstraintValidatorFactory.class, value)); return true;
-        case "basicPropertyBinding": ((BeanValidatorComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BeanValidatorComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "ignorexmlconfiguration": ((BeanValidatorComponent) target).setIgnoreXmlConfiguration(property(camelContext, boolean.class, value)); return true;
-        case "validationproviderresolver": ((BeanValidatorComponent) target).setValidationProviderResolver(property(camelContext, javax.validation.ValidationProviderResolver.class, value)); return true;
-        case "messageinterpolator": ((BeanValidatorComponent) target).setMessageInterpolator(property(camelContext, javax.validation.MessageInterpolator.class, value)); return true;
-        case "traversableresolver": ((BeanValidatorComponent) target).setTraversableResolver(property(camelContext, javax.validation.TraversableResolver.class, value)); return true;
-        case "constraintvalidatorfactory": ((BeanValidatorComponent) target).setConstraintValidatorFactory(property(camelContext, javax.validation.ConstraintValidatorFactory.class, value)); return true;
-        case "basicpropertybinding": ((BeanValidatorComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BeanValidatorComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BeanValidatorComponent target = (BeanValidatorComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "ignorexmlconfiguration":
+        case "ignoreXmlConfiguration": target.setIgnoreXmlConfiguration(property(camelContext, boolean.class, value)); return true;
+        case "validationproviderresolver":
+        case "validationProviderResolver": target.setValidationProviderResolver(property(camelContext, javax.validation.ValidationProviderResolver.class, value)); return true;
+        case "messageinterpolator":
+        case "messageInterpolator": target.setMessageInterpolator(property(camelContext, javax.validation.MessageInterpolator.class, value)); return true;
+        case "traversableresolver":
+        case "traversableResolver": target.setTraversableResolver(property(camelContext, javax.validation.TraversableResolver.class, value)); return true;
+        case "constraintvalidatorfactory":
+        case "constraintValidatorFactory": target.setConstraintValidatorFactory(property(camelContext, javax.validation.ConstraintValidatorFactory.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 682be57..1cf08db 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
@@ -12,43 +12,28 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BeanValidatorEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "group": ((BeanValidatorEndpoint) target).setGroup(property(camelContext, java.lang.String.class, value)); return true;
-        case "ignoreXmlConfiguration": ((BeanValidatorEndpoint) target).setIgnoreXmlConfiguration(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BeanValidatorEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((BeanValidatorEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "constraintValidatorFactory": ((BeanValidatorEndpoint) target).setConstraintValidatorFactory(property(camelContext, javax.validation.ConstraintValidatorFactory.class, value)); return true;
-        case "messageInterpolator": ((BeanValidatorEndpoint) target).setMessageInterpolator(property(camelContext, javax.validation.MessageInterpolator.class, value)); return true;
-        case "synchronous": ((BeanValidatorEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "traversableResolver": ((BeanValidatorEndpoint) target).setTraversableResolver(property(camelContext, javax.validation.TraversableResolver.class, value)); return true;
-        case "validationProviderResolver": ((BeanValidatorEndpoint) target).setValidationProviderResolver(property(camelContext, javax.validation.ValidationProviderResolver.class, value)); return true;
-        case "validatorFactory": ((BeanValidatorEndpoint) target).setValidatorFactory(property(camelContext, javax.validation.ValidatorFactory.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "group": ((BeanValidatorEndpoint) target).setGroup(property(camelContext, java.lang.String.class, value)); return true;
-        case "ignorexmlconfiguration": ((BeanValidatorEndpoint) target).setIgnoreXmlConfiguration(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BeanValidatorEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((BeanValidatorEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "constraintvalidatorfactory": ((BeanValidatorEndpoint) target).setConstraintValidatorFactory(property(camelContext, javax.validation.ConstraintValidatorFactory.class, value)); return true;
-        case "messageinterpolator": ((BeanValidatorEndpoint) target).setMessageInterpolator(property(camelContext, javax.validation.MessageInterpolator.class, value)); return true;
-        case "synchronous": ((BeanValidatorEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "traversableresolver": ((BeanValidatorEndpoint) target).setTraversableResolver(property(camelContext, javax.validation.TraversableResolver.class, value)); return true;
-        case "validationproviderresolver": ((BeanValidatorEndpoint) target).setValidationProviderResolver(property(camelContext, javax.validation.ValidationProviderResolver.class, value)); return true;
-        case "validatorfactory": ((BeanValidatorEndpoint) target).setValidatorFactory(property(camelContext, javax.validation.ValidatorFactory.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BeanValidatorEndpoint target = (BeanValidatorEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "group": target.setGroup(property(camelContext, java.lang.String.class, value)); return true;
+        case "ignorexmlconfiguration":
+        case "ignoreXmlConfiguration": target.setIgnoreXmlConfiguration(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "constraintvalidatorfactory":
+        case "constraintValidatorFactory": target.setConstraintValidatorFactory(property(camelContext, javax.validation.ConstraintValidatorFactory.class, value)); return true;
+        case "messageinterpolator":
+        case "messageInterpolator": target.setMessageInterpolator(property(camelContext, javax.validation.MessageInterpolator.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "traversableresolver":
+        case "traversableResolver": target.setTraversableResolver(property(camelContext, javax.validation.TraversableResolver.class, value)); return true;
+        case "validationproviderresolver":
+        case "validationProviderResolver": target.setValidationProviderResolver(property(camelContext, javax.validation.ValidationProviderResolver.class, value)); return true;
+        case "validatorfactory":
+        case "validatorFactory": target.setValidatorFactory(property(camelContext, javax.validation.ValidatorFactory.class, value)); return true;
+        default: return false;
         }
     }
 
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 8cf03d2..59cda8c 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
@@ -12,31 +12,16 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BeanComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "cache": ((BeanComponent) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "scope": ((BeanComponent) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "basicPropertyBinding": ((BeanComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BeanComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "cache": ((BeanComponent) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "scope": ((BeanComponent) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "basicpropertybinding": ((BeanComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BeanComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BeanComponent target = (BeanComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "cache": target.setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
+        case "scope": target.setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 71a68c9..9f7e9df 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
@@ -12,37 +12,19 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BeanEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "cache": ((BeanEndpoint) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "method": ((BeanEndpoint) target).setMethod(property(camelContext, java.lang.String.class, value)); return true;
-        case "scope": ((BeanEndpoint) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "lazyStartProducer": ((BeanEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((BeanEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "parameters": ((BeanEndpoint) target).setParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((BeanEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "cache": ((BeanEndpoint) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "method": ((BeanEndpoint) target).setMethod(property(camelContext, java.lang.String.class, value)); return true;
-        case "scope": ((BeanEndpoint) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "lazystartproducer": ((BeanEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((BeanEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "parameters": ((BeanEndpoint) target).setParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((BeanEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BeanEndpoint target = (BeanEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "cache": target.setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
+        case "method": target.setMethod(property(camelContext, java.lang.String.class, value)); return true;
+        case "scope": target.setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "parameters": target.setParameters(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
diff --git a/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassComponentConfigurer.java b/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassComponentConfigurer.java
index 1e17472..905f3e0 100644
--- a/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassComponentConfigurer.java
+++ b/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassComponentConfigurer.java
@@ -12,31 +12,16 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ClassComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "cache": ((ClassComponent) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "scope": ((ClassComponent) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "basicPropertyBinding": ((ClassComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ClassComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "cache": ((ClassComponent) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "scope": ((ClassComponent) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "basicpropertybinding": ((ClassComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ClassComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ClassComponent target = (ClassComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "cache": target.setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
+        case "scope": target.setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
diff --git a/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassEndpointConfigurer.java b/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassEndpointConfigurer.java
index 81905df..d41485e 100644
--- a/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassEndpointConfigurer.java
+++ b/components/camel-bean/src/generated/java/org/apache/camel/component/beanclass/ClassEndpointConfigurer.java
@@ -12,37 +12,19 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ClassEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "cache": ((ClassEndpoint) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "method": ((ClassEndpoint) target).setMethod(property(camelContext, java.lang.String.class, value)); return true;
-        case "scope": ((ClassEndpoint) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "lazyStartProducer": ((ClassEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((ClassEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "parameters": ((ClassEndpoint) target).setParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((ClassEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "cache": ((ClassEndpoint) target).setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
-        case "method": ((ClassEndpoint) target).setMethod(property(camelContext, java.lang.String.class, value)); return true;
-        case "scope": ((ClassEndpoint) target).setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
-        case "lazystartproducer": ((ClassEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((ClassEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "parameters": ((ClassEndpoint) target).setParameters(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((ClassEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ClassEndpoint target = (ClassEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "cache": target.setCache(property(camelContext, java.lang.Boolean.class, value)); return true;
+        case "method": target.setMethod(property(camelContext, java.lang.String.class, value)); return true;
+        case "scope": target.setScope(property(camelContext, org.apache.camel.BeanScope.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "parameters": target.setParameters(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 d78b8d8..e340fb3 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
@@ -12,31 +12,18 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BeanstalkComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "connectionSettingsFactory": ((BeanstalkComponent) target).setConnectionSettingsFactory(property(camelContext, org.apache.camel.component.beanstalk.ConnectionSettingsFactory.class, value)); return true;
-        case "basicPropertyBinding": ((BeanstalkComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BeanstalkComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((BeanstalkComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "connectionsettingsfactory": ((BeanstalkComponent) target).setConnectionSettingsFactory(property(camelContext, org.apache.camel.component.beanstalk.ConnectionSettingsFactory.class, value)); return true;
-        case "basicpropertybinding": ((BeanstalkComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BeanstalkComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((BeanstalkComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BeanstalkComponent target = (BeanstalkComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "connectionsettingsfactory":
+        case "connectionSettingsFactory": target.setConnectionSettingsFactory(property(camelContext, org.apache.camel.component.beanstalk.ConnectionSettingsFactory.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 c36cff1..e3c2256 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
@@ -12,81 +12,63 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BeanstalkEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "command": ((BeanstalkEndpoint) target).setCommand(property(camelContext, org.apache.camel.component.beanstalk.BeanstalkCommand.class, value)); return true;
-        case "jobDelay": ((BeanstalkEndpoint) target).setJobDelay(property(camelContext, int.class, value)); return true;
-        case "jobPriority": ((BeanstalkEndpoint) target).setJobPriority(property(camelContext, long.class, value)); return true;
-        case "jobTimeToRun": ((BeanstalkEndpoint) target).setJobTimeToRun(property(camelContext, int.class, value)); return true;
-        case "awaitJob": ((BeanstalkEndpoint) target).setAwaitJob(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((BeanstalkEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "onFailure": ((BeanstalkEndpoint) target).setOnFailure(property(camelContext, org.apache.camel.component.beanstalk.BeanstalkCommand.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((BeanstalkEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "useBlockIO": ((BeanstalkEndpoint) target).setUseBlockIO(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((BeanstalkEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((BeanstalkEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((BeanstalkEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazyStartProducer": ((BeanstalkEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((BeanstalkEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BeanstalkEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((BeanstalkEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((BeanstalkEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((BeanstalkEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((BeanstalkEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((BeanstalkEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((BeanstalkEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((BeanstalkEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((BeanstalkEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((BeanstalkEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((BeanstalkEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((BeanstalkEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((BeanstalkEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((BeanstalkEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((BeanstalkEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "command": ((BeanstalkEndpoint) target).setCommand(property(camelContext, org.apache.camel.component.beanstalk.BeanstalkCommand.class, value)); return true;
-        case "jobdelay": ((BeanstalkEndpoint) target).setJobDelay(property(camelContext, int.class, value)); return true;
-        case "jobpriority": ((BeanstalkEndpoint) target).setJobPriority(property(camelContext, long.class, value)); return true;
-        case "jobtimetorun": ((BeanstalkEndpoint) target).setJobTimeToRun(property(camelContext, int.class, value)); return true;
-        case "awaitjob": ((BeanstalkEndpoint) target).setAwaitJob(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((BeanstalkEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "onfailure": ((BeanstalkEndpoint) target).setOnFailure(property(camelContext, org.apache.camel.component.beanstalk.BeanstalkCommand.class, value)); return true;
-        case "sendemptymessagewhenidle": ((BeanstalkEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "useblockio": ((BeanstalkEndpoint) target).setUseBlockIO(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((BeanstalkEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((BeanstalkEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((BeanstalkEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazystartproducer": ((BeanstalkEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((BeanstalkEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BeanstalkEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((BeanstalkEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((BeanstalkEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((BeanstalkEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((BeanstalkEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((BeanstalkEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((BeanstalkEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((BeanstalkEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((BeanstalkEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((BeanstalkEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((BeanstalkEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((BeanstalkEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((BeanstalkEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((BeanstalkEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((BeanstalkEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BeanstalkEndpoint target = (BeanstalkEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "command": target.setCommand(property(camelContext, org.apache.camel.component.beanstalk.BeanstalkCommand.class, value)); return true;
+        case "jobdelay":
+        case "jobDelay": target.setJobDelay(property(camelContext, int.class, value)); return true;
+        case "jobpriority":
+        case "jobPriority": target.setJobPriority(property(camelContext, long.class, value)); return true;
+        case "jobtimetorun":
+        case "jobTimeToRun": target.setJobTimeToRun(property(camelContext, int.class, value)); return true;
+        case "awaitjob":
+        case "awaitJob": target.setAwaitJob(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "onfailure":
+        case "onFailure": target.setOnFailure(property(camelContext, org.apache.camel.component.beanstalk.BeanstalkCommand.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "useblockio":
+        case "useBlockIO": target.setUseBlockIO(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 037a55c..a240e92 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
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BonitaComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((BonitaComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BonitaComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((BonitaComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BonitaComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BonitaComponent target = (BonitaComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 3952256..ad3b718 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
@@ -12,39 +12,21 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BonitaEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "hostname": ((BonitaEndpoint) target).getConfiguration().setHostname(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((BonitaEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "port": ((BonitaEndpoint) target).getConfiguration().setPort(property(camelContext, java.lang.String.class, value)); return true;
-        case "processName": ((BonitaEndpoint) target).getConfiguration().setProcessName(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((BonitaEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BonitaEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "password": ((BonitaEndpoint) target).getConfiguration().setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "username": ((BonitaEndpoint) target).getConfiguration().setUsername(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "hostname": ((BonitaEndpoint) target).getConfiguration().setHostname(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((BonitaEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "port": ((BonitaEndpoint) target).getConfiguration().setPort(property(camelContext, java.lang.String.class, value)); return true;
-        case "processname": ((BonitaEndpoint) target).getConfiguration().setProcessName(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((BonitaEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BonitaEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "password": ((BonitaEndpoint) target).getConfiguration().setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "username": ((BonitaEndpoint) target).getConfiguration().setUsername(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BonitaEndpoint target = (BonitaEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "hostname": target.getConfiguration().setHostname(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "port": target.getConfiguration().setPort(property(camelContext, java.lang.String.class, value)); return true;
+        case "processname":
+        case "processName": target.getConfiguration().setProcessName(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "password": target.getConfiguration().setPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "username": target.getConfiguration().setUsername(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 700d83d..7fb81c3 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
@@ -12,31 +12,17 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BoxComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((BoxComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.box.BoxConfiguration.class, value)); return true;
-        case "basicPropertyBinding": ((BoxComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BoxComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((BoxComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((BoxComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.box.BoxConfiguration.class, value)); return true;
-        case "basicpropertybinding": ((BoxComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BoxComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((BoxComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BoxComponent target = (BoxComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.box.BoxConfiguration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 6d22504..069e2aa 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
@@ -12,99 +12,82 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BoxEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "clientId": ((BoxEndpoint) target).getConfiguration().setClientId(property(camelContext, java.lang.String.class, value)); return true;
-        case "enterpriseId": ((BoxEndpoint) target).getConfiguration().setEnterpriseId(property(camelContext, java.lang.String.class, value)); return true;
-        case "inBody": ((BoxEndpoint) target).setInBody(property(camelContext, java.lang.String.class, value)); return true;
-        case "userId": ((BoxEndpoint) target).getConfiguration().setUserId(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((BoxEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((BoxEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((BoxEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((BoxEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((BoxEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazyStartProducer": ((BoxEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((BoxEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "httpParams": ((BoxEndpoint) target).getConfiguration().setHttpParams(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((BoxEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accessTokenCache": ((BoxEndpoint) target).getConfiguration().setAccessTokenCache(property(camelContext, com.box.sdk.IAccessTokenCache.class, value)); return true;
-        case "backoffErrorThreshold": ((BoxEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((BoxEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((BoxEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((BoxEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((BoxEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "repeatCount": ((BoxEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((BoxEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((BoxEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((BoxEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((BoxEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "timeUnit": ((BoxEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((BoxEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "clientSecret": ((BoxEndpoint) target).getConfiguration().setClientSecret(property(camelContext, java.lang.String.class, value)); return true;
-        case "encryptionAlgorithm": ((BoxEndpoint) target).getConfiguration().setEncryptionAlgorithm(property(camelContext, com.box.sdk.EncryptionAlgorithm.class, value)); return true;
-        case "maxCacheEntries": ((BoxEndpoint) target).getConfiguration().setMaxCacheEntries(property(camelContext, int.class, value)); return true;
-        case "authenticationType": ((BoxEndpoint) target).getConfiguration().setAuthenticationType(property(camelContext, java.lang.String.class, value)); return true;
-        case "initialDelay": ((BoxEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "startScheduler": ((BoxEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "privateKeyFile": ((BoxEndpoint) target).getConfiguration().setPrivateKeyFile(property(camelContext, java.lang.String.class, value)); return true;
-        case "privateKeyPassword": ((BoxEndpoint) target).getConfiguration().setPrivateKeyPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "publicKeyId": ((BoxEndpoint) target).getConfiguration().setPublicKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslContextParameters": ((BoxEndpoint) target).getConfiguration().setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "userName": ((BoxEndpoint) target).getConfiguration().setUserName(property(camelContext, java.lang.String.class, value)); return true;
-        case "userPassword": ((BoxEndpoint) target).getConfiguration().setUserPassword(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "clientid": ((BoxEndpoint) target).getConfiguration().setClientId(property(camelContext, java.lang.String.class, value)); return true;
-        case "enterpriseid": ((BoxEndpoint) target).getConfiguration().setEnterpriseId(property(camelContext, java.lang.String.class, value)); return true;
-        case "inbody": ((BoxEndpoint) target).setInBody(property(camelContext, java.lang.String.class, value)); return true;
-        case "userid": ((BoxEndpoint) target).getConfiguration().setUserId(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((BoxEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendemptymessagewhenidle": ((BoxEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((BoxEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((BoxEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((BoxEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazystartproducer": ((BoxEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((BoxEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "httpparams": ((BoxEndpoint) target).getConfiguration().setHttpParams(property(camelContext, java.util.Map.class, value)); return true;
-        case "synchronous": ((BoxEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "accesstokencache": ((BoxEndpoint) target).getConfiguration().setAccessTokenCache(property(camelContext, com.box.sdk.IAccessTokenCache.class, value)); return true;
-        case "backofferrorthreshold": ((BoxEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((BoxEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((BoxEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((BoxEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((BoxEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "repeatcount": ((BoxEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((BoxEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((BoxEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((BoxEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((BoxEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "timeunit": ((BoxEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((BoxEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "clientsecret": ((BoxEndpoint) target).getConfiguration().setClientSecret(property(camelContext, java.lang.String.class, value)); return true;
-        case "encryptionalgorithm": ((BoxEndpoint) target).getConfiguration().setEncryptionAlgorithm(property(camelContext, com.box.sdk.EncryptionAlgorithm.class, value)); return true;
-        case "maxcacheentries": ((BoxEndpoint) target).getConfiguration().setMaxCacheEntries(property(camelContext, int.class, value)); return true;
-        case "authenticationtype": ((BoxEndpoint) target).getConfiguration().setAuthenticationType(property(camelContext, java.lang.String.class, value)); return true;
-        case "initialdelay": ((BoxEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "startscheduler": ((BoxEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "privatekeyfile": ((BoxEndpoint) target).getConfiguration().setPrivateKeyFile(property(camelContext, java.lang.String.class, value)); return true;
-        case "privatekeypassword": ((BoxEndpoint) target).getConfiguration().setPrivateKeyPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "publickeyid": ((BoxEndpoint) target).getConfiguration().setPublicKeyId(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslcontextparameters": ((BoxEndpoint) target).getConfiguration().setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "username": ((BoxEndpoint) target).getConfiguration().setUserName(property(camelContext, java.lang.String.class, value)); return true;
-        case "userpassword": ((BoxEndpoint) target).getConfiguration().setUserPassword(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BoxEndpoint target = (BoxEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "clientid":
+        case "clientId": target.getConfiguration().setClientId(property(camelContext, java.lang.String.class, value)); return true;
+        case "enterpriseid":
+        case "enterpriseId": target.getConfiguration().setEnterpriseId(property(camelContext, java.lang.String.class, value)); return true;
+        case "inbody":
+        case "inBody": target.setInBody(property(camelContext, java.lang.String.class, value)); return true;
+        case "userid":
+        case "userId": target.getConfiguration().setUserId(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "httpparams":
+        case "httpParams": target.getConfiguration().setHttpParams(property(camelContext, java.util.Map.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "accesstokencache":
+        case "accessTokenCache": target.getConfiguration().setAccessTokenCache(property(camelContext, com.box.sdk.IAccessTokenCache.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        case "clientsecret":
+        case "clientSecret": target.getConfiguration().setClientSecret(property(camelContext, java.lang.String.class, value)); return true;
+        case "encryptionalgorithm":
+        case "encryptionAlgorithm": target.getConfiguration().setEncryptionAlgorithm(property(camelContext, com.box.sdk.EncryptionAlgorithm.class, value)); return true;
+        case "maxcacheentries":
+        case "maxCacheEntries": target.getConfiguration().setMaxCacheEntries(property(camelContext, int.class, value)); return true;
+        case "authenticationtype":
+        case "authenticationType": target.getConfiguration().setAuthenticationType(property(camelContext, java.lang.String.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "privatekeyfile":
+        case "privateKeyFile": target.getConfiguration().setPrivateKeyFile(property(camelContext, java.lang.String.class, value)); return true;
+        case "privatekeypassword":
+        case "privateKeyPassword": target.getConfiguration().setPrivateKeyPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "publickeyid":
+        case "publicKeyId": target.getConfiguration().setPublicKeyId(property(camelContext, java.lang.String.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.getConfiguration().setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        case "username":
+        case "userName": target.getConfiguration().setUserName(property(camelContext, java.lang.String.class, value)); return true;
+        case "userpassword":
+        case "userPassword": target.getConfiguration().setUserPassword(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 3c409d1..cc3404c 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
@@ -12,33 +12,19 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BraintreeComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((BraintreeComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.braintree.BraintreeConfiguration.class, value)); return true;
-        case "logHandlerEnabled": ((BraintreeComponent) target).setLogHandlerEnabled(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((BraintreeComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BraintreeComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((BraintreeComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((BraintreeComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.braintree.BraintreeConfiguration.class, value)); return true;
-        case "loghandlerenabled": ((BraintreeComponent) target).setLogHandlerEnabled(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((BraintreeComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BraintreeComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((BraintreeComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BraintreeComponent target = (BraintreeComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.braintree.BraintreeConfiguration.class, value)); return true;
+        case "loghandlerenabled":
+        case "logHandlerEnabled": target.setLogHandlerEnabled(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 c10f57c..dd426b3 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
@@ -12,89 +12,71 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BraintreeEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "environment": ((BraintreeEndpoint) target).getConfiguration().setEnvironment(property(camelContext, java.lang.String.class, value)); return true;
-        case "inBody": ((BraintreeEndpoint) target).setInBody(property(camelContext, java.lang.String.class, value)); return true;
-        case "merchantId": ((BraintreeEndpoint) target).getConfiguration().setMerchantId(property(camelContext, java.lang.String.class, value)); return true;
-        case "privateKey": ((BraintreeEndpoint) target).getConfiguration().setPrivateKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "publicKey": ((BraintreeEndpoint) target).getConfiguration().setPublicKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((BraintreeEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((BraintreeEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((BraintreeEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((BraintreeEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((BraintreeEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazyStartProducer": ((BraintreeEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "accessToken": ((BraintreeEndpoint) target).getConfiguration().setAccessToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((BraintreeEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "httpReadTimeout": ((BraintreeEndpoint) target).getConfiguration().setHttpReadTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "synchronous": ((BraintreeEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "httpLogLevel": ((BraintreeEndpoint) target).getConfiguration().setHttpLogLevel(property(camelContext, java.lang.String.class, value)); return true;
-        case "logHandlerEnabled": ((BraintreeEndpoint) target).getConfiguration().setLogHandlerEnabled(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((BraintreeEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((BraintreeEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((BraintreeEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((BraintreeEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((BraintreeEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((BraintreeEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((BraintreeEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((BraintreeEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((BraintreeEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((BraintreeEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((BraintreeEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((BraintreeEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((BraintreeEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((BraintreeEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "proxyHost": ((BraintreeEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyPort": ((BraintreeEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "environment": ((BraintreeEndpoint) target).getConfiguration().setEnvironment(property(camelContext, java.lang.String.class, value)); return true;
-        case "inbody": ((BraintreeEndpoint) target).setInBody(property(camelContext, java.lang.String.class, value)); return true;
-        case "merchantid": ((BraintreeEndpoint) target).getConfiguration().setMerchantId(property(camelContext, java.lang.String.class, value)); return true;
-        case "privatekey": ((BraintreeEndpoint) target).getConfiguration().setPrivateKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "publickey": ((BraintreeEndpoint) target).getConfiguration().setPublicKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((BraintreeEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendemptymessagewhenidle": ((BraintreeEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((BraintreeEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((BraintreeEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((BraintreeEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazystartproducer": ((BraintreeEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "accesstoken": ((BraintreeEndpoint) target).getConfiguration().setAccessToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((BraintreeEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "httpreadtimeout": ((BraintreeEndpoint) target).getConfiguration().setHttpReadTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "synchronous": ((BraintreeEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "httploglevel": ((BraintreeEndpoint) target).getConfiguration().setHttpLogLevel(property(camelContext, java.lang.String.class, value)); return true;
-        case "loghandlerenabled": ((BraintreeEndpoint) target).getConfiguration().setLogHandlerEnabled(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((BraintreeEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((BraintreeEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((BraintreeEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((BraintreeEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((BraintreeEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((BraintreeEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((BraintreeEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((BraintreeEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((BraintreeEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((BraintreeEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((BraintreeEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((BraintreeEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((BraintreeEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((BraintreeEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-        case "proxyhost": ((BraintreeEndpoint) target).getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
-        case "proxyport": ((BraintreeEndpoint) target).getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BraintreeEndpoint target = (BraintreeEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "environment": target.getConfiguration().setEnvironment(property(camelContext, java.lang.String.class, value)); return true;
+        case "inbody":
+        case "inBody": target.setInBody(property(camelContext, java.lang.String.class, value)); return true;
+        case "merchantid":
+        case "merchantId": target.getConfiguration().setMerchantId(property(camelContext, java.lang.String.class, value)); return true;
+        case "privatekey":
+        case "privateKey": target.getConfiguration().setPrivateKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "publickey":
+        case "publicKey": target.getConfiguration().setPublicKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "accesstoken":
+        case "accessToken": target.getConfiguration().setAccessToken(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "httpreadtimeout":
+        case "httpReadTimeout": target.getConfiguration().setHttpReadTimeout(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "httploglevel":
+        case "httpLogLevel": target.getConfiguration().setHttpLogLevel(property(camelContext, java.lang.String.class, value)); return true;
+        case "loghandlerenabled":
+        case "logHandlerEnabled": target.getConfiguration().setLogHandlerEnabled(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        case "proxyhost":
+        case "proxyHost": target.getConfiguration().setProxyHost(property(camelContext, java.lang.String.class, value)); return true;
+        case "proxyport":
+        case "proxyPort": target.getConfiguration().setProxyPort(property(camelContext, java.lang.Integer.class, value)); return true;
+        default: return false;
         }
     }
 
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 1512051..a1e0055 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
@@ -12,29 +12,16 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BrowseComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((BrowseComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((BrowseComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((BrowseComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((BrowseComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((BrowseComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((BrowseComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BrowseComponent target = (BrowseComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 7d9515b..0d0ee1f 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
@@ -12,35 +12,21 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class BrowseEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "bridgeErrorHandler": ((BrowseEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((BrowseEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((BrowseEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((BrowseEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((BrowseEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BrowseEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "bridgeerrorhandler": ((BrowseEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((BrowseEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((BrowseEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((BrowseEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((BrowseEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((BrowseEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        BrowseEndpoint target = (BrowseEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 0da0bae..58ee764 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
@@ -12,29 +12,15 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CaffeineCacheComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((CaffeineCacheComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.caffeine.CaffeineConfiguration.class, value)); return true;
-        case "basicPropertyBinding": ((CaffeineCacheComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CaffeineCacheComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((CaffeineCacheComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.caffeine.CaffeineConfiguration.class, value)); return true;
-        case "basicpropertybinding": ((CaffeineCacheComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CaffeineCacheComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CaffeineCacheComponent target = (CaffeineCacheComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.caffeine.CaffeineConfiguration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 986626c..97124a1 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
@@ -12,59 +12,42 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CaffeineCacheEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "action": ((CaffeineCacheEndpoint) target).getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
-        case "cache": ((CaffeineCacheEndpoint) target).getConfiguration().setCache(property(camelContext, com.github.benmanes.caffeine.cache.Cache.class, value)); return true;
-        case "cacheLoader": ((CaffeineCacheEndpoint) target).getConfiguration().setCacheLoader(property(camelContext, com.github.benmanes.caffeine.cache.CacheLoader.class, value)); return true;
-        case "createCacheIfNotExist": ((CaffeineCacheEndpoint) target).getConfiguration().setCreateCacheIfNotExist(property(camelContext, boolean.class, value)); return true;
-        case "evictionType": ((CaffeineCacheEndpoint) target).getConfiguration().setEvictionType(property(camelContext, org.apache.camel.component.caffeine.EvictionType.class, value)); return true;
-        case "expireAfterAccessTime": ((CaffeineCacheEndpoint) target).getConfiguration().setExpireAfterAccessTime(property(camelContext, int.class, value)); return true;
-        case "expireAfterWriteTime": ((CaffeineCacheEndpoint) target).getConfiguration().setExpireAfterWriteTime(property(camelContext, int.class, value)); return true;
-        case "initialCapacity": ((CaffeineCacheEndpoint) target).getConfiguration().setInitialCapacity(property(camelContext, int.class, value)); return true;
-        case "key": ((CaffeineCacheEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "lazyStartProducer": ((CaffeineCacheEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "maximumSize": ((CaffeineCacheEndpoint) target).getConfiguration().setMaximumSize(property(camelContext, int.class, value)); return true;
-        case "removalListener": ((CaffeineCacheEndpoint) target).getConfiguration().setRemovalListener(property(camelContext, com.github.benmanes.caffeine.cache.RemovalListener.class, value)); return true;
-        case "statsCounter": ((CaffeineCacheEndpoint) target).getConfiguration().setStatsCounter(property(camelContext, com.github.benmanes.caffeine.cache.stats.StatsCounter.class, value)); return true;
-        case "statsEnabled": ((CaffeineCacheEndpoint) target).getConfiguration().setStatsEnabled(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CaffeineCacheEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "keyType": ((CaffeineCacheEndpoint) target).getConfiguration().setKeyType(property(camelContext, java.lang.String.class, value)); return true;
-        case "synchronous": ((CaffeineCacheEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "valueType": ((CaffeineCacheEndpoint) target).getConfiguration().setValueType(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "action": ((CaffeineCacheEndpoint) target).getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
-        case "cache": ((CaffeineCacheEndpoint) target).getConfiguration().setCache(property(camelContext, com.github.benmanes.caffeine.cache.Cache.class, value)); return true;
-        case "cacheloader": ((CaffeineCacheEndpoint) target).getConfiguration().setCacheLoader(property(camelContext, com.github.benmanes.caffeine.cache.CacheLoader.class, value)); return true;
-        case "createcacheifnotexist": ((CaffeineCacheEndpoint) target).getConfiguration().setCreateCacheIfNotExist(property(camelContext, boolean.class, value)); return true;
-        case "evictiontype": ((CaffeineCacheEndpoint) target).getConfiguration().setEvictionType(property(camelContext, org.apache.camel.component.caffeine.EvictionType.class, value)); return true;
-        case "expireafteraccesstime": ((CaffeineCacheEndpoint) target).getConfiguration().setExpireAfterAccessTime(property(camelContext, int.class, value)); return true;
-        case "expireafterwritetime": ((CaffeineCacheEndpoint) target).getConfiguration().setExpireAfterWriteTime(property(camelContext, int.class, value)); return true;
-        case "initialcapacity": ((CaffeineCacheEndpoint) target).getConfiguration().setInitialCapacity(property(camelContext, int.class, value)); return true;
-        case "key": ((CaffeineCacheEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "lazystartproducer": ((CaffeineCacheEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "maximumsize": ((CaffeineCacheEndpoint) target).getConfiguration().setMaximumSize(property(camelContext, int.class, value)); return true;
-        case "removallistener": ((CaffeineCacheEndpoint) target).getConfiguration().setRemovalListener(property(camelContext, com.github.benmanes.caffeine.cache.RemovalListener.class, value)); return true;
-        case "statscounter": ((CaffeineCacheEndpoint) target).getConfiguration().setStatsCounter(property(camelContext, com.github.benmanes.caffeine.cache.stats.StatsCounter.class, value)); return true;
-        case "statsenabled": ((CaffeineCacheEndpoint) target).getConfiguration().setStatsEnabled(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CaffeineCacheEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "keytype": ((CaffeineCacheEndpoint) target).getConfiguration().setKeyType(property(camelContext, java.lang.String.class, value)); return true;
-        case "synchronous": ((CaffeineCacheEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "valuetype": ((CaffeineCacheEndpoint) target).getConfiguration().setValueType(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CaffeineCacheEndpoint target = (CaffeineCacheEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "action": target.getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
+        case "cache": target.getConfiguration().setCache(property(camelContext, com.github.benmanes.caffeine.cache.Cache.class, value)); return true;
+        case "cacheloader":
+        case "cacheLoader": target.getConfiguration().setCacheLoader(property(camelContext, com.github.benmanes.caffeine.cache.CacheLoader.class, value)); return true;
+        case "createcacheifnotexist":
+        case "createCacheIfNotExist": target.getConfiguration().setCreateCacheIfNotExist(property(camelContext, boolean.class, value)); return true;
+        case "evictiontype":
+        case "evictionType": target.getConfiguration().setEvictionType(property(camelContext, org.apache.camel.component.caffeine.EvictionType.class, value)); return true;
+        case "expireafteraccesstime":
+        case "expireAfterAccessTime": target.getConfiguration().setExpireAfterAccessTime(property(camelContext, int.class, value)); return true;
+        case "expireafterwritetime":
+        case "expireAfterWriteTime": target.getConfiguration().setExpireAfterWriteTime(property(camelContext, int.class, value)); return true;
+        case "initialcapacity":
+        case "initialCapacity": target.getConfiguration().setInitialCapacity(property(camelContext, int.class, value)); return true;
+        case "key": target.getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "maximumsize":
+        case "maximumSize": target.getConfiguration().setMaximumSize(property(camelContext, int.class, value)); return true;
+        case "removallistener":
+        case "removalListener": target.getConfiguration().setRemovalListener(property(camelContext, com.github.benmanes.caffeine.cache.RemovalListener.class, value)); return true;
+        case "statscounter":
+        case "statsCounter": target.getConfiguration().setStatsCounter(property(camelContext, com.github.benmanes.caffeine.cache.stats.StatsCounter.class, value)); return true;
+        case "statsenabled":
+        case "statsEnabled": target.getConfiguration().setStatsEnabled(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "keytype":
+        case "keyType": target.getConfiguration().setKeyType(property(camelContext, java.lang.String.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "valuetype":
+        case "valueType": target.getConfiguration().setValueType(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 baed923..7d1a3e4 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
@@ -12,29 +12,15 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CaffeineLoadCacheComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "configuration": ((CaffeineLoadCacheComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.caffeine.CaffeineConfiguration.class, value)); return true;
-        case "basicPropertyBinding": ((CaffeineLoadCacheComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CaffeineLoadCacheComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "configuration": ((CaffeineLoadCacheComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.caffeine.CaffeineConfiguration.class, value)); return true;
-        case "basicpropertybinding": ((CaffeineLoadCacheComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CaffeineLoadCacheComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CaffeineLoadCacheComponent target = (CaffeineLoadCacheComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.caffeine.CaffeineConfiguration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 b6814da..1f99a46 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
@@ -12,59 +12,42 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CaffeineLoadCacheEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "action": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
-        case "cache": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setCache(property(camelContext, com.github.benmanes.caffeine.cache.Cache.class, value)); return true;
-        case "cacheLoader": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setCacheLoader(property(camelContext, com.github.benmanes.caffeine.cache.CacheLoader.class, value)); return true;
-        case "createCacheIfNotExist": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setCreateCacheIfNotExist(property(camelContext, boolean.class, value)); return true;
-        case "evictionType": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setEvictionType(property(camelContext, org.apache.camel.component.caffeine.EvictionType.class, value)); return true;
-        case "expireAfterAccessTime": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setExpireAfterAccessTime(property(camelContext, int.class, value)); return true;
-        case "expireAfterWriteTime": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setExpireAfterWriteTime(property(camelContext, int.class, value)); return true;
-        case "initialCapacity": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setInitialCapacity(property(camelContext, int.class, value)); return true;
-        case "key": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "lazyStartProducer": ((CaffeineLoadCacheEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "maximumSize": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setMaximumSize(property(camelContext, int.class, value)); return true;
-        case "removalListener": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setRemovalListener(property(camelContext, com.github.benmanes.caffeine.cache.RemovalListener.class, value)); return true;
-        case "statsCounter": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setStatsCounter(property(camelContext, com.github.benmanes.caffeine.cache.stats.StatsCounter.class, value)); return true;
-        case "statsEnabled": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setStatsEnabled(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CaffeineLoadCacheEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "keyType": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setKeyType(property(camelContext, java.lang.String.class, value)); return true;
-        case "synchronous": ((CaffeineLoadCacheEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "valueType": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setValueType(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "action": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
-        case "cache": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setCache(property(camelContext, com.github.benmanes.caffeine.cache.Cache.class, value)); return true;
-        case "cacheloader": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setCacheLoader(property(camelContext, com.github.benmanes.caffeine.cache.CacheLoader.class, value)); return true;
-        case "createcacheifnotexist": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setCreateCacheIfNotExist(property(camelContext, boolean.class, value)); return true;
-        case "evictiontype": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setEvictionType(property(camelContext, org.apache.camel.component.caffeine.EvictionType.class, value)); return true;
-        case "expireafteraccesstime": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setExpireAfterAccessTime(property(camelContext, int.class, value)); return true;
-        case "expireafterwritetime": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setExpireAfterWriteTime(property(camelContext, int.class, value)); return true;
-        case "initialcapacity": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setInitialCapacity(property(camelContext, int.class, value)); return true;
-        case "key": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
-        case "lazystartproducer": ((CaffeineLoadCacheEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "maximumsize": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setMaximumSize(property(camelContext, int.class, value)); return true;
-        case "removallistener": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setRemovalListener(property(camelContext, com.github.benmanes.caffeine.cache.RemovalListener.class, value)); return true;
-        case "statscounter": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setStatsCounter(property(camelContext, com.github.benmanes.caffeine.cache.stats.StatsCounter.class, value)); return true;
-        case "statsenabled": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setStatsEnabled(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CaffeineLoadCacheEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "keytype": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setKeyType(property(camelContext, java.lang.String.class, value)); return true;
-        case "synchronous": ((CaffeineLoadCacheEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "valuetype": ((CaffeineLoadCacheEndpoint) target).getConfiguration().setValueType(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CaffeineLoadCacheEndpoint target = (CaffeineLoadCacheEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "action": target.getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
+        case "cache": target.getConfiguration().setCache(property(camelContext, com.github.benmanes.caffeine.cache.Cache.class, value)); return true;
+        case "cacheloader":
+        case "cacheLoader": target.getConfiguration().setCacheLoader(property(camelContext, com.github.benmanes.caffeine.cache.CacheLoader.class, value)); return true;
+        case "createcacheifnotexist":
+        case "createCacheIfNotExist": target.getConfiguration().setCreateCacheIfNotExist(property(camelContext, boolean.class, value)); return true;
+        case "evictiontype":
+        case "evictionType": target.getConfiguration().setEvictionType(property(camelContext, org.apache.camel.component.caffeine.EvictionType.class, value)); return true;
+        case "expireafteraccesstime":
+        case "expireAfterAccessTime": target.getConfiguration().setExpireAfterAccessTime(property(camelContext, int.class, value)); return true;
+        case "expireafterwritetime":
+        case "expireAfterWriteTime": target.getConfiguration().setExpireAfterWriteTime(property(camelContext, int.class, value)); return true;
+        case "initialcapacity":
+        case "initialCapacity": target.getConfiguration().setInitialCapacity(property(camelContext, int.class, value)); return true;
+        case "key": target.getConfiguration().setKey(property(camelContext, java.lang.Object.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "maximumsize":
+        case "maximumSize": target.getConfiguration().setMaximumSize(property(camelContext, int.class, value)); return true;
+        case "removallistener":
+        case "removalListener": target.getConfiguration().setRemovalListener(property(camelContext, com.github.benmanes.caffeine.cache.RemovalListener.class, value)); return true;
+        case "statscounter":
+        case "statsCounter": target.getConfiguration().setStatsCounter(property(camelContext, com.github.benmanes.caffeine.cache.stats.StatsCounter.class, value)); return true;
+        case "statsenabled":
+        case "statsEnabled": target.getConfiguration().setStatsEnabled(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "keytype":
+        case "keyType": target.getConfiguration().setKeyType(property(camelContext, java.lang.String.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "valuetype":
+        case "valueType": target.getConfiguration().setValueType(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 20b504b..4af795f 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
@@ -12,29 +12,16 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CassandraComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((CassandraComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CassandraComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((CassandraComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((CassandraComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CassandraComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((CassandraComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CassandraComponent target = (CassandraComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 22be232..2d4f40c 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
@@ -12,87 +12,65 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CassandraEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "cluster": ((CassandraEndpoint) target).setCluster(property(camelContext, com.datastax.driver.core.Cluster.class, value)); return true;
-        case "clusterName": ((CassandraEndpoint) target).setClusterName(property(camelContext, java.lang.String.class, value)); return true;
-        case "consistencyLevel": ((CassandraEndpoint) target).setConsistencyLevel(property(camelContext, com.datastax.driver.core.ConsistencyLevel.class, value)); return true;
-        case "cql": ((CassandraEndpoint) target).setCql(property(camelContext, java.lang.String.class, value)); return true;
-        case "loadBalancingPolicy": ((CassandraEndpoint) target).setLoadBalancingPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((CassandraEndpoint) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "prepareStatements": ((CassandraEndpoint) target).setPrepareStatements(property(camelContext, boolean.class, value)); return true;
-        case "resultSetConversionStrategy": ((CassandraEndpoint) target).setResultSetConversionStrategy(property(camelContext, org.apache.camel.component.cassandra.ResultSetConversionStrategy.class, value)); return true;
-        case "session": ((CassandraEndpoint) target).setSession(property(camelContext, com.datastax.driver.core.Session.class, value)); return true;
-        case "username": ((CassandraEndpoint) target).setUsername(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((CassandraEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendEmptyMessageWhenIdle": ((CassandraEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((CassandraEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((CassandraEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollStrategy": ((CassandraEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazyStartProducer": ((CassandraEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CassandraEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CassandraEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backoffErrorThreshold": ((CassandraEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffIdleThreshold": ((CassandraEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffMultiplier": ((CassandraEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((CassandraEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((CassandraEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialDelay": ((CassandraEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatCount": ((CassandraEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runLoggingLevel": ((CassandraEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledExecutorService": ((CassandraEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((CassandraEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerProperties": ((CassandraEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startScheduler": ((CassandraEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeUnit": ((CassandraEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "useFixedDelay": ((CassandraEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "cluster": ((CassandraEndpoint) target).setCluster(property(camelContext, com.datastax.driver.core.Cluster.class, value)); return true;
-        case "clustername": ((CassandraEndpoint) target).setClusterName(property(camelContext, java.lang.String.class, value)); return true;
-        case "consistencylevel": ((CassandraEndpoint) target).setConsistencyLevel(property(camelContext, com.datastax.driver.core.ConsistencyLevel.class, value)); return true;
-        case "cql": ((CassandraEndpoint) target).setCql(property(camelContext, java.lang.String.class, value)); return true;
-        case "loadbalancingpolicy": ((CassandraEndpoint) target).setLoadBalancingPolicy(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((CassandraEndpoint) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "preparestatements": ((CassandraEndpoint) target).setPrepareStatements(property(camelContext, boolean.class, value)); return true;
-        case "resultsetconversionstrategy": ((CassandraEndpoint) target).setResultSetConversionStrategy(property(camelContext, org.apache.camel.component.cassandra.ResultSetConversionStrategy.class, value)); return true;
-        case "session": ((CassandraEndpoint) target).setSession(property(camelContext, com.datastax.driver.core.Session.class, value)); return true;
-        case "username": ((CassandraEndpoint) target).setUsername(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((CassandraEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sendemptymessagewhenidle": ((CassandraEndpoint) target).setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((CassandraEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((CassandraEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "pollstrategy": ((CassandraEndpoint) target).setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
-        case "lazystartproducer": ((CassandraEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CassandraEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CassandraEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "backofferrorthreshold": ((CassandraEndpoint) target).setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffidlethreshold": ((CassandraEndpoint) target).setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
-        case "backoffmultiplier": ((CassandraEndpoint) target).setBackoffMultiplier(property(camelContext, int.class, value)); return true;
-        case "delay": ((CassandraEndpoint) target).setDelay(property(camelContext, long.class, value)); return true;
-        case "greedy": ((CassandraEndpoint) target).setGreedy(property(camelContext, boolean.class, value)); return true;
-        case "initialdelay": ((CassandraEndpoint) target).setInitialDelay(property(camelContext, long.class, value)); return true;
-        case "repeatcount": ((CassandraEndpoint) target).setRepeatCount(property(camelContext, long.class, value)); return true;
-        case "runlogginglevel": ((CassandraEndpoint) target).setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
-        case "scheduledexecutorservice": ((CassandraEndpoint) target).setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
-        case "scheduler": ((CassandraEndpoint) target).setScheduler(property(camelContext, java.lang.String.class, value)); return true;
-        case "schedulerproperties": ((CassandraEndpoint) target).setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
-        case "startscheduler": ((CassandraEndpoint) target).setStartScheduler(property(camelContext, boolean.class, value)); return true;
-        case "timeunit": ((CassandraEndpoint) target).setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
-        case "usefixeddelay": ((CassandraEndpoint) target).setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CassandraEndpoint target = (CassandraEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "cluster": target.setCluster(property(camelContext, com.datastax.driver.core.Cluster.class, value)); return true;
+        case "clustername":
+        case "clusterName": target.setClusterName(property(camelContext, java.lang.String.class, value)); return true;
+        case "consistencylevel":
+        case "consistencyLevel": target.setConsistencyLevel(property(camelContext, com.datastax.driver.core.ConsistencyLevel.class, value)); return true;
+        case "cql": target.setCql(property(camelContext, java.lang.String.class, value)); return true;
+        case "loadbalancingpolicy":
+        case "loadBalancingPolicy": target.setLoadBalancingPolicy(property(camelContext, java.lang.String.class, value)); return true;
+        case "password": target.setPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "preparestatements":
+        case "prepareStatements": target.setPrepareStatements(property(camelContext, boolean.class, value)); return true;
+        case "resultsetconversionstrategy":
+        case "resultSetConversionStrategy": target.setResultSetConversionStrategy(property(camelContext, org.apache.camel.component.cassandra.ResultSetConversionStrategy.class, value)); return true;
+        case "session": target.setSession(property(camelContext, com.datastax.driver.core.Session.class, value)); return true;
+        case "username": target.setUsername(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "sendemptymessagewhenidle":
+        case "sendEmptyMessageWhenIdle": target.setSendEmptyMessageWhenIdle(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "pollstrategy":
+        case "pollStrategy": target.setPollStrategy(property(camelContext, org.apache.camel.spi.PollingConsumerPollStrategy.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "backofferrorthreshold":
+        case "backoffErrorThreshold": target.setBackoffErrorThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffidlethreshold":
+        case "backoffIdleThreshold": target.setBackoffIdleThreshold(property(camelContext, int.class, value)); return true;
+        case "backoffmultiplier":
+        case "backoffMultiplier": target.setBackoffMultiplier(property(camelContext, int.class, value)); return true;
+        case "delay": target.setDelay(property(camelContext, long.class, value)); return true;
+        case "greedy": target.setGreedy(property(camelContext, boolean.class, value)); return true;
+        case "initialdelay":
+        case "initialDelay": target.setInitialDelay(property(camelContext, long.class, value)); return true;
+        case "repeatcount":
+        case "repeatCount": target.setRepeatCount(property(camelContext, long.class, value)); return true;
+        case "runlogginglevel":
+        case "runLoggingLevel": target.setRunLoggingLevel(property(camelContext, org.apache.camel.LoggingLevel.class, value)); return true;
+        case "scheduledexecutorservice":
+        case "scheduledExecutorService": target.setScheduledExecutorService(property(camelContext, java.util.concurrent.ScheduledExecutorService.class, value)); return true;
+        case "scheduler": target.setScheduler(property(camelContext, java.lang.String.class, value)); return true;
+        case "schedulerproperties":
+        case "schedulerProperties": target.setSchedulerProperties(property(camelContext, java.util.Map.class, value)); return true;
+        case "startscheduler":
+        case "startScheduler": target.setStartScheduler(property(camelContext, boolean.class, value)); return true;
+        case "timeunit":
+        case "timeUnit": target.setTimeUnit(property(camelContext, java.util.concurrent.TimeUnit.class, value)); return true;
+        case "usefixeddelay":
+        case "useFixedDelay": target.setUseFixedDelay(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 60a7e78..091924b 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
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ChatScriptComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((ChatScriptComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ChatScriptComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((ChatScriptComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ChatScriptComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ChatScriptComponent target = (ChatScriptComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 113e9ca..f42a24d 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
@@ -12,33 +12,19 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ChatScriptEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "chatUserName": ((ChatScriptEndpoint) target).setChatUserName(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((ChatScriptEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "resetChat": ((ChatScriptEndpoint) target).setResetChat(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((ChatScriptEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ChatScriptEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "chatusername": ((ChatScriptEndpoint) target).setChatUserName(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((ChatScriptEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "resetchat": ((ChatScriptEndpoint) target).setResetChat(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((ChatScriptEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ChatScriptEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ChatScriptEndpoint target = (ChatScriptEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "chatusername":
+        case "chatUserName": target.setChatUserName(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "resetchat":
+        case "resetChat": target.setResetChat(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 a467b28..f343755 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
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ChunkComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((ChunkComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ChunkComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((ChunkComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ChunkComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ChunkComponent target = (ChunkComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 62e6dbf..27dd1af 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
@@ -12,41 +12,25 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ChunkEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "contentCache": ((ChunkEndpoint) target).setContentCache(property(camelContext, boolean.class, value)); return true;
-        case "encoding": ((ChunkEndpoint) target).setEncoding(property(camelContext, java.lang.String.class, value)); return true;
-        case "extension": ((ChunkEndpoint) target).setExtension(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((ChunkEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "themeFolder": ((ChunkEndpoint) target).setThemeFolder(property(camelContext, java.lang.String.class, value)); return true;
-        case "themeLayer": ((ChunkEndpoint) target).setThemeLayer(property(camelContext, java.lang.String.class, value)); return true;
-        case "themeSubfolder": ((ChunkEndpoint) target).setThemeSubfolder(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicPropertyBinding": ((ChunkEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ChunkEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "contentcache": ((ChunkEndpoint) target).setContentCache(property(camelContext, boolean.class, value)); return true;
-        case "encoding": ((ChunkEndpoint) target).setEncoding(property(camelContext, java.lang.String.class, value)); return true;
-        case "extension": ((ChunkEndpoint) target).setExtension(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((ChunkEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "themefolder": ((ChunkEndpoint) target).setThemeFolder(property(camelContext, java.lang.String.class, value)); return true;
-        case "themelayer": ((ChunkEndpoint) target).setThemeLayer(property(camelContext, java.lang.String.class, value)); return true;
-        case "themesubfolder": ((ChunkEndpoint) target).setThemeSubfolder(property(camelContext, java.lang.String.class, value)); return true;
-        case "basicpropertybinding": ((ChunkEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((ChunkEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ChunkEndpoint target = (ChunkEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "contentcache":
+        case "contentCache": target.setContentCache(property(camelContext, boolean.class, value)); return true;
+        case "encoding": target.setEncoding(property(camelContext, java.lang.String.class, value)); return true;
+        case "extension": target.setExtension(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "themefolder":
+        case "themeFolder": target.setThemeFolder(property(camelContext, java.lang.String.class, value)); return true;
+        case "themelayer":
+        case "themeLayer": target.setThemeLayer(property(camelContext, java.lang.String.class, value)); return true;
+        case "themesubfolder":
+        case "themeSubfolder": target.setThemeSubfolder(property(camelContext, java.lang.String.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 3756c2c..178257e 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
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CMComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((CMComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CMComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((CMComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CMComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CMComponent target = (CMComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 952384a..bf179fd 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
@@ -12,37 +12,23 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CMEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "defaultFrom": ((CMEndpoint) target).getConfiguration().setDefaultFrom(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultMaxNumberOfParts": ((CMEndpoint) target).getConfiguration().setDefaultMaxNumberOfParts(property(camelContext, int.class, value)); return true;
-        case "lazyStartProducer": ((CMEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "productToken": ((CMEndpoint) target).getConfiguration().setProductToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "testConnectionOnStartup": ((CMEndpoint) target).getConfiguration().setTestConnectionOnStartup(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CMEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CMEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "defaultfrom": ((CMEndpoint) target).getConfiguration().setDefaultFrom(property(camelContext, java.lang.String.class, value)); return true;
-        case "defaultmaxnumberofparts": ((CMEndpoint) target).getConfiguration().setDefaultMaxNumberOfParts(property(camelContext, int.class, value)); return true;
-        case "lazystartproducer": ((CMEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "producttoken": ((CMEndpoint) target).getConfiguration().setProductToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "testconnectiononstartup": ((CMEndpoint) target).getConfiguration().setTestConnectionOnStartup(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CMEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CMEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CMEndpoint target = (CMEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "defaultfrom":
+        case "defaultFrom": target.getConfiguration().setDefaultFrom(property(camelContext, java.lang.String.class, value)); return true;
+        case "defaultmaxnumberofparts":
+        case "defaultMaxNumberOfParts": target.getConfiguration().setDefaultMaxNumberOfParts(property(camelContext, int.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "producttoken":
+        case "productToken": target.getConfiguration().setProductToken(property(camelContext, java.lang.String.class, value)); return true;
+        case "testconnectiononstartup":
+        case "testConnectionOnStartup": target.getConfiguration().setTestConnectionOnStartup(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 fc16abd..4622645 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
@@ -12,31 +12,18 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CMISComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "sessionFacadeFactory": ((CMISComponent) target).setSessionFacadeFactory(property(camelContext, org.apache.camel.component.cmis.CMISSessionFacadeFactory.class, value)); return true;
-        case "basicPropertyBinding": ((CMISComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CMISComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((CMISComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "sessionfacadefactory": ((CMISComponent) target).setSessionFacadeFactory(property(camelContext, org.apache.camel.component.cmis.CMISSessionFacadeFactory.class, value)); return true;
-        case "basicpropertybinding": ((CMISComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CMISComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((CMISComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CMISComponent target = (CMISComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "sessionfacadefactory":
+        case "sessionFacadeFactory": target.setSessionFacadeFactory(property(camelContext, org.apache.camel.component.cmis.CMISSessionFacadeFactory.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 2f1296b..4f7840a 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
@@ -12,53 +12,36 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CMISEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "pageSize": ((CMISEndpoint) target).getSessionFacade().setPageSize(property(camelContext, int.class, value)); return true;
-        case "readContent": ((CMISEndpoint) target).getSessionFacade().setReadContent(property(camelContext, boolean.class, value)); return true;
-        case "readCount": ((CMISEndpoint) target).getSessionFacade().setReadCount(property(camelContext, int.class, value)); return true;
-        case "repositoryId": ((CMISEndpoint) target).getSessionFacade().setRepositoryId(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeErrorHandler": ((CMISEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "query": ((CMISEndpoint) target).getSessionFacade().setQuery(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionHandler": ((CMISEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((CMISEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((CMISEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "queryMode": ((CMISEndpoint) target).setQueryMode(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CMISEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "sessionFacadeFactory": ((CMISEndpoint) target).setSessionFacadeFactory(property(camelContext, org.apache.camel.component.cmis.CMISSessionFacadeFactory.class, value)); return true;
-        case "synchronous": ((CMISEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "password": ((CMISEndpoint) target).getSessionFacade().setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "username": ((CMISEndpoint) target).getSessionFacade().setUsername(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "pagesize": ((CMISEndpoint) target).getSessionFacade().setPageSize(property(camelContext, int.class, value)); return true;
-        case "readcontent": ((CMISEndpoint) target).getSessionFacade().setReadContent(property(camelContext, boolean.class, value)); return true;
-        case "readcount": ((CMISEndpoint) target).getSessionFacade().setReadCount(property(camelContext, int.class, value)); return true;
-        case "repositoryid": ((CMISEndpoint) target).getSessionFacade().setRepositoryId(property(camelContext, java.lang.String.class, value)); return true;
-        case "bridgeerrorhandler": ((CMISEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "query": ((CMISEndpoint) target).getSessionFacade().setQuery(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionhandler": ((CMISEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((CMISEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((CMISEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "querymode": ((CMISEndpoint) target).setQueryMode(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CMISEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "sessionfacadefactory": ((CMISEndpoint) target).setSessionFacadeFactory(property(camelContext, org.apache.camel.component.cmis.CMISSessionFacadeFactory.class, value)); return true;
-        case "synchronous": ((CMISEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "password": ((CMISEndpoint) target).getSessionFacade().setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "username": ((CMISEndpoint) target).getSessionFacade().setUsername(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CMISEndpoint target = (CMISEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "pagesize":
+        case "pageSize": target.getSessionFacade().setPageSize(property(camelContext, int.class, value)); return true;
+        case "readcontent":
+        case "readContent": target.getSessionFacade().setReadContent(property(camelContext, boolean.class, value)); return true;
+        case "readcount":
+        case "readCount": target.getSessionFacade().setReadCount(property(camelContext, int.class, value)); return true;
+        case "repositoryid":
+        case "repositoryId": target.getSessionFacade().setRepositoryId(property(camelContext, java.lang.String.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "query": target.getSessionFacade().setQuery(property(camelContext, java.lang.String.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "querymode":
+        case "queryMode": target.setQueryMode(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "sessionfacadefactory":
+        case "sessionFacadeFactory": target.setSessionFacadeFactory(property(camelContext, org.apache.camel.component.cmis.CMISSessionFacadeFactory.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "password": target.getSessionFacade().setPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "username": target.getSessionFacade().setUsername(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 efb61e7..5b97291 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
@@ -12,29 +12,16 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CoAPComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((CoAPComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CoAPComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((CoAPComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((CoAPComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CoAPComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((CoAPComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CoAPComponent target = (CoAPComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 b85aee8..8d343ce 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
@@ -12,55 +12,40 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CoAPEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "alias": ((CoAPEndpoint) target).setAlias(property(camelContext, java.lang.String.class, value)); return true;
-        case "cipherSuites": ((CoAPEndpoint) target).setCipherSuites(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientAuthentication": ((CoAPEndpoint) target).setClientAuthentication(property(camelContext, java.lang.String.class, value)); return true;
-        case "privateKey": ((CoAPEndpoint) target).setPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
-        case "pskStore": ((CoAPEndpoint) target).setPskStore(property(camelContext, org.eclipse.californium.scandium.dtls.pskstore.PskStore.class, value)); return true;
-        case "publicKey": ((CoAPEndpoint) target).setPublicKey(property(camelContext, java.security.PublicKey.class, value)); return true;
-        case "recommendedCipherSuitesOnly": ((CoAPEndpoint) target).setRecommendedCipherSuitesOnly(property(camelContext, boolean.class, value)); return true;
-        case "sslContextParameters": ((CoAPEndpoint) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "trustedRpkStore": ((CoAPEndpoint) target).setTrustedRpkStore(property(camelContext, org.eclipse.californium.scandium.dtls.rpkstore.TrustedRpkStore.class, value)); return true;
-        case "bridgeErrorHandler": ((CoAPEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "coapMethodRestrict": ((CoAPEndpoint) target).setCoapMethodRestrict(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionHandler": ((CoAPEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((CoAPEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazyStartProducer": ((CoAPEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CoAPEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CoAPEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "alias": ((CoAPEndpoint) target).setAlias(property(camelContext, java.lang.String.class, value)); return true;
-        case "ciphersuites": ((CoAPEndpoint) target).setCipherSuites(property(camelContext, java.lang.String.class, value)); return true;
-        case "clientauthentication": ((CoAPEndpoint) target).setClientAuthentication(property(camelContext, java.lang.String.class, value)); return true;
-        case "privatekey": ((CoAPEndpoint) target).setPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
-        case "pskstore": ((CoAPEndpoint) target).setPskStore(property(camelContext, org.eclipse.californium.scandium.dtls.pskstore.PskStore.class, value)); return true;
-        case "publickey": ((CoAPEndpoint) target).setPublicKey(property(camelContext, java.security.PublicKey.class, value)); return true;
-        case "recommendedciphersuitesonly": ((CoAPEndpoint) target).setRecommendedCipherSuitesOnly(property(camelContext, boolean.class, value)); return true;
-        case "sslcontextparameters": ((CoAPEndpoint) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "trustedrpkstore": ((CoAPEndpoint) target).setTrustedRpkStore(property(camelContext, org.eclipse.californium.scandium.dtls.rpkstore.TrustedRpkStore.class, value)); return true;
-        case "bridgeerrorhandler": ((CoAPEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "coapmethodrestrict": ((CoAPEndpoint) target).setCoapMethodRestrict(property(camelContext, java.lang.String.class, value)); return true;
-        case "exceptionhandler": ((CoAPEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((CoAPEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "lazystartproducer": ((CoAPEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CoAPEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CoAPEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CoAPEndpoint target = (CoAPEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "alias": target.setAlias(property(camelContext, java.lang.String.class, value)); return true;
+        case "ciphersuites":
+        case "cipherSuites": target.setCipherSuites(property(camelContext, java.lang.String.class, value)); return true;
+        case "clientauthentication":
+        case "clientAuthentication": target.setClientAuthentication(property(camelContext, java.lang.String.class, value)); return true;
+        case "privatekey":
+        case "privateKey": target.setPrivateKey(property(camelContext, java.security.PrivateKey.class, value)); return true;
+        case "pskstore":
+        case "pskStore": target.setPskStore(property(camelContext, org.eclipse.californium.scandium.dtls.pskstore.PskStore.class, value)); return true;
+        case "publickey":
+        case "publicKey": target.setPublicKey(property(camelContext, java.security.PublicKey.class, value)); return true;
+        case "recommendedciphersuitesonly":
+        case "recommendedCipherSuitesOnly": target.setRecommendedCipherSuitesOnly(property(camelContext, boolean.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        case "trustedrpkstore":
+        case "trustedRpkStore": target.setTrustedRpkStore(property(camelContext, org.eclipse.californium.scandium.dtls.rpkstore.TrustedRpkStore.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "coapmethodrestrict":
+        case "coapMethodRestrict": target.setCoapMethodRestrict(property(camelContext, java.lang.String.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 da8d683..66a3bb6 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
@@ -12,43 +12,29 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CometdComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "sslKeyPassword": ((CometdComponent) target).setSslKeyPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslPassword": ((CometdComponent) target).setSslPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslKeystore": ((CometdComponent) target).setSslKeystore(property(camelContext, java.lang.String.class, value)); return true;
-        case "securityPolicy": ((CometdComponent) target).setSecurityPolicy(property(camelContext, org.cometd.bayeux.server.SecurityPolicy.class, value)); return true;
-        case "extensions": ((CometdComponent) target).setExtensions(property(camelContext, java.util.List.class, value)); return true;
-        case "sslContextParameters": ((CometdComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "useGlobalSslContextParameters": ((CometdComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CometdComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CometdComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((CometdComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "sslkeypassword": ((CometdComponent) target).setSslKeyPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslpassword": ((CometdComponent) target).setSslPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslkeystore": ((CometdComponent) target).setSslKeystore(property(camelContext, java.lang.String.class, value)); return true;
-        case "securitypolicy": ((CometdComponent) target).setSecurityPolicy(property(camelContext, org.cometd.bayeux.server.SecurityPolicy.class, value)); return true;
-        case "extensions": ((CometdComponent) target).setExtensions(property(camelContext, java.util.List.class, value)); return true;
-        case "sslcontextparameters": ((CometdComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "useglobalsslcontextparameters": ((CometdComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CometdComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CometdComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((CometdComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CometdComponent target = (CometdComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "sslkeypassword":
+        case "sslKeyPassword": target.setSslKeyPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "sslpassword":
+        case "sslPassword": target.setSslPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "sslkeystore":
+        case "sslKeystore": target.setSslKeystore(property(camelContext, java.lang.String.class, value)); return true;
+        case "securitypolicy":
+        case "securityPolicy": target.setSecurityPolicy(property(camelContext, org.cometd.bayeux.server.SecurityPolicy.class, value)); return true;
+        case "extensions": target.setExtensions(property(camelContext, java.util.List.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        case "useglobalsslcontextparameters":
+        case "useGlobalSslContextParameters": target.setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 858d1b2..72d4ac4 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
@@ -12,59 +12,43 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class CometdEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "allowedOrigins": ((CometdEndpoint) target).setAllowedOrigins(property(camelContext, java.lang.String.class, value)); return true;
-        case "baseResource": ((CometdEndpoint) target).setBaseResource(property(camelContext, java.lang.String.class, value)); return true;
-        case "crossOriginFilterOn": ((CometdEndpoint) target).setCrossOriginFilterOn(property(camelContext, boolean.class, value)); return true;
-        case "filterPath": ((CometdEndpoint) target).setFilterPath(property(camelContext, java.lang.String.class, value)); return true;
-        case "interval": ((CometdEndpoint) target).setInterval(property(camelContext, int.class, value)); return true;
-        case "jsonCommented": ((CometdEndpoint) target).setJsonCommented(property(camelContext, boolean.class, value)); return true;
-        case "logLevel": ((CometdEndpoint) target).setLogLevel(property(camelContext, int.class, value)); return true;
-        case "maxInterval": ((CometdEndpoint) target).setMaxInterval(property(camelContext, int.class, value)); return true;
-        case "multiFrameInterval": ((CometdEndpoint) target).setMultiFrameInterval(property(camelContext, int.class, value)); return true;
-        case "timeout": ((CometdEndpoint) target).setTimeout(property(camelContext, int.class, value)); return true;
-        case "bridgeErrorHandler": ((CometdEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sessionHeadersEnabled": ((CometdEndpoint) target).setSessionHeadersEnabled(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((CometdEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((CometdEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "disconnectLocalSession": ((CometdEndpoint) target).setDisconnectLocalSession(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((CometdEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((CometdEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CometdEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "allowedorigins": ((CometdEndpoint) target).setAllowedOrigins(property(camelContext, java.lang.String.class, value)); return true;
-        case "baseresource": ((CometdEndpoint) target).setBaseResource(property(camelContext, java.lang.String.class, value)); return true;
-        case "crossoriginfilteron": ((CometdEndpoint) target).setCrossOriginFilterOn(property(camelContext, boolean.class, value)); return true;
-        case "filterpath": ((CometdEndpoint) target).setFilterPath(property(camelContext, java.lang.String.class, value)); return true;
-        case "interval": ((CometdEndpoint) target).setInterval(property(camelContext, int.class, value)); return true;
-        case "jsoncommented": ((CometdEndpoint) target).setJsonCommented(property(camelContext, boolean.class, value)); return true;
-        case "loglevel": ((CometdEndpoint) target).setLogLevel(property(camelContext, int.class, value)); return true;
-        case "maxinterval": ((CometdEndpoint) target).setMaxInterval(property(camelContext, int.class, value)); return true;
-        case "multiframeinterval": ((CometdEndpoint) target).setMultiFrameInterval(property(camelContext, int.class, value)); return true;
-        case "timeout": ((CometdEndpoint) target).setTimeout(property(camelContext, int.class, value)); return true;
-        case "bridgeerrorhandler": ((CometdEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "sessionheadersenabled": ((CometdEndpoint) target).setSessionHeadersEnabled(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((CometdEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((CometdEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "disconnectlocalsession": ((CometdEndpoint) target).setDisconnectLocalSession(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((CometdEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((CometdEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "synchronous": ((CometdEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        CometdEndpoint target = (CometdEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "allowedorigins":
+        case "allowedOrigins": target.setAllowedOrigins(property(camelContext, java.lang.String.class, value)); return true;
+        case "baseresource":
+        case "baseResource": target.setBaseResource(property(camelContext, java.lang.String.class, value)); return true;
+        case "crossoriginfilteron":
+        case "crossOriginFilterOn": target.setCrossOriginFilterOn(property(camelContext, boolean.class, value)); return true;
+        case "filterpath":
+        case "filterPath": target.setFilterPath(property(camelContext, java.lang.String.class, value)); return true;
+        case "interval": target.setInterval(property(camelContext, int.class, value)); return true;
+        case "jsoncommented":
+        case "jsonCommented": target.setJsonCommented(property(camelContext, boolean.class, value)); return true;
+        case "loglevel":
+        case "logLevel": target.setLogLevel(property(camelContext, int.class, value)); return true;
+        case "maxinterval":
+        case "maxInterval": target.setMaxInterval(property(camelContext, int.class, value)); return true;
+        case "multiframeinterval":
+        case "multiFrameInterval": target.setMultiFrameInterval(property(camelContext, int.class, value)); return true;
+        case "timeout": target.setTimeout(property(camelContext, int.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "sessionheadersenabled":
+        case "sessionHeadersEnabled": target.setSessionHeadersEnabled(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "disconnectlocalsession":
+        case "disconnectLocalSession": target.setDisconnectLocalSession(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 c1df25f..1a908b8 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
@@ -12,45 +12,28 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ConsulComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "url": ((ConsulComponent) target).setUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "datacenter": ((ConsulComponent) target).setDatacenter(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslContextParameters": ((ConsulComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "useGlobalSslContextParameters": ((ConsulComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "aclToken": ((ConsulComponent) target).setAclToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "userName": ((ConsulComponent) target).setUserName(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((ConsulComponent) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "configuration": ((ConsulComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.consul.ConsulConfiguration.class, value)); return true;
-        case "basicPropertyBinding": ((ConsulComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ConsulComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeErrorHandler": ((ConsulComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "url": ((ConsulComponent) target).setUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "datacenter": ((ConsulComponent) target).setDatacenter(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslcontextparameters": ((ConsulComponent) target).setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "useglobalsslcontextparameters": ((ConsulComponent) target).setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
-        case "acltoken": ((ConsulComponent) target).setAclToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "username": ((ConsulComponent) target).setUserName(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((ConsulComponent) target).setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "configuration": ((ConsulComponent) target).setConfiguration(property(camelContext, org.apache.camel.component.consul.ConsulConfiguration.class, value)); return true;
-        case "basicpropertybinding": ((ConsulComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ConsulComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "bridgeerrorhandler": ((ConsulComponent) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ConsulComponent target = (ConsulComponent) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "url": target.setUrl(property(camelContext, java.lang.String.class, value)); return true;
+        case "datacenter": target.setDatacenter(property(camelContext, java.lang.String.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        case "useglobalsslcontextparameters":
+        case "useGlobalSslContextParameters": target.setUseGlobalSslContextParameters(property(camelContext, boolean.class, value)); return true;
+        case "acltoken":
+        case "aclToken": target.setAclToken(property(camelContext, java.lang.String.class, value)); return true;
+        case "username":
+        case "userName": target.setUserName(property(camelContext, java.lang.String.class, value)); return true;
+        case "password": target.setPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "configuration": target.setConfiguration(property(camelContext, org.apache.camel.component.consul.ConsulConfiguration.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        default: return false;
         }
     }
 
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 971f1d9..e86d3d5 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
@@ -12,77 +12,56 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ConsulEndpointConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "connectTimeoutMillis": ((ConsulEndpoint) target).getConfiguration().setConnectTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
-        case "consulClient": ((ConsulEndpoint) target).getConfiguration().setConsulClient(property(camelContext, com.orbitz.consul.Consul.class, value)); return true;
-        case "key": ((ConsulEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "pingInstance": ((ConsulEndpoint) target).getConfiguration().setPingInstance(property(camelContext, boolean.class, value)); return true;
-        case "readTimeoutMillis": ((ConsulEndpoint) target).getConfiguration().setReadTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
-        case "tags": ((ConsulEndpoint) target).getConfiguration().setTags(property(camelContext, java.lang.String.class, value)); return true;
-        case "url": ((ConsulEndpoint) target).getConfiguration().setUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "writeTimeoutMillis": ((ConsulEndpoint) target).getConfiguration().setWriteTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
-        case "bridgeErrorHandler": ((ConsulEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionHandler": ((ConsulEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangePattern": ((ConsulEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "action": ((ConsulEndpoint) target).getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazyStartProducer": ((ConsulEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "valueAsString": ((ConsulEndpoint) target).getConfiguration().setValueAsString(property(camelContext, boolean.class, value)); return true;
-        case "basicPropertyBinding": ((ConsulEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "consistencyMode": ((ConsulEndpoint) target).getConfiguration().setConsistencyMode(property(camelContext, com.orbitz.consul.option.ConsistencyMode.class, value)); return true;
-        case "datacenter": ((ConsulEndpoint) target).getConfiguration().setDatacenter(property(camelContext, java.lang.String.class, value)); return true;
-        case "nearNode": ((ConsulEndpoint) target).getConfiguration().setNearNode(property(camelContext, java.lang.String.class, value)); return true;
-        case "nodeMeta": ((ConsulEndpoint) target).getConfiguration().setNodeMeta(property(camelContext, java.util.List.class, value)); return true;
-        case "synchronous": ((ConsulEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "blockSeconds": ((ConsulEndpoint) target).getConfiguration().setBlockSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "firstIndex": ((ConsulEndpoint) target).getConfiguration().setFirstIndex(property(camelContext, java.math.BigInteger.class, value)); return true;
-        case "recursive": ((ConsulEndpoint) target).getConfiguration().setRecursive(property(camelContext, boolean.class, value)); return true;
-        case "aclToken": ((ConsulEndpoint) target).getConfiguration().setAclToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((ConsulEndpoint) target).getConfiguration().setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslContextParameters": ((ConsulEndpoint) target).getConfiguration().setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "userName": ((ConsulEndpoint) target).getConfiguration().setUserName(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "connecttimeoutmillis": ((ConsulEndpoint) target).getConfiguration().setConnectTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
-        case "consulclient": ((ConsulEndpoint) target).getConfiguration().setConsulClient(property(camelContext, com.orbitz.consul.Consul.class, value)); return true;
-        case "key": ((ConsulEndpoint) target).getConfiguration().setKey(property(camelContext, java.lang.String.class, value)); return true;
-        case "pinginstance": ((ConsulEndpoint) target).getConfiguration().setPingInstance(property(camelContext, boolean.class, value)); return true;
-        case "readtimeoutmillis": ((ConsulEndpoint) target).getConfiguration().setReadTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
-        case "tags": ((ConsulEndpoint) target).getConfiguration().setTags(property(camelContext, java.lang.String.class, value)); return true;
-        case "url": ((ConsulEndpoint) target).getConfiguration().setUrl(property(camelContext, java.lang.String.class, value)); return true;
-        case "writetimeoutmillis": ((ConsulEndpoint) target).getConfiguration().setWriteTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
-        case "bridgeerrorhandler": ((ConsulEndpoint) target).setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
-        case "exceptionhandler": ((ConsulEndpoint) target).setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
-        case "exchangepattern": ((ConsulEndpoint) target).setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
-        case "action": ((ConsulEndpoint) target).getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
-        case "lazystartproducer": ((ConsulEndpoint) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-        case "valueasstring": ((ConsulEndpoint) target).getConfiguration().setValueAsString(property(camelContext, boolean.class, value)); return true;
-        case "basicpropertybinding": ((ConsulEndpoint) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "consistencymode": ((ConsulEndpoint) target).getConfiguration().setConsistencyMode(property(camelContext, com.orbitz.consul.option.ConsistencyMode.class, value)); return true;
-        case "datacenter": ((ConsulEndpoint) target).getConfiguration().setDatacenter(property(camelContext, java.lang.String.class, value)); return true;
-        case "nearnode": ((ConsulEndpoint) target).getConfiguration().setNearNode(property(camelContext, java.lang.String.class, value)); return true;
-        case "nodemeta": ((ConsulEndpoint) target).getConfiguration().setNodeMeta(property(camelContext, java.util.List.class, value)); return true;
-        case "synchronous": ((ConsulEndpoint) target).setSynchronous(property(camelContext, boolean.class, value)); return true;
-        case "blockseconds": ((ConsulEndpoint) target).getConfiguration().setBlockSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
-        case "firstindex": ((ConsulEndpoint) target).getConfiguration().setFirstIndex(property(camelContext, java.math.BigInteger.class, value)); return true;
-        case "recursive": ((ConsulEndpoint) target).getConfiguration().setRecursive(property(camelContext, boolean.class, value)); return true;
-        case "acltoken": ((ConsulEndpoint) target).getConfiguration().setAclToken(property(camelContext, java.lang.String.class, value)); return true;
-        case "password": ((ConsulEndpoint) target).getConfiguration().setPassword(property(camelContext, java.lang.String.class, value)); return true;
-        case "sslcontextparameters": ((ConsulEndpoint) target).getConfiguration().setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
-        case "username": ((ConsulEndpoint) target).getConfiguration().setUserName(property(camelContext, java.lang.String.class, value)); return true;
-            default: return false;
+    public boolean configure(CamelContext camelContext, Object obj, String name, Object value, boolean ignoreCase) {
+        ConsulEndpoint target = (ConsulEndpoint) obj;
+        switch (ignoreCase ? name.toLowerCase() : name) {
+        case "connecttimeoutmillis":
+        case "connectTimeoutMillis": target.getConfiguration().setConnectTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
+        case "consulclient":
+        case "consulClient": target.getConfiguration().setConsulClient(property(camelContext, com.orbitz.consul.Consul.class, value)); return true;
+        case "key": target.getConfiguration().setKey(property(camelContext, java.lang.String.class, value)); return true;
+        case "pinginstance":
+        case "pingInstance": target.getConfiguration().setPingInstance(property(camelContext, boolean.class, value)); return true;
+        case "readtimeoutmillis":
+        case "readTimeoutMillis": target.getConfiguration().setReadTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
+        case "tags": target.getConfiguration().setTags(property(camelContext, java.lang.String.class, value)); return true;
+        case "url": target.getConfiguration().setUrl(property(camelContext, java.lang.String.class, value)); return true;
+        case "writetimeoutmillis":
+        case "writeTimeoutMillis": target.getConfiguration().setWriteTimeoutMillis(property(camelContext, java.lang.Long.class, value)); return true;
+        case "bridgeerrorhandler":
+        case "bridgeErrorHandler": target.setBridgeErrorHandler(property(camelContext, boolean.class, value)); return true;
+        case "exceptionhandler":
+        case "exceptionHandler": target.setExceptionHandler(property(camelContext, org.apache.camel.spi.ExceptionHandler.class, value)); return true;
+        case "exchangepattern":
+        case "exchangePattern": target.setExchangePattern(property(camelContext, org.apache.camel.ExchangePattern.class, value)); return true;
+        case "action": target.getConfiguration().setAction(property(camelContext, java.lang.String.class, value)); return true;
+        case "lazystartproducer":
+        case "lazyStartProducer": target.setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
+        case "valueasstring":
+        case "valueAsString": target.getConfiguration().setValueAsString(property(camelContext, boolean.class, value)); return true;
+        case "basicpropertybinding":
+        case "basicPropertyBinding": target.setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
+        case "consistencymode":
+        case "consistencyMode": target.getConfiguration().setConsistencyMode(property(camelContext, com.orbitz.consul.option.ConsistencyMode.class, value)); return true;
+        case "datacenter": target.getConfiguration().setDatacenter(property(camelContext, java.lang.String.class, value)); return true;
+        case "nearnode":
+        case "nearNode": target.getConfiguration().setNearNode(property(camelContext, java.lang.String.class, value)); return true;
+        case "nodemeta":
+        case "nodeMeta": target.getConfiguration().setNodeMeta(property(camelContext, java.util.List.class, value)); return true;
+        case "synchronous": target.setSynchronous(property(camelContext, boolean.class, value)); return true;
+        case "blockseconds":
+        case "blockSeconds": target.getConfiguration().setBlockSeconds(property(camelContext, java.lang.Integer.class, value)); return true;
+        case "firstindex":
+        case "firstIndex": target.getConfiguration().setFirstIndex(property(camelContext, java.math.BigInteger.class, value)); return true;
+        case "recursive": target.getConfiguration().setRecursive(property(camelContext, boolean.class, value)); return true;
+        case "acltoken":
+        case "aclToken": target.getConfiguration().setAclToken(property(camelContext, java.lang.String.class, value)); return true;
+        case "password": target.getConfiguration().setPassword(property(camelContext, java.lang.String.class, value)); return true;
+        case "sslcontextparameters":
+        case "sslContextParameters": target.getConfiguration().setSslContextParameters(property(camelContext, org.apache.camel.support.jsse.SSLContextParameters.class, value)); return true;
+        case "username":
+        case "userName": target.getConfiguration().setUserName(property(camelContext, java.lang.String.class, value)); return true;
+        default: return false;
         }
     }
 
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 c47f0cd..5c9f63a 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
@@ -12,27 +12,14 @@ import org.apache.camel.support.component.PropertyConfigurerSupport;
 public class ControlBusComponentConfigurer extends PropertyConfigurerSupport implements GeneratedPropertyConfigurer {
 
     @Override
-    public boolean configure(CamelContext camelContext, Object target, String name, Object value, boolean ignoreCase) {
-        if (ignoreCase) {
-            return doConfigureIgnoreCase(camelContext, target, name, value);
-        } else {
-            return doConfigure(camelContext, target, name, value);
-        }
-    }
-
-    private static boolean doConfigure(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name) {
-        case "basicPropertyBinding": ((ControlBusComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazyStartProducer": ((ControlBusComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
-            default: return false;
-        }
-    }
-
-    private static boolean doConfigureIgnoreCase(CamelContext camelContext, Object target, String name, Object value) {
-        switch (name.toLowerCase()) {
-        case "basicpropertybinding": ((ControlBusComponent) target).setBasicPropertyBinding(property(camelContext, boolean.class, value)); return true;
-        case "lazystartproducer": ((ControlBusComponent) target).setLazyStartProducer(property(camelContext, boolean.class, value)); return true;
... 35413 lines suppressed ...