You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by zr...@apache.org on 2020/02/12 14:46:32 UTC

[camel] branch master updated: Add inclusion of Spring Boot starter documentation

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

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


The following commit(s) were added to refs/heads/master by this push:
     new d308dfd  Add inclusion of Spring Boot starter documentation
d308dfd is described below

commit d308dfd8b2c3410838abc9c879030786b89d1333
Author: Zoran Regvart <zr...@apache.org>
AuthorDate: Wed Feb 12 15:45:27 2020 +0100

    Add inclusion of Spring Boot starter documentation
    
    This adds the `include::` directives needed to incorporate the
    documentation from the Camel Spring Boot starters.
---
 components/camel-activemq/src/main/docs/activemq-component.adoc        | 2 ++
 components/camel-ahc-ws/src/main/docs/ahc-ws-component.adoc            | 2 ++
 components/camel-ahc/src/main/docs/ahc-component.adoc                  | 2 ++
 components/camel-amqp/src/main/docs/amqp-component.adoc                | 2 ++
 components/camel-any23/src/main/docs/any23-dataformat.adoc             | 2 ++
 components/camel-apns/src/main/docs/apns-component.adoc                | 2 ++
 .../camel-as2/camel-as2-component/src/main/docs/as2-component.adoc     | 2 ++
 components/camel-asn1/src/main/docs/asn1-dataformat.adoc               | 2 ++
 components/camel-asterisk/src/main/docs/asterisk-component.adoc        | 2 ++
 components/camel-atmos/src/main/docs/atmos-component.adoc              | 2 ++
 .../src/main/docs/atmosphere-websocket-component.adoc                  | 2 ++
 components/camel-atom/src/main/docs/atom-component.adoc                | 2 ++
 components/camel-atomix/src/main/docs/atomix-map-component.adoc        | 2 ++
 components/camel-atomix/src/main/docs/atomix-messaging-component.adoc  | 2 ++
 components/camel-atomix/src/main/docs/atomix-multimap-component.adoc   | 2 ++
 components/camel-atomix/src/main/docs/atomix-queue-component.adoc      | 2 ++
 components/camel-atomix/src/main/docs/atomix-set-component.adoc        | 2 ++
 components/camel-atomix/src/main/docs/atomix-value-component.adoc      | 2 ++
 components/camel-avro/src/main/docs/avro-component.adoc                | 2 ++
 components/camel-avro/src/main/docs/avro-dataformat.adoc               | 2 ++
 components/camel-aws-cw/src/main/docs/aws-cw-component.adoc            | 2 ++
 components/camel-aws-ddb/src/main/docs/aws-ddb-component.adoc          | 2 ++
 components/camel-aws-ddb/src/main/docs/aws-ddbstream-component.adoc    | 2 ++
 components/camel-aws-ec2/src/main/docs/aws-ec2-component.adoc          | 2 ++
 components/camel-aws-ecs/src/main/docs/aws-ecs-component.adoc          | 2 ++
 components/camel-aws-eks/src/main/docs/aws-eks-component.adoc          | 2 ++
 components/camel-aws-iam/src/main/docs/aws-iam-component.adoc          | 2 ++
 components/camel-aws-kinesis/src/main/docs/aws-kinesis-component.adoc  | 2 ++
 .../src/main/docs/aws-kinesis-firehose-component.adoc                  | 2 ++
 components/camel-aws-kms/src/main/docs/aws-kms-component.adoc          | 2 ++
 components/camel-aws-lambda/src/main/docs/aws-lambda-component.adoc    | 2 ++
 components/camel-aws-mq/src/main/docs/aws-mq-component.adoc            | 2 ++
 components/camel-aws-msk/src/main/docs/aws-msk-component.adoc          | 2 ++
 components/camel-aws-s3/src/main/docs/aws-s3-component.adoc            | 2 ++
 components/camel-aws-sdb/src/main/docs/aws-sdb-component.adoc          | 2 ++
 components/camel-aws-ses/src/main/docs/aws-ses-component.adoc          | 2 ++
 components/camel-aws-sns/src/main/docs/aws-sns-component.adoc          | 2 ++
 components/camel-aws-sqs/src/main/docs/aws-sqs-component.adoc          | 2 ++
 components/camel-aws-swf/src/main/docs/aws-swf-component.adoc          | 2 ++
 .../camel-aws-translate/src/main/docs/aws-translate-component.adoc     | 2 ++
 components/camel-aws2-cw/src/main/docs/aws2-cw-component.adoc          | 2 ++
 components/camel-aws2-ddb/src/main/docs/aws2-ddb-component.adoc        | 2 ++
 components/camel-aws2-ddb/src/main/docs/aws2-ddbstream-component.adoc  | 2 ++
 components/camel-aws2-ec2/src/main/docs/aws2-ec2-component.adoc        | 2 ++
 components/camel-aws2-ecs/src/main/docs/aws2-ecs-component.adoc        | 2 ++
 components/camel-aws2-eks/src/main/docs/aws2-eks-component.adoc        | 2 ++
 components/camel-aws2-iam/src/main/docs/aws2-iam-component.adoc        | 2 ++
 components/camel-aws2-kms/src/main/docs/aws2-kms-component.adoc        | 2 ++
 components/camel-aws2-mq/src/main/docs/aws2-mq-component.adoc          | 2 ++
 components/camel-aws2-msk/src/main/docs/aws2-msk-component.adoc        | 2 ++
 .../camel-aws2-translate/src/main/docs/aws2-translate-component.adoc   | 2 ++
 components/camel-azure/src/main/docs/azure-blob-component.adoc         | 2 ++
 components/camel-azure/src/main/docs/azure-queue-component.adoc        | 2 ++
 components/camel-azure/src/main/docs/azure.adoc                        | 2 ++
 components/camel-barcode/src/main/docs/barcode-dataformat.adoc         | 2 ++
 components/camel-base64/src/main/docs/base64-dataformat.adoc           | 2 ++
 .../camel-bean-validator/src/main/docs/bean-validator-component.adoc   | 2 ++
 components/camel-bean/src/main/docs/bean-component.adoc                | 2 ++
 components/camel-bean/src/main/docs/bean-language.adoc                 | 2 ++
 components/camel-bean/src/main/docs/class-component.adoc               | 2 ++
 components/camel-beanio/src/main/docs/beanio-dataformat.adoc           | 2 ++
 components/camel-beanstalk/src/main/docs/beanstalk-component.adoc      | 2 ++
 components/camel-bindy/src/main/docs/bindy-dataformat.adoc             | 2 ++
 components/camel-bonita/src/main/docs/bonita-component.adoc            | 2 ++
 .../camel-box/camel-box-component/src/main/docs/box-component.adoc     | 3 +++
 components/camel-braintree/src/main/docs/braintree-component.adoc      | 2 ++
 components/camel-browse/src/main/docs/browse-component.adoc            | 2 ++
 components/camel-caffeine/src/main/docs/caffeine-cache-component.adoc  | 2 ++
 .../camel-caffeine/src/main/docs/caffeine-loadcache-component.adoc     | 2 ++
 components/camel-cassandraql/src/main/docs/cql-component.adoc          | 2 ++
 components/camel-cbor/src/main/docs/cbor-dataformat.adoc               | 2 ++
 components/camel-chatscript/src/main/docs/chatscript-component.adoc    | 2 ++
 components/camel-chunk/src/main/docs/chunk-component.adoc              | 2 ++
 components/camel-cm-sms/src/main/docs/cm-sms-component.adoc            | 2 ++
 components/camel-cmis/src/main/docs/cmis-component.adoc                | 2 ++
 components/camel-coap/src/main/docs/coap-component.adoc                | 2 ++
 components/camel-cometd/src/main/docs/cometd-component.adoc            | 2 ++
 components/camel-consul/src/main/docs/consul-component.adoc            | 2 ++
 components/camel-controlbus/src/main/docs/controlbus-component.adoc    | 2 ++
 components/camel-corda/src/main/docs/corda-component.adoc              | 2 ++
 components/camel-couchbase/src/main/docs/couchbase-component.adoc      | 2 ++
 components/camel-couchdb/src/main/docs/couchdb-component.adoc          | 2 ++
 components/camel-cron/src/main/docs/cron-component.adoc                | 2 ++
 components/camel-crypto-cms/src/main/docs/crypto-cms-component.adoc    | 2 ++
 components/camel-crypto/src/main/docs/crypto-component.adoc            | 2 ++
 components/camel-crypto/src/main/docs/crypto-dataformat.adoc           | 2 ++
 components/camel-crypto/src/main/docs/pgp-dataformat.adoc              | 2 ++
 components/camel-csv/src/main/docs/csv-dataformat.adoc                 | 2 ++
 components/camel-cxf/src/main/docs/cxf-component.adoc                  | 2 ++
 components/camel-cxf/src/main/docs/cxfrs-component.adoc                | 2 ++
 components/camel-dataformat/src/main/docs/dataformat-component.adoc    | 2 ++
 components/camel-dataset/src/main/docs/dataset-component.adoc          | 2 ++
 components/camel-dataset/src/main/docs/dataset-test-component.adoc     | 2 ++
 .../src/main/docs/debezium-mongodb-component.adoc                      | 2 ++
 .../camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc   | 2 ++
 .../src/main/docs/debezium-postgres-component.adoc                     | 2 ++
 .../src/main/docs/debezium-sqlserver-component.adoc                    | 2 ++
 .../camel-digitalocean/src/main/docs/digitalocean-component.adoc       | 2 ++
 components/camel-direct/src/main/docs/direct-component.adoc            | 2 ++
 components/camel-directvm/src/main/docs/direct-vm-component.adoc       | 2 ++
 components/camel-disruptor/src/main/docs/disruptor-component.adoc      | 2 ++
 components/camel-dns/src/main/docs/dns-component.adoc                  | 2 ++
 components/camel-docker/src/main/docs/docker-component.adoc            | 2 ++
 components/camel-dozer/src/main/docs/dozer-component.adoc              | 2 ++
 components/camel-drill/src/main/docs/drill-component.adoc              | 2 ++
 components/camel-dropbox/src/main/docs/dropbox-component.adoc          | 2 ++
 components/camel-ehcache/src/main/docs/ehcache-component.adoc          | 2 ++
 .../src/main/docs/elasticsearch-rest-component.adoc                    | 2 ++
 components/camel-elsql/src/main/docs/elsql-component.adoc              | 2 ++
 components/camel-elytron/src/main/docs/elytron-component.adoc          | 2 ++
 components/camel-etcd/src/main/docs/etcd-keys-component.adoc           | 3 ++-
 components/camel-etcd/src/main/docs/etcd-stats-component.adoc          | 3 ++-
 components/camel-etcd/src/main/docs/etcd-watch-component.adoc          | 3 ++-
 components/camel-exec/src/main/docs/exec-component.adoc                | 2 ++
 components/camel-facebook/src/main/docs/facebook-component.adoc        | 2 ++
 components/camel-fastjson/src/main/docs/json-fastjson-dataformat.adoc  | 2 ++
 .../camel-fhir/camel-fhir-component/src/main/docs/fhir-component.adoc  | 3 +++
 components/camel-file-watch/src/main/docs/file-watch-component.adoc    | 2 ++
 components/camel-file/src/main/docs/file-component.adoc                | 2 ++
 components/camel-flatpack/src/main/docs/flatpack-component.adoc        | 2 ++
 components/camel-flatpack/src/main/docs/flatpack-dataformat.adoc       | 2 ++
 components/camel-flink/src/main/docs/flink-component.adoc              | 2 ++
 components/camel-fop/src/main/docs/fop-component.adoc                  | 2 ++
 components/camel-freemarker/src/main/docs/freemarker-component.adoc    | 2 ++
 components/camel-ftp/src/main/docs/ftp-component.adoc                  | 2 ++
 components/camel-ftp/src/main/docs/ftps-component.adoc                 | 2 ++
 components/camel-ftp/src/main/docs/sftp-component.adoc                 | 2 ++
 components/camel-ganglia/src/main/docs/ganglia-component.adoc          | 2 ++
 components/camel-geocoder/src/main/docs/geocoder-component.adoc        | 2 ++
 components/camel-git/src/main/docs/git-component.adoc                  | 2 ++
 components/camel-github/src/main/docs/github-component.adoc            | 2 ++
 .../camel-google-bigquery/src/main/docs/google-bigquery-component.adoc | 2 ++
 .../src/main/docs/google-bigquery-sql-component.adoc                   | 2 ++
 .../camel-google-calendar/src/main/docs/google-calendar-component.adoc | 2 ++
 .../src/main/docs/google-calendar-stream-component.adoc                | 2 ++
 .../camel-google-drive/src/main/docs/google-drive-component.adoc       | 2 ++
 components/camel-google-mail/src/main/docs/google-mail-component.adoc  | 2 ++
 .../camel-google-mail/src/main/docs/google-mail-stream-component.adoc  | 2 ++
 .../camel-google-pubsub/src/main/docs/google-pubsub-component.adoc     | 2 ++
 .../camel-google-sheets/src/main/docs/google-sheets-component.adoc     | 2 ++
 .../src/main/docs/google-sheets-stream-component.adoc                  | 2 ++
 components/camel-gora/src/main/docs/gora-component.adoc                | 2 ++
 components/camel-graphql/src/main/docs/graphql-component.adoc          | 2 ++
 components/camel-grok/src/main/docs/grok-dataformat.adoc               | 2 ++
 components/camel-groovy/src/main/docs/groovy-language.adoc             | 2 ++
 components/camel-grpc/src/main/docs/grpc-component.adoc                | 2 ++
 components/camel-gson/src/main/docs/json-gson-dataformat.adoc          | 2 ++
 .../camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc   | 2 ++
 .../camel-hazelcast/src/main/docs/hazelcast-atomicvalue-component.adoc | 2 ++
 .../camel-hazelcast/src/main/docs/hazelcast-instance-component.adoc    | 2 ++
 components/camel-hazelcast/src/main/docs/hazelcast-list-component.adoc | 2 ++
 components/camel-hazelcast/src/main/docs/hazelcast-map-component.adoc  | 2 ++
 .../camel-hazelcast/src/main/docs/hazelcast-multimap-component.adoc    | 2 ++
 .../camel-hazelcast/src/main/docs/hazelcast-queue-component.adoc       | 2 ++
 .../src/main/docs/hazelcast-replicatedmap-component.adoc               | 2 ++
 .../camel-hazelcast/src/main/docs/hazelcast-ringbuffer-component.adoc  | 2 ++
 components/camel-hazelcast/src/main/docs/hazelcast-seda-component.adoc | 2 ++
 components/camel-hazelcast/src/main/docs/hazelcast-set-component.adoc  | 2 ++
 .../camel-hazelcast/src/main/docs/hazelcast-topic-component.adoc       | 2 ++
 components/camel-hazelcast/src/main/docs/hazelcast.adoc                | 2 ++
 components/camel-hbase/src/main/docs/hbase-component.adoc              | 2 ++
 components/camel-hdfs/src/main/docs/hdfs-component.adoc                | 2 ++
 components/camel-hipchat/src/main/docs/hipchat-component.adoc          | 2 ++
 components/camel-hl7/src/main/docs/hl7-dataformat.adoc                 | 2 ++
 components/camel-hl7/src/main/docs/hl7terser-language.adoc             | 2 ++
 components/camel-http/src/main/docs/http-component.adoc                | 2 ++
 components/camel-hystrix/src/main/docs/hystrix.adoc                    | 2 ++
 components/camel-ical/src/main/docs/ical-dataformat.adoc               | 2 ++
 components/camel-iec60870/src/main/docs/iec60870-client-component.adoc | 2 ++
 components/camel-iec60870/src/main/docs/iec60870-server-component.adoc | 2 ++
 components/camel-ignite/src/main/docs/ignite-cache-component.adoc      | 2 ++
 components/camel-ignite/src/main/docs/ignite-compute-component.adoc    | 2 ++
 components/camel-ignite/src/main/docs/ignite-events-component.adoc     | 2 ++
 components/camel-ignite/src/main/docs/ignite-idgen-component.adoc      | 2 ++
 components/camel-ignite/src/main/docs/ignite-messaging-component.adoc  | 2 ++
 components/camel-ignite/src/main/docs/ignite-queue-component.adoc      | 2 ++
 components/camel-ignite/src/main/docs/ignite-set-component.adoc        | 2 ++
 components/camel-ignite/src/main/docs/ignite.adoc                      | 2 ++
 components/camel-infinispan/src/main/docs/infinispan-component.adoc    | 2 ++
 components/camel-influxdb/src/main/docs/influxdb-component.adoc        | 2 ++
 components/camel-iota/src/main/docs/iota-component.adoc                | 2 ++
 components/camel-ipfs/src/main/docs/ipfs-component.adoc                | 2 ++
 components/camel-irc/src/main/docs/irc-component.adoc                  | 2 ++
 components/camel-ironmq/src/main/docs/ironmq-component.adoc            | 2 ++
 components/camel-jackson/src/main/docs/json-jackson-dataformat.adoc    | 2 ++
 components/camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc   | 2 ++
 components/camel-jaxb/src/main/docs/jaxb-dataformat.adoc               | 2 ++
 components/camel-jbpm/src/main/docs/jbpm-component.adoc                | 2 ++
 components/camel-jcache/src/main/docs/jcache-component.adoc            | 2 ++
 components/camel-jclouds/src/main/docs/jclouds-component.adoc          | 2 ++
 components/camel-jcr/src/main/docs/jcr-component.adoc                  | 2 ++
 components/camel-jdbc/src/main/docs/jdbc-component.adoc                | 2 ++
 components/camel-jetty/src/main/docs/jetty-component.adoc              | 2 ++
 .../camel-jgroups-raft/src/main/docs/jgroups-raft-component.adoc       | 2 ++
 components/camel-jgroups/src/main/docs/jgroups-component.adoc          | 2 ++
 components/camel-jing/src/main/docs/jing-component.adoc                | 2 ++
 components/camel-jira/src/main/docs/jira-component.adoc                | 2 ++
 components/camel-jms/src/main/docs/jms-component.adoc                  | 2 ++
 components/camel-jmx/src/main/docs/jmx-component.adoc                  | 2 ++
 components/camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc    | 2 ++
 components/camel-jolt/src/main/docs/jolt-component.adoc                | 2 ++
 components/camel-jooq/src/main/docs/jooq-component.adoc                | 2 ++
 components/camel-jpa/src/main/docs/jpa-component.adoc                  | 2 ++
 components/camel-jsch/src/main/docs/scp-component.adoc                 | 2 ++
 components/camel-jslt/src/main/docs/jslt-component.adoc                | 2 ++
 .../camel-json-validator/src/main/docs/json-validator-component.adoc   | 2 ++
 components/camel-jsonapi/src/main/docs/jsonApi-dataformat.adoc         | 2 ++
 components/camel-jsonpath/src/main/docs/jsonpath-language.adoc         | 2 ++
 components/camel-jt400/src/main/docs/jt400-component.adoc              | 2 ++
 components/camel-kafka/src/main/docs/kafka-component.adoc              | 2 ++
 .../src/main/docs/kubernetes-config-maps-component.adoc                | 2 ++
 .../src/main/docs/kubernetes-deployments-component.adoc                | 2 ++
 .../camel-kubernetes/src/main/docs/kubernetes-hpa-component.adoc       | 2 ++
 .../camel-kubernetes/src/main/docs/kubernetes-job-component.adoc       | 2 ++
 .../src/main/docs/kubernetes-namespaces-component.adoc                 | 2 ++
 .../camel-kubernetes/src/main/docs/kubernetes-nodes-component.adoc     | 2 ++
 .../src/main/docs/kubernetes-persistent-volumes-claims-component.adoc  | 2 ++
 .../src/main/docs/kubernetes-persistent-volumes-component.adoc         | 2 ++
 .../camel-kubernetes/src/main/docs/kubernetes-pods-component.adoc      | 2 ++
 .../src/main/docs/kubernetes-replication-controllers-component.adoc    | 2 ++
 .../src/main/docs/kubernetes-resources-quota-component.adoc            | 2 ++
 .../camel-kubernetes/src/main/docs/kubernetes-secrets-component.adoc   | 2 ++
 .../src/main/docs/kubernetes-service-accounts-component.adoc           | 2 ++
 .../camel-kubernetes/src/main/docs/kubernetes-services-component.adoc  | 2 ++
 components/camel-kubernetes/src/main/docs/kubernetes.adoc              | 2 ++
 .../src/main/docs/openshift-build-configs-component.adoc               | 2 ++
 .../camel-kubernetes/src/main/docs/openshift-builds-component.adoc     | 2 ++
 components/camel-kudu/src/main/docs/kudu-component.adoc                | 2 ++
 components/camel-language/src/main/docs/language-component.adoc        | 2 ++
 components/camel-ldap/src/main/docs/ldap-component.adoc                | 2 ++
 components/camel-ldif/src/main/docs/ldif-component.adoc                | 2 ++
 components/camel-log/src/main/docs/log-component.adoc                  | 2 ++
 components/camel-lra/src/main/docs/lra.adoc                            | 2 ++
 components/camel-lucene/src/main/docs/lucene-component.adoc            | 2 ++
 components/camel-lumberjack/src/main/docs/lumberjack-component.adoc    | 2 ++
 components/camel-lzf/src/main/docs/lzf-dataformat.adoc                 | 2 ++
 components/camel-mail/src/main/docs/mail-component.adoc                | 2 ++
 components/camel-mail/src/main/docs/mime-multipart-dataformat.adoc     | 2 ++
 components/camel-master/src/main/docs/master-component.adoc            | 2 ++
 components/camel-metrics/src/main/docs/metrics-component.adoc          | 2 ++
 components/camel-micrometer/src/main/docs/micrometer-component.adoc    | 2 ++
 components/camel-milo/src/main/docs/milo-client-component.adoc         | 2 ++
 components/camel-milo/src/main/docs/milo-server-component.adoc         | 2 ++
 components/camel-mina/src/main/docs/mina-component.adoc                | 2 ++
 components/camel-mllp/src/main/docs/mllp-component.adoc                | 2 ++
 components/camel-mock/src/main/docs/mock-component.adoc                | 2 ++
 .../camel-mongodb-gridfs/src/main/docs/mongodb-gridfs-component.adoc   | 2 ++
 components/camel-mongodb/src/main/docs/mongodb-component.adoc          | 2 ++
 components/camel-msv/src/main/docs/msv-component.adoc                  | 2 ++
 components/camel-mustache/src/main/docs/mustache-component.adoc        | 2 ++
 components/camel-mvel/src/main/docs/mvel-component.adoc                | 2 ++
 components/camel-mvel/src/main/docs/mvel-language.adoc                 | 2 ++
 components/camel-mybatis/src/main/docs/mybatis-bean-component.adoc     | 2 ++
 components/camel-mybatis/src/main/docs/mybatis-component.adoc          | 2 ++
 components/camel-nagios/src/main/docs/nagios-component.adoc            | 2 ++
 components/camel-nats/src/main/docs/nats-component.adoc                | 2 ++
 components/camel-netty-http/src/main/docs/netty-http-component.adoc    | 2 ++
 components/camel-netty/src/main/docs/netty-component.adoc              | 2 ++
 components/camel-nitrite/src/main/docs/nitrite-component.adoc          | 2 ++
 components/camel-nsq/src/main/docs/nsq-component.adoc                  | 2 ++
 components/camel-ognl/src/main/docs/ognl-language.adoc                 | 2 ++
 .../camel-olingo2-component/src/main/docs/olingo2-component.adoc       | 3 +++
 .../camel-olingo4-component/src/main/docs/olingo4-component.adoc       | 3 +++
 .../camel-openstack/src/main/docs/openstack-cinder-component.adoc      | 2 ++
 .../camel-openstack/src/main/docs/openstack-glance-component.adoc      | 2 ++
 .../camel-openstack/src/main/docs/openstack-keystone-component.adoc    | 2 ++
 .../camel-openstack/src/main/docs/openstack-neutron-component.adoc     | 2 ++
 components/camel-openstack/src/main/docs/openstack-nova-component.adoc | 2 ++
 .../camel-openstack/src/main/docs/openstack-swift-component.adoc       | 2 ++
 components/camel-openstack/src/main/docs/openstack.adoc                | 2 ++
 components/camel-opentracing/src/main/docs/opentracing.adoc            | 2 ++
 components/camel-optaplanner/src/main/docs/optaplanner-component.adoc  | 2 ++
 components/camel-paho/src/main/docs/paho-component.adoc                | 2 ++
 components/camel-pdf/src/main/docs/pdf-component.adoc                  | 2 ++
 .../src/main/docs/pg-replication-slot-component.adoc                   | 2 ++
 components/camel-pgevent/src/main/docs/pgevent-component.adoc          | 2 ++
 .../camel-platform-http/src/main/docs/platform-http-component.adoc     | 2 ++
 components/camel-printer/src/main/docs/lpr-component.adoc              | 2 ++
 components/camel-protobuf/src/main/docs/protobuf-dataformat.adoc       | 2 ++
 components/camel-pubnub/src/main/docs/pubnub-component.adoc            | 2 ++
 components/camel-pulsar/src/main/docs/pulsar-component.adoc            | 2 ++
 components/camel-quartz/src/main/docs/quartz-component.adoc            | 2 ++
 components/camel-quickfix/src/main/docs/quickfix-component.adoc        | 2 ++
 components/camel-rabbitmq/src/main/docs/rabbitmq-component.adoc        | 2 ++
 .../src/main/docs/reactive-streams-component.adoc                      | 2 ++
 components/camel-ref/src/main/docs/ref-component.adoc                  | 2 ++
 .../camel-rest-openapi/src/main/docs/rest-openapi-component.adoc       | 2 ++
 .../camel-rest-swagger/src/main/docs/rest-swagger-component.adoc       | 2 ++
 components/camel-rest/src/main/docs/rest-api-component.adoc            | 2 ++
 components/camel-rest/src/main/docs/rest-component.adoc                | 2 ++
 .../camel-robotframework/src/main/docs/robotframework-component.adoc   | 2 ++
 components/camel-rss/src/main/docs/rss-component.adoc                  | 2 ++
 components/camel-rss/src/main/docs/rss-dataformat.adoc                 | 2 ++
 components/camel-saga/src/main/docs/saga-component.adoc                | 2 ++
 .../camel-salesforce-component/src/main/docs/salesforce-component.adoc | 3 +++
 .../camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc     | 2 ++
 components/camel-saxon/src/main/docs/xquery-component.adoc             | 2 ++
 components/camel-saxon/src/main/docs/xquery-language.adoc              | 2 ++
 components/camel-scheduler/src/main/docs/scheduler-component.adoc      | 2 ++
 components/camel-schematron/src/main/docs/schematron-component.adoc    | 2 ++
 components/camel-seda/src/main/docs/seda-component.adoc                | 2 ++
 components/camel-service/src/main/docs/service-component.adoc          | 2 ++
 .../camel-servicenow-component/src/main/docs/servicenow-component.adoc | 3 +++
 components/camel-servlet/src/main/docs/servlet-component.adoc          | 2 ++
 components/camel-sip/src/main/docs/sip-component.adoc                  | 2 ++
 components/camel-sjms/src/main/docs/sjms-batch-component.adoc          | 2 ++
 components/camel-sjms/src/main/docs/sjms-component.adoc                | 2 ++
 components/camel-sjms2/src/main/docs/sjms2-component.adoc              | 2 ++
 components/camel-slack/src/main/docs/slack-component.adoc              | 2 ++
 components/camel-smpp/src/main/docs/smpp-component.adoc                | 2 ++
 .../camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc       | 2 ++
 components/camel-snmp/src/main/docs/snmp-component.adoc                | 2 ++
 components/camel-soap/src/main/docs/soapjaxb-dataformat.adoc           | 2 ++
 components/camel-solr/src/main/docs/solr-component.adoc                | 2 ++
 components/camel-soroush/src/main/docs/soroush-component.adoc          | 2 ++
 components/camel-spark/src/main/docs/spark-component.adoc              | 2 ++
 components/camel-splunk/src/main/docs/splunk-component.adoc            | 2 ++
 .../camel-spring-batch/src/main/docs/spring-batch-component.adoc       | 2 ++
 .../src/main/docs/spring-integration-component.adoc                    | 2 ++
 components/camel-spring-ldap/src/main/docs/spring-ldap-component.adoc  | 2 ++
 .../camel-spring-redis/src/main/docs/spring-redis-component.adoc       | 2 ++
 components/camel-spring-ws/src/main/docs/spring-ws-component.adoc      | 2 ++
 components/camel-spring/src/main/docs/spel-language.adoc               | 2 ++
 components/camel-spring/src/main/docs/spring-event-component.adoc      | 2 ++
 components/camel-spring/src/main/docs/spring.adoc                      | 2 ++
 components/camel-sql/src/main/docs/sql-component.adoc                  | 2 ++
 components/camel-sql/src/main/docs/sql-stored-component.adoc           | 2 ++
 components/camel-ssh/src/main/docs/ssh-component.adoc                  | 2 ++
 components/camel-stax/src/main/docs/stax-component.adoc                | 2 ++
 components/camel-stomp/src/main/docs/stomp-component.adoc              | 2 ++
 components/camel-stream/src/main/docs/stream-component.adoc            | 2 ++
 .../camel-stringtemplate/src/main/docs/string-template-component.adoc  | 2 ++
 components/camel-stub/src/main/docs/stub-component.adoc                | 2 ++
 components/camel-syslog/src/main/docs/syslog-dataformat.adoc           | 2 ++
 components/camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc      | 2 ++
 components/camel-tarfile/src/main/docs/tarfile-dataformat.adoc         | 2 ++
 components/camel-telegram/src/main/docs/telegram-component.adoc        | 2 ++
 components/camel-thrift/src/main/docs/thrift-component.adoc            | 2 ++
 components/camel-thrift/src/main/docs/thrift-dataformat.adoc           | 2 ++
 components/camel-tika/src/main/docs/tika-component.adoc                | 2 ++
 components/camel-timer/src/main/docs/timer-component.adoc              | 2 ++
 components/camel-twilio/src/main/docs/twilio-component.adoc            | 2 ++
 .../camel-twitter/src/main/docs/twitter-directmessage-component.adoc   | 2 ++
 components/camel-twitter/src/main/docs/twitter-search-component.adoc   | 2 ++
 components/camel-twitter/src/main/docs/twitter-timeline-component.adoc | 2 ++
 components/camel-undertow/src/main/docs/undertow-component.adoc        | 2 ++
 .../src/main/docs/univocity-csv-dataformat.adoc                        | 2 ++
 .../src/main/docs/univocity-fixed-dataformat.adoc                      | 2 ++
 .../src/main/docs/univocity-tsv-dataformat.adoc                        | 2 ++
 components/camel-validator/src/main/docs/validator-component.adoc      | 2 ++
 components/camel-velocity/src/main/docs/velocity-component.adoc        | 2 ++
 components/camel-vertx/src/main/docs/vertx-component.adoc              | 2 ++
 components/camel-vm/src/main/docs/vm-component.adoc                    | 2 ++
 components/camel-weather/src/main/docs/weather-component.adoc          | 2 ++
 components/camel-web3j/src/main/docs/web3j-component.adoc              | 2 ++
 components/camel-webhook/src/main/docs/webhook-component.adoc          | 2 ++
 .../src/main/docs/websocket-jsr356-component.adoc                      | 2 ++
 components/camel-websocket/src/main/docs/websocket-component.adoc      | 2 ++
 components/camel-weka/src/main/docs/weka-component.adoc                | 2 ++
 components/camel-wordpress/src/main/docs/wordpress-component.adoc      | 2 ++
 components/camel-workday/src/main/docs/workday-component.adoc          | 2 ++
 components/camel-xchange/src/main/docs/xchange-component.adoc          | 2 ++
 components/camel-xj/src/main/docs/xj-component.adoc                    | 2 ++
 components/camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc   | 2 ++
 components/camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc  | 2 ++
 components/camel-xmpp/src/main/docs/xmpp-component.adoc                | 2 ++
 components/camel-xpath/src/main/docs/xpath-language.adoc               | 2 ++
 components/camel-xslt-saxon/src/main/docs/xslt-saxon-component.adoc    | 2 ++
 components/camel-xslt/src/main/docs/xslt-component.adoc                | 2 ++
 components/camel-xstream/src/main/docs/json-xstream-dataformat.adoc    | 2 ++
 components/camel-xstream/src/main/docs/xstream-dataformat.adoc         | 2 ++
 components/camel-yammer/src/main/docs/yammer-component.adoc            | 3 ++-
 components/camel-zendesk/src/main/docs/zendesk-component.adoc          | 2 ++
 .../camel-zip-deflater/src/main/docs/gzipdeflater-dataformat.adoc      | 2 ++
 .../camel-zip-deflater/src/main/docs/zipdeflater-dataformat.adoc       | 2 ++
 components/camel-zipfile/src/main/docs/zipfile-dataformat.adoc         | 2 ++
 components/camel-zipkin/src/main/docs/zipkin.adoc                      | 2 ++
 .../src/main/docs/zookeeper-master-component.adoc                      | 2 ++
 components/camel-zookeeper/src/main/docs/zookeeper-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/activemq-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/ahc-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/ahc-ws-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/amqp-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/any23-dataformat.adoc               | 2 ++
 docs/components/modules/ROOT/pages/apns-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/as2-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/asn1-dataformat.adoc                | 2 ++
 docs/components/modules/ROOT/pages/asterisk-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/atmos-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/atmosphere-websocket-component.adoc | 2 ++
 docs/components/modules/ROOT/pages/atom-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/atomix-map-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/atomix-messaging-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/atomix-multimap-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/atomix-queue-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/atomix-set-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/atomix-value-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/avro-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/avro-dataformat.adoc                | 2 ++
 docs/components/modules/ROOT/pages/aws-cw-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/aws-ddb-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-ddbstream-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/aws-ec2-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-ecs-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-eks-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-iam-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-kinesis-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/aws-kinesis-firehose-component.adoc | 2 ++
 docs/components/modules/ROOT/pages/aws-kms-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-lambda-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/aws-mq-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/aws-msk-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-s3-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/aws-sdb-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-ses-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-sns-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-sqs-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-swf-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws-translate-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/aws2-cw-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws2-ddb-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/aws2-ddbstream-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/aws2-ec2-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/aws2-ecs-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/aws2-eks-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/aws2-iam-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/aws2-kms-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/aws2-mq-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/aws2-msk-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/aws2-translate-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/azure-blob-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/azure-queue-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/azure.adoc                          | 2 ++
 docs/components/modules/ROOT/pages/barcode-dataformat.adoc             | 2 ++
 docs/components/modules/ROOT/pages/base64-dataformat.adoc              | 2 ++
 docs/components/modules/ROOT/pages/bean-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/bean-language.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/bean-validator-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/beanio-dataformat.adoc              | 2 ++
 docs/components/modules/ROOT/pages/beanstalk-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/bindy-dataformat.adoc               | 2 ++
 docs/components/modules/ROOT/pages/bonita-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/box-component.adoc                  | 3 +++
 docs/components/modules/ROOT/pages/braintree-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/browse-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/caffeine-cache-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/caffeine-loadcache-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/cbor-dataformat.adoc                | 2 ++
 docs/components/modules/ROOT/pages/chatscript-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/chunk-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/class-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/cm-sms-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/cmis-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/coap-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/cometd-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/consul-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/controlbus-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/corda-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/couchbase-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/couchdb-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/cql-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/cron-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/crypto-cms-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/crypto-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/crypto-dataformat.adoc              | 2 ++
 docs/components/modules/ROOT/pages/csv-dataformat.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/cxf-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/cxfrs-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/dataformat-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/dataset-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/dataset-test-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/debezium-mongodb-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/debezium-mysql-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/debezium-postgres-component.adoc    | 2 ++
 docs/components/modules/ROOT/pages/debezium-sqlserver-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/digitalocean-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/direct-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/direct-vm-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/disruptor-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/dns-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/docker-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/dozer-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/drill-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/dropbox-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/ehcache-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/elasticsearch-rest-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/elsql-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/elytron-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/etcd-keys-component.adoc            | 3 ++-
 docs/components/modules/ROOT/pages/etcd-stats-component.adoc           | 3 ++-
 docs/components/modules/ROOT/pages/etcd-watch-component.adoc           | 3 ++-
 docs/components/modules/ROOT/pages/exec-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/facebook-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/fhir-component.adoc                 | 3 +++
 docs/components/modules/ROOT/pages/file-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/file-watch-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/flatpack-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/flatpack-dataformat.adoc            | 2 ++
 docs/components/modules/ROOT/pages/flink-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/fop-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/freemarker-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/ftp-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/ftps-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/ganglia-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/geocoder-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/git-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/github-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/google-bigquery-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/google-bigquery-sql-component.adoc  | 2 ++
 docs/components/modules/ROOT/pages/google-calendar-component.adoc      | 2 ++
 .../modules/ROOT/pages/google-calendar-stream-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/google-drive-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/google-mail-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/google-mail-stream-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/google-pubsub-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/google-sheets-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/google-sheets-stream-component.adoc | 2 ++
 docs/components/modules/ROOT/pages/gora-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/graphql-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/grok-dataformat.adoc                | 2 ++
 docs/components/modules/ROOT/pages/groovy-language.adoc                | 2 ++
 docs/components/modules/ROOT/pages/grpc-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/guava-eventbus-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/gzipdeflater-dataformat.adoc        | 2 ++
 .../components/modules/ROOT/pages/hazelcast-atomicvalue-component.adoc | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-instance-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-list-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-map-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-multimap-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-queue-component.adoc      | 2 ++
 .../modules/ROOT/pages/hazelcast-replicatedmap-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-ringbuffer-component.adoc | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-seda-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-set-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/hazelcast-topic-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/hazelcast.adoc                      | 2 ++
 docs/components/modules/ROOT/pages/hbase-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/hdfs-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/hipchat-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/hl7-dataformat.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/hl7terser-language.adoc             | 2 ++
 docs/components/modules/ROOT/pages/http-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/hystrix.adoc                        | 2 ++
 docs/components/modules/ROOT/pages/ical-dataformat.adoc                | 2 ++
 docs/components/modules/ROOT/pages/iec60870-client-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/iec60870-server-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/ignite-cache-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/ignite-compute-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/ignite-events-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/ignite-idgen-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/ignite-messaging-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/ignite-queue-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/ignite-set-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/ignite.adoc                         | 2 ++
 docs/components/modules/ROOT/pages/infinispan-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/influxdb-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/iota-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/ipfs-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/irc-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/ironmq-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/jacksonxml-dataformat.adoc          | 2 ++
 docs/components/modules/ROOT/pages/jaxb-dataformat.adoc                | 2 ++
 docs/components/modules/ROOT/pages/jbpm-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/jcache-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/jclouds-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/jcr-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/jdbc-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/jetty-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/jgroups-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/jgroups-raft-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/jing-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/jira-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/jms-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/jmx-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/jolt-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/jooq-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/jpa-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/jslt-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/json-fastjson-dataformat.adoc       | 2 ++
 docs/components/modules/ROOT/pages/json-gson-dataformat.adoc           | 2 ++
 docs/components/modules/ROOT/pages/json-jackson-dataformat.adoc        | 2 ++
 docs/components/modules/ROOT/pages/json-johnzon-dataformat.adoc        | 2 ++
 docs/components/modules/ROOT/pages/json-validator-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/json-xstream-dataformat.adoc        | 2 ++
 docs/components/modules/ROOT/pages/jsonApi-dataformat.adoc             | 2 ++
 docs/components/modules/ROOT/pages/jsonpath-language.adoc              | 2 ++
 docs/components/modules/ROOT/pages/jt400-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/kafka-component.adoc                | 2 ++
 .../modules/ROOT/pages/kubernetes-config-maps-component.adoc           | 2 ++
 .../modules/ROOT/pages/kubernetes-deployments-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/kubernetes-hpa-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/kubernetes-job-component.adoc       | 2 ++
 .../components/modules/ROOT/pages/kubernetes-namespaces-component.adoc | 2 ++
 docs/components/modules/ROOT/pages/kubernetes-nodes-component.adoc     | 2 ++
 .../ROOT/pages/kubernetes-persistent-volumes-claims-component.adoc     | 2 ++
 .../modules/ROOT/pages/kubernetes-persistent-volumes-component.adoc    | 2 ++
 docs/components/modules/ROOT/pages/kubernetes-pods-component.adoc      | 2 ++
 .../ROOT/pages/kubernetes-replication-controllers-component.adoc       | 2 ++
 .../modules/ROOT/pages/kubernetes-resources-quota-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/kubernetes-secrets-component.adoc   | 2 ++
 .../modules/ROOT/pages/kubernetes-service-accounts-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/kubernetes-services-component.adoc  | 2 ++
 docs/components/modules/ROOT/pages/kubernetes.adoc                     | 2 ++
 docs/components/modules/ROOT/pages/kudu-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/language-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/ldap-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/ldif-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/log-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/lpr-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/lra.adoc                            | 2 ++
 docs/components/modules/ROOT/pages/lucene-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/lumberjack-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/lzf-dataformat.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/mail-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/master-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/metrics-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/micrometer-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/milo-client-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/milo-server-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/mime-multipart-dataformat.adoc      | 2 ++
 docs/components/modules/ROOT/pages/mina-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/mllp-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/mock-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/mongodb-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/mongodb-gridfs-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/msv-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/mustache-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/mvel-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/mvel-language.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/mybatis-bean-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/mybatis-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/nagios-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/nats-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/netty-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/netty-http-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/nitrite-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/nsq-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/ognl-language.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/olingo2-component.adoc              | 3 +++
 docs/components/modules/ROOT/pages/olingo4-component.adoc              | 3 +++
 .../modules/ROOT/pages/openshift-build-configs-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/openshift-builds-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/openstack-cinder-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/openstack-glance-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/openstack-keystone-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/openstack-neutron-component.adoc    | 2 ++
 docs/components/modules/ROOT/pages/openstack-nova-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/openstack-swift-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/openstack.adoc                      | 2 ++
 docs/components/modules/ROOT/pages/opentracing.adoc                    | 2 ++
 docs/components/modules/ROOT/pages/optaplanner-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/paho-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/pdf-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/pg-replication-slot-component.adoc  | 2 ++
 docs/components/modules/ROOT/pages/pgevent-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/pgp-dataformat.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/platform-http-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/protobuf-dataformat.adoc            | 2 ++
 docs/components/modules/ROOT/pages/pubnub-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/pulsar-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/quartz-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/quickfix-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/rabbitmq-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/reactive-streams-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/ref-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/rest-api-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/rest-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/rest-openapi-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/rest-swagger-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/robotframework-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/rss-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/rss-dataformat.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/saga-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/salesforce-component.adoc           | 3 +++
 docs/components/modules/ROOT/pages/sap-netweaver-component.adoc        | 2 ++
 docs/components/modules/ROOT/pages/scheduler-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/schematron-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/scp-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/secureXML-dataformat.adoc           | 2 ++
 docs/components/modules/ROOT/pages/seda-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/service-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/servicenow-component.adoc           | 3 +++
 docs/components/modules/ROOT/pages/servlet-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/sftp-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/sip-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/sjms-batch-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/sjms-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/sjms2-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/slack-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/smpp-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/snmp-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/soapjaxb-dataformat.adoc            | 2 ++
 docs/components/modules/ROOT/pages/solr-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/soroush-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/spark-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/spel-language.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/splunk-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/spring-batch-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/spring-event-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/spring-integration-component.adoc   | 2 ++
 docs/components/modules/ROOT/pages/spring-ldap-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/spring-redis-component.adoc         | 2 ++
 docs/components/modules/ROOT/pages/spring-ws-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/spring.adoc                         | 2 ++
 docs/components/modules/ROOT/pages/sql-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/sql-stored-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/ssh-component.adoc                  | 2 ++
 docs/components/modules/ROOT/pages/stax-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/stomp-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/stream-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/string-template-component.adoc      | 2 ++
 docs/components/modules/ROOT/pages/stub-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/syslog-dataformat.adoc              | 2 ++
 docs/components/modules/ROOT/pages/tarfile-dataformat.adoc             | 2 ++
 docs/components/modules/ROOT/pages/telegram-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/thrift-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/thrift-dataformat.adoc              | 2 ++
 docs/components/modules/ROOT/pages/tidyMarkup-dataformat.adoc          | 2 ++
 docs/components/modules/ROOT/pages/tika-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/timer-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/twilio-component.adoc               | 2 ++
 .../components/modules/ROOT/pages/twitter-directmessage-component.adoc | 2 ++
 docs/components/modules/ROOT/pages/twitter-search-component.adoc       | 2 ++
 docs/components/modules/ROOT/pages/twitter-timeline-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/undertow-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/univocity-csv-dataformat.adoc       | 2 ++
 docs/components/modules/ROOT/pages/univocity-fixed-dataformat.adoc     | 2 ++
 docs/components/modules/ROOT/pages/univocity-tsv-dataformat.adoc       | 2 ++
 docs/components/modules/ROOT/pages/validator-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/velocity-component.adoc             | 2 ++
 docs/components/modules/ROOT/pages/vertx-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/vm-component.adoc                   | 2 ++
 docs/components/modules/ROOT/pages/weather-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/web3j-component.adoc                | 2 ++
 docs/components/modules/ROOT/pages/webhook-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/websocket-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/websocket-jsr356-component.adoc     | 2 ++
 docs/components/modules/ROOT/pages/weka-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/wordpress-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/workday-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/xchange-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/xj-component.adoc                   | 2 ++
 docs/components/modules/ROOT/pages/xmlsecurity-component.adoc          | 2 ++
 docs/components/modules/ROOT/pages/xmpp-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/xpath-language.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/xquery-component.adoc               | 2 ++
 docs/components/modules/ROOT/pages/xquery-language.adoc                | 2 ++
 docs/components/modules/ROOT/pages/xslt-component.adoc                 | 2 ++
 docs/components/modules/ROOT/pages/xslt-saxon-component.adoc           | 2 ++
 docs/components/modules/ROOT/pages/xstream-dataformat.adoc             | 2 ++
 docs/components/modules/ROOT/pages/yaml-snakeyaml-dataformat.adoc      | 2 ++
 docs/components/modules/ROOT/pages/yammer-component.adoc               | 3 ++-
 docs/components/modules/ROOT/pages/zendesk-component.adoc              | 2 ++
 docs/components/modules/ROOT/pages/zipdeflater-dataformat.adoc         | 2 ++
 docs/components/modules/ROOT/pages/zipfile-dataformat.adoc             | 2 ++
 docs/components/modules/ROOT/pages/zipkin.adoc                         | 2 ++
 docs/components/modules/ROOT/pages/zookeeper-component.adoc            | 2 ++
 docs/components/modules/ROOT/pages/zookeeper-master-component.adoc     | 2 ++
 758 files changed, 1528 insertions(+), 8 deletions(-)

diff --git a/components/camel-activemq/src/main/docs/activemq-component.adoc b/components/camel-activemq/src/main/docs/activemq-component.adoc
index fc298e4..ea1475e 100644
--- a/components/camel-activemq/src/main/docs/activemq-component.adoc
+++ b/components/camel-activemq/src/main/docs/activemq-component.adoc
@@ -271,3 +271,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$activemq-starter.adoc[]
diff --git a/components/camel-ahc-ws/src/main/docs/ahc-ws-component.adoc b/components/camel-ahc-ws/src/main/docs/ahc-ws-component.adoc
index 090950d..96d4966 100644
--- a/components/camel-ahc-ws/src/main/docs/ahc-ws-component.adoc
+++ b/components/camel-ahc-ws/src/main/docs/ahc-ws-component.adoc
@@ -172,3 +172,5 @@ And the equivalent Spring sample:
 
  
 
+
+include::camel-spring-boot::page$ahc-ws-starter.adoc[]
diff --git a/components/camel-ahc/src/main/docs/ahc-component.adoc b/components/camel-ahc/src/main/docs/ahc-component.adoc
index 54aae5b..df81c79 100644
--- a/components/camel-ahc/src/main/docs/ahc-component.adoc
+++ b/components/camel-ahc/src/main/docs/ahc-component.adoc
@@ -435,3 +435,5 @@ Spring DSL based configuration of endpoint
   <to uri="ahc:https://localhost/foo?sslContextParameters=#sslContextParameters"/>
 ...
 ----------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$ahc-starter.adoc[]
diff --git a/components/camel-amqp/src/main/docs/amqp-component.adoc b/components/camel-amqp/src/main/docs/amqp-component.adoc
index 66ce739..6495b0b 100644
--- a/components/camel-amqp/src/main/docs/amqp-component.adoc
+++ b/components/camel-amqp/src/main/docs/amqp-component.adoc
@@ -382,3 +382,5 @@ Keep in mind that both  `AMQPComponent#amqpComponent()` methods and
 `AMQPConnectionDetails` pre-configure the component with the topic
 prefix, so you don't have to configure it explicitly.
 
+
+include::camel-spring-boot::page$amqp-starter.adoc[]
diff --git a/components/camel-any23/src/main/docs/any23-dataformat.adoc b/components/camel-any23/src/main/docs/any23-dataformat.adoc
index 3df2ebc..e1d4600 100644
--- a/components/camel-any23/src/main/docs/any23-dataformat.adoc
+++ b/components/camel-any23/src/main/docs/any23-dataformat.adoc
@@ -86,3 +86,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ----------------------------------------
+
+include::camel-spring-boot::page$any23-starter.adoc[]
diff --git a/components/camel-apns/src/main/docs/apns-component.adoc b/components/camel-apns/src/main/docs/apns-component.adoc
index 3e2c283..cea639b 100644
--- a/components/camel-apns/src/main/docs/apns-component.adoc
+++ b/components/camel-apns/src/main/docs/apns-component.adoc
@@ -315,3 +315,5 @@ from("apns:consumer?initialDelay=10&delay=3600&timeUnit=SECONDS")
     .to("mock:result");
 --------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$apns-starter.adoc[]
diff --git a/components/camel-as2/camel-as2-component/src/main/docs/as2-component.adoc b/components/camel-as2/camel-as2-component/src/main/docs/as2-component.adoc
index 4c6ffb4..010aa62 100644
--- a/components/camel-as2/camel-as2-component/src/main/docs/as2-component.adoc
+++ b/components/camel-as2/camel-as2-component/src/main/docs/as2-component.adoc
@@ -258,3 +258,5 @@ URI Options for _server_
 |requestUriPattern |String
 |===
 
+include::camel-spring-boot::page$as2-starter.adoc[]
+
diff --git a/components/camel-asn1/src/main/docs/asn1-dataformat.adoc b/components/camel-asn1/src/main/docs/asn1-dataformat.adoc
index 91eed2c..ccfec69 100644
--- a/components/camel-asn1/src/main/docs/asn1-dataformat.adoc
+++ b/components/camel-asn1/src/main/docs/asn1-dataformat.adoc
@@ -74,3 +74,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$asn1-starter.adoc[]
diff --git a/components/camel-asterisk/src/main/docs/asterisk-component.adoc b/components/camel-asterisk/src/main/docs/asterisk-component.adoc
index ed6ef77..10378e7 100644
--- a/components/camel-asterisk/src/main/docs/asterisk-component.adoc
+++ b/components/camel-asterisk/src/main/docs/asterisk-component.adoc
@@ -92,3 +92,5 @@ Supported actions are:
 * QUEUE_STATUS, Queue Status
 * SIP_PEERS, List SIP Peers
 * EXTENSION_STATE, Check Extension Status
+
+include::camel-spring-boot::page$asterisk-starter.adoc[]
diff --git a/components/camel-atmos/src/main/docs/atmos-component.adoc b/components/camel-atmos/src/main/docs/atmos-component.adoc
index 3144e38..b9b328c 100644
--- a/components/camel-atmos/src/main/docs/atmos-component.adoc
+++ b/components/camel-atmos/src/main/docs/atmos-component.adoc
@@ -155,3 +155,5 @@ exhange
 DOWNLOADED_FILE, DOWNLOADED_FILES, UPLOADED_FILE, UPLOADED_FILES, FOUND_FILES, DELETED_PATH, MOVED_PATH;
 -------------------------------
 
+
+include::camel-spring-boot::page$atmos-starter.adoc[]
diff --git a/components/camel-atmosphere-websocket/src/main/docs/atmosphere-websocket-component.adoc b/components/camel-atmosphere-websocket/src/main/docs/atmosphere-websocket-component.adoc
index 6937894..96b07d8 100644
--- a/components/camel-atmosphere-websocket/src/main/docs/atmosphere-websocket-component.adoc
+++ b/components/camel-atmosphere-websocket/src/main/docs/atmosphere-websocket-component.adoc
@@ -192,3 +192,5 @@ And the equivalent Spring sample:
 
  
 
+
+include::camel-spring-boot::page$atmosphere-websocket-starter.adoc[]
diff --git a/components/camel-atom/src/main/docs/atom-component.adoc b/components/camel-atom/src/main/docs/atom-component.adoc
index 9ebaa11..440b3748 100644
--- a/components/camel-atom/src/main/docs/atom-component.adoc
+++ b/components/camel-atom/src/main/docs/atom-component.adoc
@@ -158,3 +158,5 @@ In this sample we want to filter only good blogs we like to a SEDA
 queue. The sample also shows how to setup Camel standalone, not running
 in any Container or using Spring.
 
+
+include::camel-spring-boot::page$atom-starter.adoc[]
diff --git a/components/camel-atomix/src/main/docs/atomix-map-component.adoc b/components/camel-atomix/src/main/docs/atomix-map-component.adoc
index 8ec335e..e3db7d3 100644
--- a/components/camel-atomix/src/main/docs/atomix-map-component.adoc
+++ b/components/camel-atomix/src/main/docs/atomix-map-component.adoc
@@ -199,3 +199,5 @@ FluentProducerTemplate.on(context)
     .to("direct:start")
     .send();
 ----
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/components/camel-atomix/src/main/docs/atomix-messaging-component.adoc b/components/camel-atomix/src/main/docs/atomix-messaging-component.adoc
index 4fbcc80..c661633 100644
--- a/components/camel-atomix/src/main/docs/atomix-messaging-component.adoc
+++ b/components/camel-atomix/src/main/docs/atomix-messaging-component.adoc
@@ -95,3 +95,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/components/camel-atomix/src/main/docs/atomix-multimap-component.adoc b/components/camel-atomix/src/main/docs/atomix-multimap-component.adoc
index 546d188..695fe82 100644
--- a/components/camel-atomix/src/main/docs/atomix-multimap-component.adoc
+++ b/components/camel-atomix/src/main/docs/atomix-multimap-component.adoc
@@ -90,3 +90,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/components/camel-atomix/src/main/docs/atomix-queue-component.adoc b/components/camel-atomix/src/main/docs/atomix-queue-component.adoc
index 1651bd8..e257dee 100644
--- a/components/camel-atomix/src/main/docs/atomix-queue-component.adoc
+++ b/components/camel-atomix/src/main/docs/atomix-queue-component.adoc
@@ -92,3 +92,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/components/camel-atomix/src/main/docs/atomix-set-component.adoc b/components/camel-atomix/src/main/docs/atomix-set-component.adoc
index e3db99e..02546b4 100644
--- a/components/camel-atomix/src/main/docs/atomix-set-component.adoc
+++ b/components/camel-atomix/src/main/docs/atomix-set-component.adoc
@@ -93,3 +93,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/components/camel-atomix/src/main/docs/atomix-value-component.adoc b/components/camel-atomix/src/main/docs/atomix-value-component.adoc
index 79919ca..08a77a5 100644
--- a/components/camel-atomix/src/main/docs/atomix-value-component.adoc
+++ b/components/camel-atomix/src/main/docs/atomix-value-component.adoc
@@ -93,3 +93,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/components/camel-avro/src/main/docs/avro-component.adoc b/components/camel-avro/src/main/docs/avro-component.adoc
index 561db84..d1d959d 100644
--- a/components/camel-avro/src/main/docs/avro-component.adoc
+++ b/components/camel-avro/src/main/docs/avro-component.adoc
@@ -313,3 +313,5 @@ In the example above, get takes only one parameter, so `singleParameter`
 is used and `getProcessor` will receive Value class directly in body,
 while `putProcessor` will receive an array of size 2 with String key and
 Value value filled as array contents.
+
+include::camel-spring-boot::page$avro-starter.adoc[]
diff --git a/components/camel-avro/src/main/docs/avro-dataformat.adoc b/components/camel-avro/src/main/docs/avro-dataformat.adoc
index a3a5f0f..97386d1 100644
--- a/components/camel-avro/src/main/docs/avro-dataformat.adoc
+++ b/components/camel-avro/src/main/docs/avro-dataformat.adoc
@@ -142,3 +142,5 @@ The Avro dataformat supports 2 options, which are listed below.
 |===
 // dataformat options: END
 ND
+
+include::camel-spring-boot::page$avro-starter.adoc[]
diff --git a/components/camel-aws-cw/src/main/docs/aws-cw-component.adoc b/components/camel-aws-cw/src/main/docs/aws-cw-component.adoc
index e8aefcc..dd82b6b 100644
--- a/components/camel-aws-cw/src/main/docs/aws-cw-component.adoc
+++ b/components/camel-aws-cw/src/main/docs/aws-cw-component.adoc
@@ -180,3 +180,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `${camel-version`} must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-cw-starter.adoc[]
diff --git a/components/camel-aws-ddb/src/main/docs/aws-ddb-component.adoc b/components/camel-aws-ddb/src/main/docs/aws-ddb-component.adoc
index ed95266..dae3e81 100644
--- a/components/camel-aws-ddb/src/main/docs/aws-ddb-component.adoc
+++ b/components/camel-aws-ddb/src/main/docs/aws-ddb-component.adoc
@@ -359,3 +359,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ddb-starter.adoc[]
diff --git a/components/camel-aws-ddb/src/main/docs/aws-ddbstream-component.adoc b/components/camel-aws-ddb/src/main/docs/aws-ddbstream-component.adoc
index 507e2d3..12eaa24 100644
--- a/components/camel-aws-ddb/src/main/docs/aws-ddbstream-component.adoc
+++ b/components/camel-aws-ddb/src/main/docs/aws-ddbstream-component.adoc
@@ -207,3 +207,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ddb-starter.adoc[]
diff --git a/components/camel-aws-ec2/src/main/docs/aws-ec2-component.adoc b/components/camel-aws-ec2/src/main/docs/aws-ec2-component.adoc
index 4b3d672..0d76ea7 100644
--- a/components/camel-aws-ec2/src/main/docs/aws-ec2-component.adoc
+++ b/components/camel-aws-ec2/src/main/docs/aws-ec2-component.adoc
@@ -178,3 +178,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ec2-starter.adoc[]
diff --git a/components/camel-aws-ecs/src/main/docs/aws-ecs-component.adoc b/components/camel-aws-ecs/src/main/docs/aws-ecs-component.adoc
index c22db85..9aa5b0e 100644
--- a/components/camel-aws-ecs/src/main/docs/aws-ecs-component.adoc
+++ b/components/camel-aws-ecs/src/main/docs/aws-ecs-component.adoc
@@ -154,3 +154,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ecs-starter.adoc[]
diff --git a/components/camel-aws-eks/src/main/docs/aws-eks-component.adoc b/components/camel-aws-eks/src/main/docs/aws-eks-component.adoc
index b0df6ee..2666935 100644
--- a/components/camel-aws-eks/src/main/docs/aws-eks-component.adoc
+++ b/components/camel-aws-eks/src/main/docs/aws-eks-component.adoc
@@ -160,3 +160,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-eks-starter.adoc[]
diff --git a/components/camel-aws-iam/src/main/docs/aws-iam-component.adoc b/components/camel-aws-iam/src/main/docs/aws-iam-component.adoc
index 06ce7af..5e652c4 100644
--- a/components/camel-aws-iam/src/main/docs/aws-iam-component.adoc
+++ b/components/camel-aws-iam/src/main/docs/aws-iam-component.adoc
@@ -170,3 +170,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-iam-starter.adoc[]
diff --git a/components/camel-aws-kinesis/src/main/docs/aws-kinesis-component.adoc b/components/camel-aws-kinesis/src/main/docs/aws-kinesis-component.adoc
index 649e764..b4b246a 100644
--- a/components/camel-aws-kinesis/src/main/docs/aws-kinesis-component.adoc
+++ b/components/camel-aws-kinesis/src/main/docs/aws-kinesis-component.adoc
@@ -236,3 +236,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-kinesis-starter.adoc[]
diff --git a/components/camel-aws-kinesis/src/main/docs/aws-kinesis-firehose-component.adoc b/components/camel-aws-kinesis/src/main/docs/aws-kinesis-firehose-component.adoc
index 2a539c0..1e48f96 100644
--- a/components/camel-aws-kinesis/src/main/docs/aws-kinesis-firehose-component.adoc
+++ b/components/camel-aws-kinesis/src/main/docs/aws-kinesis-firehose-component.adoc
@@ -175,3 +175,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-kinesis-starter.adoc[]
diff --git a/components/camel-aws-kms/src/main/docs/aws-kms-component.adoc b/components/camel-aws-kms/src/main/docs/aws-kms-component.adoc
index dedc01f..d41adf9 100644
--- a/components/camel-aws-kms/src/main/docs/aws-kms-component.adoc
+++ b/components/camel-aws-kms/src/main/docs/aws-kms-component.adoc
@@ -158,3 +158,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-kms-starter.adoc[]
diff --git a/components/camel-aws-lambda/src/main/docs/aws-lambda-component.adoc b/components/camel-aws-lambda/src/main/docs/aws-lambda-component.adoc
index 0e8e141..8fe3cac 100644
--- a/components/camel-aws-lambda/src/main/docs/aws-lambda-component.adoc
+++ b/components/camel-aws-lambda/src/main/docs/aws-lambda-component.adoc
@@ -225,3 +225,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-lambda-starter.adoc[]
diff --git a/components/camel-aws-mq/src/main/docs/aws-mq-component.adoc b/components/camel-aws-mq/src/main/docs/aws-mq-component.adoc
index 904badd..a58f0d8 100644
--- a/components/camel-aws-mq/src/main/docs/aws-mq-component.adoc
+++ b/components/camel-aws-mq/src/main/docs/aws-mq-component.adoc
@@ -170,3 +170,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-mq-starter.adoc[]
diff --git a/components/camel-aws-msk/src/main/docs/aws-msk-component.adoc b/components/camel-aws-msk/src/main/docs/aws-msk-component.adoc
index f80f5e7..b6228f9 100644
--- a/components/camel-aws-msk/src/main/docs/aws-msk-component.adoc
+++ b/components/camel-aws-msk/src/main/docs/aws-msk-component.adoc
@@ -163,3 +163,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-msk-starter.adoc[]
diff --git a/components/camel-aws-s3/src/main/docs/aws-s3-component.adoc b/components/camel-aws-s3/src/main/docs/aws-s3-component.adoc
index f151a55..27194af 100644
--- a/components/camel-aws-s3/src/main/docs/aws-s3-component.adoc
+++ b/components/camel-aws-s3/src/main/docs/aws-s3-component.adoc
@@ -507,3 +507,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-s3-starter.adoc[]
diff --git a/components/camel-aws-sdb/src/main/docs/aws-sdb-component.adoc b/components/camel-aws-sdb/src/main/docs/aws-sdb-component.adoc
index 0a1a4b3..2e4c8ab 100644
--- a/components/camel-aws-sdb/src/main/docs/aws-sdb-component.adoc
+++ b/components/camel-aws-sdb/src/main/docs/aws-sdb-component.adoc
@@ -248,3 +248,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-sdb-starter.adoc[]
diff --git a/components/camel-aws-ses/src/main/docs/aws-ses-component.adoc b/components/camel-aws-ses/src/main/docs/aws-ses-component.adoc
index 9b4d3a7..d89ba8f 100644
--- a/components/camel-aws-ses/src/main/docs/aws-ses-component.adoc
+++ b/components/camel-aws-ses/src/main/docs/aws-ses-component.adoc
@@ -192,3 +192,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ses-starter.adoc[]
diff --git a/components/camel-aws-sns/src/main/docs/aws-sns-component.adoc b/components/camel-aws-sns/src/main/docs/aws-sns-component.adoc
index 03c514b..4ffbf31 100644
--- a/components/camel-aws-sns/src/main/docs/aws-sns-component.adoc
+++ b/components/camel-aws-sns/src/main/docs/aws-sns-component.adoc
@@ -210,3 +210,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-sns-starter.adoc[]
diff --git a/components/camel-aws-sqs/src/main/docs/aws-sqs-component.adoc b/components/camel-aws-sqs/src/main/docs/aws-sqs-component.adoc
index 0666250..0ef2a20 100644
--- a/components/camel-aws-sqs/src/main/docs/aws-sqs-component.adoc
+++ b/components/camel-aws-sqs/src/main/docs/aws-sqs-component.adoc
@@ -357,3 +357,5 @@ The other one will use a NullMessageDeduplicationIdStrategy, that will use the b
 
 In case of send batch message operation, you'll need to use the `useContentBasedDeduplication` and on the Queue you're pointing you'll need to enable the `content based deduplication` option.
 
+
+include::camel-spring-boot::page$aws-sqs-starter.adoc[]
diff --git a/components/camel-aws-swf/src/main/docs/aws-swf-component.adoc b/components/camel-aws-swf/src/main/docs/aws-swf-component.adoc
index 1ababa6..41428a7 100644
--- a/components/camel-aws-swf/src/main/docs/aws-swf-component.adoc
+++ b/components/camel-aws-swf/src/main/docs/aws-swf-component.adoc
@@ -255,3 +255,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-swf-starter.adoc[]
diff --git a/components/camel-aws-translate/src/main/docs/aws-translate-component.adoc b/components/camel-aws-translate/src/main/docs/aws-translate-component.adoc
index 7331ccf..e06434b 100644
--- a/components/camel-aws-translate/src/main/docs/aws-translate-component.adoc
+++ b/components/camel-aws-translate/src/main/docs/aws-translate-component.adoc
@@ -158,3 +158,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-translate-starter.adoc[]
diff --git a/components/camel-aws2-cw/src/main/docs/aws2-cw-component.adoc b/components/camel-aws2-cw/src/main/docs/aws2-cw-component.adoc
index b5c4917..615b1a9 100644
--- a/components/camel-aws2-cw/src/main/docs/aws2-cw-component.adoc
+++ b/components/camel-aws2-cw/src/main/docs/aws2-cw-component.adoc
@@ -167,3 +167,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `${camel-version`} must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-cw-starter.adoc[]
diff --git a/components/camel-aws2-ddb/src/main/docs/aws2-ddb-component.adoc b/components/camel-aws2-ddb/src/main/docs/aws2-ddb-component.adoc
index 14faa27..3c92f91 100644
--- a/components/camel-aws2-ddb/src/main/docs/aws2-ddb-component.adoc
+++ b/components/camel-aws2-ddb/src/main/docs/aws2-ddb-component.adoc
@@ -349,3 +349,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ddb-starter.adoc[]
diff --git a/components/camel-aws2-ddb/src/main/docs/aws2-ddbstream-component.adoc b/components/camel-aws2-ddb/src/main/docs/aws2-ddbstream-component.adoc
index a0a27e6..fa8c508 100644
--- a/components/camel-aws2-ddb/src/main/docs/aws2-ddbstream-component.adoc
+++ b/components/camel-aws2-ddb/src/main/docs/aws2-ddbstream-component.adoc
@@ -182,3 +182,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ddb-starter.adoc[]
diff --git a/components/camel-aws2-ec2/src/main/docs/aws2-ec2-component.adoc b/components/camel-aws2-ec2/src/main/docs/aws2-ec2-component.adoc
index cbd01f9..8ef9ee7 100644
--- a/components/camel-aws2-ec2/src/main/docs/aws2-ec2-component.adoc
+++ b/components/camel-aws2-ec2/src/main/docs/aws2-ec2-component.adoc
@@ -183,3 +183,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ec2-starter.adoc[]
diff --git a/components/camel-aws2-ecs/src/main/docs/aws2-ecs-component.adoc b/components/camel-aws2-ecs/src/main/docs/aws2-ecs-component.adoc
index de6d32c..b6d1e26 100644
--- a/components/camel-aws2-ecs/src/main/docs/aws2-ecs-component.adoc
+++ b/components/camel-aws2-ecs/src/main/docs/aws2-ecs-component.adoc
@@ -160,3 +160,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ecs-starter.adoc[]
diff --git a/components/camel-aws2-eks/src/main/docs/aws2-eks-component.adoc b/components/camel-aws2-eks/src/main/docs/aws2-eks-component.adoc
index e8dfca6..0ea5f52 100644
--- a/components/camel-aws2-eks/src/main/docs/aws2-eks-component.adoc
+++ b/components/camel-aws2-eks/src/main/docs/aws2-eks-component.adoc
@@ -168,3 +168,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-eks-starter.adoc[]
diff --git a/components/camel-aws2-iam/src/main/docs/aws2-iam-component.adoc b/components/camel-aws2-iam/src/main/docs/aws2-iam-component.adoc
index 9303ee6..6817dec 100644
--- a/components/camel-aws2-iam/src/main/docs/aws2-iam-component.adoc
+++ b/components/camel-aws2-iam/src/main/docs/aws2-iam-component.adoc
@@ -177,3 +177,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-iam-starter.adoc[]
diff --git a/components/camel-aws2-kms/src/main/docs/aws2-kms-component.adoc b/components/camel-aws2-kms/src/main/docs/aws2-kms-component.adoc
index 2cf9eb2..69a6c2d 100644
--- a/components/camel-aws2-kms/src/main/docs/aws2-kms-component.adoc
+++ b/components/camel-aws2-kms/src/main/docs/aws2-kms-component.adoc
@@ -165,3 +165,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-kms-starter.adoc[]
diff --git a/components/camel-aws2-mq/src/main/docs/aws2-mq-component.adoc b/components/camel-aws2-mq/src/main/docs/aws2-mq-component.adoc
index 0dc86bd..d4b545c 100644
--- a/components/camel-aws2-mq/src/main/docs/aws2-mq-component.adoc
+++ b/components/camel-aws2-mq/src/main/docs/aws2-mq-component.adoc
@@ -175,3 +175,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-mq-starter.adoc[]
diff --git a/components/camel-aws2-msk/src/main/docs/aws2-msk-component.adoc b/components/camel-aws2-msk/src/main/docs/aws2-msk-component.adoc
index 0dfdd0b..90e126c 100644
--- a/components/camel-aws2-msk/src/main/docs/aws2-msk-component.adoc
+++ b/components/camel-aws2-msk/src/main/docs/aws2-msk-component.adoc
@@ -167,3 +167,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-msk-starter.adoc[]
diff --git a/components/camel-aws2-translate/src/main/docs/aws2-translate-component.adoc b/components/camel-aws2-translate/src/main/docs/aws2-translate-component.adoc
index c5e7f31..5073e57 100644
--- a/components/camel-aws2-translate/src/main/docs/aws2-translate-component.adoc
+++ b/components/camel-aws2-translate/src/main/docs/aws2-translate-component.adoc
@@ -163,3 +163,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-translate-starter.adoc[]
diff --git a/components/camel-azure/src/main/docs/azure-blob-component.adoc b/components/camel-azure/src/main/docs/azure-blob-component.adoc
index a695816..80edcec 100644
--- a/components/camel-azure/src/main/docs/azure-blob-component.adoc
+++ b/components/camel-azure/src/main/docs/azure-blob-component.adoc
@@ -231,3 +231,5 @@ Maven users will need to add the following dependency to their `pom.xml`.
 ----
 
 where `+++${camel-version}+++` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$azure-starter.adoc[]
diff --git a/components/camel-azure/src/main/docs/azure-queue-component.adoc b/components/camel-azure/src/main/docs/azure-queue-component.adoc
index 990da36..bb5132c 100644
--- a/components/camel-azure/src/main/docs/azure-queue-component.adoc
+++ b/components/camel-azure/src/main/docs/azure-queue-component.adoc
@@ -171,3 +171,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `${camel-version`} must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$azure-starter.adoc[]
diff --git a/components/camel-azure/src/main/docs/azure.adoc b/components/camel-azure/src/main/docs/azure.adoc
index 1bb0742..9e9022f 100644
--- a/components/camel-azure/src/main/docs/azure.adoc
+++ b/components/camel-azure/src/main/docs/azure.adoc
@@ -12,3 +12,5 @@ provide connectivity to Azure services from Camel.
 |https://azure.microsoft.com/services/storage/blobs[Storage Blob Service] |xref:azure-blob-component.adoc[Azure-Blob] |Supports storing and retrieving of blobs
 |https://azure.microsoft.com/services/storage/queues[Storage Queue Service] |xref:azure-queue-component.adoc[Azure-Queue] |Supports storing and retrieving of messages in the queues
 |=======================================================================
+
+include::camel-spring-boot::page$azure-starter.adoc[]
diff --git a/components/camel-barcode/src/main/docs/barcode-dataformat.adoc b/components/camel-barcode/src/main/docs/barcode-dataformat.adoc
index c65ba99..5b0085b 100644
--- a/components/camel-barcode/src/main/docs/barcode-dataformat.adoc
+++ b/components/camel-barcode/src/main/docs/barcode-dataformat.adoc
@@ -130,3 +130,5 @@ the barcode data format as header variable:
  
 
  
+
+include::camel-spring-boot::page$barcode-starter.adoc[]
diff --git a/components/camel-base64/src/main/docs/base64-dataformat.adoc b/components/camel-base64/src/main/docs/base64-dataformat.adoc
index c450bcd..6334f51 100644
--- a/components/camel-base64/src/main/docs/base64-dataformat.adoc
+++ b/components/camel-base64/src/main/docs/base64-dataformat.adoc
@@ -112,3 +112,5 @@ If you use Maven you can just add the following to your pom.xml:
   <version>x.x.x</version>  <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$base64-starter.adoc[]
diff --git a/components/camel-bean-validator/src/main/docs/bean-validator-component.adoc b/components/camel-bean-validator/src/main/docs/bean-validator-component.adoc
index 75b7c47..cda98e6 100644
--- a/components/camel-bean-validator/src/main/docs/bean-validator-component.adoc
+++ b/components/camel-bean-validator/src/main/docs/bean-validator-component.adoc
@@ -299,3 +299,5 @@ Note that the body should include an instance of a class to validate.
 
 
 
+
+include::camel-spring-boot::page$bean-validator-starter.adoc[]
diff --git a/components/camel-bean/src/main/docs/bean-component.adoc b/components/camel-bean/src/main/docs/bean-component.adoc
index 5ec1e3f..fad6253 100644
--- a/components/camel-bean/src/main/docs/bean-component.adoc
+++ b/components/camel-bean/src/main/docs/bean-component.adoc
@@ -164,3 +164,5 @@ Bean Binding mechanism which is used throughout
 all of the various Bean Integration
 mechanisms in Camel.
 
+
+include::camel-spring-boot::page$bean-starter.adoc[]
diff --git a/components/camel-bean/src/main/docs/bean-language.adoc b/components/camel-bean/src/main/docs/bean-language.adoc
index ea8dc19..3dc250a 100644
--- a/components/camel-bean/src/main/docs/bean-language.adoc
+++ b/components/camel-bean/src/main/docs/bean-language.adoc
@@ -179,3 +179,5 @@ expression being used in a filter
 * https://github.com/apache/camel/blob/master/components/camel-spring/src/test/resources/org/apache/camel/spring/processor/aggregator.xml[aggregator.xml]
 is a Spring XML test case for the xref:manual::aggregate-eip.adoc[Aggregator] which
 uses a bean method call to test for the completion of the aggregation.
+
+include::camel-spring-boot::page$bean-starter.adoc[]
diff --git a/components/camel-bean/src/main/docs/class-component.adoc b/components/camel-bean/src/main/docs/class-component.adoc
index fc6ce35..8b7b8ea 100644
--- a/components/camel-bean/src/main/docs/class-component.adoc
+++ b/components/camel-bean/src/main/docs/class-component.adoc
@@ -129,3 +129,5 @@ See more details at the xref:bean-component.adoc[Bean] component as the *class*
 component works in much the same way.
 ====
 
+
+include::camel-spring-boot::page$bean-starter.adoc[]
diff --git a/components/camel-beanio/src/main/docs/beanio-dataformat.adoc b/components/camel-beanio/src/main/docs/beanio-dataformat.adoc
index dfe29d9..4b0560f 100644
--- a/components/camel-beanio/src/main/docs/beanio-dataformat.adoc
+++ b/components/camel-beanio/src/main/docs/beanio-dataformat.adoc
@@ -81,3 +81,5 @@ the download page for the latest versions).
   <version>2.10.0</version>
 </dependency>
 ---------------------------------------
+
+include::camel-spring-boot::page$beanio-starter.adoc[]
diff --git a/components/camel-beanstalk/src/main/docs/beanstalk-component.adoc b/components/camel-beanstalk/src/main/docs/beanstalk-component.adoc
index ca599eb..686df9d 100644
--- a/components/camel-beanstalk/src/main/docs/beanstalk-component.adoc
+++ b/components/camel-beanstalk/src/main/docs/beanstalk-component.adoc
@@ -235,3 +235,5 @@ out of buried and/or delayed state to the normal queue.
 
  
 
+
+include::camel-spring-boot::page$beanstalk-starter.adoc[]
diff --git a/components/camel-bindy/src/main/docs/bindy-dataformat.adoc b/components/camel-bindy/src/main/docs/bindy-dataformat.adoc
index f2892c3..785e45b 100644
--- a/components/camel-bindy/src/main/docs/bindy-dataformat.adoc
+++ b/components/camel-bindy/src/main/docs/bindy-dataformat.adoc
@@ -1859,3 +1859,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 --------------------------------------
+
+include::camel-spring-boot::page$bindy-starter.adoc[]
diff --git a/components/camel-bonita/src/main/docs/bonita-component.adoc b/components/camel-bonita/src/main/docs/bonita-component.adoc
index 52caba3..15c46b1 100644
--- a/components/camel-bonita/src/main/docs/bonita-component.adoc
+++ b/components/camel-bonita/src/main/docs/bonita-component.adoc
@@ -102,3 +102,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$bonita-starter.adoc[]
diff --git a/components/camel-box/camel-box-component/src/main/docs/box-component.adoc b/components/camel-box/camel-box-component/src/main/docs/box-component.adoc
index 75af02f..94e2353 100644
--- a/components/camel-box/camel-box-component/src/main/docs/box-component.adoc
+++ b/components/camel-box/camel-box-component/src/main/docs/box-component.adoc
@@ -794,3 +794,6 @@ from("direct:foo")
     .to("box://files/download")
     .to("file://...");
 ----
+
+include::camel-spring-boot::page$box-starter.adoc[]
+
diff --git a/components/camel-braintree/src/main/docs/braintree-component.adoc b/components/camel-braintree/src/main/docs/braintree-component.adoc
index 1f4f422..1d1a5ba 100644
--- a/components/camel-braintree/src/main/docs/braintree-component.adoc
+++ b/components/camel-braintree/src/main/docs/braintree-component.adoc
@@ -868,3 +868,5 @@ body in the *inBody* endpoint parameter.
 </blueprint>
 --------------------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$braintree-starter.adoc[]
diff --git a/components/camel-browse/src/main/docs/browse-component.adoc b/components/camel-browse/src/main/docs/browse-component.adoc
index 4df6b27..b0d7ecb 100644
--- a/components/camel-browse/src/main/docs/browse-component.adoc
+++ b/components/camel-browse/src/main/docs/browse-component.adoc
@@ -104,3 +104,5 @@ public void inspectRecievedOrders() {
 }
 ----
 
+
+include::camel-spring-boot::page$browse-starter.adoc[]
diff --git a/components/camel-caffeine/src/main/docs/caffeine-cache-component.adoc b/components/camel-caffeine/src/main/docs/caffeine-cache-component.adoc
index 2542c03..3faa610 100644
--- a/components/camel-caffeine/src/main/docs/caffeine-cache-component.adoc
+++ b/components/camel-caffeine/src/main/docs/caffeine-cache-component.adoc
@@ -130,3 +130,5 @@ Each time you'll use an operation on the cache you'll have two different headers
 CaffeineConstants.ACTION_HAS_RESULT
 CaffeineConstants.ACTION_SUCCEEDED
 ------------------------------------------------------------
+
+include::camel-spring-boot::page$caffeine-starter.adoc[]
diff --git a/components/camel-caffeine/src/main/docs/caffeine-loadcache-component.adoc b/components/camel-caffeine/src/main/docs/caffeine-loadcache-component.adoc
index 7b6cf39..987af55 100644
--- a/components/camel-caffeine/src/main/docs/caffeine-loadcache-component.adoc
+++ b/components/camel-caffeine/src/main/docs/caffeine-loadcache-component.adoc
@@ -98,3 +98,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$caffeine-starter.adoc[]
diff --git a/components/camel-cassandraql/src/main/docs/cql-component.adoc b/components/camel-cassandraql/src/main/docs/cql-component.adoc
index d4cf20d..48c870e 100644
--- a/components/camel-cassandraql/src/main/docs/cql-component.adoc
+++ b/components/camel-cassandraql/src/main/docs/cql-component.adoc
@@ -283,3 +283,5 @@ Arrays.asList("davsclaus", "Claus", "Ibsen")
 The same approach can be used for updating or querying the table.
 
 
+
+include::camel-spring-boot::page$cassandraql-starter.adoc[]
diff --git a/components/camel-cbor/src/main/docs/cbor-dataformat.adoc b/components/camel-cbor/src/main/docs/cbor-dataformat.adoc
index d9603f4..441064a 100644
--- a/components/camel-cbor/src/main/docs/cbor-dataformat.adoc
+++ b/components/camel-cbor/src/main/docs/cbor-dataformat.adoc
@@ -76,3 +76,5 @@ And then you can refer to this id in the route:
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$cbor-starter.adoc[]
diff --git a/components/camel-chatscript/src/main/docs/chatscript-component.adoc b/components/camel-chatscript/src/main/docs/chatscript-component.adoc
index 97d69e9..2539040 100644
--- a/components/camel-chatscript/src/main/docs/chatscript-component.adoc
+++ b/components/camel-chatscript/src/main/docs/chatscript-component.adoc
@@ -89,3 +89,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$chatscript-starter.adoc[]
diff --git a/components/camel-chunk/src/main/docs/chunk-component.adoc b/components/camel-chunk/src/main/docs/chunk-component.adoc
index da2501f..c54775d 100644
--- a/components/camel-chunk/src/main/docs/chunk-component.adoc
+++ b/components/camel-chunk/src/main/docs/chunk-component.adoc
@@ -201,3 +201,5 @@ Regards Camel Riders Bookstore
 {$body}
 ----------------------------------------------
 
+
+include::camel-spring-boot::page$chunk-starter.adoc[]
diff --git a/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc b/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc
index 49c6b2b..232e6f9 100644
--- a/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc
+++ b/components/camel-cm-sms/src/main/docs/cm-sms-component.adoc
@@ -90,3 +90,5 @@ with the following path and query parameters:
 == Sample
 
 You can try https://github.com/oalles/camel-cm-sample[this project] to see how camel-cm-sms can be integrated in a camel route. 
+
+include::camel-spring-boot::page$cm-sms-starter.adoc[]
diff --git a/components/camel-cmis/src/main/docs/cmis-component.adoc b/components/camel-cmis/src/main/docs/cmis-component.adoc
index 49ce091..905798a 100644
--- a/components/camel-cmis/src/main/docs/cmis-component.adoc
+++ b/components/camel-cmis/src/main/docs/cmis-component.adoc
@@ -146,3 +146,5 @@ Maven users will need to add the following dependency to their pom.xml.
 where `${camel-version`} must be replaced by the actual version of Camel
 (2.11 or higher).
 
+
+include::camel-spring-boot::page$cmis-starter.adoc[]
diff --git a/components/camel-coap/src/main/docs/coap-component.adoc b/components/camel-coap/src/main/docs/coap-component.adoc
index 721ba20..d01973a 100644
--- a/components/camel-coap/src/main/docs/coap-component.adoc
+++ b/components/camel-coap/src/main/docs/coap-component.adoc
@@ -130,3 +130,5 @@ The following rules determine which request method the CoAP producer will use to
  2. **GET** if a query string is provided on the target CoAP server URI.
  3. **POST** if the message exchange body is not null.
  4. **GET** otherwise.
+
+include::camel-spring-boot::page$coap-starter.adoc[]
diff --git a/components/camel-cometd/src/main/docs/cometd-component.adoc b/components/camel-cometd/src/main/docs/cometd-component.adoc
index 346825f..64ddc66 100644
--- a/components/camel-cometd/src/main/docs/cometd-component.adoc
+++ b/components/camel-cometd/src/main/docs/cometd-component.adoc
@@ -212,3 +212,5 @@ Spring DSL based configuration of endpoint
   <to uri="cometds://127.0.0.1:443/service/test?baseResource=file:./target/test-classes/webapp&timeout=240000&interval=0&maxInterval=30000&multiFrameInterval=1500&jsonCommented=true&logLevel=2"/>...
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$cometd-starter.adoc[]
diff --git a/components/camel-consul/src/main/docs/consul-component.adoc b/components/camel-consul/src/main/docs/consul-component.adoc
index c2d8980..c961a5a 100644
--- a/components/camel-consul/src/main/docs/consul-component.adoc
+++ b/components/camel-consul/src/main/docs/consul-component.adoc
@@ -148,3 +148,5 @@ with the following path and query parameters:
 |CamelConsulSession|String|The session id
 |CamelConsulValueAsString|boolean|To transform values retrieved from Consul i.e. on KV endpoint to string.
 |=======================================================================
+
+include::camel-spring-boot::page$consul-starter.adoc[]
diff --git a/components/camel-controlbus/src/main/docs/controlbus-component.adoc b/components/camel-controlbus/src/main/docs/controlbus-component.adoc
index a454391..382cd41 100644
--- a/components/camel-controlbus/src/main/docs/controlbus-component.adoc
+++ b/components/camel-controlbus/src/main/docs/controlbus-component.adoc
@@ -199,3 +199,5 @@ message we sent to the control bus component.
 ====
 You can also use other languages such as xref:groovy-language.adoc[Groovy], etc.
 ====
+
+include::camel-spring-boot::page$controlbus-starter.adoc[]
diff --git a/components/camel-corda/src/main/docs/corda-component.adoc b/components/camel-corda/src/main/docs/corda-component.adoc
index a7e2037..3cebb48 100644
--- a/components/camel-corda/src/main/docs/corda-component.adoc
+++ b/components/camel-corda/src/main/docs/corda-component.adoc
@@ -124,3 +124,5 @@ Read the node information:
 from("direct:start")
     .to("corda://localhost:10006?username=user1&password=test&operation=NODE_INFO");
 --------------------------------------------------------
+
+include::camel-spring-boot::page$corda-starter.adoc[]
diff --git a/components/camel-couchbase/src/main/docs/couchbase-component.adoc b/components/camel-couchbase/src/main/docs/couchbase-component.adoc
index 7516035..7bdb38c 100644
--- a/components/camel-couchbase/src/main/docs/couchbase-component.adoc
+++ b/components/camel-couchbase/src/main/docs/couchbase-component.adoc
@@ -134,3 +134,5 @@ In order to authenticate with newer versions of Couchbase Server 5.0 and beyond,
 
  * The value formerly interpreted as a bucket-name is now interpreted as a username. The username must correspond to a user defined on the cluster that is being accessed.
  * The value formerly interpreted as a bucket-password is now interpreted as the password of the defined user.
+
+include::camel-spring-boot::page$couchbase-starter.adoc[]
diff --git a/components/camel-couchdb/src/main/docs/couchdb-component.adoc b/components/camel-couchdb/src/main/docs/couchdb-component.adoc
index fea15e2..c17137d 100644
--- a/components/camel-couchdb/src/main/docs/couchdb-component.adoc
+++ b/components/camel-couchdb/src/main/docs/couchdb-component.adoc
@@ -168,3 +168,5 @@ exchange is used
 ----------------------------------------------------------------------------------------
 from("someProducingEndpoint").process(someProcessor).to("couchdb:http://localhost:9999")
 ----------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$couchdb-starter.adoc[]
diff --git a/components/camel-cron/src/main/docs/cron-component.adoc b/components/camel-cron/src/main/docs/cron-component.adoc
index 9171a14..c6d8c3a 100644
--- a/components/camel-cron/src/main/docs/cron-component.adoc
+++ b/components/camel-cron/src/main/docs/cron-component.adoc
@@ -133,3 +133,5 @@ Routes can also be written using the XML DSL.
     <to uri="log:info"/>
 </route>
 -------------
+
+include::camel-spring-boot::page$cron-starter.adoc[]
diff --git a/components/camel-crypto-cms/src/main/docs/crypto-cms-component.adoc b/components/camel-crypto-cms/src/main/docs/crypto-cms-component.adoc
index 20033a5..11c4411 100644
--- a/components/camel-crypto-cms/src/main/docs/crypto-cms-component.adoc
+++ b/components/camel-crypto-cms/src/main/docs/crypto-cms-component.adoc
@@ -403,3 +403,5 @@ from("direct:start")
         <to uri="mock:result" />
     </route>    
 ----
+
+include::camel-spring-boot::page$crypto-cms-starter.adoc[]
diff --git a/components/camel-crypto/src/main/docs/crypto-component.adoc b/components/camel-crypto/src/main/docs/crypto-component.adoc
index b14fae7..2b716e3 100644
--- a/components/camel-crypto/src/main/docs/crypto-component.adoc
+++ b/components/camel-crypto/src/main/docs/crypto-component.adoc
@@ -240,3 +240,5 @@ signed.getIn().setHeader(KEYSTORE_ALIAS, "bob");
 template.send("direct:alias-verify", signed);
 -------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$crypto-starter.adoc[]
diff --git a/components/camel-crypto/src/main/docs/crypto-dataformat.adoc b/components/camel-crypto/src/main/docs/crypto-dataformat.adoc
index d2b706f..607b2fd 100644
--- a/components/camel-crypto/src/main/docs/crypto-dataformat.adoc
+++ b/components/camel-crypto/src/main/docs/crypto-dataformat.adoc
@@ -276,3 +276,5 @@ need to add the following dependency to your pom.
 </dependency>
 ----------------------------------------------------------
 
+
+include::camel-spring-boot::page$crypto-starter.adoc[]
diff --git a/components/camel-crypto/src/main/docs/pgp-dataformat.adoc b/components/camel-crypto/src/main/docs/pgp-dataformat.adoc
index bbd734a..574994a 100644
--- a/components/camel-crypto/src/main/docs/pgp-dataformat.adoc
+++ b/components/camel-crypto/src/main/docs/pgp-dataformat.adoc
@@ -307,3 +307,5 @@ need to add the following dependency to your pom.
 </dependency>
 ----------------------------------------------------------
 
+
+include::camel-spring-boot::page$crypto-starter.adoc[]
diff --git a/components/camel-csv/src/main/docs/csv-dataformat.adoc b/components/camel-csv/src/main/docs/csv-dataformat.adoc
index 70fa527..c902189 100644
--- a/components/camel-csv/src/main/docs/csv-dataformat.adoc
+++ b/components/camel-csv/src/main/docs/csv-dataformat.adoc
@@ -375,3 +375,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$csv-starter.adoc[]
diff --git a/components/camel-cxf/src/main/docs/cxf-component.adoc b/components/camel-cxf/src/main/docs/cxf-component.adoc
index 2cc0bbf..5c666a5 100644
--- a/components/camel-cxf/src/main/docs/cxf-component.adoc
+++ b/components/camel-cxf/src/main/docs/cxf-component.adoc
@@ -874,3 +874,5 @@ the key SOAPAction (case-insensitive).
 
  
 
+
+include::camel-spring-boot::page$cxf-starter.adoc[]
diff --git a/components/camel-cxf/src/main/docs/cxfrs-component.adoc b/components/camel-cxf/src/main/docs/cxfrs-component.adoc
index 5bd7e1a..2f0b823 100644
--- a/components/camel-cxf/src/main/docs/cxfrs-component.adoc
+++ b/components/camel-cxf/src/main/docs/cxfrs-component.adoc
@@ -479,3 +479,5 @@ queryMap.put("q1", "new");
 queryMap.put("q2", "world");
 inMessage.setHeader(CxfConstants.CAMEL_CXF_RS_QUERY_MAP, queryMap);
 ----
+
+include::camel-spring-boot::page$cxf-starter.adoc[]
diff --git a/components/camel-dataformat/src/main/docs/dataformat-component.adoc b/components/camel-dataformat/src/main/docs/dataformat-component.adoc
index 5e2666c..527ec39 100644
--- a/components/camel-dataformat/src/main/docs/dataformat-component.adoc
+++ b/components/camel-dataformat/src/main/docs/dataformat-component.adoc
@@ -98,3 +98,5 @@ And in XML DSL you do:
   </route>
 </camelContext>
 ----
+
+include::camel-spring-boot::page$dataformat-starter.adoc[]
diff --git a/components/camel-dataset/src/main/docs/dataset-component.adoc b/components/camel-dataset/src/main/docs/dataset-component.adoc
index 1148053..b039357 100644
--- a/components/camel-dataset/src/main/docs/dataset-component.adoc
+++ b/components/camel-dataset/src/main/docs/dataset-component.adoc
@@ -239,3 +239,5 @@ the bodies from a file.
 |`delimiter` |`String` |\z |Specifies the delimiter pattern used by a `java.util.Scanner` to split
 the file into multiple payloads.
 |===
+
+include::camel-spring-boot::page$dataset-starter.adoc[]
diff --git a/components/camel-dataset/src/main/docs/dataset-test-component.adoc b/components/camel-dataset/src/main/docs/dataset-test-component.adoc
index a18ccdb..b02cdd0 100644
--- a/components/camel-dataset/src/main/docs/dataset-test-component.adoc
+++ b/components/camel-dataset/src/main/docs/dataset-test-component.adoc
@@ -121,3 +121,5 @@ method], your test case will perform the necessary assertions.
 To see how you can set other expectations on the test endpoint, see the
 xref:mock-component.adoc[Mock] component.
 
+
+include::camel-spring-boot::page$dataset-starter.adoc[]
diff --git a/components/camel-debezium-mongodb/src/main/docs/debezium-mongodb-component.adoc b/components/camel-debezium-mongodb/src/main/docs/debezium-mongodb-component.adoc
index 8929658..3d5ca22 100644
--- a/components/camel-debezium-mongodb/src/main/docs/debezium-mongodb-component.adoc
+++ b/components/camel-debezium-mongodb/src/main/docs/debezium-mongodb-component.adoc
@@ -177,3 +177,5 @@ from("debezium-mongodb:dbz-test-1?offsetStorageFileName=/usr/offset-file-1.dat&m
 By default, the component will emit the events in the body String JSON format in case of `u`, `c` or `r` operations, this can be easily converted to JSON using Camel JSON Data Format e.g: `.unmarshal().json()` like the above example. In case of operation `d`, the body will be `null`.
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-mongodb-starter.adoc[]
diff --git a/components/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc b/components/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc
index 3ea5990..7cff86c 100644
--- a/components/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc
+++ b/components/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc
@@ -227,3 +227,5 @@ from("debezium-mysql:[name]?[options]])
 ----
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-mysql-starter.adoc[]
diff --git a/components/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc b/components/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc
index 3420439..44ac383 100644
--- a/components/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc
+++ b/components/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc
@@ -210,3 +210,5 @@ from("debezium-postgres:[name]?[options]])
 ----
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-postgres-starter.adoc[]
diff --git a/components/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc b/components/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc
index 8f1d06f..d23b198 100644
--- a/components/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc
+++ b/components/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc
@@ -191,3 +191,5 @@ from("debezium-sqlserver:[name]?[options]])
 ----
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-sqlserver-starter.adoc[]
diff --git a/components/camel-digitalocean/src/main/docs/digitalocean-component.adoc b/components/camel-digitalocean/src/main/docs/digitalocean-component.adoc
index d3529bb..4455fb9 100644
--- a/components/camel-digitalocean/src/main/docs/digitalocean-component.adoc
+++ b/components/camel-digitalocean/src/main/docs/digitalocean-component.adoc
@@ -469,3 +469,5 @@ from("direct:shutdown")
     .setHeader(DigitalOceanConstants.ID, 34772987)
     .to("digitalocean:droplet?operation=shutdown&oAuthToken=XXXXXX")
 ```
+
+include::camel-spring-boot::page$digitalocean-starter.adoc[]
diff --git a/components/camel-direct/src/main/docs/direct-component.adoc b/components/camel-direct/src/main/docs/direct-component.adoc
index 51d0b12..e08d76b 100644
--- a/components/camel-direct/src/main/docs/direct-component.adoc
+++ b/components/camel-direct/src/main/docs/direct-component.adoc
@@ -134,3 +134,5 @@ And the sample using spring DSL:
 See also samples from the xref:seda-component.adoc[SEDA] component, how they can
 be used together.
 
+
+include::camel-spring-boot::page$direct-starter.adoc[]
diff --git a/components/camel-directvm/src/main/docs/direct-vm-component.adoc b/components/camel-directvm/src/main/docs/direct-vm-component.adoc
index d066f5f..dcbb781 100644
--- a/components/camel-directvm/src/main/docs/direct-vm-component.adoc
+++ b/components/camel-directvm/src/main/docs/direct-vm-component.adoc
@@ -143,3 +143,5 @@ And the sample using spring DSL:
 </route>
 ----
 
+
+include::camel-spring-boot::page$directvm-starter.adoc[]
diff --git a/components/camel-disruptor/src/main/docs/disruptor-component.adoc b/components/camel-disruptor/src/main/docs/disruptor-component.adoc
index a13b24a..ef90416 100644
--- a/components/camel-disruptor/src/main/docs/disruptor-component.adoc
+++ b/components/camel-disruptor/src/main/docs/disruptor-component.adoc
@@ -328,3 +328,5 @@ using JMX in this fashion:
 DisruptorEndpoint disruptor = context.getEndpoint("disruptor:xxxx");
 int size = disruptor.getBufferSize();
 --------------------------------------------------------------------
+
+include::camel-spring-boot::page$disruptor-starter.adoc[]
diff --git a/components/camel-dns/src/main/docs/dns-component.adoc b/components/camel-dns/src/main/docs/dns-component.adoc
index 6680fc9..2e46f83 100644
--- a/components/camel-dns/src/main/docs/dns-component.adoc
+++ b/components/camel-dns/src/main/docs/dns-component.adoc
@@ -190,3 +190,5 @@ i.e. You may have an instance in NYC and an instance in SFO. You would configure
 	<route id="routeId" autoStartup="false" routePolicyRef="dnsActivationPolicy">
 	</route>
 ----
+
+include::camel-spring-boot::page$dns-starter.adoc[]
diff --git a/components/camel-docker/src/main/docs/docker-component.adoc b/components/camel-docker/src/main/docs/docker-component.adoc
index cac5b2e..feb3b54 100644
--- a/components/camel-docker/src/main/docs/docker-component.adoc
+++ b/components/camel-docker/src/main/docs/docker-component.adoc
@@ -142,3 +142,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$docker-starter.adoc[]
diff --git a/components/camel-dozer/src/main/docs/dozer-component.adoc b/components/camel-dozer/src/main/docs/dozer-component.adoc
index 2ae6d8d..4ac2c5d 100644
--- a/components/camel-dozer/src/main/docs/dozer-component.adoc
+++ b/components/camel-dozer/src/main/docs/dozer-component.adoc
@@ -293,3 +293,5 @@ An example of mapping a message header into a target field:
 Note that any properties within your expression must be escaped with "\"
 to prevent an error when Dozer attempts to resolve variable values
 defined using the EL.
+
+include::camel-spring-boot::page$dozer-starter.adoc[]
diff --git a/components/camel-drill/src/main/docs/drill-component.adoc b/components/camel-drill/src/main/docs/drill-component.adoc
index 8bb1cbe..807cbb3 100644
--- a/components/camel-drill/src/main/docs/drill-component.adoc
+++ b/components/camel-drill/src/main/docs/drill-component.adoc
@@ -91,3 +91,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$drill-starter.adoc[]
diff --git a/components/camel-dropbox/src/main/docs/dropbox-component.adoc b/components/camel-dropbox/src/main/docs/dropbox-component.adoc
index 39fba90..7c26311 100644
--- a/components/camel-dropbox/src/main/docs/dropbox-component.adoc
+++ b/components/camel-dropbox/src/main/docs/dropbox-component.adoc
@@ -426,3 +426,5 @@ Dropbox documentation,
 
 
  
+
+include::camel-spring-boot::page$dropbox-starter.adoc[]
diff --git a/components/camel-ehcache/src/main/docs/ehcache-component.adoc b/components/camel-ehcache/src/main/docs/ehcache-component.adoc
index 8ef5e9a..56f548b 100644
--- a/components/camel-ehcache/src/main/docs/ehcache-component.adoc
+++ b/components/camel-ehcache/src/main/docs/ehcache-component.adoc
@@ -237,3 +237,5 @@ public class EhcacheAggregationRepositoryRoutesTest extends CamelTestSupport {
     }
 }
 ---------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$ehcache-starter.adoc[]
diff --git a/components/camel-elasticsearch-rest/src/main/docs/elasticsearch-rest-component.adoc b/components/camel-elasticsearch-rest/src/main/docs/elasticsearch-rest-component.adoc
index db1aa6c..e2aabca 100644
--- a/components/camel-elasticsearch-rest/src/main/docs/elasticsearch-rest-component.adoc
+++ b/components/camel-elasticsearch-rest/src/main/docs/elasticsearch-rest-component.adoc
@@ -320,3 +320,5 @@ req.types("tweets");
 MultiSearchRequest request = new MultiSearchRequest().add(req1).add(req);
 Item[] response = template.requestBody("direct:search", request, Item[].class);
 ----
+
+include::camel-spring-boot::page$elasticsearch-rest-starter.adoc[]
diff --git a/components/camel-elsql/src/main/docs/elsql-component.adoc b/components/camel-elsql/src/main/docs/elsql-component.adoc
index 9f7649f..550057d 100644
--- a/components/camel-elsql/src/main/docs/elsql-component.adoc
+++ b/components/camel-elsql/src/main/docs/elsql-component.adoc
@@ -277,3 +277,5 @@ Notice that there is no existing `Exchange` with message body and headers, so
 the simple expression you can use in the consumer are most useable for calling
 bean methods as in this example.
 
+
+include::camel-spring-boot::page$elsql-starter.adoc[]
diff --git a/components/camel-elytron/src/main/docs/elytron-component.adoc b/components/camel-elytron/src/main/docs/elytron-component.adoc
index e348456..dd52ab2 100644
--- a/components/camel-elytron/src/main/docs/elytron-component.adoc
+++ b/components/camel-elytron/src/main/docs/elytron-component.adoc
@@ -127,3 +127,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters |  | SSLContextParameters
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$elytron-starter.adoc[]
diff --git a/components/camel-etcd/src/main/docs/etcd-keys-component.adoc b/components/camel-etcd/src/main/docs/etcd-keys-component.adoc
index 84af14b..7371c03 100644
--- a/components/camel-etcd/src/main/docs/etcd-keys-component.adoc
+++ b/components/camel-etcd/src/main/docs/etcd-keys-component.adoc
@@ -77,4 +77,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters. |  | SSLContextParameters
 | *userName* (security) | The user name to use for basic authentication. |  | String
 |===
-// endpoint options: END
\ No newline at end of file
+// endpoint options: END
+include::camel-spring-boot::page$etcd-starter.adoc[]
diff --git a/components/camel-etcd/src/main/docs/etcd-stats-component.adoc b/components/camel-etcd/src/main/docs/etcd-stats-component.adoc
index c97de6f..f72ee68 100644
--- a/components/camel-etcd/src/main/docs/etcd-stats-component.adoc
+++ b/components/camel-etcd/src/main/docs/etcd-stats-component.adoc
@@ -99,4 +99,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters. |  | SSLContextParameters
 | *userName* (security) | The user name to use for basic authentication. |  | String
 |===
-// endpoint options: END
\ No newline at end of file
+// endpoint options: END
+include::camel-spring-boot::page$etcd-starter.adoc[]
diff --git a/components/camel-etcd/src/main/docs/etcd-watch-component.adoc b/components/camel-etcd/src/main/docs/etcd-watch-component.adoc
index 58f2e3e..b9295c1 100644
--- a/components/camel-etcd/src/main/docs/etcd-watch-component.adoc
+++ b/components/camel-etcd/src/main/docs/etcd-watch-component.adoc
@@ -80,4 +80,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters. |  | SSLContextParameters
 | *userName* (security) | The user name to use for basic authentication. |  | String
 |===
-// endpoint options: END
\ No newline at end of file
+// endpoint options: END
+include::camel-spring-boot::page$etcd-starter.adoc[]
diff --git a/components/camel-exec/src/main/docs/exec-component.adoc b/components/camel-exec/src/main/docs/exec-component.adoc
index 670281b..0c7e84e 100644
--- a/components/camel-exec/src/main/docs/exec-component.adoc
+++ b/components/camel-exec/src/main/docs/exec-component.adoc
@@ -253,3 +253,5 @@ such a command - `echo` - in Windows.
 from("direct:exec").to("exec:cmd?args=/C echo echoString")
 ----------------------------------------------------------
 
+
+include::camel-spring-boot::page$exec-starter.adoc[]
diff --git a/components/camel-facebook/src/main/docs/facebook-component.adoc b/components/camel-facebook/src/main/docs/facebook-component.adoc
index 64f435d..f188e5e 100644
--- a/components/camel-facebook/src/main/docs/facebook-component.adoc
+++ b/components/camel-facebook/src/main/docs/facebook-component.adoc
@@ -319,3 +319,5 @@ CamelFacebook.query header.
         .setHeader("CamelFacebook.query", header("bar"))
         .to("facebook://posts");
 --------------------------------------------------------
+
+include::camel-spring-boot::page$facebook-starter.adoc[]
diff --git a/components/camel-fastjson/src/main/docs/json-fastjson-dataformat.adoc b/components/camel-fastjson/src/main/docs/json-fastjson-dataformat.adoc
index ed8d74c..8aae1a2 100644
--- a/components/camel-fastjson/src/main/docs/json-fastjson-dataformat.adoc
+++ b/components/camel-fastjson/src/main/docs/json-fastjson-dataformat.adoc
@@ -66,3 +66,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$fastjson-starter.adoc[]
diff --git a/components/camel-fhir/camel-fhir-component/src/main/docs/fhir-component.adoc b/components/camel-fhir/camel-fhir-component/src/main/docs/fhir-component.adoc
index 03312fb..8ac75ec 100644
--- a/components/camel-fhir/camel-fhir-component/src/main/docs/fhir-component.adoc
+++ b/components/camel-fhir/camel-fhir-component/src/main/docs/fhir-component.adoc
@@ -140,3 +140,6 @@ with the following path and query parameters:
 | *username* (security) | Username to use for basic authentication |  | String
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$fhir-starter.adoc[]
+
diff --git a/components/camel-file-watch/src/main/docs/file-watch-component.adoc b/components/camel-file-watch/src/main/docs/file-watch-component.adoc
index a10cc90..d2e1714 100644
--- a/components/camel-file-watch/src/main/docs/file-watch-component.adoc
+++ b/components/camel-file-watch/src/main/docs/file-watch-component.adoc
@@ -136,3 +136,5 @@ relative filename. For absolute files this is the absolute path.
 
 |`CamelFileLastModified` |A `Long` value containing the last modified timestamp of the file.
 |===
+
+include::camel-spring-boot::page$file-watch-starter.adoc[]
diff --git a/components/camel-file/src/main/docs/file-component.adoc b/components/camel-file/src/main/docs/file-component.adoc
index be1f38c..926a244 100644
--- a/components/camel-file/src/main/docs/file-component.adoc
+++ b/components/camel-file/src/main/docs/file-component.adoc
@@ -1153,3 +1153,5 @@ prior actions such as interceptors, onCompletion to take action.
 This component has log level *TRACE* that can be helpful if you have
 problems.
 
+
+include::camel-spring-boot::page$file-starter.adoc[]
diff --git a/components/camel-flatpack/src/main/docs/flatpack-component.adoc b/components/camel-flatpack/src/main/docs/flatpack-component.adoc
index 8b4e1be..681739d 100644
--- a/components/camel-flatpack/src/main/docs/flatpack-component.adoc
+++ b/components/camel-flatpack/src/main/docs/flatpack-component.adoc
@@ -321,3 +321,5 @@ the download page for the latest versions).
 </dependency>
 -----------------------------------------
 
+
+include::camel-spring-boot::page$flatpack-starter.adoc[]
diff --git a/components/camel-flatpack/src/main/docs/flatpack-dataformat.adoc b/components/camel-flatpack/src/main/docs/flatpack-dataformat.adoc
index c01d7ec..c8702bd 100644
--- a/components/camel-flatpack/src/main/docs/flatpack-dataformat.adoc
+++ b/components/camel-flatpack/src/main/docs/flatpack-dataformat.adoc
@@ -94,3 +94,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -----------------------------------------
+
+include::camel-spring-boot::page$flatpack-starter.adoc[]
diff --git a/components/camel-flink/src/main/docs/flink-component.adoc b/components/camel-flink/src/main/docs/flink-component.adoc
index 81e6150..6eb91b5 100644
--- a/components/camel-flink/src/main/docs/flink-component.adoc
+++ b/components/camel-flink/src/main/docs/flink-component.adoc
@@ -163,3 +163,5 @@ try {
         camelContext.stop();
     }
 -----------------------------------
+
+include::camel-spring-boot::page$flink-starter.adoc[]
diff --git a/components/camel-fop/src/main/docs/fop-component.adoc b/components/camel-fop/src/main/docs/fop-component.adoc
index e070146..245eb57 100644
--- a/components/camel-fop/src/main/docs/fop-component.adoc
+++ b/components/camel-fop/src/main/docs/fop-component.adoc
@@ -170,3 +170,5 @@ from("file:source/data/xml")
     .to("file:target/data");
 ---------------------------------
 
+
+include::camel-spring-boot::page$fop-starter.adoc[]
diff --git a/components/camel-freemarker/src/main/docs/freemarker-component.adoc b/components/camel-freemarker/src/main/docs/freemarker-component.adoc
index 95e793b..9d5f8eb 100644
--- a/components/camel-freemarker/src/main/docs/freemarker-component.adoc
+++ b/components/camel-freemarker/src/main/docs/freemarker-component.adoc
@@ -245,3 +245,5 @@ ${body}
 
 And the java code:
 
+
+include::camel-spring-boot::page$freemarker-starter.adoc[]
diff --git a/components/camel-ftp/src/main/docs/ftp-component.adoc b/components/camel-ftp/src/main/docs/ftp-component.adoc
index c6d6b76..b1bee1a 100644
--- a/components/camel-ftp/src/main/docs/ftp-component.adoc
+++ b/components/camel-ftp/src/main/docs/ftp-component.adoc
@@ -753,3 +753,5 @@ String data = template.retrieveBodyNoWait("ftp://admin@localhost:21/nolist/?pass
 This component has log level *TRACE* that can be helpful if you have
 problems.
 
+
+include::camel-spring-boot::page$ftp-starter.adoc[]
diff --git a/components/camel-ftp/src/main/docs/ftps-component.adoc b/components/camel-ftp/src/main/docs/ftps-component.adoc
index e45d271..eaf2a62 100644
--- a/components/camel-ftp/src/main/docs/ftps-component.adoc
+++ b/components/camel-ftp/src/main/docs/ftps-component.adoc
@@ -193,3 +193,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$ftp-starter.adoc[]
diff --git a/components/camel-ftp/src/main/docs/sftp-component.adoc b/components/camel-ftp/src/main/docs/sftp-component.adoc
index b198040..d94e406 100644
--- a/components/camel-ftp/src/main/docs/sftp-component.adoc
+++ b/components/camel-ftp/src/main/docs/sftp-component.adoc
@@ -193,3 +193,5 @@ with the following path and query parameters:
 | *useUserKnownHostsFile* (security) | If knownHostFile has not been explicit configured then use the host file from System.getProperty(user.home)/.ssh/known_hosts | true | boolean
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$ftp-starter.adoc[]
diff --git a/components/camel-ganglia/src/main/docs/ganglia-component.adoc b/components/camel-ganglia/src/main/docs/ganglia-component.adoc
index 9db32c1..f5d8fd0 100644
--- a/components/camel-ganglia/src/main/docs/ganglia-component.adoc
+++ b/components/camel-ganglia/src/main/docs/ganglia-component.adoc
@@ -163,3 +163,5 @@ from("direct:value.for.ganglia")
 from("direct:ganglia.tx")
     .to("ganglia:239.2.11.71:8649?mode=MULTICAST&prefix=test");
 ----
+
+include::camel-spring-boot::page$ganglia-starter.adoc[]
diff --git a/components/camel-geocoder/src/main/docs/geocoder-component.adoc b/components/camel-geocoder/src/main/docs/geocoder-component.adoc
index 92dc470..e03dbdc 100644
--- a/components/camel-geocoder/src/main/docs/geocoder-component.adoc
+++ b/components/camel-geocoder/src/main/docs/geocoder-component.adoc
@@ -186,3 +186,5 @@ shown:
   from("direct:start")
     .to("geocoder:address:current")
 -----------------------------------
+
+include::camel-spring-boot::page$geocoder-starter.adoc[]
diff --git a/components/camel-git/src/main/docs/git-component.adoc b/components/camel-git/src/main/docs/git-component.adoc
index db8b1cb..578ea29 100644
--- a/components/camel-git/src/main/docs/git-component.adoc
+++ b/components/camel-git/src/main/docs/git-component.adoc
@@ -146,3 +146,5 @@ Below is an example route of a consumer that consumes commit:
 from("git:///tmp/testRepo?type=commit")
                         .to(....)
 ---------------------------------------
+
+include::camel-spring-boot::page$git-starter.adoc[]
diff --git a/components/camel-github/src/main/docs/github-component.adoc b/components/camel-github/src/main/docs/github-component.adoc
index a82517e..ecd22d8 100644
--- a/components/camel-github/src/main/docs/github-component.adoc
+++ b/components/camel-github/src/main/docs/github-component.adoc
@@ -144,3 +144,5 @@ pull request discussion is assumed.
 
 |createIssue |String (issue body text) | - GitHubIssueTitle (String) (REQUIRED): Issue Title.
 |=======================================================================
+
+include::camel-spring-boot::page$github-starter.adoc[]
diff --git a/components/camel-google-bigquery/src/main/docs/google-bigquery-component.adoc b/components/camel-google-bigquery/src/main/docs/google-bigquery-component.adoc
index 5f88cb1..9b7481f 100644
--- a/components/camel-google-bigquery/src/main/docs/google-bigquery-component.adoc
+++ b/components/camel-google-bigquery/src/main/docs/google-bigquery-component.adoc
@@ -168,3 +168,5 @@ A insert id can be set on the exchange with the header `GoogleBigQueryConstants.
 query parameter `useAsInsertId`. As an insert id need to be specified per row inserted the exchange header can't
 be used when the payload is a list - if the payload is a list the `GoogleBigQueryConstants.INSERT_ID` will
 be ignored. In that case use the query parameter `useAsInsertId`.
+
+include::camel-spring-boot::page$google-bigquery-starter.adoc[]
diff --git a/components/camel-google-bigquery/src/main/docs/google-bigquery-sql-component.adoc b/components/camel-google-bigquery/src/main/docs/google-bigquery-sql-component.adoc
index f787205..20d637e 100644
--- a/components/camel-google-bigquery/src/main/docs/google-bigquery-sql-component.adoc
+++ b/components/camel-google-bigquery/src/main/docs/google-bigquery-sql-component.adoc
@@ -138,3 +138,5 @@ with the following path and query parameters:
 == Producer Endpoints
 
 Google BigQuery SQL endpoint expects the payload to be either empty or a map of query parameters.
+
+include::camel-spring-boot::page$google-bigquery-starter.adoc[]
diff --git a/components/camel-google-calendar/src/main/docs/google-calendar-component.adoc b/components/camel-google-calendar/src/main/docs/google-calendar-component.adoc
index 45dac20..d0282b9 100644
--- a/components/camel-google-calendar/src/main/docs/google-calendar-component.adoc
+++ b/components/camel-google-calendar/src/main/docs/google-calendar-component.adoc
@@ -187,3 +187,5 @@ APIs used by the GoogleCalendarComponent. Producer endpoints can specify
 the option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-calendar-starter.adoc[]
diff --git a/components/camel-google-calendar/src/main/docs/google-calendar-stream-component.adoc b/components/camel-google-calendar/src/main/docs/google-calendar-stream-component.adoc
index d37d5ea..9a26bf3 100644
--- a/components/camel-google-calendar/src/main/docs/google-calendar-stream-component.adoc
+++ b/components/camel-google-calendar/src/main/docs/google-calendar-stream-component.adoc
@@ -140,3 +140,5 @@ from("google-calendar-stream://test?markAsRead=true&delay=5000&maxResults=5").to
 This route will consume the next five events starting from the date of polling.
 
    
+
+include::camel-spring-boot::page$google-calendar-starter.adoc[]
diff --git a/components/camel-google-drive/src/main/docs/google-drive-component.adoc b/components/camel-google-drive/src/main/docs/google-drive-component.adoc
index c2c143f..b9e3717 100644
--- a/components/camel-google-drive/src/main/docs/google-drive-component.adoc
+++ b/components/camel-google-drive/src/main/docs/google-drive-component.adoc
@@ -195,3 +195,5 @@ APIs used by the GoogleDriveComponent. Producer endpoints can specify
 the option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-drive-starter.adoc[]
diff --git a/components/camel-google-mail/src/main/docs/google-mail-component.adoc b/components/camel-google-mail/src/main/docs/google-mail-component.adoc
index a6ac741..8a01b6f 100644
--- a/components/camel-google-mail/src/main/docs/google-mail-component.adoc
+++ b/components/camel-google-mail/src/main/docs/google-mail-component.adoc
@@ -184,3 +184,5 @@ APIs used by the GoogleMailComponent. Producer endpoints can specify the
 option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-mail-starter.adoc[]
diff --git a/components/camel-google-mail/src/main/docs/google-mail-stream-component.adoc b/components/camel-google-mail/src/main/docs/google-mail-stream-component.adoc
index ad1f543..81a9f25 100644
--- a/components/camel-google-mail/src/main/docs/google-mail-stream-component.adoc
+++ b/components/camel-google-mail/src/main/docs/google-mail-stream-component.adoc
@@ -136,3 +136,5 @@ from("google-mail-stream://test?markAsRead=true&delay=5000&maxResults=5&labels=G
 This route will consume unread messages with labels Github and Apache and it will mark the messages as read.
 
    
+
+include::camel-spring-boot::page$google-mail-starter.adoc[]
diff --git a/components/camel-google-pubsub/src/main/docs/google-pubsub-component.adoc b/components/camel-google-pubsub/src/main/docs/google-pubsub-component.adoc
index 4dc4ea7..2f96dde 100644
--- a/components/camel-google-pubsub/src/main/docs/google-pubsub-component.adoc
+++ b/components/camel-google-pubsub/src/main/docs/google-pubsub-component.adoc
@@ -168,3 +168,5 @@ be redelivered to the next consumer.
 
 It is possible to delay the message redelivery by setting the acknowledgement deadline explicitly for the rollback by
 setting the message header `GooglePubsubConstants.ACK_DEADLINE` to the value in seconds.
+
+include::camel-spring-boot::page$google-pubsub-starter.adoc[]
diff --git a/components/camel-google-sheets/src/main/docs/google-sheets-component.adoc b/components/camel-google-sheets/src/main/docs/google-sheets-component.adoc
index 54fe104..938c42f 100644
--- a/components/camel-google-sheets/src/main/docs/google-sheets-component.adoc
+++ b/components/camel-google-sheets/src/main/docs/google-sheets-component.adoc
@@ -180,3 +180,5 @@ APIs used by the GoogleSheetsComponent. Producer endpoints can specify
 the option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-sheets-starter.adoc[]
diff --git a/components/camel-google-sheets/src/main/docs/google-sheets-stream-component.adoc b/components/camel-google-sheets/src/main/docs/google-sheets-stream-component.adoc
index ef7e562..5a4f09e 100644
--- a/components/camel-google-sheets/src/main/docs/google-sheets-stream-component.adoc
+++ b/components/camel-google-sheets/src/main/docs/google-sheets-stream-component.adoc
@@ -142,3 +142,5 @@ from("google-sheets-stream://data?range=A:B&delay=5000&maxResults=5").to("mock:r
 This route will consume the next ten events starting from the date of polling.
 
    
+
+include::camel-spring-boot::page$google-sheets-starter.adoc[]
diff --git a/components/camel-gora/src/main/docs/gora-component.adoc b/components/camel-gora/src/main/docs/gora-component.adoc
index ef30f85..3f900d5 100644
--- a/components/camel-gora/src/main/docs/gora-component.adoc
+++ b/components/camel-gora/src/main/docs/gora-component.adoc
@@ -279,3 +279,5 @@ For more please information and in depth configuration refer to the
 http://gora.apache.org/current/overview.html[Apache Gora Documentation]
 and the http://gora.apache.org/current/tutorial.html[Apache Gora
 Tutorial].
+
+include::camel-spring-boot::page$gora-starter.adoc[]
diff --git a/components/camel-graphql/src/main/docs/graphql-component.adoc b/components/camel-graphql/src/main/docs/graphql-component.adoc
index b27aaff..dcab145 100644
--- a/components/camel-graphql/src/main/docs/graphql-component.adoc
+++ b/components/camel-graphql/src/main/docs/graphql-component.adoc
@@ -164,3 +164,5 @@ public JsonObject addBookMutationVariables() {
 from("direct:start")
     .to("graphql://http://example.com/graphql?graphql?queryFile=addBookMutation.graphql&variables=#addBookMutationVariables")
 ----
+
+include::camel-spring-boot::page$graphql-starter.adoc[]
diff --git a/components/camel-grok/src/main/docs/grok-dataformat.adoc b/components/camel-grok/src/main/docs/grok-dataformat.adoc
index a0382f6..f936c90 100644
--- a/components/camel-grok/src/main/docs/grok-dataformat.adoc
+++ b/components/camel-grok/src/main/docs/grok-dataformat.adoc
@@ -105,3 +105,5 @@ The Grok dataformat supports 5 options, which are listed below.
 |===
 // dataformat options: END
 ND
+
+include::camel-spring-boot::page$grok-starter.adoc[]
diff --git a/components/camel-groovy/src/main/docs/groovy-language.adoc b/components/camel-groovy/src/main/docs/groovy-language.adoc
index 31d39ff..f0cd1c7 100644
--- a/components/camel-groovy/src/main/docs/groovy-language.adoc
+++ b/components/camel-groovy/src/main/docs/groovy-language.adoc
@@ -193,3 +193,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ---------------------------------------
+
+include::camel-spring-boot::page$groovy-starter.adoc[]
diff --git a/components/camel-grpc/src/main/docs/grpc-component.adoc b/components/camel-grpc/src/main/docs/grpc-component.adoc
index f3ac5da..05a19a9 100644
--- a/components/camel-grpc/src/main/docs/grpc-component.adoc
+++ b/components/camel-grpc/src/main/docs/grpc-component.adoc
@@ -290,3 +290,5 @@ http://www.grpc.io/[gRPC project site]
 
 https://www.xolstice.org/protobuf-maven-plugin[Maven Protocol Buffers Plugin]
 
+
+include::camel-spring-boot::page$grpc-starter.adoc[]
diff --git a/components/camel-gson/src/main/docs/json-gson-dataformat.adoc b/components/camel-gson/src/main/docs/json-gson-dataformat.adoc
index 386e090..69f6b88 100644
--- a/components/camel-gson/src/main/docs/json-gson-dataformat.adoc
+++ b/components/camel-gson/src/main/docs/json-gson-dataformat.adoc
@@ -67,3 +67,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$gson-starter.adoc[]
diff --git a/components/camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc b/components/camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc
index 119e822..a3550a3 100644
--- a/components/camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc
+++ b/components/camel-guava-eventbus/src/main/docs/guava-eventbus-component.adoc
@@ -228,3 +228,5 @@ follows.
 -----------------------------------------------------------------------------------------------------
 from("guava-eventbus:busName?listenerInterface=com.example.MultipleEventsListener").to("seda:queue");
 -----------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$guava-eventbus-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-atomicvalue-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-atomicvalue-component.adoc
index 1a45e6e..fb84623 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-atomicvalue-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-atomicvalue-component.adoc
@@ -215,3 +215,5 @@ Spring DSL:
     <to uri="hazelcast-atomicvalue:foo" />
 </route>
 -----------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-instance-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-instance-component.adoc
index 0603f2e..b35aff0 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-instance-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-instance-component.adoc
@@ -106,3 +106,5 @@ Header Variables inside the response message:
 
 |`CamelHazelcastInstancePort` |`Integer` |port number of the instance
 |=======================================================================
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-list-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-list-component.adoc
index ccf6548..5f1274d 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-list-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-list-component.adoc
@@ -137,3 +137,5 @@ fromF("hazelcast-%smm", HazelcastConstants.LIST_PREFIX)
                 .otherwise()
                         .log("fail!");
 -----------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-map-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-map-component.adoc
index 5d19178..9a6de8d 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-map-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-map-component.adoc
@@ -338,3 +338,5 @@ fromF("hazelcast-%sfoo", HazelcastConstants.MAP_PREFIX)
     .otherwise()
          .log("fail!");
 --------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-multimap-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-multimap-component.adoc
index aed97f1..2488f26 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-multimap-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-multimap-component.adoc
@@ -241,3 +241,5 @@ Header Variables inside the response message:
 
 |`CamelHazelcastCacheType` |`String` |the type of the cache - here multimap
 |=======================================================================
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-queue-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-queue-component.adoc
index a505f9c..14c8adf 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-queue-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-queue-component.adoc
@@ -226,3 +226,5 @@ fromF("hazelcast-%smm", HazelcastConstants.QUEUE_PREFIX)
     .otherwise()
         .log("fail!");
 -------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-replicatedmap-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-replicatedmap-component.adoc
index 26927c5..b1c13fa 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-replicatedmap-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-replicatedmap-component.adoc
@@ -214,3 +214,5 @@ Header Variables inside the response message:
 
 |`CamelHazelcastCacheType` |`String` |the type of the cache - here replicatedmap
 |=======================================================================
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-ringbuffer-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-ringbuffer-component.adoc
index 515d86f..f7a4e72 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-ringbuffer-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-ringbuffer-component.adoc
@@ -120,3 +120,5 @@ from("direct:get")
 .toF("hazelcast-%sbar", HazelcastConstants.RINGBUFFER_PREFIX)
 .to("seda:out");
 -----------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-seda-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-seda-component.adoc
index b60cc10..02befce 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-seda-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-seda-component.adoc
@@ -117,3 +117,5 @@ Spring DSL:
   <to uri="mock:result" />
 </route>
 -----------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-set-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-set-component.adoc
index 08ede1b..0f41d71 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-set-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-set-component.adoc
@@ -64,3 +64,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast-topic-component.adoc b/components/camel-hazelcast/src/main/docs/hazelcast-topic-component.adoc
index 185c6a5..5194d2f 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast-topic-component.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast-topic-component.adoc
@@ -97,3 +97,5 @@ fromF("hazelcast-%sfoo", HazelcastConstants.TOPIC_PREFIX)
     .otherwise()
       .log("...this should never have happened")
 --------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hazelcast/src/main/docs/hazelcast.adoc b/components/camel-hazelcast/src/main/docs/hazelcast.adoc
index 6f0bd01..a5830f0 100644
--- a/components/camel-hazelcast/src/main/docs/hazelcast.adoc
+++ b/components/camel-hazelcast/src/main/docs/hazelcast.adoc
@@ -186,3 +186,5 @@ to reference the service in the hazelcast endpoint.
     </route>
 </camelContext>
 --------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/components/camel-hbase/src/main/docs/hbase-component.adoc b/components/camel-hbase/src/main/docs/hbase-component.adoc
index 9917132..86a91dd 100644
--- a/components/camel-hbase/src/main/docs/hbase-component.adoc
+++ b/components/camel-hbase/src/main/docs/hbase-component.adoc
@@ -507,3 +507,5 @@ myvalue to the column myfamily:myqualifier. +
 advantage it has over the header mapping strategy is that the HBaseData
 object can be easily converted to or from xml/json.
 
+
+include::camel-spring-boot::page$hbase-starter.adoc[]
diff --git a/components/camel-hdfs/src/main/docs/hdfs-component.adoc b/components/camel-hdfs/src/main/docs/hdfs-component.adoc
index 1540138..bfdba96 100644
--- a/components/camel-hdfs/src/main/docs/hdfs-component.adoc
+++ b/components/camel-hdfs/src/main/docs/hdfs-component.adoc
@@ -336,3 +336,5 @@ static {
 }
 ------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$hdfs-starter.adoc[]
diff --git a/components/camel-hipchat/src/main/docs/hipchat-component.adoc b/components/camel-hipchat/src/main/docs/hipchat-component.adoc
index c315636..8a6716c 100644
--- a/components/camel-hipchat/src/main/docs/hipchat-component.adoc
+++ b/components/camel-hipchat/src/main/docs/hipchat-component.adoc
@@ -237,3 +237,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ------------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$hipchat-starter.adoc[]
diff --git a/components/camel-hl7/src/main/docs/hl7-dataformat.adoc b/components/camel-hl7/src/main/docs/hl7-dataformat.adoc
index a2d6657..3bb1d89 100644
--- a/components/camel-hl7/src/main/docs/hl7-dataformat.adoc
+++ b/components/camel-hl7/src/main/docs/hl7-dataformat.adoc
@@ -405,3 +405,5 @@ repository].
 </dependency>
 ----
 
+
+include::camel-spring-boot::page$hl7-starter.adoc[]
diff --git a/components/camel-hl7/src/main/docs/hl7terser-language.adoc b/components/camel-hl7/src/main/docs/hl7terser-language.adoc
index a5bad27..5ec3bd6 100644
--- a/components/camel-hl7/src/main/docs/hl7terser-language.adoc
+++ b/components/camel-hl7/src/main/docs/hl7terser-language.adoc
@@ -131,3 +131,5 @@ import ca.uhn.hl7v2.validation.impl.DefaultValidation;
       // acknowledgement
       .transform(ack())
 ----
+
+include::camel-spring-boot::page$hl7-starter.adoc[]
diff --git a/components/camel-http/src/main/docs/http-component.adoc b/components/camel-http/src/main/docs/http-component.adoc
index 60aee7b..d177386 100644
--- a/components/camel-http/src/main/docs/http-component.adoc
+++ b/components/camel-http/src/main/docs/http-component.adoc
@@ -693,3 +693,5 @@ property.
    <property name="x509HostnameVerifier" ref="hostnameVerifier"/>
 </bean>
 ----------------------------------------------------------------------------
+
+include::camel-spring-boot::page$http-starter.adoc[]
diff --git a/components/camel-hystrix/src/main/docs/hystrix.adoc b/components/camel-hystrix/src/main/docs/hystrix.adoc
index 08a544e..27b8550 100644
--- a/components/camel-hystrix/src/main/docs/hystrix.adoc
+++ b/components/camel-hystrix/src/main/docs/hystrix.adoc
@@ -19,3 +19,5 @@ for this component:
 </dependency>
 ----
 
+
+include::camel-spring-boot::page$hystrix-starter.adoc[]
diff --git a/components/camel-ical/src/main/docs/ical-dataformat.adoc b/components/camel-ical/src/main/docs/ical-dataformat.adoc
index f0abff0..aac77fc 100644
--- a/components/camel-ical/src/main/docs/ical-dataformat.adoc
+++ b/components/camel-ical/src/main/docs/ical-dataformat.adoc
@@ -70,3 +70,5 @@ for this component:
 </dependency>
 ------------------------------------------------------------
 
+
+include::camel-spring-boot::page$ical-starter.adoc[]
diff --git a/components/camel-iec60870/src/main/docs/iec60870-client-component.adoc b/components/camel-iec60870/src/main/docs/iec60870-client-component.adoc
index b808b5b..d8ec4ee 100644
--- a/components/camel-iec60870/src/main/docs/iec60870-client-component.adoc
+++ b/components/camel-iec60870/src/main/docs/iec60870-client-component.adoc
@@ -128,3 +128,5 @@ The final connection options will be evaluated in the following order:
 * Apply +protocolOptions+ if present
 * Apply +dataModuleOptions+ if present
 * Apply all explicit connection parameters (e.g. +timeZone+)
+
+include::camel-spring-boot::page$iec60870-starter.adoc[]
diff --git a/components/camel-iec60870/src/main/docs/iec60870-server-component.adoc b/components/camel-iec60870/src/main/docs/iec60870-server-component.adoc
index 3be4bab..65df120 100644
--- a/components/camel-iec60870/src/main/docs/iec60870-server-component.adoc
+++ b/components/camel-iec60870/src/main/docs/iec60870-server-component.adoc
@@ -112,3 +112,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$iec60870-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite-cache-component.adoc b/components/camel-ignite/src/main/docs/ignite-cache-component.adoc
index d6ef81c..c21cdb2 100644
--- a/components/camel-ignite/src/main/docs/ignite-cache-component.adoc
+++ b/components/camel-ignite/src/main/docs/ignite-cache-component.adoc
@@ -109,3 +109,5 @@ It does not allow you to dynamically change the cache against which a producer o
 | CamelIgniteCacheOldValue | IgniteConstants.IGNITE_CACHE_OLD_VALUE | Object |
 This header carries the old cache value when passed in the incoming cache event (consumer).
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite-compute-component.adoc b/components/camel-ignite/src/main/docs/ignite-compute-component.adoc
index 0e4169a..f06e498 100644
--- a/components/camel-ignite/src/main/docs/ignite-compute-component.adoc
+++ b/components/camel-ignite/src/main/docs/ignite-compute-component.adoc
@@ -109,3 +109,5 @@ Affinity cache name for the AFFINITY_CALL and AFFINITY_RUN operations.
 | CamelIgniteComputeAffinityKey | IgniteConstants.IGNITE_COMPUTE_AFFINITY_KEY | Object |
 Affinity key for the AFFINITY_CALL and AFFINITY_RUN operations.
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite-events-component.adoc b/components/camel-ignite/src/main/docs/ignite-events-component.adoc
index 11aa6a1..2276221 100644
--- a/components/camel-ignite/src/main/docs/ignite-events-component.adoc
+++ b/components/camel-ignite/src/main/docs/ignite-events-component.adoc
@@ -67,3 +67,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite-idgen-component.adoc b/components/camel-ignite/src/main/docs/ignite-idgen-component.adoc
index 040da6c..602fb9e 100644
--- a/components/camel-ignite/src/main/docs/ignite-idgen-component.adoc
+++ b/components/camel-ignite/src/main/docs/ignite-idgen-component.adoc
@@ -65,3 +65,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite-messaging-component.adoc b/components/camel-ignite/src/main/docs/ignite-messaging-component.adoc
index c9ec23c..c6c6f4a 100644
--- a/components/camel-ignite/src/main/docs/ignite-messaging-component.adoc
+++ b/components/camel-ignite/src/main/docs/ignite-messaging-component.adoc
@@ -84,3 +84,5 @@ It also carries the topic on which a message was received (consumer).
 | CamelIgniteMessagingUUID | IgniteConstants.IGNITE_MESSAGING_UUID | UUID |
 This header is filled in with the UUID of the subscription when a message arrives (consumer).
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite-queue-component.adoc b/components/camel-ignite/src/main/docs/ignite-queue-component.adoc
index f71f5d4..54bf4ac 100644
--- a/components/camel-ignite/src/main/docs/ignite-queue-component.adoc
+++ b/components/camel-ignite/src/main/docs/ignite-queue-component.adoc
@@ -87,3 +87,5 @@ The amount of items transferred as the result of the DRAIN operation.
 | CamelIgniteQueueTimeoutMillis | IgniteConstants.IGNITE_QUEUE_TIMEOUT_MILLIS | Long or long |
 Dynamically sets the timeout in milliseconds to use when invoking the OFFER or POLL operations. 
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite-set-component.adoc b/components/camel-ignite/src/main/docs/ignite-set-component.adoc
index fa13717..0b5009a 100644
--- a/components/camel-ignite/src/main/docs/ignite-set-component.adoc
+++ b/components/camel-ignite/src/main/docs/ignite-set-component.adoc
@@ -76,3 +76,5 @@ This endpoint uses the following headers:
 | CamelIgniteSetsOperation | IgniteConstants.IGNITE_SETS_OPERATION | IgniteSetOperation enum |
 Allows you to dynamically change the set operation.
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-ignite/src/main/docs/ignite.adoc b/components/camel-ignite/src/main/docs/ignite.adoc
index db0fcf5..f24ea9f 100644
--- a/components/camel-ignite/src/main/docs/ignite.adoc
+++ b/components/camel-ignite/src/main/docs/ignite.adoc
@@ -107,3 +107,5 @@ When installing on Apache Karaf:
 
 Please refer to the OSGi section in the Ignite documentation for more information.
 
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/components/camel-infinispan/src/main/docs/infinispan-component.adoc b/components/camel-infinispan/src/main/docs/infinispan-component.adoc
index 9031607..e280842 100644
--- a/components/camel-infinispan/src/main/docs/infinispan-component.adoc
+++ b/components/camel-infinispan/src/main/docs/infinispan-component.adoc
@@ -819,3 +819,5 @@ XML file as well:
 </camelContext>
 ----
 
+
+include::camel-spring-boot::page$infinispan-starter.adoc[]
diff --git a/components/camel-influxdb/src/main/docs/influxdb-component.adoc b/components/camel-influxdb/src/main/docs/influxdb-component.adoc
index 1789cc9..31bab88 100644
--- a/components/camel-influxdb/src/main/docs/influxdb-component.adoc
+++ b/components/camel-influxdb/src/main/docs/influxdb-component.adoc
@@ -118,3 +118,5 @@ from("direct:start")
 
 For more information, see these resources...
 
+
+include::camel-spring-boot::page$influxdb-starter.adoc[]
diff --git a/components/camel-iota/src/main/docs/iota-component.adoc b/components/camel-iota/src/main/docs/iota-component.adoc
index f88ab03..f230df9 100644
--- a/components/camel-iota/src/main/docs/iota-component.adoc
+++ b/components/camel-iota/src/main/docs/iota-component.adoc
@@ -146,3 +146,5 @@ The following route defined in Spring XML retrieve transfers data
 </route>
 ----
 
+
+include::camel-spring-boot::page$iota-starter.adoc[]
diff --git a/components/camel-ipfs/src/main/docs/ipfs-component.adoc b/components/camel-ipfs/src/main/docs/ipfs-component.adoc
index bca773c..f64815b 100644
--- a/components/camel-ipfs/src/main/docs/ipfs-component.adoc
+++ b/components/camel-ipfs/src/main/docs/ipfs-component.adoc
@@ -96,3 +96,5 @@ from("direct:start").to("ipfs:add")
 from("direct:start").to("ipfs:get?outdir=target")
 from("direct:start").to("ipfs:cat");
 ---------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$ipfs-starter.adoc[]
diff --git a/components/camel-irc/src/main/docs/irc-component.adoc b/components/camel-irc/src/main/docs/irc-component.adoc
index 0d1897a..a7933be 100644
--- a/components/camel-irc/src/main/docs/irc-component.adoc
+++ b/components/camel-irc/src/main/docs/irc-component.adoc
@@ -226,3 +226,5 @@ You can specify the destination in the following header:
 |Header |Type |Description
 |`irc.sendTo` |`String` |The channel (or the person) name.
 |=====================================================================
+
+include::camel-spring-boot::page$irc-starter.adoc[]
diff --git a/components/camel-ironmq/src/main/docs/ironmq-component.adoc b/components/camel-ironmq/src/main/docs/ironmq-component.adoc
index b105877..8707e47 100644
--- a/components/camel-ironmq/src/main/docs/ironmq-component.adoc
+++ b/components/camel-ironmq/src/main/docs/ironmq-component.adoc
@@ -175,3 +175,5 @@ Dequeue from activemq jms and enqueue the messages on IronMQ.
 from("activemq:foo")
   .to("ironmq:testqueue?projectId=myIronMQProjectid&token=myIronMQToken");
 --------------------------------------------------
+
+include::camel-spring-boot::page$ironmq-starter.adoc[]
diff --git a/components/camel-jackson/src/main/docs/json-jackson-dataformat.adoc b/components/camel-jackson/src/main/docs/json-jackson-dataformat.adoc
index 582b4d0..14eee06 100644
--- a/components/camel-jackson/src/main/docs/json-jackson-dataformat.adoc
+++ b/components/camel-jackson/src/main/docs/json-jackson-dataformat.adoc
@@ -75,3 +75,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$jackson-starter.adoc[]
diff --git a/components/camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc b/components/camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc
index a672019..0938e36 100644
--- a/components/camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc
+++ b/components/camel-jacksonxml/src/main/docs/jacksonxml-dataformat.adoc
@@ -362,3 +362,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$jacksonxml-starter.adoc[]
diff --git a/components/camel-jaxb/src/main/docs/jaxb-dataformat.adoc b/components/camel-jaxb/src/main/docs/jaxb-dataformat.adoc
index f2be5a9..1986964 100644
--- a/components/camel-jaxb/src/main/docs/jaxb-dataformat.adoc
+++ b/components/camel-jaxb/src/main/docs/jaxb-dataformat.adoc
@@ -317,3 +317,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$jaxb-starter.adoc[]
diff --git a/components/camel-jbpm/src/main/docs/jbpm-component.adoc b/components/camel-jbpm/src/main/docs/jbpm-component.adoc
index 53ea083..f90094a 100644
--- a/components/camel-jbpm/src/main/docs/jbpm-component.adoc
+++ b/components/camel-jbpm/src/main/docs/jbpm-component.adoc
@@ -290,3 +290,5 @@ from("direct:start")
         &deploymentId=evaluation");
 ----------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jbpm-starter.adoc[]
diff --git a/components/camel-jcache/src/main/docs/jcache-component.adoc b/components/camel-jcache/src/main/docs/jcache-component.adoc
index d346057..f597f41 100644
--- a/components/camel-jcache/src/main/docs/jcache-component.adoc
+++ b/components/camel-jcache/src/main/docs/jcache-component.adoc
@@ -330,3 +330,5 @@ If the determined _key_ is _null_, nothing is looked up or stored in cache.
 In case of an exception during the route, the error handled is called as always. If the exception gets _handled()_,
  the policy stores the Exchange body, otherwise nothing is added to the cache.
  If an exception happens during evaluating the keyExpression, the routing fails, the error handler is called as normally.
+
+include::camel-spring-boot::page$jcache-starter.adoc[]
diff --git a/components/camel-jclouds/src/main/docs/jclouds-component.adoc b/components/camel-jclouds/src/main/docs/jclouds-component.adoc
index e2b2c91..5be5d55 100644
--- a/components/camel-jclouds/src/main/docs/jclouds-component.adoc
+++ b/components/camel-jclouds/src/main/docs/jclouds-component.adoc
@@ -372,3 +372,5 @@ Here is the same using spring xml.
 </route>
 ----------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jclouds-starter.adoc[]
diff --git a/components/camel-jcr/src/main/docs/jcr-component.adoc b/components/camel-jcr/src/main/docs/jcr-component.adoc
index 4f65ed7..73edeb2 100644
--- a/components/camel-jcr/src/main/docs/jcr-component.adoc
+++ b/components/camel-jcr/src/main/docs/jcr-component.adoc
@@ -136,3 +136,5 @@ all the children.
 </route>
 ---------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jcr-starter.adoc[]
diff --git a/components/camel-jdbc/src/main/docs/jdbc-component.adoc b/components/camel-jdbc/src/main/docs/jdbc-component.adoc
index b92d7d5..5e60af2 100644
--- a/components/camel-jdbc/src/main/docs/jdbc-component.adoc
+++ b/components/camel-jdbc/src/main/docs/jdbc-component.adoc
@@ -316,3 +316,5 @@ from("timer://MoveNewCustomersEveryHour?period=3600000")
         .to("jdbc:testdb");
 ----
 
+
+include::camel-spring-boot::page$jdbc-starter.adoc[]
diff --git a/components/camel-jetty/src/main/docs/jetty-component.adoc b/components/camel-jetty/src/main/docs/jetty-component.adoc
index e0de879..51ab58c 100644
--- a/components/camel-jetty/src/main/docs/jetty-component.adoc
+++ b/components/camel-jetty/src/main/docs/jetty-component.adoc
@@ -614,3 +614,5 @@ running another instance of Jetty outside of the Camel context and
 sharing the same MBeanServer between the instances, you can provide both
 instances with a reference to the same MBeanContainer in order to avoid
 name collisions when registering Jetty MBeans.
+
+include::camel-spring-boot::page$jetty-starter.adoc[]
diff --git a/components/camel-jgroups-raft/src/main/docs/jgroups-raft-component.adoc b/components/camel-jgroups-raft/src/main/docs/jgroups-raft-component.adoc
index 12aa856..7946eeb 100644
--- a/components/camel-jgroups-raft/src/main/docs/jgroups-raft-component.adoc
+++ b/components/camel-jgroups-raft/src/main/docs/jgroups-raft-component.adoc
@@ -179,3 +179,5 @@ context.addService(service);
 
 from("master:mycluster:jetty:http://localhost:8080/orders").to("jms:orders"); 
 -----------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$jgroups-raft-starter.adoc[]
diff --git a/components/camel-jgroups/src/main/docs/jgroups-component.adoc b/components/camel-jgroups/src/main/docs/jgroups-component.adoc
index 634f30e..494c876 100644
--- a/components/camel-jgroups/src/main/docs/jgroups-component.adoc
+++ b/components/camel-jgroups/src/main/docs/jgroups-component.adoc
@@ -267,3 +267,5 @@ context.addService(service);
 
 from("master:mycluster:jetty:http://localhost:8080/orders").to("jms:orders"); 
 -----------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$jgroups-starter.adoc[]
diff --git a/components/camel-jing/src/main/docs/jing-component.adoc b/components/camel-jing/src/main/docs/jing-component.adoc
index cd0ae6e..66a0fc8 100644
--- a/components/camel-jing/src/main/docs/jing-component.adoc
+++ b/components/camel-jing/src/main/docs/jing-component.adoc
@@ -122,3 +122,5 @@ schema (which is supplied on the classpath).
         </route>
     </camelContext>
 ----
+
+include::camel-spring-boot::page$jing-starter.adoc[]
diff --git a/components/camel-jira/src/main/docs/jira-component.adoc b/components/camel-jira/src/main/docs/jira-component.adoc
index 0b50349..4e2ac35 100644
--- a/components/camel-jira/src/main/docs/jira-component.adoc
+++ b/components/camel-jira/src/main/docs/jira-component.adoc
@@ -255,3 +255,5 @@ Required:
 * `IssueWatchersAdd`: A list of strings with the usernames to add to the watcher list.
 * `IssueWatchersRemove`: A list of strings with the usernames to remove from the watcher list.
 
+
+include::camel-spring-boot::page$jira-starter.adoc[]
diff --git a/components/camel-jms/src/main/docs/jms-component.adoc b/components/camel-jms/src/main/docs/jms-component.adoc
index f7d4389..67283ec 100644
--- a/components/camel-jms/src/main/docs/jms-component.adoc
+++ b/components/camel-jms/src/main/docs/jms-component.adoc
@@ -1336,3 +1336,5 @@ wmq.setDestinationResolver(new DestinationResolver() {
 });
 ----------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jms-starter.adoc[]
diff --git a/components/camel-jmx/src/main/docs/jmx-component.adoc b/components/camel-jmx/src/main/docs/jmx-component.adoc
index daddbf6..c532a22 100644
--- a/components/camel-jmx/src/main/docs/jmx-component.adoc
+++ b/components/camel-jmx/src/main/docs/jmx-component.adoc
@@ -90,3 +90,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$jmx-starter.adoc[]
diff --git a/components/camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc b/components/camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc
index 9cfe2d6..8224826 100644
--- a/components/camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc
+++ b/components/camel-johnzon/src/main/docs/json-johnzon-dataformat.adoc
@@ -67,3 +67,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$johnzon-starter.adoc[]
diff --git a/components/camel-jolt/src/main/docs/jolt-component.adoc b/components/camel-jolt/src/main/docs/jolt-component.adoc
index 4240256..6b15574 100644
--- a/components/camel-jolt/src/main/docs/jolt-component.adoc
+++ b/components/camel-jolt/src/main/docs/jolt-component.adoc
@@ -133,3 +133,5 @@ from("direct:in").
 
  
 
+
+include::camel-spring-boot::page$jolt-starter.adoc[]
diff --git a/components/camel-jooq/src/main/docs/jooq-component.adoc b/components/camel-jooq/src/main/docs/jooq-component.adoc
index de56733..1e9b490 100644
--- a/components/camel-jooq/src/main/docs/jooq-component.adoc
+++ b/components/camel-jooq/src/main/docs/jooq-component.adoc
@@ -273,3 +273,5 @@ public class BookStoreRecordBean {
     }
 }
 ----
+
+include::camel-spring-boot::page$jooq-starter.adoc[]
diff --git a/components/camel-jpa/src/main/docs/jpa-component.adoc b/components/camel-jpa/src/main/docs/jpa-component.adoc
index edfc677..8ce0d40 100644
--- a/components/camel-jpa/src/main/docs/jpa-component.adoc
+++ b/components/camel-jpa/src/main/docs/jpa-component.adoc
@@ -442,3 +442,5 @@ argument to the JVM:
 -javaagent:<path_to_your_local_m2_cache>/org/apache/openjpa/openjpa/2.2.1/openjpa-2.2.1.jar
 -------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jpa-starter.adoc[]
diff --git a/components/camel-jsch/src/main/docs/scp-component.adoc b/components/camel-jsch/src/main/docs/scp-component.adoc
index f35a2ca..59bf273 100644
--- a/components/camel-jsch/src/main/docs/scp-component.adoc
+++ b/components/camel-jsch/src/main/docs/scp-component.adoc
@@ -131,3 +131,5 @@ Currently camel-jsch only supports a
 https://www.javadoc.io/doc/org.apache.camel/camel-api/current/org/apache/camel/Producer.html[Producer]
 (i.e. copy files to another host). 
 
+
+include::camel-spring-boot::page$jsch-starter.adoc[]
diff --git a/components/camel-jslt/src/main/docs/jslt-component.adoc b/components/camel-jslt/src/main/docs/jslt-component.adoc
index ab35eaf..d11e5bf 100644
--- a/components/camel-jslt/src/main/docs/jslt-component.adoc
+++ b/components/camel-jslt/src/main/docs/jslt-component.adoc
@@ -137,3 +137,5 @@ from("direct:in").
   setHeader("CamelJsltResourceUri").constant(".published").
   to("jslt:dummy");
 ---------------------------------------------------------------------
+
+include::camel-spring-boot::page$jslt-starter.adoc[]
diff --git a/components/camel-json-validator/src/main/docs/json-validator-component.adoc b/components/camel-json-validator/src/main/docs/json-validator-component.adoc
index 729aafb..43de707d 100644
--- a/components/camel-json-validator/src/main/docs/json-validator-component.adoc
+++ b/components/camel-json-validator/src/main/docs/json-validator-component.adoc
@@ -145,3 +145,5 @@ from("direct:start")
   .to("json-validator:myschema.json")
   .to("mock:end")
 ----
+
+include::camel-spring-boot::page$json-validator-starter.adoc[]
diff --git a/components/camel-jsonapi/src/main/docs/jsonApi-dataformat.adoc b/components/camel-jsonapi/src/main/docs/jsonApi-dataformat.adoc
index 3b326bb..56d2e45 100644
--- a/components/camel-jsonapi/src/main/docs/jsonApi-dataformat.adoc
+++ b/components/camel-jsonapi/src/main/docs/jsonApi-dataformat.adoc
@@ -36,3 +36,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$jsonapi-starter.adoc[]
diff --git a/components/camel-jsonpath/src/main/docs/jsonpath-language.adoc b/components/camel-jsonpath/src/main/docs/jsonpath-language.adoc
index 9ef0c5f..6d631c7 100644
--- a/components/camel-jsonpath/src/main/docs/jsonpath-language.adoc
+++ b/components/camel-jsonpath/src/main/docs/jsonpath-language.adoc
@@ -336,3 +336,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ----
+
+include::camel-spring-boot::page$jsonpath-starter.adoc[]
diff --git a/components/camel-jt400/src/main/docs/jt400-component.adoc b/components/camel-jt400/src/main/docs/jt400-component.adoc
index b9c4b1b..745857d 100644
--- a/components/camel-jt400/src/main/docs/jt400-component.adoc
+++ b/components/camel-jt400/src/main/docs/jt400-component.adoc
@@ -205,3 +205,5 @@ from("jt400://username:password@system/lib.lib/MSGOUTDQ.DTAQ?keyed=true&searchKe
 .to("jms:queue:output");
 -------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jt400-starter.adoc[]
diff --git a/components/camel-kafka/src/main/docs/kafka-component.adoc b/components/camel-kafka/src/main/docs/kafka-component.adoc
index a68d250..7317930 100644
--- a/components/camel-kafka/src/main/docs/kafka-component.adoc
+++ b/components/camel-kafka/src/main/docs/kafka-component.adoc
@@ -486,3 +486,5 @@ from("kafka:my_topic?headerFilterStrategy=#myStrategy")
 ```
 
 `myStrategy` object should be subclass of `HeaderFilterStrategy` and must be placed in the Camel registry, either manually or by registration as a bean in Spring/Blueprint, as it is `CamelContext` aware.
+
+include::camel-spring-boot::page$kafka-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-config-maps-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-config-maps-component.adoc
index 4998c9f..e961ce0 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-config-maps-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-config-maps-component.adoc
@@ -138,3 +138,5 @@ fromF("kubernetes-config-maps://%s?oauthToken=%s&namespace=default&resourceName=
 
 This consumer will return a list of events on the namespace default for the config map test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-deployments-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-deployments-component.adoc
index 9324003..e7fe780 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-deployments-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-deployments-component.adoc
@@ -149,3 +149,5 @@ fromF("kubernetes-deployments://%s?oauthToken=%s&namespace=default&resourceName=
 
 This consumer will return a list of events on the namespace default for the deployment test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-hpa-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-hpa-component.adoc
index efc86a2..776a04c 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-hpa-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-hpa-component.adoc
@@ -149,3 +149,5 @@ fromF("kubernetes-hpa://%s?oauthToken=%s&namespace=default&resourceName=test", h
 
 This consumer will return a list of events on the namespace default for the hpa test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-job-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-job-component.adoc
index 31a9b9e..12042e4 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-job-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-job-component.adoc
@@ -130,3 +130,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of Jobs from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-namespaces-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-namespaces-component.adoc
index 55a509b..4b813a2 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-namespaces-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-namespaces-component.adoc
@@ -150,3 +150,5 @@ fromF("kubernetes-namespaces://%s?oauthToken=%s&namespace=default", host, authTo
 This consumer will return a list of events on the namespace default.
 
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-nodes-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-nodes-component.adoc
index 0753204..45d1e9b 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-nodes-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-nodes-component.adoc
@@ -150,3 +150,5 @@ fromF("kubernetes-nodes://%s?oauthToken=%s&resourceName=test", host, authToken).
 
 This consumer will return a list of events for the node test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-claims-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-claims-component.adoc
index 509e584..47544e6 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-claims-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-claims-component.adoc
@@ -121,3 +121,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of pvc from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-component.adoc
index ee3e9a1..2cf0d67 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-persistent-volumes-component.adoc
@@ -118,3 +118,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of pv from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-pods-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-pods-component.adoc
index 9fb97f0..6223494 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-pods-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-pods-component.adoc
@@ -148,3 +148,5 @@ fromF("kubernetes-pods://%s?oauthToken=%s&namespace=default&resourceName=test",
 
 This consumer will return a list of events on the namespace default for the pod test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-replication-controllers-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-replication-controllers-component.adoc
index a538dc9..363237b 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-replication-controllers-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-replication-controllers-component.adoc
@@ -150,3 +150,5 @@ fromF("kubernetes-replication-controllers://%s?oauthToken=%s&namespace=default&r
 
 This consumer will return a list of events on the namespace default for the rc test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-resources-quota-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-resources-quota-component.adoc
index 24ecfd9..59c491f 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-resources-quota-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-resources-quota-component.adoc
@@ -121,3 +121,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of Resource Quotas from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-secrets-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-secrets-component.adoc
index 511d86d..766c58c 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-secrets-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-secrets-component.adoc
@@ -121,3 +121,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of Secrets from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-service-accounts-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-service-accounts-component.adoc
index df9173e..b2600fa 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-service-accounts-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-service-accounts-component.adoc
@@ -118,3 +118,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of Services from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes-services-component.adoc b/components/camel-kubernetes/src/main/docs/kubernetes-services-component.adoc
index f1bbbca..0461019 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes-services-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes-services-component.adoc
@@ -148,3 +148,5 @@ fromF("kubernetes-services://%s?oauthToken=%s&namespace=default&resourceName=tes
 --------------------------------------------------------------------------------
 
 This consumer will return a list of events on the namespace default for the service test.
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/kubernetes.adoc b/components/camel-kubernetes/src/main/docs/kubernetes.adoc
index cde56e6..73a94fc 100644
--- a/components/camel-kubernetes/src/main/docs/kubernetes.adoc
+++ b/components/camel-kubernetes/src/main/docs/kubernetes.adoc
@@ -147,3 +147,5 @@ from("direct:createPod")
 -------------------------------------------------------------
 
 By using the KubernetesConstants.KUBERNETES_POD_NAME header you can specify your Pod name and pass it to this operation.
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/openshift-build-configs-component.adoc b/components/camel-kubernetes/src/main/docs/openshift-build-configs-component.adoc
index 0caa774..e3fe242 100644
--- a/components/camel-kubernetes/src/main/docs/openshift-build-configs-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/openshift-build-configs-component.adoc
@@ -118,3 +118,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of Build configs from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kubernetes/src/main/docs/openshift-builds-component.adoc b/components/camel-kubernetes/src/main/docs/openshift-builds-component.adoc
index f78cf8a..d399d57 100644
--- a/components/camel-kubernetes/src/main/docs/openshift-builds-component.adoc
+++ b/components/camel-kubernetes/src/main/docs/openshift-builds-component.adoc
@@ -118,3 +118,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of Builds from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/components/camel-kudu/src/main/docs/kudu-component.adoc b/components/camel-kudu/src/main/docs/kudu-component.adoc
index 3eb31a7..ff51487 100644
--- a/components/camel-kudu/src/main/docs/kudu-component.adoc
+++ b/components/camel-kudu/src/main/docs/kudu-component.adoc
@@ -125,3 +125,5 @@ To use this feature, add the following dependencies to your spring boot pom.xml
     <version>${camel.version}</version> <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$kudu-starter.adoc[]
diff --git a/components/camel-language/src/main/docs/language-component.adoc b/components/camel-language/src/main/docs/language-component.adoc
index fd68a6a..a3b75cc 100644
--- a/components/camel-language/src/main/docs/language-component.adoc
+++ b/components/camel-language/src/main/docs/language-component.adoc
@@ -147,3 +147,5 @@ updated script is used:
 You can refer to the resource similar to the
 other xref:language-component.adoc[Language]s in Camel by prefixing with
 `"resource:"` as shown below:
+
+include::camel-spring-boot::page$language-starter.adoc[]
diff --git a/components/camel-ldap/src/main/docs/ldap-component.adoc b/components/camel-ldap/src/main/docs/ldap-component.adoc
index 830f573..9303158 100644
--- a/components/camel-ldap/src/main/docs/ldap-component.adoc
+++ b/components/camel-ldap/src/main/docs/ldap-component.adoc
@@ -359,3 +359,5 @@ public class CustomSocketFactory extends SSLSocketFactory {
 
  
 
+
+include::camel-spring-boot::page$ldap-starter.adoc[]
diff --git a/components/camel-ldif/src/main/docs/ldif-component.adoc b/components/camel-ldif/src/main/docs/ldif-component.adoc
index cfad5b9..b0fb2f1 100644
--- a/components/camel-ldif/src/main/docs/ldif-component.adoc
+++ b/components/camel-ldif/src/main/docs/ldif-component.adoc
@@ -187,3 +187,5 @@ if (results.size() > 0) {
   }
 }
 ----
+
+include::camel-spring-boot::page$ldif-starter.adoc[]
diff --git a/components/camel-log/src/main/docs/log-component.adoc b/components/camel-log/src/main/docs/log-component.adoc
index 4cf2001..a11dce2 100644
--- a/components/camel-log/src/main/docs/log-component.adoc
+++ b/components/camel-log/src/main/docs/log-component.adoc
@@ -343,3 +343,5 @@ should be the bundle which contains route definition. To do this, either
 register single instance of `org.slf4j.Logger` in the Registry or
 reference it using `logger` URI parameter.
 
+
+include::camel-spring-boot::page$log-starter.adoc[]
diff --git a/components/camel-lra/src/main/docs/lra.adoc b/components/camel-lra/src/main/docs/lra.adoc
index d919bc8..21723a9 100644
--- a/components/camel-lra/src/main/docs/lra.adoc
+++ b/components/camel-lra/src/main/docs/lra.adoc
@@ -17,3 +17,5 @@ for this component:
 </dependency>
 ----
 
+
+include::camel-spring-boot::page$lra-starter.adoc[]
diff --git a/components/camel-lucene/src/main/docs/lucene-component.adoc b/components/camel-lucene/src/main/docs/lucene-component.adoc
index 716d7fb..dc91b31 100644
--- a/components/camel-lucene/src/main/docs/lucene-component.adoc
+++ b/components/camel-lucene/src/main/docs/lucene-component.adoc
@@ -239,3 +239,5 @@ RouteBuilder builder = new RouteBuilder() {
    }
 };
 -------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$lucene-starter.adoc[]
diff --git a/components/camel-lumberjack/src/main/docs/lumberjack-component.adoc b/components/camel-lumberjack/src/main/docs/lumberjack-component.adoc
index f5fbbb2..40af538 100644
--- a/components/camel-lumberjack/src/main/docs/lumberjack-component.adoc
+++ b/components/camel-lumberjack/src/main/docs/lumberjack-component.adoc
@@ -120,3 +120,5 @@ RouteBuilder builder = new RouteBuilder() {
     }
 };
 ------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$lumberjack-starter.adoc[]
diff --git a/components/camel-lzf/src/main/docs/lzf-dataformat.adoc b/components/camel-lzf/src/main/docs/lzf-dataformat.adoc
index 70323b9..1e4b648 100644
--- a/components/camel-lzf/src/main/docs/lzf-dataformat.adoc
+++ b/components/camel-lzf/src/main/docs/lzf-dataformat.adoc
@@ -67,3 +67,5 @@ substituting the version number for the latest & greatest release.
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$lzf-starter.adoc[]
diff --git a/components/camel-mail/src/main/docs/mail-component.adoc b/components/camel-mail/src/main/docs/mail-component.adoc
index 14c784a..72f5f96 100644
--- a/components/camel-mail/src/main/docs/mail-component.adoc
+++ b/components/camel-mail/src/main/docs/mail-component.adoc
@@ -676,3 +676,5 @@ The parameter maxMessagePerPoll and fetchSize allow you to restrict the number m
 These parameters should help to prevent bad performance when working with folders that contain a lot of messages.
 In previous versions these parameters have been evaluated too late, so that big mailboxes could still cause performance problems.
 With Camel 3.1 these parameters are evaluated earlier during the poll to avoid these problems.
+
+include::camel-spring-boot::page$mail-starter.adoc[]
diff --git a/components/camel-mail/src/main/docs/mime-multipart-dataformat.adoc b/components/camel-mail/src/main/docs/mime-multipart-dataformat.adoc
index 75b2705..11a6f01 100644
--- a/components/camel-mail/src/main/docs/mime-multipart-dataformat.adoc
+++ b/components/camel-mail/src/main/docs/mime-multipart-dataformat.adoc
@@ -194,3 +194,5 @@ If you use Maven you can just add the following to your pom.xml:
   <version>x.x.x</version> <!-- use the same version as your Camel core version -->
 </dependency>
 -----------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$mail-starter.adoc[]
diff --git a/components/camel-master/src/main/docs/master-component.adoc b/components/camel-master/src/main/docs/master-component.adoc
index 89f7472..ce6f7f0 100644
--- a/components/camel-master/src/main/docs/master-component.adoc
+++ b/components/camel-master/src/main/docs/master-component.adoc
@@ -166,3 +166,5 @@ Camel provide the following ClusterService implementations:
 - camel-kubernetes
 - camel-zookeeper
 
+
+include::camel-spring-boot::page$master-starter.adoc[]
diff --git a/components/camel-metrics/src/main/docs/metrics-component.adoc b/components/camel-metrics/src/main/docs/metrics-component.adoc
index 2a99d1b..15c01b4 100644
--- a/components/camel-metrics/src/main/docs/metrics-component.adoc
+++ b/components/camel-metrics/src/main/docs/metrics-component.adoc
@@ -635,3 +635,5 @@ with `name=MetricsMessageHistoryService`.
 This factory allows you to gather performance information about Camel Thread Pools by injecting a InstrumentedThreadPoolFactory
 which collects information from inside of Camel.
 See more details at Advanced configuration of CamelContext using Spring
+
+include::camel-spring-boot::page$metrics-starter.adoc[]
diff --git a/components/camel-micrometer/src/main/docs/micrometer-component.adoc b/components/camel-micrometer/src/main/docs/micrometer-component.adoc
index 6dc7eee..d1fe0df 100644
--- a/components/camel-micrometer/src/main/docs/micrometer-component.adoc
+++ b/components/camel-micrometer/src/main/docs/micrometer-component.adoc
@@ -570,3 +570,5 @@ an MBean name.
 
 `camel-example-micrometer` provides an example how to set up Micrometer monitoring with
 Camel using Java configuration and a Prometheus backend.
+
+include::camel-spring-boot::page$micrometer-starter.adoc[]
diff --git a/components/camel-milo/src/main/docs/milo-client-component.adoc b/components/camel-milo/src/main/docs/milo-client-component.adoc
index 8ef506d..1722505 100644
--- a/components/camel-milo/src/main/docs/milo-client-component.adoc
+++ b/components/camel-milo/src/main/docs/milo-client-component.adoc
@@ -213,3 +213,5 @@ The known security policy URIs and enum literals are can be seen here: https://g
 
 **Note:** In any case security policies are considered case sensitive.
 
+
+include::camel-spring-boot::page$milo-starter.adoc[]
diff --git a/components/camel-milo/src/main/docs/milo-server-component.adoc b/components/camel-milo/src/main/docs/milo-server-component.adoc
index 17623f2..331edaa 100644
--- a/components/camel-milo/src/main/docs/milo-server-component.adoc
+++ b/components/camel-milo/src/main/docs/milo-server-component.adoc
@@ -114,3 +114,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$milo-starter.adoc[]
diff --git a/components/camel-mina/src/main/docs/mina-component.adoc b/components/camel-mina/src/main/docs/mina-component.adoc
index 8ee1775..6721b46 100644
--- a/components/camel-mina/src/main/docs/mina-component.adoc
+++ b/components/camel-mina/src/main/docs/mina-component.adoc
@@ -278,3 +278,5 @@ can also implement some customized filters. Please note that `codec` and
 filters you may define are appended to the end of the filter chain; that
 is, after `codec` and `logger`.
 
+
+include::camel-spring-boot::page$mina-starter.adoc[]
diff --git a/components/camel-mllp/src/main/docs/mllp-component.adoc b/components/camel-mllp/src/main/docs/mllp-component.adoc
index f659e4d..3ef4743 100644
--- a/components/camel-mllp/src/main/docs/mllp-component.adoc
+++ b/components/camel-mllp/src/main/docs/mllp-component.adoc
@@ -228,3 +228,5 @@ The state of the TCP Socket can be controlled by these properties on the Camel e
 |CamelMllpCloseConnectionAfterSend | Boolean | If true, the Socket will be closed immediately after sending data
 |CamelMllpResetConnectionAfterSend | Boolean | If true, the Socket will be reset immediately after sending any data
 |====================================
+
+include::camel-spring-boot::page$mllp-starter.adoc[]
diff --git a/components/camel-mock/src/main/docs/mock-component.adoc b/components/camel-mock/src/main/docs/mock-component.adoc
index d350967..901842a 100644
--- a/components/camel-mock/src/main/docs/mock-component.adoc
+++ b/components/camel-mock/src/main/docs/mock-component.adoc
@@ -490,3 +490,5 @@ In the example above we use `seconds` as the time unit, but Camel offers
 ====
 
 
+
+include::camel-spring-boot::page$mock-starter.adoc[]
diff --git a/components/camel-mongodb-gridfs/src/main/docs/mongodb-gridfs-component.adoc b/components/camel-mongodb-gridfs/src/main/docs/mongodb-gridfs-component.adoc
index b068a43..7aef8cf 100644
--- a/components/camel-mongodb-gridfs/src/main/docs/mongodb-gridfs-component.adoc
+++ b/components/camel-mongodb-gridfs/src/main/docs/mongodb-gridfs-component.adoc
@@ -213,3 +213,5 @@ headers.put(Exchange.FILE_NAME, "filename.txt");
 template.requestBodyAndHeaders("direct:remove", "", headers);
 ------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$mongodb-gridfs-starter.adoc[]
diff --git a/components/camel-mongodb/src/main/docs/mongodb-component.adoc b/components/camel-mongodb/src/main/docs/mongodb-component.adoc
index 2ca131e..d8a2736 100644
--- a/components/camel-mongodb/src/main/docs/mongodb-component.adoc
+++ b/components/camel-mongodb/src/main/docs/mongodb-component.adoc
@@ -1010,3 +1010,5 @@ object to a `Map`, which is in turn used to initialise a new
 
 This type converter is auto-discovered, so you don't need to configure anything manually.
 
+
+include::camel-spring-boot::page$mongodb-starter.adoc[]
diff --git a/components/camel-msv/src/main/docs/msv-component.adoc b/components/camel-msv/src/main/docs/msv-component.adoc
index 0eb0b7a..ceba083 100644
--- a/components/camel-msv/src/main/docs/msv-component.adoc
+++ b/components/camel-msv/src/main/docs/msv-component.adoc
@@ -128,3 +128,5 @@ based on whether or not the XML matches the given
 http://relaxng.org/[RelaxNG XML Schema] (which is supplied on the
 classpath).
 
+
+include::camel-spring-boot::page$msv-starter.adoc[]
diff --git a/components/camel-mustache/src/main/docs/mustache-component.adoc b/components/camel-mustache/src/main/docs/mustache-component.adoc
index 238002c..295e5eb 100644
--- a/components/camel-mustache/src/main/docs/mustache-component.adoc
+++ b/components/camel-mustache/src/main/docs/mustache-component.adoc
@@ -188,3 +188,5 @@ Regards Camel Riders Bookstore
 {{body}}
 -------------------------------------------------
 
+
+include::camel-spring-boot::page$mustache-starter.adoc[]
diff --git a/components/camel-mvel/src/main/docs/mvel-component.adoc b/components/camel-mvel/src/main/docs/mvel-component.adoc
index fe9a9f2..89f68a7 100644
--- a/components/camel-mvel/src/main/docs/mvel-component.adoc
+++ b/components/camel-mvel/src/main/docs/mvel-component.adoc
@@ -190,3 +190,5 @@ from("direct:in").
   to("velocity:dummy");
 ------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$mvel-starter.adoc[]
diff --git a/components/camel-mvel/src/main/docs/mvel-language.adoc b/components/camel-mvel/src/main/docs/mvel-language.adoc
index 5bd4ed0..fff5070 100644
--- a/components/camel-mvel/src/main/docs/mvel-language.adoc
+++ b/components/camel-mvel/src/main/docs/mvel-language.adoc
@@ -119,3 +119,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$mvel-starter.adoc[]
diff --git a/components/camel-mybatis/src/main/docs/mybatis-bean-component.adoc b/components/camel-mybatis/src/main/docs/mybatis-bean-component.adoc
index cbc9620..366b50c 100644
--- a/components/camel-mybatis/src/main/docs/mybatis-bean-component.adoc
+++ b/components/camel-mybatis/src/main/docs/mybatis-bean-component.adoc
@@ -157,3 +157,5 @@ public interface AccountService {
 }
 ----
 
+
+include::camel-spring-boot::page$mybatis-starter.adoc[]
diff --git a/components/camel-mybatis/src/main/docs/mybatis-component.adoc b/components/camel-mybatis/src/main/docs/mybatis-component.adoc
index 2398160..ff1e813 100644
--- a/components/camel-mybatis/src/main/docs/mybatis-component.adoc
+++ b/components/camel-mybatis/src/main/docs/mybatis-component.adoc
@@ -416,3 +416,5 @@ usual:
 </camelContext>
 ----
 
+
+include::camel-spring-boot::page$mybatis-starter.adoc[]
diff --git a/components/camel-nagios/src/main/docs/nagios-component.adoc b/components/camel-nagios/src/main/docs/nagios-component.adoc
index e3d989a..e560c5c 100644
--- a/components/camel-nagios/src/main/docs/nagios-component.adoc
+++ b/components/camel-nagios/src/main/docs/nagios-component.adoc
@@ -152,3 +152,5 @@ In Spring XML its just a matter of defining a Spring bean with the type
 xref:manual::advanced-configuration-of-camelcontext-using-spring.adoc[Advanced
 configuration of CamelContext using Spring].
 
+
+include::camel-spring-boot::page$nagios-starter.adoc[]
diff --git a/components/camel-nats/src/main/docs/nats-component.adoc b/components/camel-nats/src/main/docs/nats-component.adoc
index 106c16b..16f18c5 100644
--- a/components/camel-nats/src/main/docs/nats-component.adoc
+++ b/components/camel-nats/src/main/docs/nats-component.adoc
@@ -202,3 +202,5 @@ from("direct:send")
 from("nats:mytopic?maxMessages=5&queueName=myqueue")
   .to("mock:result");
 ----
+
+include::camel-spring-boot::page$nats-starter.adoc[]
diff --git a/components/camel-netty-http/src/main/docs/netty-http-component.adoc b/components/camel-netty-http/src/main/docs/netty-http-component.adoc
index 3755020..d1d5e46 100644
--- a/components/camel-netty-http/src/main/docs/netty-http-component.adoc
+++ b/components/camel-netty-http/src/main/docs/netty-http-component.adoc
@@ -572,3 +572,5 @@ below:
 </route>
 -----------------------------------------------------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$netty-http-starter.adoc[]
diff --git a/components/camel-netty/src/main/docs/netty-component.adoc b/components/camel-netty/src/main/docs/netty-component.adoc
index aa1f445..a33a6ab 100644
--- a/components/camel-netty/src/main/docs/netty-component.adoc
+++ b/components/camel-netty/src/main/docs/netty-component.adoc
@@ -719,3 +719,5 @@ This provides support for timeout and other complexities you otherwise would nee
 You can find an example with the Apache Camel source code in the examples directory
 under the `camel-example-netty-custom-correlation` directory.
 
+
+include::camel-spring-boot::page$netty-starter.adoc[]
diff --git a/components/camel-nitrite/src/main/docs/nitrite-component.adoc b/components/camel-nitrite/src/main/docs/nitrite-component.adoc
index 52b3dc3..89ba58e 100644
--- a/components/camel-nitrite/src/main/docs/nitrite-component.adoc
+++ b/components/camel-nitrite/src/main/docs/nitrite-component.adoc
@@ -186,3 +186,5 @@ from("direct:getByID")
     .to("nitrite:/path/to/database.db?collection=myCollection")
     .to("log:result");
 ----
+
+include::camel-spring-boot::page$nitrite-starter.adoc[]
diff --git a/components/camel-nsq/src/main/docs/nsq-component.adoc b/components/camel-nsq/src/main/docs/nsq-component.adoc
index 4f98989..c53ee56 100644
--- a/components/camel-nsq/src/main/docs/nsq-component.adoc
+++ b/components/camel-nsq/src/main/docs/nsq-component.adoc
@@ -133,3 +133,5 @@ Then you can omit the servers from the endpoint URI
 from("direct:start").to("nsq:myTopic");
 ----
 
+
+include::camel-spring-boot::page$nsq-starter.adoc[]
diff --git a/components/camel-ognl/src/main/docs/ognl-language.adoc b/components/camel-ognl/src/main/docs/ognl-language.adoc
index 4b38ea9..fa4427a 100644
--- a/components/camel-ognl/src/main/docs/ognl-language.adoc
+++ b/components/camel-ognl/src/main/docs/ognl-language.adoc
@@ -126,3 +126,5 @@ the download page for the latest versions).
 
 Otherwise, you'll also need
 https://repo1.maven.org/maven2/org/apache/servicemix/bundles/org.apache.servicemix.bundles.ognl/2.7.3_4/org.apache.servicemix.bundles.ognl-2.7.3_4.jar[OGNL]
+
+include::camel-spring-boot::page$ognl-starter.adoc[]
diff --git a/components/camel-olingo2/camel-olingo2-component/src/main/docs/olingo2-component.adoc b/components/camel-olingo2/camel-olingo2-component/src/main/docs/olingo2-component.adoc
index 589ece0..f8e5a72 100644
--- a/components/camel-olingo2/camel-olingo2-component/src/main/docs/olingo2-component.adoc
+++ b/components/camel-olingo2/camel-olingo2-component/src/main/docs/olingo2-component.adoc
@@ -316,3 +316,6 @@ consumer endpoint will produce an *ODataFeed* value the first time, and
 from("olingo2://read/Manufacturers?queryParams=#paramsBean&timeUnit=SECONDS&delay=30")
     .to("bean:blah");
 ---------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$olingo2-starter.adoc[]
+
diff --git a/components/camel-olingo4/camel-olingo4-component/src/main/docs/olingo4-component.adoc b/components/camel-olingo4/camel-olingo4-component/src/main/docs/olingo4-component.adoc
index 1cd6171..72b3ff3 100644
--- a/components/camel-olingo4/camel-olingo4-component/src/main/docs/olingo4-component.adoc
+++ b/components/camel-olingo4/camel-olingo4-component/src/main/docs/olingo4-component.adoc
@@ -294,3 +294,6 @@ actions that don't expect an input.
 from("direct:...")
     .to("olingo4://action/People");
 ------------------------------------------------------------
+
+include::camel-spring-boot::page$olingo4-starter.adoc[]
+
diff --git a/components/camel-openstack/src/main/docs/openstack-cinder-component.adoc b/components/camel-openstack/src/main/docs/openstack-cinder-component.adoc
index 58c82dd..737d500 100644
--- a/components/camel-openstack/src/main/docs/openstack-cinder-component.adoc
+++ b/components/camel-openstack/src/main/docs/openstack-cinder-component.adoc
@@ -184,3 +184,5 @@ If you need more precise volume settings you can create new object of the type *
 
 If you need more precise server settings you can create new object of the type *org.openstack4j.model.storage.block.VolumeSnapshot* and send in the message body.
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/components/camel-openstack/src/main/docs/openstack-glance-component.adoc b/components/camel-openstack/src/main/docs/openstack-glance-component.adoc
index b121746..57b1553 100644
--- a/components/camel-openstack/src/main/docs/openstack-glance-component.adoc
+++ b/components/camel-openstack/src/main/docs/openstack-glance-component.adoc
@@ -144,3 +144,5 @@ with the following path and query parameters:
 |`properties` | `Map` | Image properties.
 |=========================================================================
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/components/camel-openstack/src/main/docs/openstack-keystone-component.adoc b/components/camel-openstack/src/main/docs/openstack-keystone-component.adoc
index 379926f..3d0f9ee 100644
--- a/components/camel-openstack/src/main/docs/openstack-keystone-component.adoc
+++ b/components/camel-openstack/src/main/docs/openstack-keystone-component.adoc
@@ -290,3 +290,5 @@ If you need more precise region settings you can create new object of the type *
 
 If you need more precise user settings you can create new object of the type *org.openstack4j.model.identity.v3.User* and send in the message body.
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/components/camel-openstack/src/main/docs/openstack-neutron-component.adoc b/components/camel-openstack/src/main/docs/openstack-neutron-component.adoc
index 7645dd2..da87202 100644
--- a/components/camel-openstack/src/main/docs/openstack-neutron-component.adoc
+++ b/components/camel-openstack/src/main/docs/openstack-neutron-component.adoc
@@ -263,3 +263,5 @@ If you need more precise subnet settings you can create new object of the type *
 |=========================================================================
 
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/components/camel-openstack/src/main/docs/openstack-nova-component.adoc b/components/camel-openstack/src/main/docs/openstack-nova-component.adoc
index 7c9baa6..f298e9f 100644
--- a/components/camel-openstack/src/main/docs/openstack-nova-component.adoc
+++ b/components/camel-openstack/src/main/docs/openstack-nova-component.adoc
@@ -213,3 +213,5 @@ If you need more precise server settings you can create new object of the type *
 
 |=========================================================================
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/components/camel-openstack/src/main/docs/openstack-swift-component.adoc b/components/camel-openstack/src/main/docs/openstack-swift-component.adoc
index 6315759..8e85f54 100644
--- a/components/camel-openstack/src/main/docs/openstack-swift-component.adoc
+++ b/components/camel-openstack/src/main/docs/openstack-swift-component.adoc
@@ -190,3 +190,5 @@ or *org.openstack4j.model.storage.object.options.ContainerListOptions* for listi
 
 |=========================================================================
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/components/camel-openstack/src/main/docs/openstack.adoc b/components/camel-openstack/src/main/docs/openstack.adoc
index ca411ec..0bb35c6 100644
--- a/components/camel-openstack/src/main/docs/openstack.adoc
+++ b/components/camel-openstack/src/main/docs/openstack.adoc
@@ -30,3 +30,5 @@ for this component:
 |=======================================================================
 
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/components/camel-opentracing/src/main/docs/opentracing.adoc b/components/camel-opentracing/src/main/docs/opentracing.adoc
index 14de671..a404a4d 100644
--- a/components/camel-opentracing/src/main/docs/opentracing.adoc
+++ b/components/camel-opentracing/src/main/docs/opentracing.adoc
@@ -97,3 +97,5 @@ How this agent is used will be specific to how you execute your application. _Se
 
 You can find an example demonstrating the three ways to configure OpenTracing here:
 https://github.com/apache/camel/tree/master/examples/camel-example-opentracing[camel-example-opentracing]
+
+include::camel-spring-boot::page$opentracing-starter.adoc[]
diff --git a/components/camel-optaplanner/src/main/docs/optaplanner-component.adoc b/components/camel-optaplanner/src/main/docs/optaplanner-component.adoc
index 15077ba..90ac521 100644
--- a/components/camel-optaplanner/src/main/docs/optaplanner-component.adoc
+++ b/components/camel-optaplanner/src/main/docs/optaplanner-component.adoc
@@ -162,3 +162,5 @@ from("cxfrs:bean:rsServer?bindingStyle=SimpleConsumer")
   .to("optaplanner:/org/foo/barSolverConfig.xml");
 -------------------------------------------------------
 
+
+include::camel-spring-boot::page$optaplanner-starter.adoc[]
diff --git a/components/camel-paho/src/main/docs/paho-component.adoc b/components/camel-paho/src/main/docs/paho-component.adoc
index e7c4cf0..e231d56 100644
--- a/components/camel-paho/src/main/docs/paho-component.adoc
+++ b/components/camel-paho/src/main/docs/paho-component.adoc
@@ -215,3 +215,5 @@ from("direct:test")
     .setHeader(PahoConstants.CAMEL_PAHO_OVERRIDE_TOPIC, simple("${header.customerId}"))
     .to("paho:some/target/queue");
 ----
+
+include::camel-spring-boot::page$paho-starter.adoc[]
diff --git a/components/camel-pdf/src/main/docs/pdf-component.adoc b/components/camel-pdf/src/main/docs/pdf-component.adoc
index 7a81315..ab0ca3c 100644
--- a/components/camel-pdf/src/main/docs/pdf-component.adoc
+++ b/components/camel-pdf/src/main/docs/pdf-component.adoc
@@ -113,3 +113,5 @@ https://pdfbox.apache.org/docs/1.8.10/javadocs/org/apache/pdfbox/pdmodel/encrypt
 *Mandatory* header if PDF document is encrypted.
 |=======================================================================
 
+
+include::camel-spring-boot::page$pdf-starter.adoc[]
diff --git a/components/camel-pg-replication-slot/src/main/docs/pg-replication-slot-component.adoc b/components/camel-pg-replication-slot/src/main/docs/pg-replication-slot-component.adoc
index f771d97..b7c128a 100644
--- a/components/camel-pg-replication-slot/src/main/docs/pg-replication-slot-component.adoc
+++ b/components/camel-pg-replication-slot/src/main/docs/pg-replication-slot-component.adoc
@@ -136,3 +136,5 @@ this component to sync data from PostgreSQL to other database, make sure your op
 instead of INSERT,...). This will make sure repeated messages won't affect your system negatively.
 ====
 
+
+include::camel-spring-boot::page$pg-replication-slot-starter.adoc[]
diff --git a/components/camel-pgevent/src/main/docs/pgevent-component.adoc b/components/camel-pgevent/src/main/docs/pgevent-component.adoc
index 11be6eb..968cd7f 100644
--- a/components/camel-pgevent/src/main/docs/pgevent-component.adoc
+++ b/components/camel-pgevent/src/main/docs/pgevent-component.adoc
@@ -99,3 +99,5 @@ with the following path and query parameters:
 
 
 
+
+include::camel-spring-boot::page$pgevent-starter.adoc[]
diff --git a/components/camel-platform-http/src/main/docs/platform-http-component.adoc b/components/camel-platform-http/src/main/docs/platform-http-component.adoc
index d873aa3..78c228d 100644
--- a/components/camel-platform-http/src/main/docs/platform-http-component.adoc
+++ b/components/camel-platform-http/src/main/docs/platform-http-component.adoc
@@ -80,3 +80,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$platform-http-starter.adoc[]
diff --git a/components/camel-printer/src/main/docs/lpr-component.adoc b/components/camel-printer/src/main/docs/lpr-component.adoc
index 7197783..28d8f93 100644
--- a/components/camel-printer/src/main/docs/lpr-component.adoc
+++ b/components/camel-printer/src/main/docs/lpr-component.adoc
@@ -161,3 +161,5 @@ RouteBuilder builder = new RouteBuilder() {
            "&flavor=DocFlavor.INPUT_STREAM")
     }};
 --------------------------------------------------
+
+include::camel-spring-boot::page$printer-starter.adoc[]
diff --git a/components/camel-protobuf/src/main/docs/protobuf-dataformat.adoc b/components/camel-protobuf/src/main/docs/protobuf-dataformat.adoc
index 915232c..9d2fb84 100644
--- a/components/camel-protobuf/src/main/docs/protobuf-dataformat.adoc
+++ b/components/camel-protobuf/src/main/docs/protobuf-dataformat.adoc
@@ -220,3 +220,5 @@ To use Protobuf in your camel routes you need to add the a dependency on
   <!-- use the same version as your Camel core version -->
 </dependency>
 -----------------------------------------
+
+include::camel-spring-boot::page$protobuf-starter.adoc[]
diff --git a/components/camel-pubnub/src/main/docs/pubnub-component.adoc b/components/camel-pubnub/src/main/docs/pubnub-component.adoc
index 332953c..7cd4474 100644
--- a/components/camel-pubnub/src/main/docs/pubnub-component.adoc
+++ b/components/camel-pubnub/src/main/docs/pubnub-component.adoc
@@ -214,3 +214,5 @@ The example PubNubSensorExample already contains a subscribe key provided by Pub
 The example illustrates the PubNub component subscribing to a infinite stream of sensor data.
 
 
+
+include::camel-spring-boot::page$pubnub-starter.adoc[]
diff --git a/components/camel-pulsar/src/main/docs/pulsar-component.adoc b/components/camel-pulsar/src/main/docs/pulsar-component.adoc
index e41f09e..029a7e0 100644
--- a/components/camel-pulsar/src/main/docs/pulsar-component.adoc
+++ b/components/camel-pulsar/src/main/docs/pulsar-component.adoc
@@ -142,3 +142,5 @@ with the following path and query parameters:
 | `manual_acknowledgement` | `PulsarManualAcknowledgement` | If allowManualAcknowledgement is set, this will contain the object for manually acknowledging the Pulsar message; otherwise it is unset
 |===
 // message-headers options: END
+
+include::camel-spring-boot::page$pulsar-starter.adoc[]
diff --git a/components/camel-quartz/src/main/docs/quartz-component.adoc b/components/camel-quartz/src/main/docs/quartz-component.adoc
index 02ec855..221adf5 100644
--- a/components/camel-quartz/src/main/docs/quartz-component.adoc
+++ b/components/camel-quartz/src/main/docs/quartz-component.adoc
@@ -452,3 +452,5 @@ Users can then use the cron component instead of the quartz component, as in the
     from("cron://name?schedule=0+0/5+12-18+?+*+MON-FRI")
     .to("activemq:Totally.Rocks");
 ----
+
+include::camel-spring-boot::page$quartz-starter.adoc[]
diff --git a/components/camel-quickfix/src/main/docs/quickfix-component.adoc b/components/camel-quickfix/src/main/docs/quickfix-component.adoc
index a5323e8..fded72c 100644
--- a/components/camel-quickfix/src/main/docs/quickfix-component.adoc
+++ b/components/camel-quickfix/src/main/docs/quickfix-component.adoc
@@ -592,3 +592,5 @@ Direction : from FIX gateway
 </route>
 ----
 
+
+include::camel-spring-boot::page$quickfix-starter.adoc[]
diff --git a/components/camel-rabbitmq/src/main/docs/rabbitmq-component.adoc b/components/camel-rabbitmq/src/main/docs/rabbitmq-component.adoc
index 0d2e469..9778ac4 100644
--- a/components/camel-rabbitmq/src/main/docs/rabbitmq-component.adoc
+++ b/components/camel-rabbitmq/src/main/docs/rabbitmq-component.adoc
@@ -374,3 +374,5 @@ public Map<String, Object> bindArgsBuilder() {
 }
 ----
 
+
+include::camel-spring-boot::page$rabbitmq-starter.adoc[]
diff --git a/components/camel-reactive-streams/src/main/docs/reactive-streams-component.adoc b/components/camel-reactive-streams/src/main/docs/reactive-streams-component.adoc
index 24ae3b4..1238d82 100644
--- a/components/camel-reactive-streams/src/main/docs/reactive-streams-component.adoc
+++ b/components/camel-reactive-streams/src/main/docs/reactive-streams-component.adoc
@@ -419,3 +419,5 @@ To use the starter, add the following to your spring boot pom.xml file:
 ------------------------------------------------------
 
 
+
+include::camel-spring-boot::page$reactive-streams-starter.adoc[]
diff --git a/components/camel-ref/src/main/docs/ref-component.adoc b/components/camel-ref/src/main/docs/ref-component.adoc
index cb67b45..9a5b4bb 100644
--- a/components/camel-ref/src/main/docs/ref-component.adoc
+++ b/components/camel-ref/src/main/docs/ref-component.adoc
@@ -117,3 +117,5 @@ You could, of course, have used the `ref` attribute instead:
 ----
 
 Which is the more common way to write it.
+
+include::camel-spring-boot::page$ref-starter.adoc[]
diff --git a/components/camel-rest-openapi/src/main/docs/rest-openapi-component.adoc b/components/camel-rest-openapi/src/main/docs/rest-openapi-component.adoc
index b716aa8..1215428 100644
--- a/components/camel-rest-openapi/src/main/docs/rest-openapi-component.adoc
+++ b/components/camel-rest-openapi/src/main/docs/rest-openapi-component.adoc
@@ -217,3 +217,5 @@ String getPetJsonById(int petId) {
     return template.requestBodyAndHeaders("petstore:getPetById", null, "petId", petId);
 }
 ----
+
+include::camel-spring-boot::page$rest-openapi-starter.adoc[]
diff --git a/components/camel-rest-swagger/src/main/docs/rest-swagger-component.adoc b/components/camel-rest-swagger/src/main/docs/rest-swagger-component.adoc
index 8778318..1f88123 100644
--- a/components/camel-rest-swagger/src/main/docs/rest-swagger-component.adoc
+++ b/components/camel-rest-swagger/src/main/docs/rest-swagger-component.adoc
@@ -215,3 +215,5 @@ String getPetJsonById(int petId) {
     return template.requestBodyAndHeaders("petstore:getPetById", null, "petId", petId);
 }
 ----
+
+include::camel-spring-boot::page$rest-swagger-starter.adoc[]
diff --git a/components/camel-rest/src/main/docs/rest-api-component.adoc b/components/camel-rest/src/main/docs/rest-api-component.adoc
index 47ef218..3cb63bf 100644
--- a/components/camel-rest/src/main/docs/rest-api-component.adoc
+++ b/components/camel-rest/src/main/docs/rest-api-component.adoc
@@ -64,3 +64,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$rest-starter.adoc[]
diff --git a/components/camel-rest/src/main/docs/rest-component.adoc b/components/camel-rest/src/main/docs/rest-component.adoc
index 12f7631..295ee6e 100644
--- a/components/camel-rest/src/main/docs/rest-component.adoc
+++ b/components/camel-rest/src/main/docs/rest-component.adoc
@@ -255,3 +255,5 @@ Rest DSL with SERVLET as
 transport that can be deployed on Apache Tomcat, or similar web
 containers.
 
+
+include::camel-spring-boot::page$rest-starter.adoc[]
diff --git a/components/camel-robotframework/src/main/docs/robotframework-component.adoc b/components/camel-robotframework/src/main/docs/robotframework-component.adoc
index 8f66ce3..f7d8866 100644
--- a/components/camel-robotframework/src/main/docs/robotframework-component.adoc
+++ b/components/camel-robotframework/src/main/docs/robotframework-component.adoc
@@ -242,3 +242,5 @@ And the `template.robot` file:
 
 Please note that when you pass values through Camel Exchange to test cases,
 they will be available as case-sensitive ``body``, ``headers.[yourHeaderName]`` and ``properties.[yourPropertyName]``
+
+include::camel-spring-boot::page$robotframework-starter.adoc[]
diff --git a/components/camel-rss/src/main/docs/rss-component.adoc b/components/camel-rss/src/main/docs/rss-component.adoc
index 4a613a5..c0a4ed1 100644
--- a/components/camel-rss/src/main/docs/rss-component.adoc
+++ b/components/camel-rss/src/main/docs/rss-component.adoc
@@ -206,3 +206,5 @@ public static class FilterBean {
 }
 ----
 
+
+include::camel-spring-boot::page$rss-starter.adoc[]
diff --git a/components/camel-rss/src/main/docs/rss-dataformat.adoc b/components/camel-rss/src/main/docs/rss-dataformat.adoc
index 412d516..de7adff 100644
--- a/components/camel-rss/src/main/docs/rss-dataformat.adoc
+++ b/components/camel-rss/src/main/docs/rss-dataformat.adoc
@@ -39,3 +39,5 @@ The RSS dataformat supports 1 options, which are listed below.
 |===
 // dataformat options: END
 ND
+
+include::camel-spring-boot::page$rss-starter.adoc[]
diff --git a/components/camel-saga/src/main/docs/saga-component.adoc b/components/camel-saga/src/main/docs/saga-component.adoc
index c0a07c3..d178940 100644
--- a/components/camel-saga/src/main/docs/saga-component.adoc
+++ b/components/camel-saga/src/main/docs/saga-component.adoc
@@ -68,3 +68,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$saga-starter.adoc[]
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/docs/salesforce-component.adoc b/components/camel-salesforce/camel-salesforce-component/src/main/docs/salesforce-component.adoc
index f655cf1..cd8da67 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/docs/salesforce-component.adoc
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/docs/salesforce-component.adoc
@@ -777,3 +777,6 @@ with the following path and query parameters:
 | *synchronous* (advanced) | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | boolean
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$salesforce-starter.adoc[]
+
diff --git a/components/camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc b/components/camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc
index c715df8..db6c66c 100644
--- a/components/camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc
+++ b/components/camel-sap-netweaver/src/main/docs/sap-netweaver-component.adoc
@@ -200,3 +200,5 @@ Destination city: SAN FRANCISCO
 Destination airport: SFO
 -------------------------------
 
+
+include::camel-spring-boot::page$sap-netweaver-starter.adoc[]
diff --git a/components/camel-saxon/src/main/docs/xquery-component.adoc b/components/camel-saxon/src/main/docs/xquery-component.adoc
index 905eaad..7dbe8a7 100644
--- a/components/camel-saxon/src/main/docs/xquery-component.adoc
+++ b/components/camel-saxon/src/main/docs/xquery-component.adoc
@@ -296,3 +296,5 @@ substituting the version number for the latest & greatest release.
   <version>x.x.x</version>
 </dependency>
 --------------------------------------
+
+include::camel-spring-boot::page$saxon-starter.adoc[]
diff --git a/components/camel-saxon/src/main/docs/xquery-language.adoc b/components/camel-saxon/src/main/docs/xquery-language.adoc
index 0f63694..6204943 100644
--- a/components/camel-saxon/src/main/docs/xquery-language.adoc
+++ b/components/camel-saxon/src/main/docs/xquery-language.adoc
@@ -154,3 +154,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 --------------------------------------
+
+include::camel-spring-boot::page$saxon-starter.adoc[]
diff --git a/components/camel-scheduler/src/main/docs/scheduler-component.adoc b/components/camel-scheduler/src/main/docs/scheduler-component.adoc
index ce37664..93997cb 100644
--- a/components/camel-scheduler/src/main/docs/scheduler-component.adoc
+++ b/components/camel-scheduler/src/main/docs/scheduler-component.adoc
@@ -166,3 +166,5 @@ The consumer will otherwise as by default return 1 message polled to the
 scheduler, every time the consumer has completed processing the
 exchange.
 
+
+include::camel-spring-boot::page$scheduler-starter.adoc[]
diff --git a/components/camel-schematron/src/main/docs/schematron-component.adoc b/components/camel-schematron/src/main/docs/schematron-component.adoc
index 40f9b4f..8c11a6e 100644
--- a/components/camel-schematron/src/main/docs/schematron-component.adoc
+++ b/components/camel-schematron/src/main/docs/schematron-component.adoc
@@ -207,3 +207,5 @@ to get you started on Schematron.
 * http://www.schematron.com[Schematron official site]. This contains
 links to other resources
 ====
+
+include::camel-spring-boot::page$schematron-starter.adoc[]
diff --git a/components/camel-seda/src/main/docs/seda-component.adoc b/components/camel-seda/src/main/docs/seda-component.adoc
index 2bab05d..5b063cb 100644
--- a/components/camel-seda/src/main/docs/seda-component.adoc
+++ b/components/camel-seda/src/main/docs/seda-component.adoc
@@ -316,3 +316,5 @@ SedaEndpoint seda = context.getEndpoint("seda:xxxx");
 int size = seda.getExchanges().size();
 ----
 
+
+include::camel-spring-boot::page$seda-starter.adoc[]
diff --git a/components/camel-service/src/main/docs/service-component.adoc b/components/camel-service/src/main/docs/service-component.adoc
index 4f51e39..bbbb36a 100644
--- a/components/camel-service/src/main/docs/service-component.adoc
+++ b/components/camel-service/src/main/docs/service-component.adoc
@@ -79,3 +79,5 @@ Camel provide the following ServiceRegistry implementations:
 - camel-zookeeper
 - camel-spring-cloud
 
+
+include::camel-spring-boot::page$service-starter.adoc[]
diff --git a/components/camel-servicenow/camel-servicenow-component/src/main/docs/servicenow-component.adoc b/components/camel-servicenow/camel-servicenow-component/src/main/docs/servicenow-component.adoc
index 645f5c3..68be9c0 100644
--- a/components/camel-servicenow/camel-servicenow-component/src/main/docs/servicenow-component.adoc
+++ b/components/camel-servicenow/camel-servicenow-component/src/main/docs/servicenow-component.adoc
@@ -322,3 +322,6 @@ FluentProducerTemplate.on(context)
     .to("direct:servicenow")
     .send();
 -------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$servicenow-starter.adoc[]
+
diff --git a/components/camel-servlet/src/main/docs/servlet-component.adoc b/components/camel-servlet/src/main/docs/servlet-component.adoc
index bdbdb04..3283f34 100644
--- a/components/camel-servlet/src/main/docs/servlet-component.adoc
+++ b/components/camel-servlet/src/main/docs/servlet-component.adoc
@@ -459,3 +459,5 @@ The automatic mapping of the Camel servlet can also be disabled.
 | camel.component.servlet.mapping.servlet-name | CamelServlet | The name of the Camel servlet
 |=======================================================================
 
+
+include::camel-spring-boot::page$servlet-starter.adoc[]
diff --git a/components/camel-sip/src/main/docs/sip-component.adoc b/components/camel-sip/src/main/docs/sip-component.adoc
index d3bca5c..32e0725 100644
--- a/components/camel-sip/src/main/docs/sip-component.adoc
+++ b/components/camel-sip/src/main/docs/sip-component.adoc
@@ -233,3 +233,5 @@ Subscriber. It has a separate SIP stackName distinct from Publisher as
 well as Subscriber. While it is set up as a Camel Consumer, it does not
 actually send any messages along the route to the endpoint
 "mock:neverland".
+
+include::camel-spring-boot::page$sip-starter.adoc[]
diff --git a/components/camel-sjms/src/main/docs/sjms-batch-component.adoc b/components/camel-sjms/src/main/docs/sjms-batch-component.adoc
index 6591a02..ec25423 100644
--- a/components/camel-sjms/src/main/docs/sjms-batch-component.adoc
+++ b/components/camel-sjms/src/main/docs/sjms-batch-component.adoc
@@ -199,3 +199,5 @@ with the following path and query parameters:
 The `completionSize` endpoint attribute is used in conjunction with
 `completionTimeout`, where the first condition to be met will cause the
 aggregated `Exchange` to be emitted down the route.
+
+include::camel-spring-boot::page$sjms-starter.adoc[]
diff --git a/components/camel-sjms/src/main/docs/sjms-component.adoc b/components/camel-sjms/src/main/docs/sjms-component.adoc
index 67c023a..ad309b6 100644
--- a/components/camel-sjms/src/main/docs/sjms-component.adoc
+++ b/components/camel-sjms/src/main/docs/sjms-component.adoc
@@ -471,3 +471,5 @@ Not at all. Below is an example of the SJMS component using the Spring XML:
 Springless refers to moving away from the dependency on the Spring JMS
 API. A new JMS client API is being developed from the ground up to power
 SJMS.
+
+include::camel-spring-boot::page$sjms-starter.adoc[]
diff --git a/components/camel-sjms2/src/main/docs/sjms2-component.adoc b/components/camel-sjms2/src/main/docs/sjms2-component.adoc
index f633411..9b17fe8 100644
--- a/components/camel-sjms2/src/main/docs/sjms2-component.adoc
+++ b/components/camel-sjms2/src/main/docs/sjms2-component.adoc
@@ -579,3 +579,5 @@ DSL:
 Springless refers to moving away from the dependency on the Spring JMS
 API. A new JMS client API is being developed from the ground up to power
 SJMS2.
+
+include::camel-spring-boot::page$sjms2-starter.adoc[]
diff --git a/components/camel-slack/src/main/docs/slack-component.adoc b/components/camel-slack/src/main/docs/slack-component.adoc
index da9d83e..f4f9901 100644
--- a/components/camel-slack/src/main/docs/slack-component.adoc
+++ b/components/camel-slack/src/main/docs/slack-component.adoc
@@ -173,3 +173,5 @@ from("slack://general?token=RAW(<YOUR_TOKEN>)&maxResults=1")
 
 In this way you'll get the last message from general channel. The consumer will take track of the timestamp of the last message consumed and in the next poll it will check from that timestamp.
 
+
+include::camel-spring-boot::page$slack-starter.adoc[]
diff --git a/components/camel-smpp/src/main/docs/smpp-component.adoc b/components/camel-smpp/src/main/docs/smpp-component.adoc
index a1e8f37..2589541 100644
--- a/components/camel-smpp/src/main/docs/smpp-component.adoc
+++ b/components/camel-smpp/src/main/docs/smpp-component.adoc
@@ -624,3 +624,5 @@ configuration:
 log4j.logger.org.apache.camel.component.smpp=DEBUG
 --------------------------------------------------
 
+
+include::camel-spring-boot::page$smpp-starter.adoc[]
diff --git a/components/camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc b/components/camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc
index dffae6d..3592a7b 100644
--- a/components/camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc
+++ b/components/camel-snakeyaml/src/main/docs/yaml-snakeyaml-dataformat.adoc
@@ -147,3 +147,5 @@ substituting the version number for the latest & greatest release
  
 
  
+
+include::camel-spring-boot::page$snakeyaml-starter.adoc[]
diff --git a/components/camel-snmp/src/main/docs/snmp-component.adoc b/components/camel-snmp/src/main/docs/snmp-component.adoc
index 1a038e5..df721d5 100644
--- a/components/camel-snmp/src/main/docs/snmp-component.adoc
+++ b/components/camel-snmp/src/main/docs/snmp-component.adoc
@@ -213,3 +213,5 @@ convertBodyTo(String.class).
 to("activemq:snmp.states");
 ------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$snmp-starter.adoc[]
diff --git a/components/camel-soap/src/main/docs/soapjaxb-dataformat.adoc b/components/camel-soap/src/main/docs/soapjaxb-dataformat.adoc
index 9ea957f..b90168c 100644
--- a/components/camel-soap/src/main/docs/soapjaxb-dataformat.adoc
+++ b/components/camel-soap/src/main/docs/soapjaxb-dataformat.adoc
@@ -236,3 +236,5 @@ following dependency to your pom.
   <version>x.y.z</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$soap-starter.adoc[]
diff --git a/components/camel-solr/src/main/docs/solr-component.adoc b/components/camel-solr/src/main/docs/solr-component.adoc
index b4039ea..ec0c4b1 100644
--- a/components/camel-solr/src/main/docs/solr-component.adoc
+++ b/components/camel-solr/src/main/docs/solr-component.adoc
@@ -226,3 +226,5 @@ Tutorial]
 
 http://wiki.apache.org/solr/SolrQuerySyntax[Solr Query Syntax]
 
+
+include::camel-spring-boot::page$solr-starter.adoc[]
diff --git a/components/camel-soroush/src/main/docs/soroush-component.adoc b/components/camel-soroush/src/main/docs/soroush-component.adoc
index 579e3a0..1f4a357 100644
--- a/components/camel-soroush/src/main/docs/soroush-component.adoc
+++ b/components/camel-soroush/src/main/docs/soroush-component.adoc
@@ -258,3 +258,5 @@ onException(CongestionException.class).log("Failed to processing ${id}")
 -------------
 
 _Donated by https://www.mohaymen.ir[Mohaymen ICT] to ASF_
+
+include::camel-spring-boot::page$soroush-starter.adoc[]
diff --git a/components/camel-spark/src/main/docs/spark-component.adoc b/components/camel-spark/src/main/docs/spark-component.adoc
index 4d6711c..a740c8f 100644
--- a/components/camel-spark/src/main/docs/spark-component.adoc
+++ b/components/camel-spark/src/main/docs/spark-component.adoc
@@ -407,3 +407,5 @@ Dataset<Row> cars(HiveContext hiveContext) {
     return jsonCars;
 }
 ------------------------------------------------------------------------
+
+include::camel-spring-boot::page$spark-starter.adoc[]
diff --git a/components/camel-splunk/src/main/docs/splunk-component.adoc b/components/camel-splunk/src/main/docs/splunk-component.adoc
index e1a3da0..5b77603 100644
--- a/components/camel-splunk/src/main/docs/splunk-component.adoc
+++ b/components/camel-splunk/src/main/docs/splunk-component.adoc
@@ -250,3 +250,5 @@ data with prebuilt apps for analyzing and displaying this.  +
  For example the jmx app. could be used to publish jmx attributes, eg.
 route and jvm metrics to Splunk, and displaying this on a dashboard.
 
+
+include::camel-spring-boot::page$splunk-starter.adoc[]
diff --git a/components/camel-spring-batch/src/main/docs/spring-batch-component.adoc b/components/camel-spring-batch/src/main/docs/spring-batch-component.adoc
index 5b452ed..e1c26da 100644
--- a/components/camel-spring-batch/src/main/docs/spring-batch-component.adoc
+++ b/components/camel-spring-batch/src/main/docs/spring-batch-component.adoc
@@ -283,3 +283,5 @@ JMS queue.
   </batch:listeners>
 </batch:job>
 -----------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$spring-batch-starter.adoc[]
diff --git a/components/camel-spring-integration/src/main/docs/spring-integration-component.adoc b/components/camel-spring-integration/src/main/docs/spring-integration-component.adoc
index 727f36c..584caa4 100644
--- a/components/camel-spring-integration/src/main/docs/spring-integration-component.adoc
+++ b/components/camel-spring-integration/src/main/docs/spring-integration-component.adoc
@@ -125,3 +125,5 @@ This example uses the following namespaces:
 
 You can bind your source or target to a Camel endpoint as follows:
 
+
+include::camel-spring-boot::page$spring-integration-starter.adoc[]
diff --git a/components/camel-spring-ldap/src/main/docs/spring-ldap-component.adoc b/components/camel-spring-ldap/src/main/docs/spring-ldap-component.adoc
index fd919b4..c8695ad 100644
--- a/components/camel-spring-ldap/src/main/docs/spring-ldap-component.adoc
+++ b/components/camel-spring-ldap/src/main/docs/spring-ldap-component.adoc
@@ -149,3 +149,5 @@ in `org.apache.camel.springldap.SpringLdapProducer`:
 * public static final String MODIFICATION_ITEMS = "modificationItems";
 * public static final String FUNCTION = "function";
 * public static final String REQUEST = "request";
+
+include::camel-spring-boot::page$spring-ldap-starter.adoc[]
diff --git a/components/camel-spring-redis/src/main/docs/spring-redis-component.adoc b/components/camel-spring-redis/src/main/docs/spring-redis-component.adoc
index c15bb3f..8f258c7 100644
--- a/components/camel-spring-redis/src/main/docs/spring-redis-component.adoc
+++ b/components/camel-spring-redis/src/main/docs/spring-redis-component.adoc
@@ -401,3 +401,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `${camel-version`} must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$spring-redis-starter.adoc[]
diff --git a/components/camel-spring-ws/src/main/docs/spring-ws-component.adoc b/components/camel-spring-ws/src/main/docs/spring-ws-component.adoc
index 052f6bb..6897adf 100644
--- a/components/camel-spring-ws/src/main/docs/spring-ws-component.adoc
+++ b/components/camel-spring-ws/src/main/docs/spring-ws-component.adoc
@@ -614,3 +614,5 @@ from("spring-ws:rootqname:{http://example.com/}GetFoo?endpointMapping=#endpointM
 .to("mock:example").marshal(jaxb);
 --------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$spring-ws-starter.adoc[]
diff --git a/components/camel-spring/src/main/docs/spel-language.adoc b/components/camel-spring/src/main/docs/spel-language.adoc
index 844000a..e0791c3 100644
--- a/components/camel-spring/src/main/docs/spel-language.adoc
+++ b/components/camel-spring/src/main/docs/spel-language.adoc
@@ -156,3 +156,5 @@ eg to refer to a file on the classpath you can do:
 .setHeader("myHeader").spel("resource:classpath:myspel.txt")
 ----
 
+
+include::camel-spring-boot::page$spring-starter.adoc[]
diff --git a/components/camel-spring/src/main/docs/spring-event-component.adoc b/components/camel-spring/src/main/docs/spring-event-component.adoc
index e0dce0e..fe00110 100644
--- a/components/camel-spring/src/main/docs/spring-event-component.adoc
+++ b/components/camel-spring/src/main/docs/spring-event-component.adoc
@@ -82,3 +82,5 @@ with the following path and query parameters:
 
 
 
+
+include::camel-spring-boot::page$spring-starter.adoc[]
diff --git a/components/camel-spring/src/main/docs/spring.adoc b/components/camel-spring/src/main/docs/spring.adoc
index 65bda6f..4437e63 100644
--- a/components/camel-spring/src/main/docs/spring.adoc
+++ b/components/camel-spring/src/main/docs/spring.adoc
@@ -408,3 +408,5 @@ Users can then use the cron component inside routes of their Spring or Spring-bo
   <to uri="log:info"/>
 </route>
 ----
+
+include::camel-spring-boot::page$spring-starter.adoc[]
diff --git a/components/camel-sql/src/main/docs/sql-component.adoc b/components/camel-sql/src/main/docs/sql-component.adoc
index e987c4e..40c6aed 100644
--- a/components/camel-sql/src/main/docs/sql-component.adoc
+++ b/components/camel-sql/src/main/docs/sql-component.adoc
@@ -852,3 +852,5 @@ To use this feature, add the following dependencies to your spring boot pom.xml
 
 You should also include the specific database driver, if needed.
 
+
+include::camel-spring-boot::page$sql-starter.adoc[]
diff --git a/components/camel-sql/src/main/docs/sql-stored-component.adoc b/components/camel-sql/src/main/docs/sql-stored-component.adoc
index 0a07907..725b413 100644
--- a/components/camel-sql/src/main/docs/sql-stored-component.adoc
+++ b/components/camel-sql/src/main/docs/sql-stored-component.adoc
@@ -257,3 +257,5 @@ To use this feature, add the following dependencies to your spring boot pom.xml
 
 You should also include the specific database driver, if needed.
 
+
+include::camel-spring-boot::page$sql-starter.adoc[]
diff --git a/components/camel-ssh/src/main/docs/ssh-component.adoc b/components/camel-ssh/src/main/docs/ssh-component.adoc
index adcbb44..fa93e02 100644
--- a/components/camel-ssh/src/main/docs/ssh-component.adoc
+++ b/components/camel-ssh/src/main/docs/ssh-component.adoc
@@ -227,3 +227,5 @@ of Camel you are using.
 See the `examples/camel-example-ssh` and
 `examples/camel-example-ssh-security` in the Camel distribution.
 
+
+include::camel-spring-boot::page$ssh-starter.adoc[]
diff --git a/components/camel-stax/src/main/docs/stax-component.adoc b/components/camel-stax/src/main/docs/stax-component.adoc
index eb9f41b..8e19eca 100644
--- a/components/camel-stax/src/main/docs/stax-component.adoc
+++ b/components/camel-stax/src/main/docs/stax-component.adoc
@@ -227,3 +227,5 @@ from("file:target/in")
 
 The example above could be implemented as follows in XML DSL
 
+
+include::camel-spring-boot::page$stax-starter.adoc[]
diff --git a/components/camel-stomp/src/main/docs/stomp-component.adoc b/components/camel-stomp/src/main/docs/stomp-component.adoc
index daf62d8..8652acd 100644
--- a/components/camel-stomp/src/main/docs/stomp-component.adoc
+++ b/components/camel-stomp/src/main/docs/stomp-component.adoc
@@ -159,3 +159,5 @@ implements the Polling Consumer pattern for
 consuming message exchanges from the endpoint via a
 https://www.javadoc.io/doc/org.apache.camel/camel-api/current/org/apache/camel/PollingConsumer.html[PollingConsumer]
 
+
+include::camel-spring-boot::page$stomp-starter.adoc[]
diff --git a/components/camel-stream/src/main/docs/stream-component.adoc b/components/camel-stream/src/main/docs/stream-component.adoc
index ea05f3b..57f892d 100644
--- a/components/camel-stream/src/main/docs/stream-component.adoc
+++ b/components/camel-stream/src/main/docs/stream-component.adoc
@@ -163,3 +163,5 @@ If you want to re-load the file if it rollover/rewritten then you should also tu
 from("stream:file?fileName=/server/logs/server.log&scanStream=true&scanStreamDelay=1000&retry=true&fileWatcher=true")
   .to("bean:logService?method=parseLogLine");
 ----
+
+include::camel-spring-boot::page$stream-starter.adoc[]
diff --git a/components/camel-stringtemplate/src/main/docs/string-template-component.adoc b/components/camel-stringtemplate/src/main/docs/string-template-component.adoc
index 60e906c..bea3733 100644
--- a/components/camel-stringtemplate/src/main/docs/string-template-component.adoc
+++ b/components/camel-stringtemplate/src/main/docs/string-template-component.adoc
@@ -150,3 +150,5 @@ Regards Camel Riders Bookstore
 
 And the java code is as follows:
 
+
+include::camel-spring-boot::page$stringtemplate-starter.adoc[]
diff --git a/components/camel-stub/src/main/docs/stub-component.adoc b/components/camel-stub/src/main/docs/stub-component.adoc
index 3c343d1..e4e3b90 100644
--- a/components/camel-stub/src/main/docs/stub-component.adoc
+++ b/components/camel-stub/src/main/docs/stub-component.adoc
@@ -111,3 +111,5 @@ Here are a few samples of stubbing endpoint uris
 stub:smtp://somehost.foo.com?user=whatnot&something=else
 stub:http://somehost.bar.com/something
 ----
+
+include::camel-spring-boot::page$stub-starter.adoc[]
diff --git a/components/camel-syslog/src/main/docs/syslog-dataformat.adoc b/components/camel-syslog/src/main/docs/syslog-dataformat.adoc
index 669fd79..f7d3a92 100644
--- a/components/camel-syslog/src/main/docs/syslog-dataformat.adoc
+++ b/components/camel-syslog/src/main/docs/syslog-dataformat.adoc
@@ -131,3 +131,5 @@ The same route using xref:mina-component.adoc[Mina Component]
 </camelContext>
 -------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$syslog-starter.adoc[]
diff --git a/components/camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc b/components/camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc
index c1e9efe..d726059 100644
--- a/components/camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc
+++ b/components/camel-tagsoup/src/main/docs/tidyMarkup-dataformat.adoc
@@ -82,3 +82,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ----------------------------------------
+
+include::camel-spring-boot::page$tagsoup-starter.adoc[]
diff --git a/components/camel-tarfile/src/main/docs/tarfile-dataformat.adoc b/components/camel-tarfile/src/main/docs/tarfile-dataformat.adoc
index a9830fd..d70ba79 100644
--- a/components/camel-tarfile/src/main/docs/tarfile-dataformat.adoc
+++ b/components/camel-tarfile/src/main/docs/tarfile-dataformat.adoc
@@ -166,3 +166,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$tarfile-starter.adoc[]
diff --git a/components/camel-telegram/src/main/docs/telegram-component.adoc b/components/camel-telegram/src/main/docs/telegram-component.adoc
index 1cf7412..0e0b9c4 100644
--- a/components/camel-telegram/src/main/docs/telegram-component.adoc
+++ b/components/camel-telegram/src/main/docs/telegram-component.adoc
@@ -432,3 +432,5 @@ You need to ensure that your server is exposed to the internet and to pass the r
 *camel.component.webhook.configuration.webhook-external-url* property.
 
 Refer to the *camel-webhook* component documentation for instructions on how to set it.
+
+include::camel-spring-boot::page$telegram-starter.adoc[]
diff --git a/components/camel-thrift/src/main/docs/thrift-component.adoc b/components/camel-thrift/src/main/docs/thrift-component.adoc
index 12d5ec9..7ee9a20 100644
--- a/components/camel-thrift/src/main/docs/thrift-component.adoc
+++ b/components/camel-thrift/src/main/docs/thrift-component.adoc
@@ -165,3 +165,5 @@ It's possible to automate Java code generation for .thrift files using *thrift-m
 https://github.com/apache/thrift/[Thrift project GitHub]
 https://thrift.apache.org/tutorial/java [Apache Thrift Java tutorial]
 
+
+include::camel-spring-boot::page$thrift-starter.adoc[]
diff --git a/components/camel-thrift/src/main/docs/thrift-dataformat.adoc b/components/camel-thrift/src/main/docs/thrift-dataformat.adoc
index a26bc91..aa79846 100644
--- a/components/camel-thrift/src/main/docs/thrift-dataformat.adoc
+++ b/components/camel-thrift/src/main/docs/thrift-dataformat.adoc
@@ -155,3 +155,5 @@ To use Thrift in your camel routes you need to add the a dependency on
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$thrift-starter.adoc[]
diff --git a/components/camel-tika/src/main/docs/tika-component.adoc b/components/camel-tika/src/main/docs/tika-component.adoc
index 9ff686d..3419089 100644
--- a/components/camel-tika/src/main/docs/tika-component.adoc
+++ b/components/camel-tika/src/main/docs/tika-component.adoc
@@ -104,3 +104,5 @@ The file should be placed in the Body.
 from("direct:start")
         .to("tika:parse");
 ----
+
+include::camel-spring-boot::page$tika-starter.adoc[]
diff --git a/components/camel-timer/src/main/docs/timer-component.adoc b/components/camel-timer/src/main/docs/timer-component.adoc
index da42f55..8adb7f7 100644
--- a/components/camel-timer/src/main/docs/timer-component.adoc
+++ b/components/camel-timer/src/main/docs/timer-component.adoc
@@ -191,3 +191,5 @@ starting the route. To do that you use the repeatCount option as shown:
 </route>
 ----
 
+
+include::camel-spring-boot::page$timer-starter.adoc[]
diff --git a/components/camel-twilio/src/main/docs/twilio-component.adoc b/components/camel-twilio/src/main/docs/twilio-component.adoc
index eae3258..c85e5b0 100644
--- a/components/camel-twilio/src/main/docs/twilio-component.adoc
+++ b/components/camel-twilio/src/main/docs/twilio-component.adoc
@@ -222,3 +222,5 @@ endpoints with *CamelTwilio.* prefix.
 All result message bodies utilize objects provided by the Twilio Java SDK.
 Producer endpoints can specify the option name for incoming message body
 in the *inBody* endpoint parameter.
+
+include::camel-spring-boot::page$twilio-starter.adoc[]
diff --git a/components/camel-twitter/src/main/docs/twitter-directmessage-component.adoc b/components/camel-twitter/src/main/docs/twitter-directmessage-component.adoc
index 048f318..2aa3c9a 100644
--- a/components/camel-twitter/src/main/docs/twitter-directmessage-component.adoc
+++ b/components/camel-twitter/src/main/docs/twitter-directmessage-component.adoc
@@ -108,3 +108,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$twitter-starter.adoc[]
diff --git a/components/camel-twitter/src/main/docs/twitter-search-component.adoc b/components/camel-twitter/src/main/docs/twitter-search-component.adoc
index 8ffcfbc..5c01aa5 100644
--- a/components/camel-twitter/src/main/docs/twitter-search-component.adoc
+++ b/components/camel-twitter/src/main/docs/twitter-search-component.adoc
@@ -117,3 +117,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$twitter-starter.adoc[]
diff --git a/components/camel-twitter/src/main/docs/twitter-timeline-component.adoc b/components/camel-twitter/src/main/docs/twitter-timeline-component.adoc
index 8552946..c410009 100644
--- a/components/camel-twitter/src/main/docs/twitter-timeline-component.adoc
+++ b/components/camel-twitter/src/main/docs/twitter-timeline-component.adoc
@@ -112,3 +112,5 @@ with the following path and query parameters:
 The timelineType can be one of: public, home, user, mentions or retweetsofme.
 
 
+
+include::camel-spring-boot::page$twitter-starter.adoc[]
diff --git a/components/camel-undertow/src/main/docs/undertow-component.adoc b/components/camel-undertow/src/main/docs/undertow-component.adoc
index 0503b49..7c723a0 100644
--- a/components/camel-undertow/src/main/docs/undertow-component.adoc
+++ b/components/camel-undertow/src/main/docs/undertow-component.adoc
@@ -204,3 +204,5 @@ If you actually want to expose routes by HTTP and already have a
 Servlet, you should instead refer to the
 xref:servlet-component.adoc[Servlet Transport].
 
+
+include::camel-spring-boot::page$undertow-starter.adoc[]
diff --git a/components/camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc b/components/camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc
index b33f0ee..fc567c8 100644
--- a/components/camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc
+++ b/components/camel-univocity-parsers/src/main/docs/univocity-csv-dataformat.adoc
@@ -168,3 +168,5 @@ All the rows can either:
     <to uri="mock:result"/>
 </route>
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$univocity-parsers-starter.adoc[]
diff --git a/components/camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc b/components/camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc
index 55884d9..1d48db0 100644
--- a/components/camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc
+++ b/components/camel-univocity-parsers/src/main/docs/univocity-fixed-dataformat.adoc
@@ -167,3 +167,5 @@ All the rows can either:
     <to uri="mock:result"/>
 </route>
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$univocity-parsers-starter.adoc[]
diff --git a/components/camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc b/components/camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc
index 93dca3c..b084aa6 100644
--- a/components/camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc
+++ b/components/camel-univocity-parsers/src/main/docs/univocity-tsv-dataformat.adoc
@@ -165,3 +165,5 @@ All the rows can either:
     <to uri="mock:result"/>
 </route>
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$univocity-parsers-starter.adoc[]
diff --git a/components/camel-validator/src/main/docs/validator-component.adoc b/components/camel-validator/src/main/docs/validator-component.adoc
index 1e29ab8..c2461f4 100644
--- a/components/camel-validator/src/main/docs/validator-component.adoc
+++ b/components/camel-validator/src/main/docs/validator-component.adoc
@@ -114,3 +114,5 @@ validator endpoint is cleared and reread with the next process call with
 the JMX operation `clearCachedSchema`. You can also use this method to
 programmatically clear the cache. This method is available on the
 `ValidatorEndpoint` class.
+
+include::camel-spring-boot::page$validator-starter.adoc[]
diff --git a/components/camel-velocity/src/main/docs/velocity-component.adoc b/components/camel-velocity/src/main/docs/velocity-component.adoc
index a10dcef..7126cfa 100644
--- a/components/camel-velocity/src/main/docs/velocity-component.adoc
+++ b/components/camel-velocity/src/main/docs/velocity-component.adoc
@@ -272,3 +272,5 @@ ${body}
 
 And the java code:
 
+
+include::camel-spring-boot::page$velocity-starter.adoc[]
diff --git a/components/camel-vertx/src/main/docs/vertx-component.adoc b/components/camel-vertx/src/main/docs/vertx-component.adoc
index 5efd7b8..34304a4 100644
--- a/components/camel-vertx/src/main/docs/vertx-component.adoc
+++ b/components/camel-vertx/src/main/docs/vertx-component.adoc
@@ -123,3 +123,5 @@ vertxComponent.setVertx(vertx);
 camelContext.addComponent("vertx", vertxComponent);
 -----------------------------------------------------
 
+
+include::camel-spring-boot::page$vertx-starter.adoc[]
diff --git a/components/camel-vm/src/main/docs/vm-component.adoc b/components/camel-vm/src/main/docs/vm-component.adoc
index db4ca88..957c8f6 100644
--- a/components/camel-vm/src/main/docs/vm-component.adoc
+++ b/components/camel-vm/src/main/docs/vm-component.adoc
@@ -136,3 +136,5 @@ deployed in another `.war` application):
 from("vm:order.email").bean(MyOrderEmailSender.class);
 ----
 
+
+include::camel-spring-boot::page$vm-starter.adoc[]
diff --git a/components/camel-weather/src/main/docs/weather-component.adoc b/components/camel-weather/src/main/docs/weather-component.adoc
index 7c2d5d4..9c68c32 100644
--- a/components/camel-weather/src/main/docs/weather-component.adoc
+++ b/components/camel-weather/src/main/docs/weather-component.adoc
@@ -206,3 +206,5 @@ And to get the weather at the current location, then:
 --------------------------------------------------------------------------------------------------------------------------------
   String json = template.requestBodyAndHeader("direct:start", "", "CamelWeatherLocation", "current&appid=APIKEY", String.class);
 --------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$weather-starter.adoc[]
diff --git a/components/camel-web3j/src/main/docs/web3j-component.adoc b/components/camel-web3j/src/main/docs/web3j-component.adoc
index 5006ea2..955dcb2 100644
--- a/components/camel-web3j/src/main/docs/web3j-component.adoc
+++ b/components/camel-web3j/src/main/docs/web3j-component.adoc
@@ -162,3 +162,5 @@ Read the balance of an address at a specific block number:
 from("direct:start")
     .to("web3j://http://127.0.0.1:7545?operation=ETH_GET_BALANCE&address=0xc8CDceCE5d006dAB638029EBCf6Dd666efF5A952&atBlock=10");
 --------------------------------------------------------
+
+include::camel-spring-boot::page$web3j-starter.adoc[]
diff --git a/components/camel-webhook/src/main/docs/webhook-component.adoc b/components/camel-webhook/src/main/docs/webhook-component.adoc
index e013466..61867f3 100644
--- a/components/camel-webhook/src/main/docs/webhook-component.adoc
+++ b/components/camel-webhook/src/main/docs/webhook-component.adoc
@@ -102,3 +102,5 @@ You can append query options to the URI in the following format,
 == Examples
 
 Examples of webhook component are provided in the documentation of the delegate components that support it.
+
+include::camel-spring-boot::page$webhook-starter.adoc[]
diff --git a/components/camel-websocket-jsr356/src/main/docs/websocket-jsr356-component.adoc b/components/camel-websocket-jsr356/src/main/docs/websocket-jsr356-component.adoc
index 7ec1071..72dba4a 100644
--- a/components/camel-websocket-jsr356/src/main/docs/websocket-jsr356-component.adoc
+++ b/components/camel-websocket-jsr356/src/main/docs/websocket-jsr356-component.adoc
@@ -84,3 +84,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$websocket-jsr356-starter.adoc[]
diff --git a/components/camel-websocket/src/main/docs/websocket-component.adoc b/components/camel-websocket/src/main/docs/websocket-component.adoc
index b04739c..68a1cde 100644
--- a/components/camel-websocket/src/main/docs/websocket-component.adoc
+++ b/components/camel-websocket/src/main/docs/websocket-component.adoc
@@ -245,3 +245,5 @@ Java DSL based configuration of endpoint
 ...
 ----------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$websocket-starter.adoc[]
diff --git a/components/camel-weka/src/main/docs/weka-component.adoc b/components/camel-weka/src/main/docs/weka-component.adoc
index 05ef0de..78ab431 100644
--- a/components/camel-weka/src/main/docs/weka-component.adoc
+++ b/components/camel-weka/src/main/docs/weka-component.adoc
@@ -254,3 +254,5 @@ try (CamelContext camelctx = new DefaultCamelContext()) {
 * https://www.cs.waikato.ac.nz/ml/weka/courses.html[Machine Learning Courses,window=_blank]
 * https://waikato.github.io/weka-wiki/documentation/[Weka Documentation,window=_blank]
 * https://tdiesler.github.io/nessus-weka[Nessus-Weka,window=_blank]
+
+include::camel-spring-boot::page$weka-starter.adoc[]
diff --git a/components/camel-wordpress/src/main/docs/wordpress-component.adoc b/components/camel-wordpress/src/main/docs/wordpress-component.adoc
index 09d9319..e5415ca 100644
--- a/components/camel-wordpress/src/main/docs/wordpress-component.adoc
+++ b/components/camel-wordpress/src/main/docs/wordpress-component.adoc
@@ -124,3 +124,5 @@ At this time, `camel-wordpress` only supports Basic Authentication (more to come
 `from("direct:deletePost").to("wordpress:post:delete?id=9&user=ben&password=password123").to("mock:resultDelete");`
 
 **It's not recommend to use Basic Authentication in production without TLS!!**
+
+include::camel-spring-boot::page$wordpress-starter.adoc[]
diff --git a/components/camel-workday/src/main/docs/workday-component.adoc b/components/camel-workday/src/main/docs/workday-component.adoc
index ee0e449..28fb290 100644
--- a/components/camel-workday/src/main/docs/workday-component.adoc
+++ b/components/camel-workday/src/main/docs/workday-component.adoc
@@ -78,3 +78,5 @@ with the following path and query parameters:
 | *tenant* (tenant) | *Required* Workday Tenant name. |  | String
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$workday-starter.adoc[]
diff --git a/components/camel-xchange/src/main/docs/xchange-component.adoc b/components/camel-xchange/src/main/docs/xchange-component.adoc
index 639d336..2bc3798 100644
--- a/components/camel-xchange/src/main/docs/xchange-component.adoc
+++ b/components/camel-xchange/src/main/docs/xchange-component.adoc
@@ -115,3 +115,5 @@ In this sample we find the current Bitcoin market price in USDT:
 ---------------------------------------------------------------------------------------------
 from("direct:ticker").to("xchange:binance?service=market&method=ticker&currencyPair=BTC/USDT")
 ---------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$xchange-starter.adoc[]
diff --git a/components/camel-xj/src/main/docs/xj-component.adoc b/components/camel-xj/src/main/docs/xj-component.adoc
index 6e0cff7..8667d34 100644
--- a/components/camel-xj/src/main/docs/xj-component.adoc
+++ b/components/camel-xj/src/main/docs/xj-component.adoc
@@ -491,3 +491,5 @@ that aren't allowed in XML element names.
 | boolean | Generate a json boolean
 | null | Generate an empty value, using the word null
 |===
+
+include::camel-spring-boot::page$xj-starter.adoc[]
diff --git a/components/camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc b/components/camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc
index 496165c..9bc7f26 100644
--- a/components/camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc
+++ b/components/camel-xmlsecurity/src/main/docs/secureXML-dataformat.adoc
@@ -230,3 +230,5 @@ Spring XML Recipient
 == Dependencies
 
 This data format is provided within the *camel-xmlsecurity* component.
+
+include::camel-spring-boot::page$xmlsecurity-starter.adoc[]
diff --git a/components/camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc b/components/camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc
index 570c509..61132f5 100644
--- a/components/camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc
+++ b/components/camel-xmlsecurity/src/main/docs/xmlsecurity-component.adoc
@@ -714,3 +714,5 @@ the XML signer endpoint).
 * The `AllDataObjectsTimeStamp` element is not supported
 * The `IndividualDataObjectsTimeStamp` element is not supported
 
+
+include::camel-spring-boot::page$xmlsecurity-starter.adoc[]
diff --git a/components/camel-xmpp/src/main/docs/xmpp-component.adoc b/components/camel-xmpp/src/main/docs/xmpp-component.adoc
index 9de7953..efbcde4 100644
--- a/components/camel-xmpp/src/main/docs/xmpp-component.adoc
+++ b/components/camel-xmpp/src/main/docs/xmpp-component.adoc
@@ -181,3 +181,5 @@ from("direct:start").
 
  
 
+
+include::camel-spring-boot::page$xmpp-starter.adoc[]
diff --git a/components/camel-xpath/src/main/docs/xpath-language.adoc b/components/camel-xpath/src/main/docs/xpath-language.adoc
index 15a19cd..5677f5c 100644
--- a/components/camel-xpath/src/main/docs/xpath-language.adoc
+++ b/components/camel-xpath/src/main/docs/xpath-language.adoc
@@ -491,3 +491,5 @@ eg to refer to a file on the classpath you can do:
 == Dependencies
 
 The XPath language is part of camel-core.
+
+include::camel-spring-boot::page$xpath-starter.adoc[]
diff --git a/components/camel-xslt-saxon/src/main/docs/xslt-saxon-component.adoc b/components/camel-xslt-saxon/src/main/docs/xslt-saxon-component.adoc
index 35e11c4..9eee085 100644
--- a/components/camel-xslt-saxon/src/main/docs/xslt-saxon-component.adoc
+++ b/components/camel-xslt-saxon/src/main/docs/xslt-saxon-component.adoc
@@ -278,3 +278,5 @@ xsl:message.
 
 The exception is stored on the Exchange as a warning with the
 key `Exchange.XSLT_WARNING.`
+
+include::camel-spring-boot::page$xslt-saxon-starter.adoc[]
diff --git a/components/camel-xslt/src/main/docs/xslt-component.adoc b/components/camel-xslt/src/main/docs/xslt-component.adoc
index b1f1968..fb9ffee 100644
--- a/components/camel-xslt/src/main/docs/xslt-component.adoc
+++ b/components/camel-xslt/src/main/docs/xslt-component.adoc
@@ -233,3 +233,5 @@ xsl:message.
 The exception is stored on the Exchange as a warning with the
 key `Exchange.XSLT_WARNING.`
 
+
+include::camel-spring-boot::page$xslt-starter.adoc[]
diff --git a/components/camel-xstream/src/main/docs/json-xstream-dataformat.adoc b/components/camel-xstream/src/main/docs/json-xstream-dataformat.adoc
index d8fee0c..a9c8142 100644
--- a/components/camel-xstream/src/main/docs/json-xstream-dataformat.adoc
+++ b/components/camel-xstream/src/main/docs/json-xstream-dataformat.adoc
@@ -86,3 +86,5 @@ from("direct:marshal").
   to("mock:marshaled");
 ---------------------------------------------------------
 
+
+include::camel-spring-boot::page$xstream-starter.adoc[]
diff --git a/components/camel-xstream/src/main/docs/xstream-dataformat.adoc b/components/camel-xstream/src/main/docs/xstream-dataformat.adoc
index c6ffcd8..93afea2 100644
--- a/components/camel-xstream/src/main/docs/xstream-dataformat.adoc
+++ b/components/camel-xstream/src/main/docs/xstream-dataformat.adoc
@@ -140,3 +140,5 @@ DataFormat instance by setting its type permissions property.
         ...
 
 -------------------------------------------------------------------
+
+include::camel-spring-boot::page$xstream-starter.adoc[]
diff --git a/components/camel-yammer/src/main/docs/yammer-component.adoc b/components/camel-yammer/src/main/docs/yammer-component.adoc
index ec290a4..940020d 100644
--- a/components/camel-yammer/src/main/docs/yammer-component.adoc
+++ b/components/camel-yammer/src/main/docs/yammer-component.adoc
@@ -339,4 +339,5 @@ from("direct:start")
     .to("mock:result");
 ----
 
-This will go out and fetch the current user's `User` object and set it as the Camel message body.
\ No newline at end of file
+This will go out and fetch the current user's `User` object and set it as the Camel message body.
+include::camel-spring-boot::page$yammer-starter.adoc[]
diff --git a/components/camel-zendesk/src/main/docs/zendesk-component.adoc b/components/camel-zendesk/src/main/docs/zendesk-component.adoc
index b86eee5..920c041 100644
--- a/components/camel-zendesk/src/main/docs/zendesk-component.adoc
+++ b/components/camel-zendesk/src/main/docs/zendesk-component.adoc
@@ -136,3 +136,5 @@ the arugument name of each API methods on the original `org.zendesk.client.v2.Ze
 All result message bodies utilize objects provided by the Zendesk Java Client.
 Producer endpoints can specify the option name for incoming message body
 in the *inBody* endpoint parameter.
+
+include::camel-spring-boot::page$zendesk-starter.adoc[]
diff --git a/components/camel-zip-deflater/src/main/docs/gzipdeflater-dataformat.adoc b/components/camel-zip-deflater/src/main/docs/gzipdeflater-dataformat.adoc
index 6b48849..23fe6e9 100644
--- a/components/camel-zip-deflater/src/main/docs/gzipdeflater-dataformat.adoc
+++ b/components/camel-zip-deflater/src/main/docs/gzipdeflater-dataformat.adoc
@@ -59,3 +59,5 @@ from("activemq:queue:MY_QUEUE").unmarshal().gzipDeflater().process(new UnGZipped
 
 This data format is provided in *camel-core* so no additional
 dependencies is needed.
+
+include::camel-spring-boot::page$zip-deflater-starter.adoc[]
diff --git a/components/camel-zip-deflater/src/main/docs/zipdeflater-dataformat.adoc b/components/camel-zip-deflater/src/main/docs/zipdeflater-dataformat.adoc
index e93cad6..9cd1143 100644
--- a/components/camel-zip-deflater/src/main/docs/zipdeflater-dataformat.adoc
+++ b/components/camel-zip-deflater/src/main/docs/zipdeflater-dataformat.adoc
@@ -64,3 +64,5 @@ unmarshalling to avoid errors.
 ----
 from("activemq:queue:MY_QUEUE").unmarshal().zipDeflater().process(new UnZippedMessageProcessor()); 
 ----
+
+include::camel-spring-boot::page$zip-deflater-starter.adoc[]
diff --git a/components/camel-zipfile/src/main/docs/zipfile-dataformat.adoc b/components/camel-zipfile/src/main/docs/zipfile-dataformat.adoc
index 1fc8413..e80e2cd 100644
--- a/components/camel-zipfile/src/main/docs/zipfile-dataformat.adoc
+++ b/components/camel-zipfile/src/main/docs/zipfile-dataformat.adoc
@@ -165,3 +165,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$zipfile-starter.adoc[]
diff --git a/components/camel-zipkin/src/main/docs/zipkin.adoc b/components/camel-zipkin/src/main/docs/zipkin.adoc
index 195a9d8..c311966 100644
--- a/components/camel-zipkin/src/main/docs/zipkin.adoc
+++ b/components/camel-zipkin/src/main/docs/zipkin.adoc
@@ -276,3 +276,5 @@ If you are using Spring Boot then you can add the `camel-zipkin-starter` depende
 You can then configure camel-zipkin in the `application.properties` file where you can configure the hostname and port number for the Zipkin Server, and all the other options as listed in the options table above.
 
 You can find an example of this in the https://github.com/apache/camel/tree/master/examples/camel-example-zipkin[camel-example-zipkin]
+
+include::camel-spring-boot::page$zipkin-starter.adoc[]
diff --git a/components/camel-zookeeper-master/src/main/docs/zookeeper-master-component.adoc b/components/camel-zookeeper-master/src/main/docs/zookeeper-master-component.adoc
index 325f985..99c10a7 100644
--- a/components/camel-zookeeper-master/src/main/docs/zookeeper-master-component.adoc
+++ b/components/camel-zookeeper-master/src/main/docs/zookeeper-master-component.adoc
@@ -152,3 +152,5 @@ A little example
         .to("file:target/outbox");
 ----
 
+
+include::camel-spring-boot::page$zookeeper-master-starter.adoc[]
diff --git a/components/camel-zookeeper/src/main/docs/zookeeper-component.adoc b/components/camel-zookeeper/src/main/docs/zookeeper-component.adoc
index 61021f8..59831aa 100644
--- a/components/camel-zookeeper/src/main/docs/zookeeper-component.adoc
+++ b/components/camel-zookeeper/src/main/docs/zookeeper-component.adoc
@@ -225,3 +225,5 @@ Object testPayload = ...
 template.sendBodyAndHeader("direct:create-and-write-to-persistent-znode", testPayload, "CamelZooKeeperCreateMode", "PERSISTENT");
 ----
 
+
+include::camel-spring-boot::page$zookeeper-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/activemq-component.adoc b/docs/components/modules/ROOT/pages/activemq-component.adoc
index 50ad476..542bbb7 100644
--- a/docs/components/modules/ROOT/pages/activemq-component.adoc
+++ b/docs/components/modules/ROOT/pages/activemq-component.adoc
@@ -272,3 +272,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$activemq-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ahc-component.adoc b/docs/components/modules/ROOT/pages/ahc-component.adoc
index 383bb96..955ff6b 100644
--- a/docs/components/modules/ROOT/pages/ahc-component.adoc
+++ b/docs/components/modules/ROOT/pages/ahc-component.adoc
@@ -436,3 +436,5 @@ Spring DSL based configuration of endpoint
   <to uri="ahc:https://localhost/foo?sslContextParameters=#sslContextParameters"/>
 ...
 ----------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$ahc-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ahc-ws-component.adoc b/docs/components/modules/ROOT/pages/ahc-ws-component.adoc
index acab224..f2f43ae 100644
--- a/docs/components/modules/ROOT/pages/ahc-ws-component.adoc
+++ b/docs/components/modules/ROOT/pages/ahc-ws-component.adoc
@@ -173,3 +173,5 @@ And the equivalent Spring sample:
 
  
 
+
+include::camel-spring-boot::page$ahc-ws-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/amqp-component.adoc b/docs/components/modules/ROOT/pages/amqp-component.adoc
index 3e9c266..6757f69 100644
--- a/docs/components/modules/ROOT/pages/amqp-component.adoc
+++ b/docs/components/modules/ROOT/pages/amqp-component.adoc
@@ -383,3 +383,5 @@ Keep in mind that both  `AMQPComponent#amqpComponent()` methods and
 `AMQPConnectionDetails` pre-configure the component with the topic
 prefix, so you don't have to configure it explicitly.
 
+
+include::camel-spring-boot::page$amqp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/any23-dataformat.adoc b/docs/components/modules/ROOT/pages/any23-dataformat.adoc
index 36b6a9c..3720911 100644
--- a/docs/components/modules/ROOT/pages/any23-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/any23-dataformat.adoc
@@ -87,3 +87,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ----------------------------------------
+
+include::camel-spring-boot::page$any23-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/apns-component.adoc b/docs/components/modules/ROOT/pages/apns-component.adoc
index c973d3e..3b2d2a8 100644
--- a/docs/components/modules/ROOT/pages/apns-component.adoc
+++ b/docs/components/modules/ROOT/pages/apns-component.adoc
@@ -316,3 +316,5 @@ from("apns:consumer?initialDelay=10&delay=3600&timeUnit=SECONDS")
     .to("mock:result");
 --------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$apns-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/as2-component.adoc b/docs/components/modules/ROOT/pages/as2-component.adoc
index 61af405..b0ce520 100644
--- a/docs/components/modules/ROOT/pages/as2-component.adoc
+++ b/docs/components/modules/ROOT/pages/as2-component.adoc
@@ -259,3 +259,5 @@ URI Options for _server_
 |requestUriPattern |String
 |===
 
+include::camel-spring-boot::page$as2-starter.adoc[]
+
diff --git a/docs/components/modules/ROOT/pages/asn1-dataformat.adoc b/docs/components/modules/ROOT/pages/asn1-dataformat.adoc
index bb62fec..f4fd2cc 100644
--- a/docs/components/modules/ROOT/pages/asn1-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/asn1-dataformat.adoc
@@ -75,3 +75,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$asn1-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/asterisk-component.adoc b/docs/components/modules/ROOT/pages/asterisk-component.adoc
index f1880ff..12fe33d 100644
--- a/docs/components/modules/ROOT/pages/asterisk-component.adoc
+++ b/docs/components/modules/ROOT/pages/asterisk-component.adoc
@@ -93,3 +93,5 @@ Supported actions are:
 * QUEUE_STATUS, Queue Status
 * SIP_PEERS, List SIP Peers
 * EXTENSION_STATE, Check Extension Status
+
+include::camel-spring-boot::page$asterisk-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atmos-component.adoc b/docs/components/modules/ROOT/pages/atmos-component.adoc
index 99a2b68..9d2a476 100644
--- a/docs/components/modules/ROOT/pages/atmos-component.adoc
+++ b/docs/components/modules/ROOT/pages/atmos-component.adoc
@@ -156,3 +156,5 @@ exhange
 DOWNLOADED_FILE, DOWNLOADED_FILES, UPLOADED_FILE, UPLOADED_FILES, FOUND_FILES, DELETED_PATH, MOVED_PATH;
 -------------------------------
 
+
+include::camel-spring-boot::page$atmos-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atmosphere-websocket-component.adoc b/docs/components/modules/ROOT/pages/atmosphere-websocket-component.adoc
index b2a78e4..3560254 100644
--- a/docs/components/modules/ROOT/pages/atmosphere-websocket-component.adoc
+++ b/docs/components/modules/ROOT/pages/atmosphere-websocket-component.adoc
@@ -193,3 +193,5 @@ And the equivalent Spring sample:
 
  
 
+
+include::camel-spring-boot::page$atmosphere-websocket-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atom-component.adoc b/docs/components/modules/ROOT/pages/atom-component.adoc
index 572e9cf..c244518 100644
--- a/docs/components/modules/ROOT/pages/atom-component.adoc
+++ b/docs/components/modules/ROOT/pages/atom-component.adoc
@@ -159,3 +159,5 @@ In this sample we want to filter only good blogs we like to a SEDA
 queue. The sample also shows how to setup Camel standalone, not running
 in any Container or using Spring.
 
+
+include::camel-spring-boot::page$atom-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atomix-map-component.adoc b/docs/components/modules/ROOT/pages/atomix-map-component.adoc
index 907a41e..5e0bb85 100644
--- a/docs/components/modules/ROOT/pages/atomix-map-component.adoc
+++ b/docs/components/modules/ROOT/pages/atomix-map-component.adoc
@@ -200,3 +200,5 @@ FluentProducerTemplate.on(context)
     .to("direct:start")
     .send();
 ----
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atomix-messaging-component.adoc b/docs/components/modules/ROOT/pages/atomix-messaging-component.adoc
index e5e3570..e19bf62 100644
--- a/docs/components/modules/ROOT/pages/atomix-messaging-component.adoc
+++ b/docs/components/modules/ROOT/pages/atomix-messaging-component.adoc
@@ -96,3 +96,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atomix-multimap-component.adoc b/docs/components/modules/ROOT/pages/atomix-multimap-component.adoc
index 10befce..d8fb1b1 100644
--- a/docs/components/modules/ROOT/pages/atomix-multimap-component.adoc
+++ b/docs/components/modules/ROOT/pages/atomix-multimap-component.adoc
@@ -91,3 +91,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atomix-queue-component.adoc b/docs/components/modules/ROOT/pages/atomix-queue-component.adoc
index 3a56392..2b551f1 100644
--- a/docs/components/modules/ROOT/pages/atomix-queue-component.adoc
+++ b/docs/components/modules/ROOT/pages/atomix-queue-component.adoc
@@ -93,3 +93,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atomix-set-component.adoc b/docs/components/modules/ROOT/pages/atomix-set-component.adoc
index 46db61d..7320c42 100644
--- a/docs/components/modules/ROOT/pages/atomix-set-component.adoc
+++ b/docs/components/modules/ROOT/pages/atomix-set-component.adoc
@@ -94,3 +94,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/atomix-value-component.adoc b/docs/components/modules/ROOT/pages/atomix-value-component.adoc
index 3d9b19f..318f611 100644
--- a/docs/components/modules/ROOT/pages/atomix-value-component.adoc
+++ b/docs/components/modules/ROOT/pages/atomix-value-component.adoc
@@ -94,3 +94,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$atomix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/avro-component.adoc b/docs/components/modules/ROOT/pages/avro-component.adoc
index 541ab28..60c8d11 100644
--- a/docs/components/modules/ROOT/pages/avro-component.adoc
+++ b/docs/components/modules/ROOT/pages/avro-component.adoc
@@ -314,3 +314,5 @@ In the example above, get takes only one parameter, so `singleParameter`
 is used and `getProcessor` will receive Value class directly in body,
 while `putProcessor` will receive an array of size 2 with String key and
 Value value filled as array contents.
+
+include::camel-spring-boot::page$avro-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/avro-dataformat.adoc b/docs/components/modules/ROOT/pages/avro-dataformat.adoc
index e144770..82b72c3 100644
--- a/docs/components/modules/ROOT/pages/avro-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/avro-dataformat.adoc
@@ -143,3 +143,5 @@ The Avro dataformat supports 2 options, which are listed below.
 |===
 // dataformat options: END
 ND
+
+include::camel-spring-boot::page$avro-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-cw-component.adoc b/docs/components/modules/ROOT/pages/aws-cw-component.adoc
index 92beae5..1505f59 100644
--- a/docs/components/modules/ROOT/pages/aws-cw-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-cw-component.adoc
@@ -181,3 +181,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `${camel-version`} must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-cw-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-ddb-component.adoc b/docs/components/modules/ROOT/pages/aws-ddb-component.adoc
index 5b1168d..b3bf2fd 100644
--- a/docs/components/modules/ROOT/pages/aws-ddb-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-ddb-component.adoc
@@ -360,3 +360,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ddb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-ddbstream-component.adoc b/docs/components/modules/ROOT/pages/aws-ddbstream-component.adoc
index cc72e2b..20e2ad6 100644
--- a/docs/components/modules/ROOT/pages/aws-ddbstream-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-ddbstream-component.adoc
@@ -208,3 +208,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ddb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-ec2-component.adoc b/docs/components/modules/ROOT/pages/aws-ec2-component.adoc
index 5c579de..f4d8278 100644
--- a/docs/components/modules/ROOT/pages/aws-ec2-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-ec2-component.adoc
@@ -179,3 +179,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ec2-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-ecs-component.adoc b/docs/components/modules/ROOT/pages/aws-ecs-component.adoc
index 1d83a0a..86929b7 100644
--- a/docs/components/modules/ROOT/pages/aws-ecs-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-ecs-component.adoc
@@ -155,3 +155,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ecs-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-eks-component.adoc b/docs/components/modules/ROOT/pages/aws-eks-component.adoc
index 3f1994e..aa3135e 100644
--- a/docs/components/modules/ROOT/pages/aws-eks-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-eks-component.adoc
@@ -161,3 +161,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-eks-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-iam-component.adoc b/docs/components/modules/ROOT/pages/aws-iam-component.adoc
index 0682178..5d39d01 100644
--- a/docs/components/modules/ROOT/pages/aws-iam-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-iam-component.adoc
@@ -171,3 +171,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-iam-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-kinesis-component.adoc b/docs/components/modules/ROOT/pages/aws-kinesis-component.adoc
index bb7813f..0a3f8c8 100644
--- a/docs/components/modules/ROOT/pages/aws-kinesis-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-kinesis-component.adoc
@@ -237,3 +237,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-kinesis-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-kinesis-firehose-component.adoc b/docs/components/modules/ROOT/pages/aws-kinesis-firehose-component.adoc
index 725ed00..7be5565 100644
--- a/docs/components/modules/ROOT/pages/aws-kinesis-firehose-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-kinesis-firehose-component.adoc
@@ -176,3 +176,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-kinesis-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-kms-component.adoc b/docs/components/modules/ROOT/pages/aws-kms-component.adoc
index 0d5a45c..f54d3e6 100644
--- a/docs/components/modules/ROOT/pages/aws-kms-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-kms-component.adoc
@@ -159,3 +159,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-kms-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-lambda-component.adoc b/docs/components/modules/ROOT/pages/aws-lambda-component.adoc
index 68d5f5e..91817e3 100644
--- a/docs/components/modules/ROOT/pages/aws-lambda-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-lambda-component.adoc
@@ -226,3 +226,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-lambda-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-mq-component.adoc b/docs/components/modules/ROOT/pages/aws-mq-component.adoc
index 71d8e9e..4cbeaf8 100644
--- a/docs/components/modules/ROOT/pages/aws-mq-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-mq-component.adoc
@@ -171,3 +171,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-mq-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-msk-component.adoc b/docs/components/modules/ROOT/pages/aws-msk-component.adoc
index b84f1f7..1a7a645 100644
--- a/docs/components/modules/ROOT/pages/aws-msk-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-msk-component.adoc
@@ -164,3 +164,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-msk-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-s3-component.adoc b/docs/components/modules/ROOT/pages/aws-s3-component.adoc
index 368f356..7754134 100644
--- a/docs/components/modules/ROOT/pages/aws-s3-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-s3-component.adoc
@@ -508,3 +508,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-s3-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-sdb-component.adoc b/docs/components/modules/ROOT/pages/aws-sdb-component.adoc
index 75ec8d1..81c01ae 100644
--- a/docs/components/modules/ROOT/pages/aws-sdb-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-sdb-component.adoc
@@ -249,3 +249,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-sdb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-ses-component.adoc b/docs/components/modules/ROOT/pages/aws-ses-component.adoc
index 0c6cf81..be43d81 100644
--- a/docs/components/modules/ROOT/pages/aws-ses-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-ses-component.adoc
@@ -193,3 +193,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-ses-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-sns-component.adoc b/docs/components/modules/ROOT/pages/aws-sns-component.adoc
index 954a58b..5b74552 100644
--- a/docs/components/modules/ROOT/pages/aws-sns-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-sns-component.adoc
@@ -211,3 +211,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-sns-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-sqs-component.adoc b/docs/components/modules/ROOT/pages/aws-sqs-component.adoc
index 82c2890..adb8377 100644
--- a/docs/components/modules/ROOT/pages/aws-sqs-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-sqs-component.adoc
@@ -358,3 +358,5 @@ The other one will use a NullMessageDeduplicationIdStrategy, that will use the b
 
 In case of send batch message operation, you'll need to use the `useContentBasedDeduplication` and on the Queue you're pointing you'll need to enable the `content based deduplication` option.
 
+
+include::camel-spring-boot::page$aws-sqs-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-swf-component.adoc b/docs/components/modules/ROOT/pages/aws-swf-component.adoc
index 367ad63..7e7d407 100644
--- a/docs/components/modules/ROOT/pages/aws-swf-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-swf-component.adoc
@@ -256,3 +256,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-swf-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws-translate-component.adoc b/docs/components/modules/ROOT/pages/aws-translate-component.adoc
index 7a18f0c..46fadd1 100644
--- a/docs/components/modules/ROOT/pages/aws-translate-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws-translate-component.adoc
@@ -159,3 +159,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$aws-translate-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-cw-component.adoc b/docs/components/modules/ROOT/pages/aws2-cw-component.adoc
index d2fa682..e522400 100644
--- a/docs/components/modules/ROOT/pages/aws2-cw-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-cw-component.adoc
@@ -168,3 +168,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `${camel-version`} must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-cw-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-ddb-component.adoc b/docs/components/modules/ROOT/pages/aws2-ddb-component.adoc
index 549d16a..42bd554 100644
--- a/docs/components/modules/ROOT/pages/aws2-ddb-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-ddb-component.adoc
@@ -350,3 +350,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ddb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-ddbstream-component.adoc b/docs/components/modules/ROOT/pages/aws2-ddbstream-component.adoc
index becfab9..8c05b60 100644
--- a/docs/components/modules/ROOT/pages/aws2-ddbstream-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-ddbstream-component.adoc
@@ -183,3 +183,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ddb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-ec2-component.adoc b/docs/components/modules/ROOT/pages/aws2-ec2-component.adoc
index 1c30022..73d7ee1 100644
--- a/docs/components/modules/ROOT/pages/aws2-ec2-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-ec2-component.adoc
@@ -184,3 +184,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ec2-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-ecs-component.adoc b/docs/components/modules/ROOT/pages/aws2-ecs-component.adoc
index 06f585c..dac3c8e 100644
--- a/docs/components/modules/ROOT/pages/aws2-ecs-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-ecs-component.adoc
@@ -161,3 +161,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-ecs-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-eks-component.adoc b/docs/components/modules/ROOT/pages/aws2-eks-component.adoc
index 32fd490..7ead982 100644
--- a/docs/components/modules/ROOT/pages/aws2-eks-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-eks-component.adoc
@@ -169,3 +169,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-eks-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-iam-component.adoc b/docs/components/modules/ROOT/pages/aws2-iam-component.adoc
index 8c4513f..ca0a3f8 100644
--- a/docs/components/modules/ROOT/pages/aws2-iam-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-iam-component.adoc
@@ -178,3 +178,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-iam-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-kms-component.adoc b/docs/components/modules/ROOT/pages/aws2-kms-component.adoc
index 5e5b537..957fffc 100644
--- a/docs/components/modules/ROOT/pages/aws2-kms-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-kms-component.adoc
@@ -166,3 +166,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-kms-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-mq-component.adoc b/docs/components/modules/ROOT/pages/aws2-mq-component.adoc
index e162e0b..861e80f 100644
--- a/docs/components/modules/ROOT/pages/aws2-mq-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-mq-component.adoc
@@ -176,3 +176,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-mq-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-msk-component.adoc b/docs/components/modules/ROOT/pages/aws2-msk-component.adoc
index 2a654bd..bf32fdf 100644
--- a/docs/components/modules/ROOT/pages/aws2-msk-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-msk-component.adoc
@@ -168,3 +168,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-msk-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/aws2-translate-component.adoc b/docs/components/modules/ROOT/pages/aws2-translate-component.adoc
index a6e4d15..5d7cc53 100644
--- a/docs/components/modules/ROOT/pages/aws2-translate-component.adoc
+++ b/docs/components/modules/ROOT/pages/aws2-translate-component.adoc
@@ -164,3 +164,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ---------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$aws2-translate-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/azure-blob-component.adoc b/docs/components/modules/ROOT/pages/azure-blob-component.adoc
index 25e114e..cec20e9 100644
--- a/docs/components/modules/ROOT/pages/azure-blob-component.adoc
+++ b/docs/components/modules/ROOT/pages/azure-blob-component.adoc
@@ -232,3 +232,5 @@ Maven users will need to add the following dependency to their `pom.xml`.
 ----
 
 where `+++${camel-version}+++` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$azure-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/azure-queue-component.adoc b/docs/components/modules/ROOT/pages/azure-queue-component.adoc
index 144db9d..e139c22 100644
--- a/docs/components/modules/ROOT/pages/azure-queue-component.adoc
+++ b/docs/components/modules/ROOT/pages/azure-queue-component.adoc
@@ -172,3 +172,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `${camel-version`} must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$azure-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/azure.adoc b/docs/components/modules/ROOT/pages/azure.adoc
index 836b222..843bbbd 100644
--- a/docs/components/modules/ROOT/pages/azure.adoc
+++ b/docs/components/modules/ROOT/pages/azure.adoc
@@ -13,3 +13,5 @@ provide connectivity to Azure services from Camel.
 |https://azure.microsoft.com/services/storage/blobs[Storage Blob Service] |xref:azure-blob-component.adoc[Azure-Blob] |Supports storing and retrieving of blobs
 |https://azure.microsoft.com/services/storage/queues[Storage Queue Service] |xref:azure-queue-component.adoc[Azure-Queue] |Supports storing and retrieving of messages in the queues
 |=======================================================================
+
+include::camel-spring-boot::page$azure-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/barcode-dataformat.adoc b/docs/components/modules/ROOT/pages/barcode-dataformat.adoc
index 19d76a1..f1f394b 100644
--- a/docs/components/modules/ROOT/pages/barcode-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/barcode-dataformat.adoc
@@ -131,3 +131,5 @@ the barcode data format as header variable:
  
 
  
+
+include::camel-spring-boot::page$barcode-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/base64-dataformat.adoc b/docs/components/modules/ROOT/pages/base64-dataformat.adoc
index ce48c10..180e2ab 100644
--- a/docs/components/modules/ROOT/pages/base64-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/base64-dataformat.adoc
@@ -113,3 +113,5 @@ If you use Maven you can just add the following to your pom.xml:
   <version>x.x.x</version>  <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$base64-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/bean-component.adoc b/docs/components/modules/ROOT/pages/bean-component.adoc
index 610e626..1cf2476 100644
--- a/docs/components/modules/ROOT/pages/bean-component.adoc
+++ b/docs/components/modules/ROOT/pages/bean-component.adoc
@@ -165,3 +165,5 @@ Bean Binding mechanism which is used throughout
 all of the various Bean Integration
 mechanisms in Camel.
 
+
+include::camel-spring-boot::page$bean-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/bean-language.adoc b/docs/components/modules/ROOT/pages/bean-language.adoc
index 74b365c..5a78c35 100644
--- a/docs/components/modules/ROOT/pages/bean-language.adoc
+++ b/docs/components/modules/ROOT/pages/bean-language.adoc
@@ -180,3 +180,5 @@ expression being used in a filter
 * https://github.com/apache/camel/blob/master/components/camel-spring/src/test/resources/org/apache/camel/spring/processor/aggregator.xml[aggregator.xml]
 is a Spring XML test case for the xref:manual::aggregate-eip.adoc[Aggregator] which
 uses a bean method call to test for the completion of the aggregation.
+
+include::camel-spring-boot::page$bean-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/bean-validator-component.adoc b/docs/components/modules/ROOT/pages/bean-validator-component.adoc
index 8fe7b1d..ce73b25 100644
--- a/docs/components/modules/ROOT/pages/bean-validator-component.adoc
+++ b/docs/components/modules/ROOT/pages/bean-validator-component.adoc
@@ -300,3 +300,5 @@ Note that the body should include an instance of a class to validate.
 
 
 
+
+include::camel-spring-boot::page$bean-validator-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/beanio-dataformat.adoc b/docs/components/modules/ROOT/pages/beanio-dataformat.adoc
index e1a52f0..47c90b1 100644
--- a/docs/components/modules/ROOT/pages/beanio-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/beanio-dataformat.adoc
@@ -82,3 +82,5 @@ the download page for the latest versions).
   <version>2.10.0</version>
 </dependency>
 ---------------------------------------
+
+include::camel-spring-boot::page$beanio-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/beanstalk-component.adoc b/docs/components/modules/ROOT/pages/beanstalk-component.adoc
index 77689e7..890510b 100644
--- a/docs/components/modules/ROOT/pages/beanstalk-component.adoc
+++ b/docs/components/modules/ROOT/pages/beanstalk-component.adoc
@@ -236,3 +236,5 @@ out of buried and/or delayed state to the normal queue.
 
  
 
+
+include::camel-spring-boot::page$beanstalk-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/bindy-dataformat.adoc b/docs/components/modules/ROOT/pages/bindy-dataformat.adoc
index e531577..1cfbd61 100644
--- a/docs/components/modules/ROOT/pages/bindy-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/bindy-dataformat.adoc
@@ -1860,3 +1860,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 --------------------------------------
+
+include::camel-spring-boot::page$bindy-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/bonita-component.adoc b/docs/components/modules/ROOT/pages/bonita-component.adoc
index a564732..b28d51b 100644
--- a/docs/components/modules/ROOT/pages/bonita-component.adoc
+++ b/docs/components/modules/ROOT/pages/bonita-component.adoc
@@ -103,3 +103,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$bonita-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/box-component.adoc b/docs/components/modules/ROOT/pages/box-component.adoc
index 5cc4ded..0bcdb5e 100644
--- a/docs/components/modules/ROOT/pages/box-component.adoc
+++ b/docs/components/modules/ROOT/pages/box-component.adoc
@@ -795,3 +795,6 @@ from("direct:foo")
     .to("box://files/download")
     .to("file://...");
 ----
+
+include::camel-spring-boot::page$box-starter.adoc[]
+
diff --git a/docs/components/modules/ROOT/pages/braintree-component.adoc b/docs/components/modules/ROOT/pages/braintree-component.adoc
index e3d1179..f310df6 100644
--- a/docs/components/modules/ROOT/pages/braintree-component.adoc
+++ b/docs/components/modules/ROOT/pages/braintree-component.adoc
@@ -869,3 +869,5 @@ body in the *inBody* endpoint parameter.
 </blueprint>
 --------------------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$braintree-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/browse-component.adoc b/docs/components/modules/ROOT/pages/browse-component.adoc
index b5bc48d..0896473 100644
--- a/docs/components/modules/ROOT/pages/browse-component.adoc
+++ b/docs/components/modules/ROOT/pages/browse-component.adoc
@@ -105,3 +105,5 @@ public void inspectRecievedOrders() {
 }
 ----
 
+
+include::camel-spring-boot::page$browse-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/caffeine-cache-component.adoc b/docs/components/modules/ROOT/pages/caffeine-cache-component.adoc
index 950e934..2e56142 100644
--- a/docs/components/modules/ROOT/pages/caffeine-cache-component.adoc
+++ b/docs/components/modules/ROOT/pages/caffeine-cache-component.adoc
@@ -131,3 +131,5 @@ Each time you'll use an operation on the cache you'll have two different headers
 CaffeineConstants.ACTION_HAS_RESULT
 CaffeineConstants.ACTION_SUCCEEDED
 ------------------------------------------------------------
+
+include::camel-spring-boot::page$caffeine-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/caffeine-loadcache-component.adoc b/docs/components/modules/ROOT/pages/caffeine-loadcache-component.adoc
index 6394932..a35dd72 100644
--- a/docs/components/modules/ROOT/pages/caffeine-loadcache-component.adoc
+++ b/docs/components/modules/ROOT/pages/caffeine-loadcache-component.adoc
@@ -99,3 +99,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$caffeine-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cbor-dataformat.adoc b/docs/components/modules/ROOT/pages/cbor-dataformat.adoc
index 5f6f622..504d6fb 100644
--- a/docs/components/modules/ROOT/pages/cbor-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/cbor-dataformat.adoc
@@ -77,3 +77,5 @@ And then you can refer to this id in the route:
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$cbor-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/chatscript-component.adoc b/docs/components/modules/ROOT/pages/chatscript-component.adoc
index 5a344fa..efe7753 100644
--- a/docs/components/modules/ROOT/pages/chatscript-component.adoc
+++ b/docs/components/modules/ROOT/pages/chatscript-component.adoc
@@ -90,3 +90,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$chatscript-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/chunk-component.adoc b/docs/components/modules/ROOT/pages/chunk-component.adoc
index 37ce9d5..cd93050 100644
--- a/docs/components/modules/ROOT/pages/chunk-component.adoc
+++ b/docs/components/modules/ROOT/pages/chunk-component.adoc
@@ -202,3 +202,5 @@ Regards Camel Riders Bookstore
 {$body}
 ----------------------------------------------
 
+
+include::camel-spring-boot::page$chunk-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/class-component.adoc b/docs/components/modules/ROOT/pages/class-component.adoc
index ca4f76b..daa7c3b 100644
--- a/docs/components/modules/ROOT/pages/class-component.adoc
+++ b/docs/components/modules/ROOT/pages/class-component.adoc
@@ -130,3 +130,5 @@ See more details at the xref:bean-component.adoc[Bean] component as the *class*
 component works in much the same way.
 ====
 
+
+include::camel-spring-boot::page$bean-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cm-sms-component.adoc b/docs/components/modules/ROOT/pages/cm-sms-component.adoc
index c7327f0..5cb17c5 100644
--- a/docs/components/modules/ROOT/pages/cm-sms-component.adoc
+++ b/docs/components/modules/ROOT/pages/cm-sms-component.adoc
@@ -91,3 +91,5 @@ with the following path and query parameters:
 == Sample
 
 You can try https://github.com/oalles/camel-cm-sample[this project] to see how camel-cm-sms can be integrated in a camel route. 
+
+include::camel-spring-boot::page$cm-sms-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cmis-component.adoc b/docs/components/modules/ROOT/pages/cmis-component.adoc
index fab2e21..ad856f3 100644
--- a/docs/components/modules/ROOT/pages/cmis-component.adoc
+++ b/docs/components/modules/ROOT/pages/cmis-component.adoc
@@ -147,3 +147,5 @@ Maven users will need to add the following dependency to their pom.xml.
 where `${camel-version`} must be replaced by the actual version of Camel
 (2.11 or higher).
 
+
+include::camel-spring-boot::page$cmis-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/coap-component.adoc b/docs/components/modules/ROOT/pages/coap-component.adoc
index 3f27b23..e18b574 100644
--- a/docs/components/modules/ROOT/pages/coap-component.adoc
+++ b/docs/components/modules/ROOT/pages/coap-component.adoc
@@ -131,3 +131,5 @@ The following rules determine which request method the CoAP producer will use to
  2. **GET** if a query string is provided on the target CoAP server URI.
  3. **POST** if the message exchange body is not null.
  4. **GET** otherwise.
+
+include::camel-spring-boot::page$coap-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cometd-component.adoc b/docs/components/modules/ROOT/pages/cometd-component.adoc
index e28f0f4..a101db7 100644
--- a/docs/components/modules/ROOT/pages/cometd-component.adoc
+++ b/docs/components/modules/ROOT/pages/cometd-component.adoc
@@ -213,3 +213,5 @@ Spring DSL based configuration of endpoint
   <to uri="cometds://127.0.0.1:443/service/test?baseResource=file:./target/test-classes/webapp&timeout=240000&interval=0&maxInterval=30000&multiFrameInterval=1500&jsonCommented=true&logLevel=2"/>...
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$cometd-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/consul-component.adoc b/docs/components/modules/ROOT/pages/consul-component.adoc
index 87a9eeb..d552b73 100644
--- a/docs/components/modules/ROOT/pages/consul-component.adoc
+++ b/docs/components/modules/ROOT/pages/consul-component.adoc
@@ -149,3 +149,5 @@ with the following path and query parameters:
 |CamelConsulSession|String|The session id
 |CamelConsulValueAsString|boolean|To transform values retrieved from Consul i.e. on KV endpoint to string.
 |=======================================================================
+
+include::camel-spring-boot::page$consul-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/controlbus-component.adoc b/docs/components/modules/ROOT/pages/controlbus-component.adoc
index 089ba02..d951d23 100644
--- a/docs/components/modules/ROOT/pages/controlbus-component.adoc
+++ b/docs/components/modules/ROOT/pages/controlbus-component.adoc
@@ -200,3 +200,5 @@ message we sent to the control bus component.
 ====
 You can also use other languages such as xref:groovy-language.adoc[Groovy], etc.
 ====
+
+include::camel-spring-boot::page$controlbus-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/corda-component.adoc b/docs/components/modules/ROOT/pages/corda-component.adoc
index 8998e8e..2f934a7 100644
--- a/docs/components/modules/ROOT/pages/corda-component.adoc
+++ b/docs/components/modules/ROOT/pages/corda-component.adoc
@@ -125,3 +125,5 @@ Read the node information:
 from("direct:start")
     .to("corda://localhost:10006?username=user1&password=test&operation=NODE_INFO");
 --------------------------------------------------------
+
+include::camel-spring-boot::page$corda-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/couchbase-component.adoc b/docs/components/modules/ROOT/pages/couchbase-component.adoc
index 17afd07..dab2f82 100644
--- a/docs/components/modules/ROOT/pages/couchbase-component.adoc
+++ b/docs/components/modules/ROOT/pages/couchbase-component.adoc
@@ -135,3 +135,5 @@ In order to authenticate with newer versions of Couchbase Server 5.0 and beyond,
 
  * The value formerly interpreted as a bucket-name is now interpreted as a username. The username must correspond to a user defined on the cluster that is being accessed.
  * The value formerly interpreted as a bucket-password is now interpreted as the password of the defined user.
+
+include::camel-spring-boot::page$couchbase-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/couchdb-component.adoc b/docs/components/modules/ROOT/pages/couchdb-component.adoc
index abe95be..9c37810 100644
--- a/docs/components/modules/ROOT/pages/couchdb-component.adoc
+++ b/docs/components/modules/ROOT/pages/couchdb-component.adoc
@@ -169,3 +169,5 @@ exchange is used
 ----------------------------------------------------------------------------------------
 from("someProducingEndpoint").process(someProcessor).to("couchdb:http://localhost:9999")
 ----------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$couchdb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cql-component.adoc b/docs/components/modules/ROOT/pages/cql-component.adoc
index 764ea6b..06acaba 100644
--- a/docs/components/modules/ROOT/pages/cql-component.adoc
+++ b/docs/components/modules/ROOT/pages/cql-component.adoc
@@ -284,3 +284,5 @@ Arrays.asList("davsclaus", "Claus", "Ibsen")
 The same approach can be used for updating or querying the table.
 
 
+
+include::camel-spring-boot::page$cassandraql-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cron-component.adoc b/docs/components/modules/ROOT/pages/cron-component.adoc
index 647e3c2..6ba69ff 100644
--- a/docs/components/modules/ROOT/pages/cron-component.adoc
+++ b/docs/components/modules/ROOT/pages/cron-component.adoc
@@ -134,3 +134,5 @@ Routes can also be written using the XML DSL.
     <to uri="log:info"/>
 </route>
 -------------
+
+include::camel-spring-boot::page$cron-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/crypto-cms-component.adoc b/docs/components/modules/ROOT/pages/crypto-cms-component.adoc
index 1d162fa..0a65ffc 100644
--- a/docs/components/modules/ROOT/pages/crypto-cms-component.adoc
+++ b/docs/components/modules/ROOT/pages/crypto-cms-component.adoc
@@ -404,3 +404,5 @@ from("direct:start")
         <to uri="mock:result" />
     </route>    
 ----
+
+include::camel-spring-boot::page$crypto-cms-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/crypto-component.adoc b/docs/components/modules/ROOT/pages/crypto-component.adoc
index eb08041..893b45a 100644
--- a/docs/components/modules/ROOT/pages/crypto-component.adoc
+++ b/docs/components/modules/ROOT/pages/crypto-component.adoc
@@ -241,3 +241,5 @@ signed.getIn().setHeader(KEYSTORE_ALIAS, "bob");
 template.send("direct:alias-verify", signed);
 -------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$crypto-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/crypto-dataformat.adoc b/docs/components/modules/ROOT/pages/crypto-dataformat.adoc
index b8df61a..42734c0 100644
--- a/docs/components/modules/ROOT/pages/crypto-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/crypto-dataformat.adoc
@@ -277,3 +277,5 @@ need to add the following dependency to your pom.
 </dependency>
 ----------------------------------------------------------
 
+
+include::camel-spring-boot::page$crypto-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/csv-dataformat.adoc b/docs/components/modules/ROOT/pages/csv-dataformat.adoc
index f3ebf96..eea0d92 100644
--- a/docs/components/modules/ROOT/pages/csv-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/csv-dataformat.adoc
@@ -376,3 +376,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$csv-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cxf-component.adoc b/docs/components/modules/ROOT/pages/cxf-component.adoc
index c373d00..341fe2c 100644
--- a/docs/components/modules/ROOT/pages/cxf-component.adoc
+++ b/docs/components/modules/ROOT/pages/cxf-component.adoc
@@ -875,3 +875,5 @@ the key SOAPAction (case-insensitive).
 
  
 
+
+include::camel-spring-boot::page$cxf-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/cxfrs-component.adoc b/docs/components/modules/ROOT/pages/cxfrs-component.adoc
index 1a81847..799d39c 100644
--- a/docs/components/modules/ROOT/pages/cxfrs-component.adoc
+++ b/docs/components/modules/ROOT/pages/cxfrs-component.adoc
@@ -480,3 +480,5 @@ queryMap.put("q1", "new");
 queryMap.put("q2", "world");
 inMessage.setHeader(CxfConstants.CAMEL_CXF_RS_QUERY_MAP, queryMap);
 ----
+
+include::camel-spring-boot::page$cxf-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/dataformat-component.adoc b/docs/components/modules/ROOT/pages/dataformat-component.adoc
index 264b8df..2312a91 100644
--- a/docs/components/modules/ROOT/pages/dataformat-component.adoc
+++ b/docs/components/modules/ROOT/pages/dataformat-component.adoc
@@ -99,3 +99,5 @@ And in XML DSL you do:
   </route>
 </camelContext>
 ----
+
+include::camel-spring-boot::page$dataformat-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/dataset-component.adoc b/docs/components/modules/ROOT/pages/dataset-component.adoc
index 073a870..430e3e5 100644
--- a/docs/components/modules/ROOT/pages/dataset-component.adoc
+++ b/docs/components/modules/ROOT/pages/dataset-component.adoc
@@ -240,3 +240,5 @@ the bodies from a file.
 |`delimiter` |`String` |\z |Specifies the delimiter pattern used by a `java.util.Scanner` to split
 the file into multiple payloads.
 |===
+
+include::camel-spring-boot::page$dataset-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/dataset-test-component.adoc b/docs/components/modules/ROOT/pages/dataset-test-component.adoc
index 8706758..42f552f 100644
--- a/docs/components/modules/ROOT/pages/dataset-test-component.adoc
+++ b/docs/components/modules/ROOT/pages/dataset-test-component.adoc
@@ -122,3 +122,5 @@ method], your test case will perform the necessary assertions.
 To see how you can set other expectations on the test endpoint, see the
 xref:mock-component.adoc[Mock] component.
 
+
+include::camel-spring-boot::page$dataset-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/debezium-mongodb-component.adoc b/docs/components/modules/ROOT/pages/debezium-mongodb-component.adoc
index 8cbcc0e..c8cd3db 100644
--- a/docs/components/modules/ROOT/pages/debezium-mongodb-component.adoc
+++ b/docs/components/modules/ROOT/pages/debezium-mongodb-component.adoc
@@ -178,3 +178,5 @@ from("debezium-mongodb:dbz-test-1?offsetStorageFileName=/usr/offset-file-1.dat&m
 By default, the component will emit the events in the body String JSON format in case of `u`, `c` or `r` operations, this can be easily converted to JSON using Camel JSON Data Format e.g: `.unmarshal().json()` like the above example. In case of operation `d`, the body will be `null`.
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-mongodb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/debezium-mysql-component.adoc b/docs/components/modules/ROOT/pages/debezium-mysql-component.adoc
index b500bbd..5179ab2 100644
--- a/docs/components/modules/ROOT/pages/debezium-mysql-component.adoc
+++ b/docs/components/modules/ROOT/pages/debezium-mysql-component.adoc
@@ -228,3 +228,5 @@ from("debezium-mysql:[name]?[options]])
 ----
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-mysql-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/debezium-postgres-component.adoc b/docs/components/modules/ROOT/pages/debezium-postgres-component.adoc
index 1427e8a..ddf1d3d 100644
--- a/docs/components/modules/ROOT/pages/debezium-postgres-component.adoc
+++ b/docs/components/modules/ROOT/pages/debezium-postgres-component.adoc
@@ -211,3 +211,5 @@ from("debezium-postgres:[name]?[options]])
 ----
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-postgres-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/debezium-sqlserver-component.adoc b/docs/components/modules/ROOT/pages/debezium-sqlserver-component.adoc
index 933a6e7..5aea470 100644
--- a/docs/components/modules/ROOT/pages/debezium-sqlserver-component.adoc
+++ b/docs/components/modules/ROOT/pages/debezium-sqlserver-component.adoc
@@ -192,3 +192,5 @@ from("debezium-sqlserver:[name]?[options]])
 ----
 
 *Important Note:* This component is a thin wrapper around Debezium Engine as mentioned, therefore before using this component in production, you need to understand how Debezium works and how configurations can reflect the expected behavior, especially in regards to https://debezium.io/documentation/reference/0.9/operations/embedded.html#_handling_failures[handling failures].
+
+include::camel-spring-boot::page$debezium-sqlserver-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/digitalocean-component.adoc b/docs/components/modules/ROOT/pages/digitalocean-component.adoc
index 182c874..19e2f00 100644
--- a/docs/components/modules/ROOT/pages/digitalocean-component.adoc
+++ b/docs/components/modules/ROOT/pages/digitalocean-component.adoc
@@ -470,3 +470,5 @@ from("direct:shutdown")
     .setHeader(DigitalOceanConstants.ID, 34772987)
     .to("digitalocean:droplet?operation=shutdown&oAuthToken=XXXXXX")
 ```
+
+include::camel-spring-boot::page$digitalocean-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/direct-component.adoc b/docs/components/modules/ROOT/pages/direct-component.adoc
index 0881a66..fbbaaa6 100644
--- a/docs/components/modules/ROOT/pages/direct-component.adoc
+++ b/docs/components/modules/ROOT/pages/direct-component.adoc
@@ -135,3 +135,5 @@ And the sample using spring DSL:
 See also samples from the xref:seda-component.adoc[SEDA] component, how they can
 be used together.
 
+
+include::camel-spring-boot::page$direct-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/direct-vm-component.adoc b/docs/components/modules/ROOT/pages/direct-vm-component.adoc
index 9f270d6..c4509d4 100644
--- a/docs/components/modules/ROOT/pages/direct-vm-component.adoc
+++ b/docs/components/modules/ROOT/pages/direct-vm-component.adoc
@@ -144,3 +144,5 @@ And the sample using spring DSL:
 </route>
 ----
 
+
+include::camel-spring-boot::page$directvm-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/disruptor-component.adoc b/docs/components/modules/ROOT/pages/disruptor-component.adoc
index a490103..c009636 100644
--- a/docs/components/modules/ROOT/pages/disruptor-component.adoc
+++ b/docs/components/modules/ROOT/pages/disruptor-component.adoc
@@ -329,3 +329,5 @@ using JMX in this fashion:
 DisruptorEndpoint disruptor = context.getEndpoint("disruptor:xxxx");
 int size = disruptor.getBufferSize();
 --------------------------------------------------------------------
+
+include::camel-spring-boot::page$disruptor-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/dns-component.adoc b/docs/components/modules/ROOT/pages/dns-component.adoc
index 69ffaaa..666b035 100644
--- a/docs/components/modules/ROOT/pages/dns-component.adoc
+++ b/docs/components/modules/ROOT/pages/dns-component.adoc
@@ -191,3 +191,5 @@ i.e. You may have an instance in NYC and an instance in SFO. You would configure
 	<route id="routeId" autoStartup="false" routePolicyRef="dnsActivationPolicy">
 	</route>
 ----
+
+include::camel-spring-boot::page$dns-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/docker-component.adoc b/docs/components/modules/ROOT/pages/docker-component.adoc
index f8ced69..ca359db 100644
--- a/docs/components/modules/ROOT/pages/docker-component.adoc
+++ b/docs/components/modules/ROOT/pages/docker-component.adoc
@@ -143,3 +143,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$docker-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/dozer-component.adoc b/docs/components/modules/ROOT/pages/dozer-component.adoc
index 8156dfe..2dab0df 100644
--- a/docs/components/modules/ROOT/pages/dozer-component.adoc
+++ b/docs/components/modules/ROOT/pages/dozer-component.adoc
@@ -294,3 +294,5 @@ An example of mapping a message header into a target field:
 Note that any properties within your expression must be escaped with "\"
 to prevent an error when Dozer attempts to resolve variable values
 defined using the EL.
+
+include::camel-spring-boot::page$dozer-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/drill-component.adoc b/docs/components/modules/ROOT/pages/drill-component.adoc
index 79abc83..e962219 100644
--- a/docs/components/modules/ROOT/pages/drill-component.adoc
+++ b/docs/components/modules/ROOT/pages/drill-component.adoc
@@ -92,3 +92,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$drill-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/dropbox-component.adoc b/docs/components/modules/ROOT/pages/dropbox-component.adoc
index 48bf5ac..a3b4bfa 100644
--- a/docs/components/modules/ROOT/pages/dropbox-component.adoc
+++ b/docs/components/modules/ROOT/pages/dropbox-component.adoc
@@ -427,3 +427,5 @@ Dropbox documentation,
 
 
  
+
+include::camel-spring-boot::page$dropbox-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ehcache-component.adoc b/docs/components/modules/ROOT/pages/ehcache-component.adoc
index 59b43c1..2df845e 100644
--- a/docs/components/modules/ROOT/pages/ehcache-component.adoc
+++ b/docs/components/modules/ROOT/pages/ehcache-component.adoc
@@ -238,3 +238,5 @@ public class EhcacheAggregationRepositoryRoutesTest extends CamelTestSupport {
     }
 }
 ---------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$ehcache-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/elasticsearch-rest-component.adoc b/docs/components/modules/ROOT/pages/elasticsearch-rest-component.adoc
index 350950d..b670a66 100644
--- a/docs/components/modules/ROOT/pages/elasticsearch-rest-component.adoc
+++ b/docs/components/modules/ROOT/pages/elasticsearch-rest-component.adoc
@@ -321,3 +321,5 @@ req.types("tweets");
 MultiSearchRequest request = new MultiSearchRequest().add(req1).add(req);
 Item[] response = template.requestBody("direct:search", request, Item[].class);
 ----
+
+include::camel-spring-boot::page$elasticsearch-rest-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/elsql-component.adoc b/docs/components/modules/ROOT/pages/elsql-component.adoc
index e22a715..9248949 100644
--- a/docs/components/modules/ROOT/pages/elsql-component.adoc
+++ b/docs/components/modules/ROOT/pages/elsql-component.adoc
@@ -278,3 +278,5 @@ Notice that there is no existing `Exchange` with message body and headers, so
 the simple expression you can use in the consumer are most useable for calling
 bean methods as in this example.
 
+
+include::camel-spring-boot::page$elsql-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/elytron-component.adoc b/docs/components/modules/ROOT/pages/elytron-component.adoc
index d5979e0..d041cc8 100644
--- a/docs/components/modules/ROOT/pages/elytron-component.adoc
+++ b/docs/components/modules/ROOT/pages/elytron-component.adoc
@@ -128,3 +128,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters |  | SSLContextParameters
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$elytron-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/etcd-keys-component.adoc b/docs/components/modules/ROOT/pages/etcd-keys-component.adoc
index 9bc654b..4ed664a 100644
--- a/docs/components/modules/ROOT/pages/etcd-keys-component.adoc
+++ b/docs/components/modules/ROOT/pages/etcd-keys-component.adoc
@@ -78,4 +78,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters. |  | SSLContextParameters
 | *userName* (security) | The user name to use for basic authentication. |  | String
 |===
-// endpoint options: END
\ No newline at end of file
+// endpoint options: END
+include::camel-spring-boot::page$etcd-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/etcd-stats-component.adoc b/docs/components/modules/ROOT/pages/etcd-stats-component.adoc
index 3b4b59b..ab50d5d 100644
--- a/docs/components/modules/ROOT/pages/etcd-stats-component.adoc
+++ b/docs/components/modules/ROOT/pages/etcd-stats-component.adoc
@@ -100,4 +100,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters. |  | SSLContextParameters
 | *userName* (security) | The user name to use for basic authentication. |  | String
 |===
-// endpoint options: END
\ No newline at end of file
+// endpoint options: END
+include::camel-spring-boot::page$etcd-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/etcd-watch-component.adoc b/docs/components/modules/ROOT/pages/etcd-watch-component.adoc
index 7b3f3cb..51fa5fc 100644
--- a/docs/components/modules/ROOT/pages/etcd-watch-component.adoc
+++ b/docs/components/modules/ROOT/pages/etcd-watch-component.adoc
@@ -81,4 +81,5 @@ with the following path and query parameters:
 | *sslContextParameters* (security) | To configure security using SSLContextParameters. |  | SSLContextParameters
 | *userName* (security) | The user name to use for basic authentication. |  | String
 |===
-// endpoint options: END
\ No newline at end of file
+// endpoint options: END
+include::camel-spring-boot::page$etcd-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/exec-component.adoc b/docs/components/modules/ROOT/pages/exec-component.adoc
index a4c4969..9d2a5e0 100644
--- a/docs/components/modules/ROOT/pages/exec-component.adoc
+++ b/docs/components/modules/ROOT/pages/exec-component.adoc
@@ -254,3 +254,5 @@ such a command - `echo` - in Windows.
 from("direct:exec").to("exec:cmd?args=/C echo echoString")
 ----------------------------------------------------------
 
+
+include::camel-spring-boot::page$exec-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/facebook-component.adoc b/docs/components/modules/ROOT/pages/facebook-component.adoc
index 2ff72e3..c33bf53 100644
--- a/docs/components/modules/ROOT/pages/facebook-component.adoc
+++ b/docs/components/modules/ROOT/pages/facebook-component.adoc
@@ -320,3 +320,5 @@ CamelFacebook.query header.
         .setHeader("CamelFacebook.query", header("bar"))
         .to("facebook://posts");
 --------------------------------------------------------
+
+include::camel-spring-boot::page$facebook-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/fhir-component.adoc b/docs/components/modules/ROOT/pages/fhir-component.adoc
index 2d01e62..c603cdc 100644
--- a/docs/components/modules/ROOT/pages/fhir-component.adoc
+++ b/docs/components/modules/ROOT/pages/fhir-component.adoc
@@ -141,3 +141,6 @@ with the following path and query parameters:
 | *username* (security) | Username to use for basic authentication |  | String
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$fhir-starter.adoc[]
+
diff --git a/docs/components/modules/ROOT/pages/file-component.adoc b/docs/components/modules/ROOT/pages/file-component.adoc
index 5da2aae..b1cab97 100644
--- a/docs/components/modules/ROOT/pages/file-component.adoc
+++ b/docs/components/modules/ROOT/pages/file-component.adoc
@@ -1154,3 +1154,5 @@ prior actions such as interceptors, onCompletion to take action.
 This component has log level *TRACE* that can be helpful if you have
 problems.
 
+
+include::camel-spring-boot::page$file-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/file-watch-component.adoc b/docs/components/modules/ROOT/pages/file-watch-component.adoc
index 1c458f1..cfada59 100644
--- a/docs/components/modules/ROOT/pages/file-watch-component.adoc
+++ b/docs/components/modules/ROOT/pages/file-watch-component.adoc
@@ -137,3 +137,5 @@ relative filename. For absolute files this is the absolute path.
 
 |`CamelFileLastModified` |A `Long` value containing the last modified timestamp of the file.
 |===
+
+include::camel-spring-boot::page$file-watch-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/flatpack-component.adoc b/docs/components/modules/ROOT/pages/flatpack-component.adoc
index 395b75d..f3fcf31 100644
--- a/docs/components/modules/ROOT/pages/flatpack-component.adoc
+++ b/docs/components/modules/ROOT/pages/flatpack-component.adoc
@@ -322,3 +322,5 @@ the download page for the latest versions).
 </dependency>
 -----------------------------------------
 
+
+include::camel-spring-boot::page$flatpack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/flatpack-dataformat.adoc b/docs/components/modules/ROOT/pages/flatpack-dataformat.adoc
index 4855d4d..0f0efea 100644
--- a/docs/components/modules/ROOT/pages/flatpack-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/flatpack-dataformat.adoc
@@ -95,3 +95,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -----------------------------------------
+
+include::camel-spring-boot::page$flatpack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/flink-component.adoc b/docs/components/modules/ROOT/pages/flink-component.adoc
index d391c59..159b801 100644
--- a/docs/components/modules/ROOT/pages/flink-component.adoc
+++ b/docs/components/modules/ROOT/pages/flink-component.adoc
@@ -164,3 +164,5 @@ try {
         camelContext.stop();
     }
 -----------------------------------
+
+include::camel-spring-boot::page$flink-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/fop-component.adoc b/docs/components/modules/ROOT/pages/fop-component.adoc
index 2fdc883..b0500a3 100644
--- a/docs/components/modules/ROOT/pages/fop-component.adoc
+++ b/docs/components/modules/ROOT/pages/fop-component.adoc
@@ -171,3 +171,5 @@ from("file:source/data/xml")
     .to("file:target/data");
 ---------------------------------
 
+
+include::camel-spring-boot::page$fop-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/freemarker-component.adoc b/docs/components/modules/ROOT/pages/freemarker-component.adoc
index 2a83797..cf0d9eb 100644
--- a/docs/components/modules/ROOT/pages/freemarker-component.adoc
+++ b/docs/components/modules/ROOT/pages/freemarker-component.adoc
@@ -246,3 +246,5 @@ ${body}
 
 And the java code:
 
+
+include::camel-spring-boot::page$freemarker-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ftp-component.adoc b/docs/components/modules/ROOT/pages/ftp-component.adoc
index 6377e90..fd2a819 100644
--- a/docs/components/modules/ROOT/pages/ftp-component.adoc
+++ b/docs/components/modules/ROOT/pages/ftp-component.adoc
@@ -754,3 +754,5 @@ String data = template.retrieveBodyNoWait("ftp://admin@localhost:21/nolist/?pass
 This component has log level *TRACE* that can be helpful if you have
 problems.
 
+
+include::camel-spring-boot::page$ftp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ftps-component.adoc b/docs/components/modules/ROOT/pages/ftps-component.adoc
index 3fb1bc1..3129ced 100644
--- a/docs/components/modules/ROOT/pages/ftps-component.adoc
+++ b/docs/components/modules/ROOT/pages/ftps-component.adoc
@@ -194,3 +194,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$ftp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ganglia-component.adoc b/docs/components/modules/ROOT/pages/ganglia-component.adoc
index 6b942ee..5e4a7ab 100644
--- a/docs/components/modules/ROOT/pages/ganglia-component.adoc
+++ b/docs/components/modules/ROOT/pages/ganglia-component.adoc
@@ -164,3 +164,5 @@ from("direct:value.for.ganglia")
 from("direct:ganglia.tx")
     .to("ganglia:239.2.11.71:8649?mode=MULTICAST&prefix=test");
 ----
+
+include::camel-spring-boot::page$ganglia-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/geocoder-component.adoc b/docs/components/modules/ROOT/pages/geocoder-component.adoc
index fcc10a9..b28e5f0 100644
--- a/docs/components/modules/ROOT/pages/geocoder-component.adoc
+++ b/docs/components/modules/ROOT/pages/geocoder-component.adoc
@@ -187,3 +187,5 @@ shown:
   from("direct:start")
     .to("geocoder:address:current")
 -----------------------------------
+
+include::camel-spring-boot::page$geocoder-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/git-component.adoc b/docs/components/modules/ROOT/pages/git-component.adoc
index fd399e3..a56b1c3 100644
--- a/docs/components/modules/ROOT/pages/git-component.adoc
+++ b/docs/components/modules/ROOT/pages/git-component.adoc
@@ -147,3 +147,5 @@ Below is an example route of a consumer that consumes commit:
 from("git:///tmp/testRepo?type=commit")
                         .to(....)
 ---------------------------------------
+
+include::camel-spring-boot::page$git-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/github-component.adoc b/docs/components/modules/ROOT/pages/github-component.adoc
index aef5cb9..86d8cff 100644
--- a/docs/components/modules/ROOT/pages/github-component.adoc
+++ b/docs/components/modules/ROOT/pages/github-component.adoc
@@ -145,3 +145,5 @@ pull request discussion is assumed.
 
 |createIssue |String (issue body text) | - GitHubIssueTitle (String) (REQUIRED): Issue Title.
 |=======================================================================
+
+include::camel-spring-boot::page$github-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-bigquery-component.adoc b/docs/components/modules/ROOT/pages/google-bigquery-component.adoc
index 9798d2a..0c42733 100644
--- a/docs/components/modules/ROOT/pages/google-bigquery-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-bigquery-component.adoc
@@ -169,3 +169,5 @@ A insert id can be set on the exchange with the header `GoogleBigQueryConstants.
 query parameter `useAsInsertId`. As an insert id need to be specified per row inserted the exchange header can't
 be used when the payload is a list - if the payload is a list the `GoogleBigQueryConstants.INSERT_ID` will
 be ignored. In that case use the query parameter `useAsInsertId`.
+
+include::camel-spring-boot::page$google-bigquery-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-bigquery-sql-component.adoc b/docs/components/modules/ROOT/pages/google-bigquery-sql-component.adoc
index 6170ff0..c09f328 100644
--- a/docs/components/modules/ROOT/pages/google-bigquery-sql-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-bigquery-sql-component.adoc
@@ -139,3 +139,5 @@ with the following path and query parameters:
 == Producer Endpoints
 
 Google BigQuery SQL endpoint expects the payload to be either empty or a map of query parameters.
+
+include::camel-spring-boot::page$google-bigquery-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-calendar-component.adoc b/docs/components/modules/ROOT/pages/google-calendar-component.adoc
index e306864..c42cc29 100644
--- a/docs/components/modules/ROOT/pages/google-calendar-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-calendar-component.adoc
@@ -188,3 +188,5 @@ APIs used by the GoogleCalendarComponent. Producer endpoints can specify
 the option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-calendar-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-calendar-stream-component.adoc b/docs/components/modules/ROOT/pages/google-calendar-stream-component.adoc
index feb761c..ed1dd2f 100644
--- a/docs/components/modules/ROOT/pages/google-calendar-stream-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-calendar-stream-component.adoc
@@ -141,3 +141,5 @@ from("google-calendar-stream://test?markAsRead=true&delay=5000&maxResults=5").to
 This route will consume the next five events starting from the date of polling.
 
    
+
+include::camel-spring-boot::page$google-calendar-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-drive-component.adoc b/docs/components/modules/ROOT/pages/google-drive-component.adoc
index 821dc6e..eeff71c 100644
--- a/docs/components/modules/ROOT/pages/google-drive-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-drive-component.adoc
@@ -196,3 +196,5 @@ APIs used by the GoogleDriveComponent. Producer endpoints can specify
 the option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-drive-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-mail-component.adoc b/docs/components/modules/ROOT/pages/google-mail-component.adoc
index 7439619..4210f3e 100644
--- a/docs/components/modules/ROOT/pages/google-mail-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-mail-component.adoc
@@ -185,3 +185,5 @@ APIs used by the GoogleMailComponent. Producer endpoints can specify the
 option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-mail-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-mail-stream-component.adoc b/docs/components/modules/ROOT/pages/google-mail-stream-component.adoc
index d49e613..197b275 100644
--- a/docs/components/modules/ROOT/pages/google-mail-stream-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-mail-stream-component.adoc
@@ -137,3 +137,5 @@ from("google-mail-stream://test?markAsRead=true&delay=5000&maxResults=5&labels=G
 This route will consume unread messages with labels Github and Apache and it will mark the messages as read.
 
    
+
+include::camel-spring-boot::page$google-mail-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-pubsub-component.adoc b/docs/components/modules/ROOT/pages/google-pubsub-component.adoc
index 1cf6c88..49c3d6b 100644
--- a/docs/components/modules/ROOT/pages/google-pubsub-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-pubsub-component.adoc
@@ -169,3 +169,5 @@ be redelivered to the next consumer.
 
 It is possible to delay the message redelivery by setting the acknowledgement deadline explicitly for the rollback by
 setting the message header `GooglePubsubConstants.ACK_DEADLINE` to the value in seconds.
+
+include::camel-spring-boot::page$google-pubsub-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-sheets-component.adoc b/docs/components/modules/ROOT/pages/google-sheets-component.adoc
index b7730e8..d942152 100644
--- a/docs/components/modules/ROOT/pages/google-sheets-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-sheets-component.adoc
@@ -181,3 +181,5 @@ APIs used by the GoogleSheetsComponent. Producer endpoints can specify
 the option name for incoming message body in the `inBody` endpoint URI
 parameter. For endpoints that return an array or collection, a consumer
 endpoint will map every element to distinct messages.     
+
+include::camel-spring-boot::page$google-sheets-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/google-sheets-stream-component.adoc b/docs/components/modules/ROOT/pages/google-sheets-stream-component.adoc
index ce170c3..67db8b9 100644
--- a/docs/components/modules/ROOT/pages/google-sheets-stream-component.adoc
+++ b/docs/components/modules/ROOT/pages/google-sheets-stream-component.adoc
@@ -143,3 +143,5 @@ from("google-sheets-stream://data?range=A:B&delay=5000&maxResults=5").to("mock:r
 This route will consume the next ten events starting from the date of polling.
 
    
+
+include::camel-spring-boot::page$google-sheets-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/gora-component.adoc b/docs/components/modules/ROOT/pages/gora-component.adoc
index d5709c6..356db0d 100644
--- a/docs/components/modules/ROOT/pages/gora-component.adoc
+++ b/docs/components/modules/ROOT/pages/gora-component.adoc
@@ -280,3 +280,5 @@ For more please information and in depth configuration refer to the
 http://gora.apache.org/current/overview.html[Apache Gora Documentation]
 and the http://gora.apache.org/current/tutorial.html[Apache Gora
 Tutorial].
+
+include::camel-spring-boot::page$gora-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/graphql-component.adoc b/docs/components/modules/ROOT/pages/graphql-component.adoc
index 639d42b4..43df777 100644
--- a/docs/components/modules/ROOT/pages/graphql-component.adoc
+++ b/docs/components/modules/ROOT/pages/graphql-component.adoc
@@ -165,3 +165,5 @@ public JsonObject addBookMutationVariables() {
 from("direct:start")
     .to("graphql://http://example.com/graphql?graphql?queryFile=addBookMutation.graphql&variables=#addBookMutationVariables")
 ----
+
+include::camel-spring-boot::page$graphql-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/grok-dataformat.adoc b/docs/components/modules/ROOT/pages/grok-dataformat.adoc
index 68a0c31..39c9f3c 100644
--- a/docs/components/modules/ROOT/pages/grok-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/grok-dataformat.adoc
@@ -106,3 +106,5 @@ The Grok dataformat supports 5 options, which are listed below.
 |===
 // dataformat options: END
 ND
+
+include::camel-spring-boot::page$grok-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/groovy-language.adoc b/docs/components/modules/ROOT/pages/groovy-language.adoc
index 031548c..11cefac 100644
--- a/docs/components/modules/ROOT/pages/groovy-language.adoc
+++ b/docs/components/modules/ROOT/pages/groovy-language.adoc
@@ -194,3 +194,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ---------------------------------------
+
+include::camel-spring-boot::page$groovy-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/grpc-component.adoc b/docs/components/modules/ROOT/pages/grpc-component.adoc
index f96bf58..4ca97f4 100644
--- a/docs/components/modules/ROOT/pages/grpc-component.adoc
+++ b/docs/components/modules/ROOT/pages/grpc-component.adoc
@@ -291,3 +291,5 @@ http://www.grpc.io/[gRPC project site]
 
 https://www.xolstice.org/protobuf-maven-plugin[Maven Protocol Buffers Plugin]
 
+
+include::camel-spring-boot::page$grpc-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/guava-eventbus-component.adoc b/docs/components/modules/ROOT/pages/guava-eventbus-component.adoc
index b8b3d67..5918340 100644
--- a/docs/components/modules/ROOT/pages/guava-eventbus-component.adoc
+++ b/docs/components/modules/ROOT/pages/guava-eventbus-component.adoc
@@ -229,3 +229,5 @@ follows.
 -----------------------------------------------------------------------------------------------------
 from("guava-eventbus:busName?listenerInterface=com.example.MultipleEventsListener").to("seda:queue");
 -----------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$guava-eventbus-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/gzipdeflater-dataformat.adoc b/docs/components/modules/ROOT/pages/gzipdeflater-dataformat.adoc
index 6251102..0e255f8 100644
--- a/docs/components/modules/ROOT/pages/gzipdeflater-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/gzipdeflater-dataformat.adoc
@@ -60,3 +60,5 @@ from("activemq:queue:MY_QUEUE").unmarshal().gzipDeflater().process(new UnGZipped
 
 This data format is provided in *camel-core* so no additional
 dependencies is needed.
+
+include::camel-spring-boot::page$zip-deflater-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-atomicvalue-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-atomicvalue-component.adoc
index fe3e2ce..764df92 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-atomicvalue-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-atomicvalue-component.adoc
@@ -216,3 +216,5 @@ Spring DSL:
     <to uri="hazelcast-atomicvalue:foo" />
 </route>
 -----------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-instance-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-instance-component.adoc
index dd2d3f9..569211e 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-instance-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-instance-component.adoc
@@ -107,3 +107,5 @@ Header Variables inside the response message:
 
 |`CamelHazelcastInstancePort` |`Integer` |port number of the instance
 |=======================================================================
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-list-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-list-component.adoc
index 5d13811..fd4f1c6 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-list-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-list-component.adoc
@@ -138,3 +138,5 @@ fromF("hazelcast-%smm", HazelcastConstants.LIST_PREFIX)
                 .otherwise()
                         .log("fail!");
 -----------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-map-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-map-component.adoc
index e124762..4cdfc95 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-map-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-map-component.adoc
@@ -339,3 +339,5 @@ fromF("hazelcast-%sfoo", HazelcastConstants.MAP_PREFIX)
     .otherwise()
          .log("fail!");
 --------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-multimap-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-multimap-component.adoc
index 0177615..5c965ef 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-multimap-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-multimap-component.adoc
@@ -242,3 +242,5 @@ Header Variables inside the response message:
 
 |`CamelHazelcastCacheType` |`String` |the type of the cache - here multimap
 |=======================================================================
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-queue-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-queue-component.adoc
index 80f4815..90142f1 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-queue-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-queue-component.adoc
@@ -227,3 +227,5 @@ fromF("hazelcast-%smm", HazelcastConstants.QUEUE_PREFIX)
     .otherwise()
         .log("fail!");
 -------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-replicatedmap-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-replicatedmap-component.adoc
index 75734c01..69dd798 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-replicatedmap-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-replicatedmap-component.adoc
@@ -215,3 +215,5 @@ Header Variables inside the response message:
 
 |`CamelHazelcastCacheType` |`String` |the type of the cache - here replicatedmap
 |=======================================================================
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-ringbuffer-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-ringbuffer-component.adoc
index db1aace..ebf50c5 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-ringbuffer-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-ringbuffer-component.adoc
@@ -121,3 +121,5 @@ from("direct:get")
 .toF("hazelcast-%sbar", HazelcastConstants.RINGBUFFER_PREFIX)
 .to("seda:out");
 -----------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-seda-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-seda-component.adoc
index e6ffa1c..d825a90 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-seda-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-seda-component.adoc
@@ -118,3 +118,5 @@ Spring DSL:
   <to uri="mock:result" />
 </route>
 -----------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-set-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-set-component.adoc
index 3492293..6c3a911 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-set-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-set-component.adoc
@@ -65,3 +65,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast-topic-component.adoc b/docs/components/modules/ROOT/pages/hazelcast-topic-component.adoc
index f28418b..1fe4191 100644
--- a/docs/components/modules/ROOT/pages/hazelcast-topic-component.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast-topic-component.adoc
@@ -98,3 +98,5 @@ fromF("hazelcast-%sfoo", HazelcastConstants.TOPIC_PREFIX)
     .otherwise()
       .log("...this should never have happened")
 --------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hazelcast.adoc b/docs/components/modules/ROOT/pages/hazelcast.adoc
index 7d8f122..5182d3e 100644
--- a/docs/components/modules/ROOT/pages/hazelcast.adoc
+++ b/docs/components/modules/ROOT/pages/hazelcast.adoc
@@ -187,3 +187,5 @@ to reference the service in the hazelcast endpoint.
     </route>
 </camelContext>
 --------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$hazelcast-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hbase-component.adoc b/docs/components/modules/ROOT/pages/hbase-component.adoc
index 3f59439..2abd6cd 100644
--- a/docs/components/modules/ROOT/pages/hbase-component.adoc
+++ b/docs/components/modules/ROOT/pages/hbase-component.adoc
@@ -508,3 +508,5 @@ myvalue to the column myfamily:myqualifier. +
 advantage it has over the header mapping strategy is that the HBaseData
 object can be easily converted to or from xml/json.
 
+
+include::camel-spring-boot::page$hbase-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hdfs-component.adoc b/docs/components/modules/ROOT/pages/hdfs-component.adoc
index 3ee93a2..6636015 100644
--- a/docs/components/modules/ROOT/pages/hdfs-component.adoc
+++ b/docs/components/modules/ROOT/pages/hdfs-component.adoc
@@ -337,3 +337,5 @@ static {
 }
 ------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$hdfs-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hipchat-component.adoc b/docs/components/modules/ROOT/pages/hipchat-component.adoc
index 2f83cd3..77e3bfc 100644
--- a/docs/components/modules/ROOT/pages/hipchat-component.adoc
+++ b/docs/components/modules/ROOT/pages/hipchat-component.adoc
@@ -238,3 +238,5 @@ Maven users will need to add the following dependency to their pom.xml.
 ------------------------------------------
 
 where `$\{camel-version\}` must be replaced by the actual version of Camel.
+
+include::camel-spring-boot::page$hipchat-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hl7-dataformat.adoc b/docs/components/modules/ROOT/pages/hl7-dataformat.adoc
index a15d535..7af3cba 100644
--- a/docs/components/modules/ROOT/pages/hl7-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/hl7-dataformat.adoc
@@ -406,3 +406,5 @@ repository].
 </dependency>
 ----
 
+
+include::camel-spring-boot::page$hl7-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hl7terser-language.adoc b/docs/components/modules/ROOT/pages/hl7terser-language.adoc
index d893ddb..474b48a 100644
--- a/docs/components/modules/ROOT/pages/hl7terser-language.adoc
+++ b/docs/components/modules/ROOT/pages/hl7terser-language.adoc
@@ -132,3 +132,5 @@ import ca.uhn.hl7v2.validation.impl.DefaultValidation;
       // acknowledgement
       .transform(ack())
 ----
+
+include::camel-spring-boot::page$hl7-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/http-component.adoc b/docs/components/modules/ROOT/pages/http-component.adoc
index dfc3440..7f1c0fd 100644
--- a/docs/components/modules/ROOT/pages/http-component.adoc
+++ b/docs/components/modules/ROOT/pages/http-component.adoc
@@ -694,3 +694,5 @@ property.
    <property name="x509HostnameVerifier" ref="hostnameVerifier"/>
 </bean>
 ----------------------------------------------------------------------------
+
+include::camel-spring-boot::page$http-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/hystrix.adoc b/docs/components/modules/ROOT/pages/hystrix.adoc
index 0aa7373..f314f47 100644
--- a/docs/components/modules/ROOT/pages/hystrix.adoc
+++ b/docs/components/modules/ROOT/pages/hystrix.adoc
@@ -20,3 +20,5 @@ for this component:
 </dependency>
 ----
 
+
+include::camel-spring-boot::page$hystrix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ical-dataformat.adoc b/docs/components/modules/ROOT/pages/ical-dataformat.adoc
index ca9e93f..d683e9c 100644
--- a/docs/components/modules/ROOT/pages/ical-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/ical-dataformat.adoc
@@ -71,3 +71,5 @@ for this component:
 </dependency>
 ------------------------------------------------------------
 
+
+include::camel-spring-boot::page$ical-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/iec60870-client-component.adoc b/docs/components/modules/ROOT/pages/iec60870-client-component.adoc
index 6b275ab..9300678 100644
--- a/docs/components/modules/ROOT/pages/iec60870-client-component.adoc
+++ b/docs/components/modules/ROOT/pages/iec60870-client-component.adoc
@@ -129,3 +129,5 @@ The final connection options will be evaluated in the following order:
 * Apply +protocolOptions+ if present
 * Apply +dataModuleOptions+ if present
 * Apply all explicit connection parameters (e.g. +timeZone+)
+
+include::camel-spring-boot::page$iec60870-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/iec60870-server-component.adoc b/docs/components/modules/ROOT/pages/iec60870-server-component.adoc
index 4505d2b..82458b7 100644
--- a/docs/components/modules/ROOT/pages/iec60870-server-component.adoc
+++ b/docs/components/modules/ROOT/pages/iec60870-server-component.adoc
@@ -113,3 +113,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$iec60870-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite-cache-component.adoc b/docs/components/modules/ROOT/pages/ignite-cache-component.adoc
index 1bea00d..4de1291 100644
--- a/docs/components/modules/ROOT/pages/ignite-cache-component.adoc
+++ b/docs/components/modules/ROOT/pages/ignite-cache-component.adoc
@@ -110,3 +110,5 @@ It does not allow you to dynamically change the cache against which a producer o
 | CamelIgniteCacheOldValue | IgniteConstants.IGNITE_CACHE_OLD_VALUE | Object |
 This header carries the old cache value when passed in the incoming cache event (consumer).
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite-compute-component.adoc b/docs/components/modules/ROOT/pages/ignite-compute-component.adoc
index 4673aeb..5dd406b 100644
--- a/docs/components/modules/ROOT/pages/ignite-compute-component.adoc
+++ b/docs/components/modules/ROOT/pages/ignite-compute-component.adoc
@@ -110,3 +110,5 @@ Affinity cache name for the AFFINITY_CALL and AFFINITY_RUN operations.
 | CamelIgniteComputeAffinityKey | IgniteConstants.IGNITE_COMPUTE_AFFINITY_KEY | Object |
 Affinity key for the AFFINITY_CALL and AFFINITY_RUN operations.
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite-events-component.adoc b/docs/components/modules/ROOT/pages/ignite-events-component.adoc
index 4fa4e95..8031c4e 100644
--- a/docs/components/modules/ROOT/pages/ignite-events-component.adoc
+++ b/docs/components/modules/ROOT/pages/ignite-events-component.adoc
@@ -68,3 +68,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite-idgen-component.adoc b/docs/components/modules/ROOT/pages/ignite-idgen-component.adoc
index d2ba7d9..797bb73 100644
--- a/docs/components/modules/ROOT/pages/ignite-idgen-component.adoc
+++ b/docs/components/modules/ROOT/pages/ignite-idgen-component.adoc
@@ -66,3 +66,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite-messaging-component.adoc b/docs/components/modules/ROOT/pages/ignite-messaging-component.adoc
index c2d99e8..f0e636e 100644
--- a/docs/components/modules/ROOT/pages/ignite-messaging-component.adoc
+++ b/docs/components/modules/ROOT/pages/ignite-messaging-component.adoc
@@ -85,3 +85,5 @@ It also carries the topic on which a message was received (consumer).
 | CamelIgniteMessagingUUID | IgniteConstants.IGNITE_MESSAGING_UUID | UUID |
 This header is filled in with the UUID of the subscription when a message arrives (consumer).
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite-queue-component.adoc b/docs/components/modules/ROOT/pages/ignite-queue-component.adoc
index 5a4da9a..f801bbc 100644
--- a/docs/components/modules/ROOT/pages/ignite-queue-component.adoc
+++ b/docs/components/modules/ROOT/pages/ignite-queue-component.adoc
@@ -88,3 +88,5 @@ The amount of items transferred as the result of the DRAIN operation.
 | CamelIgniteQueueTimeoutMillis | IgniteConstants.IGNITE_QUEUE_TIMEOUT_MILLIS | Long or long |
 Dynamically sets the timeout in milliseconds to use when invoking the OFFER or POLL operations. 
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite-set-component.adoc b/docs/components/modules/ROOT/pages/ignite-set-component.adoc
index 1290ed5..e8a1b2b 100644
--- a/docs/components/modules/ROOT/pages/ignite-set-component.adoc
+++ b/docs/components/modules/ROOT/pages/ignite-set-component.adoc
@@ -77,3 +77,5 @@ This endpoint uses the following headers:
 | CamelIgniteSetsOperation | IgniteConstants.IGNITE_SETS_OPERATION | IgniteSetOperation enum |
 Allows you to dynamically change the set operation.
 |=======================================================================
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ignite.adoc b/docs/components/modules/ROOT/pages/ignite.adoc
index 7a045b0..22df121 100644
--- a/docs/components/modules/ROOT/pages/ignite.adoc
+++ b/docs/components/modules/ROOT/pages/ignite.adoc
@@ -108,3 +108,5 @@ When installing on Apache Karaf:
 
 Please refer to the OSGi section in the Ignite documentation for more information.
 
+
+include::camel-spring-boot::page$ignite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/infinispan-component.adoc b/docs/components/modules/ROOT/pages/infinispan-component.adoc
index a116cd5..20b0fb9 100644
--- a/docs/components/modules/ROOT/pages/infinispan-component.adoc
+++ b/docs/components/modules/ROOT/pages/infinispan-component.adoc
@@ -820,3 +820,5 @@ XML file as well:
 </camelContext>
 ----
 
+
+include::camel-spring-boot::page$infinispan-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/influxdb-component.adoc b/docs/components/modules/ROOT/pages/influxdb-component.adoc
index bcd122d..7a32db8 100644
--- a/docs/components/modules/ROOT/pages/influxdb-component.adoc
+++ b/docs/components/modules/ROOT/pages/influxdb-component.adoc
@@ -119,3 +119,5 @@ from("direct:start")
 
 For more information, see these resources...
 
+
+include::camel-spring-boot::page$influxdb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/iota-component.adoc b/docs/components/modules/ROOT/pages/iota-component.adoc
index 7df31d9..194f077 100644
--- a/docs/components/modules/ROOT/pages/iota-component.adoc
+++ b/docs/components/modules/ROOT/pages/iota-component.adoc
@@ -147,3 +147,5 @@ The following route defined in Spring XML retrieve transfers data
 </route>
 ----
 
+
+include::camel-spring-boot::page$iota-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ipfs-component.adoc b/docs/components/modules/ROOT/pages/ipfs-component.adoc
index 78482e8..74d63e8 100644
--- a/docs/components/modules/ROOT/pages/ipfs-component.adoc
+++ b/docs/components/modules/ROOT/pages/ipfs-component.adoc
@@ -97,3 +97,5 @@ from("direct:start").to("ipfs:add")
 from("direct:start").to("ipfs:get?outdir=target")
 from("direct:start").to("ipfs:cat");
 ---------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$ipfs-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/irc-component.adoc b/docs/components/modules/ROOT/pages/irc-component.adoc
index 5be099b..795f4a9 100644
--- a/docs/components/modules/ROOT/pages/irc-component.adoc
+++ b/docs/components/modules/ROOT/pages/irc-component.adoc
@@ -227,3 +227,5 @@ You can specify the destination in the following header:
 |Header |Type |Description
 |`irc.sendTo` |`String` |The channel (or the person) name.
 |=====================================================================
+
+include::camel-spring-boot::page$irc-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ironmq-component.adoc b/docs/components/modules/ROOT/pages/ironmq-component.adoc
index da4a2a9..82d39d0 100644
--- a/docs/components/modules/ROOT/pages/ironmq-component.adoc
+++ b/docs/components/modules/ROOT/pages/ironmq-component.adoc
@@ -176,3 +176,5 @@ Dequeue from activemq jms and enqueue the messages on IronMQ.
 from("activemq:foo")
   .to("ironmq:testqueue?projectId=myIronMQProjectid&token=myIronMQToken");
 --------------------------------------------------
+
+include::camel-spring-boot::page$ironmq-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jacksonxml-dataformat.adoc b/docs/components/modules/ROOT/pages/jacksonxml-dataformat.adoc
index bab30de..26274a6 100644
--- a/docs/components/modules/ROOT/pages/jacksonxml-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/jacksonxml-dataformat.adoc
@@ -363,3 +363,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$jacksonxml-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jaxb-dataformat.adoc b/docs/components/modules/ROOT/pages/jaxb-dataformat.adoc
index 0e48feb..eb2da43 100644
--- a/docs/components/modules/ROOT/pages/jaxb-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/jaxb-dataformat.adoc
@@ -318,3 +318,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$jaxb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jbpm-component.adoc b/docs/components/modules/ROOT/pages/jbpm-component.adoc
index e11ef23..d9e72e6 100644
--- a/docs/components/modules/ROOT/pages/jbpm-component.adoc
+++ b/docs/components/modules/ROOT/pages/jbpm-component.adoc
@@ -291,3 +291,5 @@ from("direct:start")
         &deploymentId=evaluation");
 ----------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jbpm-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jcache-component.adoc b/docs/components/modules/ROOT/pages/jcache-component.adoc
index c36766b..cec957d 100644
--- a/docs/components/modules/ROOT/pages/jcache-component.adoc
+++ b/docs/components/modules/ROOT/pages/jcache-component.adoc
@@ -331,3 +331,5 @@ If the determined _key_ is _null_, nothing is looked up or stored in cache.
 In case of an exception during the route, the error handled is called as always. If the exception gets _handled()_,
  the policy stores the Exchange body, otherwise nothing is added to the cache.
  If an exception happens during evaluating the keyExpression, the routing fails, the error handler is called as normally.
+
+include::camel-spring-boot::page$jcache-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jclouds-component.adoc b/docs/components/modules/ROOT/pages/jclouds-component.adoc
index ce476a4..2cfe745 100644
--- a/docs/components/modules/ROOT/pages/jclouds-component.adoc
+++ b/docs/components/modules/ROOT/pages/jclouds-component.adoc
@@ -373,3 +373,5 @@ Here is the same using spring xml.
 </route>
 ----------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jclouds-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jcr-component.adoc b/docs/components/modules/ROOT/pages/jcr-component.adoc
index 1ba68ce..bec7358 100644
--- a/docs/components/modules/ROOT/pages/jcr-component.adoc
+++ b/docs/components/modules/ROOT/pages/jcr-component.adoc
@@ -137,3 +137,5 @@ all the children.
 </route>
 ---------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jcr-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jdbc-component.adoc b/docs/components/modules/ROOT/pages/jdbc-component.adoc
index a476841..1c53dcd 100644
--- a/docs/components/modules/ROOT/pages/jdbc-component.adoc
+++ b/docs/components/modules/ROOT/pages/jdbc-component.adoc
@@ -317,3 +317,5 @@ from("timer://MoveNewCustomersEveryHour?period=3600000")
         .to("jdbc:testdb");
 ----
 
+
+include::camel-spring-boot::page$jdbc-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jetty-component.adoc b/docs/components/modules/ROOT/pages/jetty-component.adoc
index 98eb420..87f0bb5 100644
--- a/docs/components/modules/ROOT/pages/jetty-component.adoc
+++ b/docs/components/modules/ROOT/pages/jetty-component.adoc
@@ -615,3 +615,5 @@ running another instance of Jetty outside of the Camel context and
 sharing the same MBeanServer between the instances, you can provide both
 instances with a reference to the same MBeanContainer in order to avoid
 name collisions when registering Jetty MBeans.
+
+include::camel-spring-boot::page$jetty-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jgroups-component.adoc b/docs/components/modules/ROOT/pages/jgroups-component.adoc
index 34e4ea4..6ce1e1b 100644
--- a/docs/components/modules/ROOT/pages/jgroups-component.adoc
+++ b/docs/components/modules/ROOT/pages/jgroups-component.adoc
@@ -268,3 +268,5 @@ context.addService(service);
 
 from("master:mycluster:jetty:http://localhost:8080/orders").to("jms:orders"); 
 -----------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$jgroups-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jgroups-raft-component.adoc b/docs/components/modules/ROOT/pages/jgroups-raft-component.adoc
index 8e94803..0c5255c 100644
--- a/docs/components/modules/ROOT/pages/jgroups-raft-component.adoc
+++ b/docs/components/modules/ROOT/pages/jgroups-raft-component.adoc
@@ -180,3 +180,5 @@ context.addService(service);
 
 from("master:mycluster:jetty:http://localhost:8080/orders").to("jms:orders"); 
 -----------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$jgroups-raft-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jing-component.adoc b/docs/components/modules/ROOT/pages/jing-component.adoc
index d8ec4de..9cc4108 100644
--- a/docs/components/modules/ROOT/pages/jing-component.adoc
+++ b/docs/components/modules/ROOT/pages/jing-component.adoc
@@ -123,3 +123,5 @@ schema (which is supplied on the classpath).
         </route>
     </camelContext>
 ----
+
+include::camel-spring-boot::page$jing-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jira-component.adoc b/docs/components/modules/ROOT/pages/jira-component.adoc
index caada88..db16564 100644
--- a/docs/components/modules/ROOT/pages/jira-component.adoc
+++ b/docs/components/modules/ROOT/pages/jira-component.adoc
@@ -256,3 +256,5 @@ Required:
 * `IssueWatchersAdd`: A list of strings with the usernames to add to the watcher list.
 * `IssueWatchersRemove`: A list of strings with the usernames to remove from the watcher list.
 
+
+include::camel-spring-boot::page$jira-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jms-component.adoc b/docs/components/modules/ROOT/pages/jms-component.adoc
index c68879b..69c684c 100644
--- a/docs/components/modules/ROOT/pages/jms-component.adoc
+++ b/docs/components/modules/ROOT/pages/jms-component.adoc
@@ -1337,3 +1337,5 @@ wmq.setDestinationResolver(new DestinationResolver() {
 });
 ----------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jms-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jmx-component.adoc b/docs/components/modules/ROOT/pages/jmx-component.adoc
index 29b3abe..9be9d22 100644
--- a/docs/components/modules/ROOT/pages/jmx-component.adoc
+++ b/docs/components/modules/ROOT/pages/jmx-component.adoc
@@ -91,3 +91,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$jmx-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jolt-component.adoc b/docs/components/modules/ROOT/pages/jolt-component.adoc
index 4fb7371..e373524 100644
--- a/docs/components/modules/ROOT/pages/jolt-component.adoc
+++ b/docs/components/modules/ROOT/pages/jolt-component.adoc
@@ -134,3 +134,5 @@ from("direct:in").
 
  
 
+
+include::camel-spring-boot::page$jolt-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jooq-component.adoc b/docs/components/modules/ROOT/pages/jooq-component.adoc
index ad0ab8e..277d27b 100644
--- a/docs/components/modules/ROOT/pages/jooq-component.adoc
+++ b/docs/components/modules/ROOT/pages/jooq-component.adoc
@@ -274,3 +274,5 @@ public class BookStoreRecordBean {
     }
 }
 ----
+
+include::camel-spring-boot::page$jooq-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jpa-component.adoc b/docs/components/modules/ROOT/pages/jpa-component.adoc
index a689a36..7a75750 100644
--- a/docs/components/modules/ROOT/pages/jpa-component.adoc
+++ b/docs/components/modules/ROOT/pages/jpa-component.adoc
@@ -443,3 +443,5 @@ argument to the JVM:
 -javaagent:<path_to_your_local_m2_cache>/org/apache/openjpa/openjpa/2.2.1/openjpa-2.2.1.jar
 -------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jpa-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jslt-component.adoc b/docs/components/modules/ROOT/pages/jslt-component.adoc
index 4f97f07..9f4f711 100644
--- a/docs/components/modules/ROOT/pages/jslt-component.adoc
+++ b/docs/components/modules/ROOT/pages/jslt-component.adoc
@@ -138,3 +138,5 @@ from("direct:in").
   setHeader("CamelJsltResourceUri").constant(".published").
   to("jslt:dummy");
 ---------------------------------------------------------------------
+
+include::camel-spring-boot::page$jslt-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/json-fastjson-dataformat.adoc b/docs/components/modules/ROOT/pages/json-fastjson-dataformat.adoc
index fc4da76..14ca7ff 100644
--- a/docs/components/modules/ROOT/pages/json-fastjson-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/json-fastjson-dataformat.adoc
@@ -67,3 +67,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$fastjson-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/json-gson-dataformat.adoc b/docs/components/modules/ROOT/pages/json-gson-dataformat.adoc
index 0b5f48f..72cab1c 100644
--- a/docs/components/modules/ROOT/pages/json-gson-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/json-gson-dataformat.adoc
@@ -68,3 +68,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$gson-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/json-jackson-dataformat.adoc b/docs/components/modules/ROOT/pages/json-jackson-dataformat.adoc
index cfc045f..117bd23 100644
--- a/docs/components/modules/ROOT/pages/json-jackson-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/json-jackson-dataformat.adoc
@@ -76,3 +76,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$jackson-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/json-johnzon-dataformat.adoc b/docs/components/modules/ROOT/pages/json-johnzon-dataformat.adoc
index a62cf69..09120f6 100644
--- a/docs/components/modules/ROOT/pages/json-johnzon-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/json-johnzon-dataformat.adoc
@@ -68,3 +68,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$johnzon-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/json-validator-component.adoc b/docs/components/modules/ROOT/pages/json-validator-component.adoc
index ae5c8c6..2f46849 100644
--- a/docs/components/modules/ROOT/pages/json-validator-component.adoc
+++ b/docs/components/modules/ROOT/pages/json-validator-component.adoc
@@ -146,3 +146,5 @@ from("direct:start")
   .to("json-validator:myschema.json")
   .to("mock:end")
 ----
+
+include::camel-spring-boot::page$json-validator-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/json-xstream-dataformat.adoc b/docs/components/modules/ROOT/pages/json-xstream-dataformat.adoc
index 396c592..30bff78 100644
--- a/docs/components/modules/ROOT/pages/json-xstream-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/json-xstream-dataformat.adoc
@@ -87,3 +87,5 @@ from("direct:marshal").
   to("mock:marshaled");
 ---------------------------------------------------------
 
+
+include::camel-spring-boot::page$xstream-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jsonApi-dataformat.adoc b/docs/components/modules/ROOT/pages/jsonApi-dataformat.adoc
index c4124fe..4fd139a 100644
--- a/docs/components/modules/ROOT/pages/jsonApi-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/jsonApi-dataformat.adoc
@@ -37,3 +37,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$jsonapi-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jsonpath-language.adoc b/docs/components/modules/ROOT/pages/jsonpath-language.adoc
index 3d550a9..d9cf497 100644
--- a/docs/components/modules/ROOT/pages/jsonpath-language.adoc
+++ b/docs/components/modules/ROOT/pages/jsonpath-language.adoc
@@ -337,3 +337,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ----
+
+include::camel-spring-boot::page$jsonpath-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/jt400-component.adoc b/docs/components/modules/ROOT/pages/jt400-component.adoc
index 9055ee9..9845fc0 100644
--- a/docs/components/modules/ROOT/pages/jt400-component.adoc
+++ b/docs/components/modules/ROOT/pages/jt400-component.adoc
@@ -206,3 +206,5 @@ from("jt400://username:password@system/lib.lib/MSGOUTDQ.DTAQ?keyed=true&searchKe
 .to("jms:queue:output");
 -------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$jt400-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kafka-component.adoc b/docs/components/modules/ROOT/pages/kafka-component.adoc
index a34b2fb..4bb5162 100644
--- a/docs/components/modules/ROOT/pages/kafka-component.adoc
+++ b/docs/components/modules/ROOT/pages/kafka-component.adoc
@@ -487,3 +487,5 @@ from("kafka:my_topic?headerFilterStrategy=#myStrategy")
 ```
 
 `myStrategy` object should be subclass of `HeaderFilterStrategy` and must be placed in the Camel registry, either manually or by registration as a bean in Spring/Blueprint, as it is `CamelContext` aware.
+
+include::camel-spring-boot::page$kafka-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-config-maps-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-config-maps-component.adoc
index 6df25d2..f032c46 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-config-maps-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-config-maps-component.adoc
@@ -139,3 +139,5 @@ fromF("kubernetes-config-maps://%s?oauthToken=%s&namespace=default&resourceName=
 
 This consumer will return a list of events on the namespace default for the config map test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-deployments-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-deployments-component.adoc
index c5d1e64..14d7af9 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-deployments-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-deployments-component.adoc
@@ -150,3 +150,5 @@ fromF("kubernetes-deployments://%s?oauthToken=%s&namespace=default&resourceName=
 
 This consumer will return a list of events on the namespace default for the deployment test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-hpa-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-hpa-component.adoc
index fba9175..982dea0 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-hpa-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-hpa-component.adoc
@@ -150,3 +150,5 @@ fromF("kubernetes-hpa://%s?oauthToken=%s&namespace=default&resourceName=test", h
 
 This consumer will return a list of events on the namespace default for the hpa test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-job-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-job-component.adoc
index 054fbd3..86b629e 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-job-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-job-component.adoc
@@ -131,3 +131,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of Jobs from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-namespaces-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-namespaces-component.adoc
index efcadec..9d9d7bd 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-namespaces-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-namespaces-component.adoc
@@ -151,3 +151,5 @@ fromF("kubernetes-namespaces://%s?oauthToken=%s&namespace=default", host, authTo
 This consumer will return a list of events on the namespace default.
 
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-nodes-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-nodes-component.adoc
index b7a559c..1bf3e49 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-nodes-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-nodes-component.adoc
@@ -151,3 +151,5 @@ fromF("kubernetes-nodes://%s?oauthToken=%s&resourceName=test", host, authToken).
 
 This consumer will return a list of events for the node test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-claims-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-claims-component.adoc
index e3c4eff..7b506aa 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-claims-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-claims-component.adoc
@@ -122,3 +122,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of pvc from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-component.adoc
index bce3e5e..585015d 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-persistent-volumes-component.adoc
@@ -119,3 +119,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of pv from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-pods-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-pods-component.adoc
index d441cd5..e7f535d 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-pods-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-pods-component.adoc
@@ -149,3 +149,5 @@ fromF("kubernetes-pods://%s?oauthToken=%s&namespace=default&resourceName=test",
 
 This consumer will return a list of events on the namespace default for the pod test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-replication-controllers-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-replication-controllers-component.adoc
index cc7f0a6..4589e57 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-replication-controllers-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-replication-controllers-component.adoc
@@ -151,3 +151,5 @@ fromF("kubernetes-replication-controllers://%s?oauthToken=%s&namespace=default&r
 
 This consumer will return a list of events on the namespace default for the rc test.
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-resources-quota-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-resources-quota-component.adoc
index 3736612..3a7b15a 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-resources-quota-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-resources-quota-component.adoc
@@ -122,3 +122,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of Resource Quotas from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-secrets-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-secrets-component.adoc
index bbcc2f2..dddbdd3 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-secrets-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-secrets-component.adoc
@@ -122,3 +122,5 @@ from("direct:listByLabels").process(new Processor() {
 
 This operation return a List of Secrets from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
 
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-service-accounts-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-service-accounts-component.adoc
index 7c69c42..1414c13 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-service-accounts-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-service-accounts-component.adoc
@@ -119,3 +119,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of Services from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes-services-component.adoc b/docs/components/modules/ROOT/pages/kubernetes-services-component.adoc
index 88c8889..27b434e 100644
--- a/docs/components/modules/ROOT/pages/kubernetes-services-component.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes-services-component.adoc
@@ -149,3 +149,5 @@ fromF("kubernetes-services://%s?oauthToken=%s&namespace=default&resourceName=tes
 --------------------------------------------------------------------------------
 
 This consumer will return a list of events on the namespace default for the service test.
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kubernetes.adoc b/docs/components/modules/ROOT/pages/kubernetes.adoc
index 61e029e..74e5710 100644
--- a/docs/components/modules/ROOT/pages/kubernetes.adoc
+++ b/docs/components/modules/ROOT/pages/kubernetes.adoc
@@ -148,3 +148,5 @@ from("direct:createPod")
 -------------------------------------------------------------
 
 By using the KubernetesConstants.KUBERNETES_POD_NAME header you can specify your Pod name and pass it to this operation.
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/kudu-component.adoc b/docs/components/modules/ROOT/pages/kudu-component.adoc
index c8f02ae..24ed20c 100644
--- a/docs/components/modules/ROOT/pages/kudu-component.adoc
+++ b/docs/components/modules/ROOT/pages/kudu-component.adoc
@@ -126,3 +126,5 @@ To use this feature, add the following dependencies to your spring boot pom.xml
     <version>${camel.version}</version> <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$kudu-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/language-component.adoc b/docs/components/modules/ROOT/pages/language-component.adoc
index c137d41..476c9f0 100644
--- a/docs/components/modules/ROOT/pages/language-component.adoc
+++ b/docs/components/modules/ROOT/pages/language-component.adoc
@@ -148,3 +148,5 @@ updated script is used:
 You can refer to the resource similar to the
 other xref:language-component.adoc[Language]s in Camel by prefixing with
 `"resource:"` as shown below:
+
+include::camel-spring-boot::page$language-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ldap-component.adoc b/docs/components/modules/ROOT/pages/ldap-component.adoc
index 14cb986..fc688f7 100644
--- a/docs/components/modules/ROOT/pages/ldap-component.adoc
+++ b/docs/components/modules/ROOT/pages/ldap-component.adoc
@@ -360,3 +360,5 @@ public class CustomSocketFactory extends SSLSocketFactory {
 
  
 
+
+include::camel-spring-boot::page$ldap-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ldif-component.adoc b/docs/components/modules/ROOT/pages/ldif-component.adoc
index eb96678..de65a8b 100644
--- a/docs/components/modules/ROOT/pages/ldif-component.adoc
+++ b/docs/components/modules/ROOT/pages/ldif-component.adoc
@@ -188,3 +188,5 @@ if (results.size() > 0) {
   }
 }
 ----
+
+include::camel-spring-boot::page$ldif-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/log-component.adoc b/docs/components/modules/ROOT/pages/log-component.adoc
index 4985909..b5e73c6 100644
--- a/docs/components/modules/ROOT/pages/log-component.adoc
+++ b/docs/components/modules/ROOT/pages/log-component.adoc
@@ -344,3 +344,5 @@ should be the bundle which contains route definition. To do this, either
 register single instance of `org.slf4j.Logger` in the Registry or
 reference it using `logger` URI parameter.
 
+
+include::camel-spring-boot::page$log-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/lpr-component.adoc b/docs/components/modules/ROOT/pages/lpr-component.adoc
index 24fcc0e..f9ae7cb 100644
--- a/docs/components/modules/ROOT/pages/lpr-component.adoc
+++ b/docs/components/modules/ROOT/pages/lpr-component.adoc
@@ -162,3 +162,5 @@ RouteBuilder builder = new RouteBuilder() {
            "&flavor=DocFlavor.INPUT_STREAM")
     }};
 --------------------------------------------------
+
+include::camel-spring-boot::page$printer-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/lra.adoc b/docs/components/modules/ROOT/pages/lra.adoc
index 16287d1..3b41fa8 100644
--- a/docs/components/modules/ROOT/pages/lra.adoc
+++ b/docs/components/modules/ROOT/pages/lra.adoc
@@ -18,3 +18,5 @@ for this component:
 </dependency>
 ----
 
+
+include::camel-spring-boot::page$lra-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/lucene-component.adoc b/docs/components/modules/ROOT/pages/lucene-component.adoc
index 4268d42..ea39509 100644
--- a/docs/components/modules/ROOT/pages/lucene-component.adoc
+++ b/docs/components/modules/ROOT/pages/lucene-component.adoc
@@ -240,3 +240,5 @@ RouteBuilder builder = new RouteBuilder() {
    }
 };
 -------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$lucene-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/lumberjack-component.adoc b/docs/components/modules/ROOT/pages/lumberjack-component.adoc
index db9d483..88f23b1 100644
--- a/docs/components/modules/ROOT/pages/lumberjack-component.adoc
+++ b/docs/components/modules/ROOT/pages/lumberjack-component.adoc
@@ -121,3 +121,5 @@ RouteBuilder builder = new RouteBuilder() {
     }
 };
 ------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$lumberjack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/lzf-dataformat.adoc b/docs/components/modules/ROOT/pages/lzf-dataformat.adoc
index edbac63..b4ce7c2 100644
--- a/docs/components/modules/ROOT/pages/lzf-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/lzf-dataformat.adoc
@@ -68,3 +68,5 @@ substituting the version number for the latest & greatest release.
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$lzf-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mail-component.adoc b/docs/components/modules/ROOT/pages/mail-component.adoc
index dbf8729..2efba86 100644
--- a/docs/components/modules/ROOT/pages/mail-component.adoc
+++ b/docs/components/modules/ROOT/pages/mail-component.adoc
@@ -677,3 +677,5 @@ The parameter maxMessagePerPoll and fetchSize allow you to restrict the number m
 These parameters should help to prevent bad performance when working with folders that contain a lot of messages.
 In previous versions these parameters have been evaluated too late, so that big mailboxes could still cause performance problems.
 With Camel 3.1 these parameters are evaluated earlier during the poll to avoid these problems.
+
+include::camel-spring-boot::page$mail-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/master-component.adoc b/docs/components/modules/ROOT/pages/master-component.adoc
index f3abb19..4f2c602 100644
--- a/docs/components/modules/ROOT/pages/master-component.adoc
+++ b/docs/components/modules/ROOT/pages/master-component.adoc
@@ -167,3 +167,5 @@ Camel provide the following ClusterService implementations:
 - camel-kubernetes
 - camel-zookeeper
 
+
+include::camel-spring-boot::page$master-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/metrics-component.adoc b/docs/components/modules/ROOT/pages/metrics-component.adoc
index c2b717d..3083af4 100644
--- a/docs/components/modules/ROOT/pages/metrics-component.adoc
+++ b/docs/components/modules/ROOT/pages/metrics-component.adoc
@@ -636,3 +636,5 @@ with `name=MetricsMessageHistoryService`.
 This factory allows you to gather performance information about Camel Thread Pools by injecting a InstrumentedThreadPoolFactory
 which collects information from inside of Camel.
 See more details at Advanced configuration of CamelContext using Spring
+
+include::camel-spring-boot::page$metrics-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/micrometer-component.adoc b/docs/components/modules/ROOT/pages/micrometer-component.adoc
index df9378d..bb4172d 100644
--- a/docs/components/modules/ROOT/pages/micrometer-component.adoc
+++ b/docs/components/modules/ROOT/pages/micrometer-component.adoc
@@ -571,3 +571,5 @@ an MBean name.
 
 `camel-example-micrometer` provides an example how to set up Micrometer monitoring with
 Camel using Java configuration and a Prometheus backend.
+
+include::camel-spring-boot::page$micrometer-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/milo-client-component.adoc b/docs/components/modules/ROOT/pages/milo-client-component.adoc
index 6a5c6fc..a2e84fb 100644
--- a/docs/components/modules/ROOT/pages/milo-client-component.adoc
+++ b/docs/components/modules/ROOT/pages/milo-client-component.adoc
@@ -214,3 +214,5 @@ The known security policy URIs and enum literals are can be seen here: https://g
 
 **Note:** In any case security policies are considered case sensitive.
 
+
+include::camel-spring-boot::page$milo-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/milo-server-component.adoc b/docs/components/modules/ROOT/pages/milo-server-component.adoc
index c8cd39b..1169e8b 100644
--- a/docs/components/modules/ROOT/pages/milo-server-component.adoc
+++ b/docs/components/modules/ROOT/pages/milo-server-component.adoc
@@ -115,3 +115,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$milo-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mime-multipart-dataformat.adoc b/docs/components/modules/ROOT/pages/mime-multipart-dataformat.adoc
index 0860f2b..8ba6f94 100644
--- a/docs/components/modules/ROOT/pages/mime-multipart-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/mime-multipart-dataformat.adoc
@@ -195,3 +195,5 @@ If you use Maven you can just add the following to your pom.xml:
   <version>x.x.x</version> <!-- use the same version as your Camel core version -->
 </dependency>
 -----------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$mail-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mina-component.adoc b/docs/components/modules/ROOT/pages/mina-component.adoc
index 924bf36..9455d20 100644
--- a/docs/components/modules/ROOT/pages/mina-component.adoc
+++ b/docs/components/modules/ROOT/pages/mina-component.adoc
@@ -279,3 +279,5 @@ can also implement some customized filters. Please note that `codec` and
 filters you may define are appended to the end of the filter chain; that
 is, after `codec` and `logger`.
 
+
+include::camel-spring-boot::page$mina-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mllp-component.adoc b/docs/components/modules/ROOT/pages/mllp-component.adoc
index 6b3d764..96dde79 100644
--- a/docs/components/modules/ROOT/pages/mllp-component.adoc
+++ b/docs/components/modules/ROOT/pages/mllp-component.adoc
@@ -229,3 +229,5 @@ The state of the TCP Socket can be controlled by these properties on the Camel e
 |CamelMllpCloseConnectionAfterSend | Boolean | If true, the Socket will be closed immediately after sending data
 |CamelMllpResetConnectionAfterSend | Boolean | If true, the Socket will be reset immediately after sending any data
 |====================================
+
+include::camel-spring-boot::page$mllp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mock-component.adoc b/docs/components/modules/ROOT/pages/mock-component.adoc
index fd06dfc..52e54dc 100644
--- a/docs/components/modules/ROOT/pages/mock-component.adoc
+++ b/docs/components/modules/ROOT/pages/mock-component.adoc
@@ -491,3 +491,5 @@ In the example above we use `seconds` as the time unit, but Camel offers
 ====
 
 
+
+include::camel-spring-boot::page$mock-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mongodb-component.adoc b/docs/components/modules/ROOT/pages/mongodb-component.adoc
index ed5a61f..070f904 100644
--- a/docs/components/modules/ROOT/pages/mongodb-component.adoc
+++ b/docs/components/modules/ROOT/pages/mongodb-component.adoc
@@ -1011,3 +1011,5 @@ object to a `Map`, which is in turn used to initialise a new
 
 This type converter is auto-discovered, so you don't need to configure anything manually.
 
+
+include::camel-spring-boot::page$mongodb-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mongodb-gridfs-component.adoc b/docs/components/modules/ROOT/pages/mongodb-gridfs-component.adoc
index 94c2dd3..5d0477e 100644
--- a/docs/components/modules/ROOT/pages/mongodb-gridfs-component.adoc
+++ b/docs/components/modules/ROOT/pages/mongodb-gridfs-component.adoc
@@ -214,3 +214,5 @@ headers.put(Exchange.FILE_NAME, "filename.txt");
 template.requestBodyAndHeaders("direct:remove", "", headers);
 ------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$mongodb-gridfs-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/msv-component.adoc b/docs/components/modules/ROOT/pages/msv-component.adoc
index 11524c1..d1fae04 100644
--- a/docs/components/modules/ROOT/pages/msv-component.adoc
+++ b/docs/components/modules/ROOT/pages/msv-component.adoc
@@ -129,3 +129,5 @@ based on whether or not the XML matches the given
 http://relaxng.org/[RelaxNG XML Schema] (which is supplied on the
 classpath).
 
+
+include::camel-spring-boot::page$msv-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mustache-component.adoc b/docs/components/modules/ROOT/pages/mustache-component.adoc
index dd8c669..2fb1310 100644
--- a/docs/components/modules/ROOT/pages/mustache-component.adoc
+++ b/docs/components/modules/ROOT/pages/mustache-component.adoc
@@ -189,3 +189,5 @@ Regards Camel Riders Bookstore
 {{body}}
 -------------------------------------------------
 
+
+include::camel-spring-boot::page$mustache-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mvel-component.adoc b/docs/components/modules/ROOT/pages/mvel-component.adoc
index 5faef1a..859e9f41 100644
--- a/docs/components/modules/ROOT/pages/mvel-component.adoc
+++ b/docs/components/modules/ROOT/pages/mvel-component.adoc
@@ -191,3 +191,5 @@ from("direct:in").
   to("velocity:dummy");
 ------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$mvel-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mvel-language.adoc b/docs/components/modules/ROOT/pages/mvel-language.adoc
index 107507d..c635c8f 100644
--- a/docs/components/modules/ROOT/pages/mvel-language.adoc
+++ b/docs/components/modules/ROOT/pages/mvel-language.adoc
@@ -120,3 +120,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$mvel-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mybatis-bean-component.adoc b/docs/components/modules/ROOT/pages/mybatis-bean-component.adoc
index 34678c4..fc4a6a7 100644
--- a/docs/components/modules/ROOT/pages/mybatis-bean-component.adoc
+++ b/docs/components/modules/ROOT/pages/mybatis-bean-component.adoc
@@ -158,3 +158,5 @@ public interface AccountService {
 }
 ----
 
+
+include::camel-spring-boot::page$mybatis-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/mybatis-component.adoc b/docs/components/modules/ROOT/pages/mybatis-component.adoc
index 17a5122..e367d3c 100644
--- a/docs/components/modules/ROOT/pages/mybatis-component.adoc
+++ b/docs/components/modules/ROOT/pages/mybatis-component.adoc
@@ -417,3 +417,5 @@ usual:
 </camelContext>
 ----
 
+
+include::camel-spring-boot::page$mybatis-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/nagios-component.adoc b/docs/components/modules/ROOT/pages/nagios-component.adoc
index dc5a254..b7d348e 100644
--- a/docs/components/modules/ROOT/pages/nagios-component.adoc
+++ b/docs/components/modules/ROOT/pages/nagios-component.adoc
@@ -153,3 +153,5 @@ In Spring XML its just a matter of defining a Spring bean with the type
 xref:manual::advanced-configuration-of-camelcontext-using-spring.adoc[Advanced
 configuration of CamelContext using Spring].
 
+
+include::camel-spring-boot::page$nagios-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/nats-component.adoc b/docs/components/modules/ROOT/pages/nats-component.adoc
index 8996923..4bd5d30 100644
--- a/docs/components/modules/ROOT/pages/nats-component.adoc
+++ b/docs/components/modules/ROOT/pages/nats-component.adoc
@@ -203,3 +203,5 @@ from("direct:send")
 from("nats:mytopic?maxMessages=5&queueName=myqueue")
   .to("mock:result");
 ----
+
+include::camel-spring-boot::page$nats-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/netty-component.adoc b/docs/components/modules/ROOT/pages/netty-component.adoc
index 1cae628..67049ac 100644
--- a/docs/components/modules/ROOT/pages/netty-component.adoc
+++ b/docs/components/modules/ROOT/pages/netty-component.adoc
@@ -720,3 +720,5 @@ This provides support for timeout and other complexities you otherwise would nee
 You can find an example with the Apache Camel source code in the examples directory
 under the `camel-example-netty-custom-correlation` directory.
 
+
+include::camel-spring-boot::page$netty-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/netty-http-component.adoc b/docs/components/modules/ROOT/pages/netty-http-component.adoc
index 2bd9048..2f9e05c 100644
--- a/docs/components/modules/ROOT/pages/netty-http-component.adoc
+++ b/docs/components/modules/ROOT/pages/netty-http-component.adoc
@@ -573,3 +573,5 @@ below:
 </route>
 -----------------------------------------------------------------------------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$netty-http-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/nitrite-component.adoc b/docs/components/modules/ROOT/pages/nitrite-component.adoc
index c254525..2a0d709 100644
--- a/docs/components/modules/ROOT/pages/nitrite-component.adoc
+++ b/docs/components/modules/ROOT/pages/nitrite-component.adoc
@@ -187,3 +187,5 @@ from("direct:getByID")
     .to("nitrite:/path/to/database.db?collection=myCollection")
     .to("log:result");
 ----
+
+include::camel-spring-boot::page$nitrite-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/nsq-component.adoc b/docs/components/modules/ROOT/pages/nsq-component.adoc
index 1f1aea0..d74f29d 100644
--- a/docs/components/modules/ROOT/pages/nsq-component.adoc
+++ b/docs/components/modules/ROOT/pages/nsq-component.adoc
@@ -134,3 +134,5 @@ Then you can omit the servers from the endpoint URI
 from("direct:start").to("nsq:myTopic");
 ----
 
+
+include::camel-spring-boot::page$nsq-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ognl-language.adoc b/docs/components/modules/ROOT/pages/ognl-language.adoc
index b90994a..b968f84 100644
--- a/docs/components/modules/ROOT/pages/ognl-language.adoc
+++ b/docs/components/modules/ROOT/pages/ognl-language.adoc
@@ -127,3 +127,5 @@ the download page for the latest versions).
 
 Otherwise, you'll also need
 https://repo1.maven.org/maven2/org/apache/servicemix/bundles/org.apache.servicemix.bundles.ognl/2.7.3_4/org.apache.servicemix.bundles.ognl-2.7.3_4.jar[OGNL]
+
+include::camel-spring-boot::page$ognl-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/olingo2-component.adoc b/docs/components/modules/ROOT/pages/olingo2-component.adoc
index 243ac19..074ee69 100644
--- a/docs/components/modules/ROOT/pages/olingo2-component.adoc
+++ b/docs/components/modules/ROOT/pages/olingo2-component.adoc
@@ -317,3 +317,6 @@ consumer endpoint will produce an *ODataFeed* value the first time, and
 from("olingo2://read/Manufacturers?queryParams=#paramsBean&timeUnit=SECONDS&delay=30")
     .to("bean:blah");
 ---------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$olingo2-starter.adoc[]
+
diff --git a/docs/components/modules/ROOT/pages/olingo4-component.adoc b/docs/components/modules/ROOT/pages/olingo4-component.adoc
index 851ac7a..d316f80 100644
--- a/docs/components/modules/ROOT/pages/olingo4-component.adoc
+++ b/docs/components/modules/ROOT/pages/olingo4-component.adoc
@@ -295,3 +295,6 @@ actions that don't expect an input.
 from("direct:...")
     .to("olingo4://action/People");
 ------------------------------------------------------------
+
+include::camel-spring-boot::page$olingo4-starter.adoc[]
+
diff --git a/docs/components/modules/ROOT/pages/openshift-build-configs-component.adoc b/docs/components/modules/ROOT/pages/openshift-build-configs-component.adoc
index e4cbb26..aa9c2f1 100644
--- a/docs/components/modules/ROOT/pages/openshift-build-configs-component.adoc
+++ b/docs/components/modules/ROOT/pages/openshift-build-configs-component.adoc
@@ -119,3 +119,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of Build configs from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openshift-builds-component.adoc b/docs/components/modules/ROOT/pages/openshift-builds-component.adoc
index dc630f3..71a882c 100644
--- a/docs/components/modules/ROOT/pages/openshift-builds-component.adoc
+++ b/docs/components/modules/ROOT/pages/openshift-builds-component.adoc
@@ -119,3 +119,5 @@ from("direct:listByLabels").process(new Processor() {
 --------------------------------------------------------------------------------
 
 This operation return a List of Builds from your cluster, using a label selector (with key1 and key2, with value value1 and value2)
+
+include::camel-spring-boot::page$kubernetes-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openstack-cinder-component.adoc b/docs/components/modules/ROOT/pages/openstack-cinder-component.adoc
index fc0925e..a045985 100644
--- a/docs/components/modules/ROOT/pages/openstack-cinder-component.adoc
+++ b/docs/components/modules/ROOT/pages/openstack-cinder-component.adoc
@@ -185,3 +185,5 @@ If you need more precise volume settings you can create new object of the type *
 
 If you need more precise server settings you can create new object of the type *org.openstack4j.model.storage.block.VolumeSnapshot* and send in the message body.
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openstack-glance-component.adoc b/docs/components/modules/ROOT/pages/openstack-glance-component.adoc
index b26f6a8..8b691e1 100644
--- a/docs/components/modules/ROOT/pages/openstack-glance-component.adoc
+++ b/docs/components/modules/ROOT/pages/openstack-glance-component.adoc
@@ -145,3 +145,5 @@ with the following path and query parameters:
 |`properties` | `Map` | Image properties.
 |=========================================================================
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openstack-keystone-component.adoc b/docs/components/modules/ROOT/pages/openstack-keystone-component.adoc
index f585035..824c40e 100644
--- a/docs/components/modules/ROOT/pages/openstack-keystone-component.adoc
+++ b/docs/components/modules/ROOT/pages/openstack-keystone-component.adoc
@@ -291,3 +291,5 @@ If you need more precise region settings you can create new object of the type *
 
 If you need more precise user settings you can create new object of the type *org.openstack4j.model.identity.v3.User* and send in the message body.
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openstack-neutron-component.adoc b/docs/components/modules/ROOT/pages/openstack-neutron-component.adoc
index e3e048e..ed1f6d7 100644
--- a/docs/components/modules/ROOT/pages/openstack-neutron-component.adoc
+++ b/docs/components/modules/ROOT/pages/openstack-neutron-component.adoc
@@ -264,3 +264,5 @@ If you need more precise subnet settings you can create new object of the type *
 |=========================================================================
 
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openstack-nova-component.adoc b/docs/components/modules/ROOT/pages/openstack-nova-component.adoc
index 661cc86..29bc378 100644
--- a/docs/components/modules/ROOT/pages/openstack-nova-component.adoc
+++ b/docs/components/modules/ROOT/pages/openstack-nova-component.adoc
@@ -214,3 +214,5 @@ If you need more precise server settings you can create new object of the type *
 
 |=========================================================================
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openstack-swift-component.adoc b/docs/components/modules/ROOT/pages/openstack-swift-component.adoc
index 3b83fa5..4223353 100644
--- a/docs/components/modules/ROOT/pages/openstack-swift-component.adoc
+++ b/docs/components/modules/ROOT/pages/openstack-swift-component.adoc
@@ -191,3 +191,5 @@ or *org.openstack4j.model.storage.object.options.ContainerListOptions* for listi
 
 |=========================================================================
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/openstack.adoc b/docs/components/modules/ROOT/pages/openstack.adoc
index e8240b5..23ff0ab 100644
--- a/docs/components/modules/ROOT/pages/openstack.adoc
+++ b/docs/components/modules/ROOT/pages/openstack.adoc
@@ -31,3 +31,5 @@ for this component:
 |=======================================================================
 
 
+
+include::camel-spring-boot::page$openstack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/opentracing.adoc b/docs/components/modules/ROOT/pages/opentracing.adoc
index 8d498a8..1347a1b 100644
--- a/docs/components/modules/ROOT/pages/opentracing.adoc
+++ b/docs/components/modules/ROOT/pages/opentracing.adoc
@@ -98,3 +98,5 @@ How this agent is used will be specific to how you execute your application. _Se
 
 You can find an example demonstrating the three ways to configure OpenTracing here:
 https://github.com/apache/camel/tree/master/examples/camel-example-opentracing[camel-example-opentracing]
+
+include::camel-spring-boot::page$opentracing-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/optaplanner-component.adoc b/docs/components/modules/ROOT/pages/optaplanner-component.adoc
index ca26486..270278a 100644
--- a/docs/components/modules/ROOT/pages/optaplanner-component.adoc
+++ b/docs/components/modules/ROOT/pages/optaplanner-component.adoc
@@ -163,3 +163,5 @@ from("cxfrs:bean:rsServer?bindingStyle=SimpleConsumer")
   .to("optaplanner:/org/foo/barSolverConfig.xml");
 -------------------------------------------------------
 
+
+include::camel-spring-boot::page$optaplanner-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/paho-component.adoc b/docs/components/modules/ROOT/pages/paho-component.adoc
index 9fd9c00..f8a9788 100644
--- a/docs/components/modules/ROOT/pages/paho-component.adoc
+++ b/docs/components/modules/ROOT/pages/paho-component.adoc
@@ -216,3 +216,5 @@ from("direct:test")
     .setHeader(PahoConstants.CAMEL_PAHO_OVERRIDE_TOPIC, simple("${header.customerId}"))
     .to("paho:some/target/queue");
 ----
+
+include::camel-spring-boot::page$paho-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/pdf-component.adoc b/docs/components/modules/ROOT/pages/pdf-component.adoc
index ff64723..2a65558 100644
--- a/docs/components/modules/ROOT/pages/pdf-component.adoc
+++ b/docs/components/modules/ROOT/pages/pdf-component.adoc
@@ -114,3 +114,5 @@ https://pdfbox.apache.org/docs/1.8.10/javadocs/org/apache/pdfbox/pdmodel/encrypt
 *Mandatory* header if PDF document is encrypted.
 |=======================================================================
 
+
+include::camel-spring-boot::page$pdf-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/pg-replication-slot-component.adoc b/docs/components/modules/ROOT/pages/pg-replication-slot-component.adoc
index 517612c..d393aca 100644
--- a/docs/components/modules/ROOT/pages/pg-replication-slot-component.adoc
+++ b/docs/components/modules/ROOT/pages/pg-replication-slot-component.adoc
@@ -137,3 +137,5 @@ this component to sync data from PostgreSQL to other database, make sure your op
 instead of INSERT,...). This will make sure repeated messages won't affect your system negatively.
 ====
 
+
+include::camel-spring-boot::page$pg-replication-slot-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/pgevent-component.adoc b/docs/components/modules/ROOT/pages/pgevent-component.adoc
index 6e4a46c..2ca567e 100644
--- a/docs/components/modules/ROOT/pages/pgevent-component.adoc
+++ b/docs/components/modules/ROOT/pages/pgevent-component.adoc
@@ -100,3 +100,5 @@ with the following path and query parameters:
 
 
 
+
+include::camel-spring-boot::page$pgevent-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/pgp-dataformat.adoc b/docs/components/modules/ROOT/pages/pgp-dataformat.adoc
index 22e4e44..c7367e9 100644
--- a/docs/components/modules/ROOT/pages/pgp-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/pgp-dataformat.adoc
@@ -308,3 +308,5 @@ need to add the following dependency to your pom.
 </dependency>
 ----------------------------------------------------------
 
+
+include::camel-spring-boot::page$crypto-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/platform-http-component.adoc b/docs/components/modules/ROOT/pages/platform-http-component.adoc
index eb932f6..6dbd692 100644
--- a/docs/components/modules/ROOT/pages/platform-http-component.adoc
+++ b/docs/components/modules/ROOT/pages/platform-http-component.adoc
@@ -81,3 +81,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$platform-http-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/protobuf-dataformat.adoc b/docs/components/modules/ROOT/pages/protobuf-dataformat.adoc
index 59c4f9f..95dbb0b 100644
--- a/docs/components/modules/ROOT/pages/protobuf-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/protobuf-dataformat.adoc
@@ -221,3 +221,5 @@ To use Protobuf in your camel routes you need to add the a dependency on
   <!-- use the same version as your Camel core version -->
 </dependency>
 -----------------------------------------
+
+include::camel-spring-boot::page$protobuf-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/pubnub-component.adoc b/docs/components/modules/ROOT/pages/pubnub-component.adoc
index 1f2b70a..7c7a2ef 100644
--- a/docs/components/modules/ROOT/pages/pubnub-component.adoc
+++ b/docs/components/modules/ROOT/pages/pubnub-component.adoc
@@ -215,3 +215,5 @@ The example PubNubSensorExample already contains a subscribe key provided by Pub
 The example illustrates the PubNub component subscribing to a infinite stream of sensor data.
 
 
+
+include::camel-spring-boot::page$pubnub-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/pulsar-component.adoc b/docs/components/modules/ROOT/pages/pulsar-component.adoc
index ffd3483..9c0f474 100644
--- a/docs/components/modules/ROOT/pages/pulsar-component.adoc
+++ b/docs/components/modules/ROOT/pages/pulsar-component.adoc
@@ -143,3 +143,5 @@ with the following path and query parameters:
 | `manual_acknowledgement` | `PulsarManualAcknowledgement` | If allowManualAcknowledgement is set, this will contain the object for manually acknowledging the Pulsar message; otherwise it is unset
 |===
 // message-headers options: END
+
+include::camel-spring-boot::page$pulsar-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/quartz-component.adoc b/docs/components/modules/ROOT/pages/quartz-component.adoc
index 224441b..0b2b797 100644
--- a/docs/components/modules/ROOT/pages/quartz-component.adoc
+++ b/docs/components/modules/ROOT/pages/quartz-component.adoc
@@ -453,3 +453,5 @@ Users can then use the cron component instead of the quartz component, as in the
     from("cron://name?schedule=0+0/5+12-18+?+*+MON-FRI")
     .to("activemq:Totally.Rocks");
 ----
+
+include::camel-spring-boot::page$quartz-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/quickfix-component.adoc b/docs/components/modules/ROOT/pages/quickfix-component.adoc
index c57a96d..5dd1669 100644
--- a/docs/components/modules/ROOT/pages/quickfix-component.adoc
+++ b/docs/components/modules/ROOT/pages/quickfix-component.adoc
@@ -593,3 +593,5 @@ Direction : from FIX gateway
 </route>
 ----
 
+
+include::camel-spring-boot::page$quickfix-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/rabbitmq-component.adoc b/docs/components/modules/ROOT/pages/rabbitmq-component.adoc
index 81d4395..fba9e1a 100644
--- a/docs/components/modules/ROOT/pages/rabbitmq-component.adoc
+++ b/docs/components/modules/ROOT/pages/rabbitmq-component.adoc
@@ -375,3 +375,5 @@ public Map<String, Object> bindArgsBuilder() {
 }
 ----
 
+
+include::camel-spring-boot::page$rabbitmq-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/reactive-streams-component.adoc b/docs/components/modules/ROOT/pages/reactive-streams-component.adoc
index 3f794a6..0547cb8 100644
--- a/docs/components/modules/ROOT/pages/reactive-streams-component.adoc
+++ b/docs/components/modules/ROOT/pages/reactive-streams-component.adoc
@@ -420,3 +420,5 @@ To use the starter, add the following to your spring boot pom.xml file:
 ------------------------------------------------------
 
 
+
+include::camel-spring-boot::page$reactive-streams-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ref-component.adoc b/docs/components/modules/ROOT/pages/ref-component.adoc
index 4e9e40e..01924b1 100644
--- a/docs/components/modules/ROOT/pages/ref-component.adoc
+++ b/docs/components/modules/ROOT/pages/ref-component.adoc
@@ -118,3 +118,5 @@ You could, of course, have used the `ref` attribute instead:
 ----
 
 Which is the more common way to write it.
+
+include::camel-spring-boot::page$ref-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/rest-api-component.adoc b/docs/components/modules/ROOT/pages/rest-api-component.adoc
index 1e61f3f..4026199 100644
--- a/docs/components/modules/ROOT/pages/rest-api-component.adoc
+++ b/docs/components/modules/ROOT/pages/rest-api-component.adoc
@@ -65,3 +65,5 @@ with the following path and query parameters:
 // endpoint options: END
 
 
+
+include::camel-spring-boot::page$rest-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/rest-component.adoc b/docs/components/modules/ROOT/pages/rest-component.adoc
index 255357a..b2c842d 100644
--- a/docs/components/modules/ROOT/pages/rest-component.adoc
+++ b/docs/components/modules/ROOT/pages/rest-component.adoc
@@ -256,3 +256,5 @@ Rest DSL with SERVLET as
 transport that can be deployed on Apache Tomcat, or similar web
 containers.
 
+
+include::camel-spring-boot::page$rest-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/rest-openapi-component.adoc b/docs/components/modules/ROOT/pages/rest-openapi-component.adoc
index 07cd651..1f8a8c9 100644
--- a/docs/components/modules/ROOT/pages/rest-openapi-component.adoc
+++ b/docs/components/modules/ROOT/pages/rest-openapi-component.adoc
@@ -218,3 +218,5 @@ String getPetJsonById(int petId) {
     return template.requestBodyAndHeaders("petstore:getPetById", null, "petId", petId);
 }
 ----
+
+include::camel-spring-boot::page$rest-openapi-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/rest-swagger-component.adoc b/docs/components/modules/ROOT/pages/rest-swagger-component.adoc
index 716fb11..01c341b 100644
--- a/docs/components/modules/ROOT/pages/rest-swagger-component.adoc
+++ b/docs/components/modules/ROOT/pages/rest-swagger-component.adoc
@@ -216,3 +216,5 @@ String getPetJsonById(int petId) {
     return template.requestBodyAndHeaders("petstore:getPetById", null, "petId", petId);
 }
 ----
+
+include::camel-spring-boot::page$rest-swagger-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/robotframework-component.adoc b/docs/components/modules/ROOT/pages/robotframework-component.adoc
index dc77af9..b99ea57 100644
--- a/docs/components/modules/ROOT/pages/robotframework-component.adoc
+++ b/docs/components/modules/ROOT/pages/robotframework-component.adoc
@@ -243,3 +243,5 @@ And the `template.robot` file:
 
 Please note that when you pass values through Camel Exchange to test cases,
 they will be available as case-sensitive ``body``, ``headers.[yourHeaderName]`` and ``properties.[yourPropertyName]``
+
+include::camel-spring-boot::page$robotframework-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/rss-component.adoc b/docs/components/modules/ROOT/pages/rss-component.adoc
index f7c8427..f9ba8ac 100644
--- a/docs/components/modules/ROOT/pages/rss-component.adoc
+++ b/docs/components/modules/ROOT/pages/rss-component.adoc
@@ -207,3 +207,5 @@ public static class FilterBean {
 }
 ----
 
+
+include::camel-spring-boot::page$rss-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/rss-dataformat.adoc b/docs/components/modules/ROOT/pages/rss-dataformat.adoc
index 33d88d5..04c014a 100644
--- a/docs/components/modules/ROOT/pages/rss-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/rss-dataformat.adoc
@@ -40,3 +40,5 @@ The RSS dataformat supports 1 options, which are listed below.
 |===
 // dataformat options: END
 ND
+
+include::camel-spring-boot::page$rss-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/saga-component.adoc b/docs/components/modules/ROOT/pages/saga-component.adoc
index 3bad73f..189fdff 100644
--- a/docs/components/modules/ROOT/pages/saga-component.adoc
+++ b/docs/components/modules/ROOT/pages/saga-component.adoc
@@ -69,3 +69,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$saga-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/salesforce-component.adoc b/docs/components/modules/ROOT/pages/salesforce-component.adoc
index e7f3bda..63f8647 100644
--- a/docs/components/modules/ROOT/pages/salesforce-component.adoc
+++ b/docs/components/modules/ROOT/pages/salesforce-component.adoc
@@ -778,3 +778,6 @@ with the following path and query parameters:
 | *synchronous* (advanced) | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | boolean
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$salesforce-starter.adoc[]
+
diff --git a/docs/components/modules/ROOT/pages/sap-netweaver-component.adoc b/docs/components/modules/ROOT/pages/sap-netweaver-component.adoc
index 8eb7296..2df62bc 100644
--- a/docs/components/modules/ROOT/pages/sap-netweaver-component.adoc
+++ b/docs/components/modules/ROOT/pages/sap-netweaver-component.adoc
@@ -201,3 +201,5 @@ Destination city: SAN FRANCISCO
 Destination airport: SFO
 -------------------------------
 
+
+include::camel-spring-boot::page$sap-netweaver-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/scheduler-component.adoc b/docs/components/modules/ROOT/pages/scheduler-component.adoc
index ad624ff..9013ecc 100644
--- a/docs/components/modules/ROOT/pages/scheduler-component.adoc
+++ b/docs/components/modules/ROOT/pages/scheduler-component.adoc
@@ -167,3 +167,5 @@ The consumer will otherwise as by default return 1 message polled to the
 scheduler, every time the consumer has completed processing the
 exchange.
 
+
+include::camel-spring-boot::page$scheduler-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/schematron-component.adoc b/docs/components/modules/ROOT/pages/schematron-component.adoc
index dcc71cf..433a24e 100644
--- a/docs/components/modules/ROOT/pages/schematron-component.adoc
+++ b/docs/components/modules/ROOT/pages/schematron-component.adoc
@@ -208,3 +208,5 @@ to get you started on Schematron.
 * http://www.schematron.com[Schematron official site]. This contains
 links to other resources
 ====
+
+include::camel-spring-boot::page$schematron-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/scp-component.adoc b/docs/components/modules/ROOT/pages/scp-component.adoc
index 4242d21..4ffb945 100644
--- a/docs/components/modules/ROOT/pages/scp-component.adoc
+++ b/docs/components/modules/ROOT/pages/scp-component.adoc
@@ -132,3 +132,5 @@ Currently camel-jsch only supports a
 https://www.javadoc.io/doc/org.apache.camel/camel-api/current/org/apache/camel/Producer.html[Producer]
 (i.e. copy files to another host). 
 
+
+include::camel-spring-boot::page$jsch-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/secureXML-dataformat.adoc b/docs/components/modules/ROOT/pages/secureXML-dataformat.adoc
index 00bc1b9..b302e79 100644
--- a/docs/components/modules/ROOT/pages/secureXML-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/secureXML-dataformat.adoc
@@ -231,3 +231,5 @@ Spring XML Recipient
 == Dependencies
 
 This data format is provided within the *camel-xmlsecurity* component.
+
+include::camel-spring-boot::page$xmlsecurity-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/seda-component.adoc b/docs/components/modules/ROOT/pages/seda-component.adoc
index 8045f07..9330881 100644
--- a/docs/components/modules/ROOT/pages/seda-component.adoc
+++ b/docs/components/modules/ROOT/pages/seda-component.adoc
@@ -317,3 +317,5 @@ SedaEndpoint seda = context.getEndpoint("seda:xxxx");
 int size = seda.getExchanges().size();
 ----
 
+
+include::camel-spring-boot::page$seda-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/service-component.adoc b/docs/components/modules/ROOT/pages/service-component.adoc
index 3200fca..ae4559e 100644
--- a/docs/components/modules/ROOT/pages/service-component.adoc
+++ b/docs/components/modules/ROOT/pages/service-component.adoc
@@ -80,3 +80,5 @@ Camel provide the following ServiceRegistry implementations:
 - camel-zookeeper
 - camel-spring-cloud
 
+
+include::camel-spring-boot::page$service-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/servicenow-component.adoc b/docs/components/modules/ROOT/pages/servicenow-component.adoc
index 78ff9ed..769dc61 100644
--- a/docs/components/modules/ROOT/pages/servicenow-component.adoc
+++ b/docs/components/modules/ROOT/pages/servicenow-component.adoc
@@ -323,3 +323,6 @@ FluentProducerTemplate.on(context)
     .to("direct:servicenow")
     .send();
 -------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$servicenow-starter.adoc[]
+
diff --git a/docs/components/modules/ROOT/pages/servlet-component.adoc b/docs/components/modules/ROOT/pages/servlet-component.adoc
index aec7d22..d6097d5 100644
--- a/docs/components/modules/ROOT/pages/servlet-component.adoc
+++ b/docs/components/modules/ROOT/pages/servlet-component.adoc
@@ -460,3 +460,5 @@ The automatic mapping of the Camel servlet can also be disabled.
 | camel.component.servlet.mapping.servlet-name | CamelServlet | The name of the Camel servlet
 |=======================================================================
 
+
+include::camel-spring-boot::page$servlet-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/sftp-component.adoc b/docs/components/modules/ROOT/pages/sftp-component.adoc
index 13f6cbf..1aa541a 100644
--- a/docs/components/modules/ROOT/pages/sftp-component.adoc
+++ b/docs/components/modules/ROOT/pages/sftp-component.adoc
@@ -194,3 +194,5 @@ with the following path and query parameters:
 | *useUserKnownHostsFile* (security) | If knownHostFile has not been explicit configured then use the host file from System.getProperty(user.home)/.ssh/known_hosts | true | boolean
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$ftp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/sip-component.adoc b/docs/components/modules/ROOT/pages/sip-component.adoc
index 2391785..9dc52f1 100644
--- a/docs/components/modules/ROOT/pages/sip-component.adoc
+++ b/docs/components/modules/ROOT/pages/sip-component.adoc
@@ -234,3 +234,5 @@ Subscriber. It has a separate SIP stackName distinct from Publisher as
 well as Subscriber. While it is set up as a Camel Consumer, it does not
 actually send any messages along the route to the endpoint
 "mock:neverland".
+
+include::camel-spring-boot::page$sip-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/sjms-batch-component.adoc b/docs/components/modules/ROOT/pages/sjms-batch-component.adoc
index 8f01fd3..c4dc57e 100644
--- a/docs/components/modules/ROOT/pages/sjms-batch-component.adoc
+++ b/docs/components/modules/ROOT/pages/sjms-batch-component.adoc
@@ -200,3 +200,5 @@ with the following path and query parameters:
 The `completionSize` endpoint attribute is used in conjunction with
 `completionTimeout`, where the first condition to be met will cause the
 aggregated `Exchange` to be emitted down the route.
+
+include::camel-spring-boot::page$sjms-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/sjms-component.adoc b/docs/components/modules/ROOT/pages/sjms-component.adoc
index 9046449..e3d5250 100644
--- a/docs/components/modules/ROOT/pages/sjms-component.adoc
+++ b/docs/components/modules/ROOT/pages/sjms-component.adoc
@@ -472,3 +472,5 @@ Not at all. Below is an example of the SJMS component using the Spring XML:
 Springless refers to moving away from the dependency on the Spring JMS
 API. A new JMS client API is being developed from the ground up to power
 SJMS.
+
+include::camel-spring-boot::page$sjms-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/sjms2-component.adoc b/docs/components/modules/ROOT/pages/sjms2-component.adoc
index f1eef5a..14ecf3a 100644
--- a/docs/components/modules/ROOT/pages/sjms2-component.adoc
+++ b/docs/components/modules/ROOT/pages/sjms2-component.adoc
@@ -580,3 +580,5 @@ DSL:
 Springless refers to moving away from the dependency on the Spring JMS
 API. A new JMS client API is being developed from the ground up to power
 SJMS2.
+
+include::camel-spring-boot::page$sjms2-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/slack-component.adoc b/docs/components/modules/ROOT/pages/slack-component.adoc
index e4ef04a..17f7ffc 100644
--- a/docs/components/modules/ROOT/pages/slack-component.adoc
+++ b/docs/components/modules/ROOT/pages/slack-component.adoc
@@ -174,3 +174,5 @@ from("slack://general?token=RAW(<YOUR_TOKEN>)&maxResults=1")
 
 In this way you'll get the last message from general channel. The consumer will take track of the timestamp of the last message consumed and in the next poll it will check from that timestamp.
 
+
+include::camel-spring-boot::page$slack-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/smpp-component.adoc b/docs/components/modules/ROOT/pages/smpp-component.adoc
index 10b9a4e..31667b3 100644
--- a/docs/components/modules/ROOT/pages/smpp-component.adoc
+++ b/docs/components/modules/ROOT/pages/smpp-component.adoc
@@ -625,3 +625,5 @@ configuration:
 log4j.logger.org.apache.camel.component.smpp=DEBUG
 --------------------------------------------------
 
+
+include::camel-spring-boot::page$smpp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/snmp-component.adoc b/docs/components/modules/ROOT/pages/snmp-component.adoc
index d2b1b22..2789aee 100644
--- a/docs/components/modules/ROOT/pages/snmp-component.adoc
+++ b/docs/components/modules/ROOT/pages/snmp-component.adoc
@@ -214,3 +214,5 @@ convertBodyTo(String.class).
 to("activemq:snmp.states");
 ------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$snmp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/soapjaxb-dataformat.adoc b/docs/components/modules/ROOT/pages/soapjaxb-dataformat.adoc
index 57b129d..17add2a 100644
--- a/docs/components/modules/ROOT/pages/soapjaxb-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/soapjaxb-dataformat.adoc
@@ -237,3 +237,5 @@ following dependency to your pom.
   <version>x.y.z</version>
 </dependency>
 -------------------------------------
+
+include::camel-spring-boot::page$soap-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/solr-component.adoc b/docs/components/modules/ROOT/pages/solr-component.adoc
index 3c583b4..4d8c2a5 100644
--- a/docs/components/modules/ROOT/pages/solr-component.adoc
+++ b/docs/components/modules/ROOT/pages/solr-component.adoc
@@ -227,3 +227,5 @@ Tutorial]
 
 http://wiki.apache.org/solr/SolrQuerySyntax[Solr Query Syntax]
 
+
+include::camel-spring-boot::page$solr-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/soroush-component.adoc b/docs/components/modules/ROOT/pages/soroush-component.adoc
index c66a16a..a819e5f 100644
--- a/docs/components/modules/ROOT/pages/soroush-component.adoc
+++ b/docs/components/modules/ROOT/pages/soroush-component.adoc
@@ -259,3 +259,5 @@ onException(CongestionException.class).log("Failed to processing ${id}")
 -------------
 
 _Donated by https://www.mohaymen.ir[Mohaymen ICT] to ASF_
+
+include::camel-spring-boot::page$soroush-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spark-component.adoc b/docs/components/modules/ROOT/pages/spark-component.adoc
index 1b77801..88b740d 100644
--- a/docs/components/modules/ROOT/pages/spark-component.adoc
+++ b/docs/components/modules/ROOT/pages/spark-component.adoc
@@ -408,3 +408,5 @@ Dataset<Row> cars(HiveContext hiveContext) {
     return jsonCars;
 }
 ------------------------------------------------------------------------
+
+include::camel-spring-boot::page$spark-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spel-language.adoc b/docs/components/modules/ROOT/pages/spel-language.adoc
index d862045..f6c6268 100644
--- a/docs/components/modules/ROOT/pages/spel-language.adoc
+++ b/docs/components/modules/ROOT/pages/spel-language.adoc
@@ -157,3 +157,5 @@ eg to refer to a file on the classpath you can do:
 .setHeader("myHeader").spel("resource:classpath:myspel.txt")
 ----
 
+
+include::camel-spring-boot::page$spring-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/splunk-component.adoc b/docs/components/modules/ROOT/pages/splunk-component.adoc
index b80cba9..a89a275 100644
--- a/docs/components/modules/ROOT/pages/splunk-component.adoc
+++ b/docs/components/modules/ROOT/pages/splunk-component.adoc
@@ -251,3 +251,5 @@ data with prebuilt apps for analyzing and displaying this.  +
  For example the jmx app. could be used to publish jmx attributes, eg.
 route and jvm metrics to Splunk, and displaying this on a dashboard.
 
+
+include::camel-spring-boot::page$splunk-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spring-batch-component.adoc b/docs/components/modules/ROOT/pages/spring-batch-component.adoc
index 9414703..b8ee767 100644
--- a/docs/components/modules/ROOT/pages/spring-batch-component.adoc
+++ b/docs/components/modules/ROOT/pages/spring-batch-component.adoc
@@ -284,3 +284,5 @@ JMS queue.
   </batch:listeners>
 </batch:job>
 -----------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$spring-batch-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spring-event-component.adoc b/docs/components/modules/ROOT/pages/spring-event-component.adoc
index 6d007f0..774afc7 100644
--- a/docs/components/modules/ROOT/pages/spring-event-component.adoc
+++ b/docs/components/modules/ROOT/pages/spring-event-component.adoc
@@ -83,3 +83,5 @@ with the following path and query parameters:
 
 
 
+
+include::camel-spring-boot::page$spring-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spring-integration-component.adoc b/docs/components/modules/ROOT/pages/spring-integration-component.adoc
index d947672..5f19c3e 100644
--- a/docs/components/modules/ROOT/pages/spring-integration-component.adoc
+++ b/docs/components/modules/ROOT/pages/spring-integration-component.adoc
@@ -126,3 +126,5 @@ This example uses the following namespaces:
 
 You can bind your source or target to a Camel endpoint as follows:
 
+
+include::camel-spring-boot::page$spring-integration-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spring-ldap-component.adoc b/docs/components/modules/ROOT/pages/spring-ldap-component.adoc
index 03b557c..c6a598a 100644
--- a/docs/components/modules/ROOT/pages/spring-ldap-component.adoc
+++ b/docs/components/modules/ROOT/pages/spring-ldap-component.adoc
@@ -150,3 +150,5 @@ in `org.apache.camel.springldap.SpringLdapProducer`:
 * public static final String MODIFICATION_ITEMS = "modificationItems";
 * public static final String FUNCTION = "function";
 * public static final String REQUEST = "request";
+
+include::camel-spring-boot::page$spring-ldap-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spring-redis-component.adoc b/docs/components/modules/ROOT/pages/spring-redis-component.adoc
index ff4859b..19f9ee2 100644
--- a/docs/components/modules/ROOT/pages/spring-redis-component.adoc
+++ b/docs/components/modules/ROOT/pages/spring-redis-component.adoc
@@ -402,3 +402,5 @@ Maven users will need to add the following dependency to their pom.xml.
 
 where `${camel-version`} must be replaced by the actual version of Camel.
 
+
+include::camel-spring-boot::page$spring-redis-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spring-ws-component.adoc b/docs/components/modules/ROOT/pages/spring-ws-component.adoc
index dceece5..0af4006 100644
--- a/docs/components/modules/ROOT/pages/spring-ws-component.adoc
+++ b/docs/components/modules/ROOT/pages/spring-ws-component.adoc
@@ -615,3 +615,5 @@ from("spring-ws:rootqname:{http://example.com/}GetFoo?endpointMapping=#endpointM
 .to("mock:example").marshal(jaxb);
 --------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$spring-ws-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/spring.adoc b/docs/components/modules/ROOT/pages/spring.adoc
index 82c58be..529364e 100644
--- a/docs/components/modules/ROOT/pages/spring.adoc
+++ b/docs/components/modules/ROOT/pages/spring.adoc
@@ -409,3 +409,5 @@ Users can then use the cron component inside routes of their Spring or Spring-bo
   <to uri="log:info"/>
 </route>
 ----
+
+include::camel-spring-boot::page$spring-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/sql-component.adoc b/docs/components/modules/ROOT/pages/sql-component.adoc
index a62f84f..d7a6a7f 100644
--- a/docs/components/modules/ROOT/pages/sql-component.adoc
+++ b/docs/components/modules/ROOT/pages/sql-component.adoc
@@ -853,3 +853,5 @@ To use this feature, add the following dependencies to your spring boot pom.xml
 
 You should also include the specific database driver, if needed.
 
+
+include::camel-spring-boot::page$sql-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/sql-stored-component.adoc b/docs/components/modules/ROOT/pages/sql-stored-component.adoc
index 0ed7d3c..49d723f 100644
--- a/docs/components/modules/ROOT/pages/sql-stored-component.adoc
+++ b/docs/components/modules/ROOT/pages/sql-stored-component.adoc
@@ -258,3 +258,5 @@ To use this feature, add the following dependencies to your spring boot pom.xml
 
 You should also include the specific database driver, if needed.
 
+
+include::camel-spring-boot::page$sql-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/ssh-component.adoc b/docs/components/modules/ROOT/pages/ssh-component.adoc
index 0eb3de5..e1b994e 100644
--- a/docs/components/modules/ROOT/pages/ssh-component.adoc
+++ b/docs/components/modules/ROOT/pages/ssh-component.adoc
@@ -228,3 +228,5 @@ of Camel you are using.
 See the `examples/camel-example-ssh` and
 `examples/camel-example-ssh-security` in the Camel distribution.
 
+
+include::camel-spring-boot::page$ssh-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/stax-component.adoc b/docs/components/modules/ROOT/pages/stax-component.adoc
index f11bf9a..aae3041 100644
--- a/docs/components/modules/ROOT/pages/stax-component.adoc
+++ b/docs/components/modules/ROOT/pages/stax-component.adoc
@@ -228,3 +228,5 @@ from("file:target/in")
 
 The example above could be implemented as follows in XML DSL
 
+
+include::camel-spring-boot::page$stax-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/stomp-component.adoc b/docs/components/modules/ROOT/pages/stomp-component.adoc
index 9202ba4..04ae994 100644
--- a/docs/components/modules/ROOT/pages/stomp-component.adoc
+++ b/docs/components/modules/ROOT/pages/stomp-component.adoc
@@ -160,3 +160,5 @@ implements the Polling Consumer pattern for
 consuming message exchanges from the endpoint via a
 https://www.javadoc.io/doc/org.apache.camel/camel-api/current/org/apache/camel/PollingConsumer.html[PollingConsumer]
 
+
+include::camel-spring-boot::page$stomp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/stream-component.adoc b/docs/components/modules/ROOT/pages/stream-component.adoc
index d3010a9..f17cf40 100644
--- a/docs/components/modules/ROOT/pages/stream-component.adoc
+++ b/docs/components/modules/ROOT/pages/stream-component.adoc
@@ -164,3 +164,5 @@ If you want to re-load the file if it rollover/rewritten then you should also tu
 from("stream:file?fileName=/server/logs/server.log&scanStream=true&scanStreamDelay=1000&retry=true&fileWatcher=true")
   .to("bean:logService?method=parseLogLine");
 ----
+
+include::camel-spring-boot::page$stream-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/string-template-component.adoc b/docs/components/modules/ROOT/pages/string-template-component.adoc
index e7a9435..d3447ce 100644
--- a/docs/components/modules/ROOT/pages/string-template-component.adoc
+++ b/docs/components/modules/ROOT/pages/string-template-component.adoc
@@ -151,3 +151,5 @@ Regards Camel Riders Bookstore
 
 And the java code is as follows:
 
+
+include::camel-spring-boot::page$stringtemplate-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/stub-component.adoc b/docs/components/modules/ROOT/pages/stub-component.adoc
index 525e52d..b4f51e1 100644
--- a/docs/components/modules/ROOT/pages/stub-component.adoc
+++ b/docs/components/modules/ROOT/pages/stub-component.adoc
@@ -112,3 +112,5 @@ Here are a few samples of stubbing endpoint uris
 stub:smtp://somehost.foo.com?user=whatnot&something=else
 stub:http://somehost.bar.com/something
 ----
+
+include::camel-spring-boot::page$stub-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/syslog-dataformat.adoc b/docs/components/modules/ROOT/pages/syslog-dataformat.adoc
index 8182fa2..cab0d3e 100644
--- a/docs/components/modules/ROOT/pages/syslog-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/syslog-dataformat.adoc
@@ -132,3 +132,5 @@ The same route using xref:mina-component.adoc[Mina Component]
 </camelContext>
 -------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$syslog-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/tarfile-dataformat.adoc b/docs/components/modules/ROOT/pages/tarfile-dataformat.adoc
index adb1696..62598e1 100644
--- a/docs/components/modules/ROOT/pages/tarfile-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/tarfile-dataformat.adoc
@@ -167,3 +167,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----------------------------------------------------------
+
+include::camel-spring-boot::page$tarfile-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/telegram-component.adoc b/docs/components/modules/ROOT/pages/telegram-component.adoc
index acc028a..b039fb2 100644
--- a/docs/components/modules/ROOT/pages/telegram-component.adoc
+++ b/docs/components/modules/ROOT/pages/telegram-component.adoc
@@ -433,3 +433,5 @@ You need to ensure that your server is exposed to the internet and to pass the r
 *camel.component.webhook.configuration.webhook-external-url* property.
 
 Refer to the *camel-webhook* component documentation for instructions on how to set it.
+
+include::camel-spring-boot::page$telegram-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/thrift-component.adoc b/docs/components/modules/ROOT/pages/thrift-component.adoc
index 0a544c3..3e2231f 100644
--- a/docs/components/modules/ROOT/pages/thrift-component.adoc
+++ b/docs/components/modules/ROOT/pages/thrift-component.adoc
@@ -166,3 +166,5 @@ It's possible to automate Java code generation for .thrift files using *thrift-m
 https://github.com/apache/thrift/[Thrift project GitHub]
 https://thrift.apache.org/tutorial/java [Apache Thrift Java tutorial]
 
+
+include::camel-spring-boot::page$thrift-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/thrift-dataformat.adoc b/docs/components/modules/ROOT/pages/thrift-dataformat.adoc
index c7e9023..0fa5cf2 100644
--- a/docs/components/modules/ROOT/pages/thrift-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/thrift-dataformat.adoc
@@ -156,3 +156,5 @@ To use Thrift in your camel routes you need to add the a dependency on
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$thrift-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/tidyMarkup-dataformat.adoc b/docs/components/modules/ROOT/pages/tidyMarkup-dataformat.adoc
index 87cb8d3..157570e 100644
--- a/docs/components/modules/ROOT/pages/tidyMarkup-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/tidyMarkup-dataformat.adoc
@@ -83,3 +83,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 ----------------------------------------
+
+include::camel-spring-boot::page$tagsoup-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/tika-component.adoc b/docs/components/modules/ROOT/pages/tika-component.adoc
index e8f6892..1fa2431 100644
--- a/docs/components/modules/ROOT/pages/tika-component.adoc
+++ b/docs/components/modules/ROOT/pages/tika-component.adoc
@@ -105,3 +105,5 @@ The file should be placed in the Body.
 from("direct:start")
         .to("tika:parse");
 ----
+
+include::camel-spring-boot::page$tika-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/timer-component.adoc b/docs/components/modules/ROOT/pages/timer-component.adoc
index 7dfb0ca..0460a10 100644
--- a/docs/components/modules/ROOT/pages/timer-component.adoc
+++ b/docs/components/modules/ROOT/pages/timer-component.adoc
@@ -192,3 +192,5 @@ starting the route. To do that you use the repeatCount option as shown:
 </route>
 ----
 
+
+include::camel-spring-boot::page$timer-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/twilio-component.adoc b/docs/components/modules/ROOT/pages/twilio-component.adoc
index 0713be0..8f9d887 100644
--- a/docs/components/modules/ROOT/pages/twilio-component.adoc
+++ b/docs/components/modules/ROOT/pages/twilio-component.adoc
@@ -223,3 +223,5 @@ endpoints with *CamelTwilio.* prefix.
 All result message bodies utilize objects provided by the Twilio Java SDK.
 Producer endpoints can specify the option name for incoming message body
 in the *inBody* endpoint parameter.
+
+include::camel-spring-boot::page$twilio-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/twitter-directmessage-component.adoc b/docs/components/modules/ROOT/pages/twitter-directmessage-component.adoc
index e49d564..43719a0 100644
--- a/docs/components/modules/ROOT/pages/twitter-directmessage-component.adoc
+++ b/docs/components/modules/ROOT/pages/twitter-directmessage-component.adoc
@@ -109,3 +109,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$twitter-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/twitter-search-component.adoc b/docs/components/modules/ROOT/pages/twitter-search-component.adoc
index 5964bf2..86f9e83 100644
--- a/docs/components/modules/ROOT/pages/twitter-search-component.adoc
+++ b/docs/components/modules/ROOT/pages/twitter-search-component.adoc
@@ -118,3 +118,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$twitter-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/twitter-timeline-component.adoc b/docs/components/modules/ROOT/pages/twitter-timeline-component.adoc
index 9749de3..2c63dda 100644
--- a/docs/components/modules/ROOT/pages/twitter-timeline-component.adoc
+++ b/docs/components/modules/ROOT/pages/twitter-timeline-component.adoc
@@ -113,3 +113,5 @@ with the following path and query parameters:
 The timelineType can be one of: public, home, user, mentions or retweetsofme.
 
 
+
+include::camel-spring-boot::page$twitter-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/undertow-component.adoc b/docs/components/modules/ROOT/pages/undertow-component.adoc
index 01a0ca7..ab3507f 100644
--- a/docs/components/modules/ROOT/pages/undertow-component.adoc
+++ b/docs/components/modules/ROOT/pages/undertow-component.adoc
@@ -205,3 +205,5 @@ If you actually want to expose routes by HTTP and already have a
 Servlet, you should instead refer to the
 xref:servlet-component.adoc[Servlet Transport].
 
+
+include::camel-spring-boot::page$undertow-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/univocity-csv-dataformat.adoc b/docs/components/modules/ROOT/pages/univocity-csv-dataformat.adoc
index 55be238..ea11937 100644
--- a/docs/components/modules/ROOT/pages/univocity-csv-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/univocity-csv-dataformat.adoc
@@ -169,3 +169,5 @@ All the rows can either:
     <to uri="mock:result"/>
 </route>
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$univocity-parsers-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/univocity-fixed-dataformat.adoc b/docs/components/modules/ROOT/pages/univocity-fixed-dataformat.adoc
index e4db309..a899afa 100644
--- a/docs/components/modules/ROOT/pages/univocity-fixed-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/univocity-fixed-dataformat.adoc
@@ -168,3 +168,5 @@ All the rows can either:
     <to uri="mock:result"/>
 </route>
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$univocity-parsers-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/univocity-tsv-dataformat.adoc b/docs/components/modules/ROOT/pages/univocity-tsv-dataformat.adoc
index e709928..e548bc1 100644
--- a/docs/components/modules/ROOT/pages/univocity-tsv-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/univocity-tsv-dataformat.adoc
@@ -166,3 +166,5 @@ All the rows can either:
     <to uri="mock:result"/>
 </route>
 ------------------------------------------------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$univocity-parsers-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/validator-component.adoc b/docs/components/modules/ROOT/pages/validator-component.adoc
index 3959a5e..c336c2a 100644
--- a/docs/components/modules/ROOT/pages/validator-component.adoc
+++ b/docs/components/modules/ROOT/pages/validator-component.adoc
@@ -115,3 +115,5 @@ validator endpoint is cleared and reread with the next process call with
 the JMX operation `clearCachedSchema`. You can also use this method to
 programmatically clear the cache. This method is available on the
 `ValidatorEndpoint` class.
+
+include::camel-spring-boot::page$validator-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/velocity-component.adoc b/docs/components/modules/ROOT/pages/velocity-component.adoc
index dec9b5e..745af7f 100644
--- a/docs/components/modules/ROOT/pages/velocity-component.adoc
+++ b/docs/components/modules/ROOT/pages/velocity-component.adoc
@@ -273,3 +273,5 @@ ${body}
 
 And the java code:
 
+
+include::camel-spring-boot::page$velocity-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/vertx-component.adoc b/docs/components/modules/ROOT/pages/vertx-component.adoc
index 4813e60..41e025b 100644
--- a/docs/components/modules/ROOT/pages/vertx-component.adoc
+++ b/docs/components/modules/ROOT/pages/vertx-component.adoc
@@ -124,3 +124,5 @@ vertxComponent.setVertx(vertx);
 camelContext.addComponent("vertx", vertxComponent);
 -----------------------------------------------------
 
+
+include::camel-spring-boot::page$vertx-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/vm-component.adoc b/docs/components/modules/ROOT/pages/vm-component.adoc
index d0a9edb..5b452d6 100644
--- a/docs/components/modules/ROOT/pages/vm-component.adoc
+++ b/docs/components/modules/ROOT/pages/vm-component.adoc
@@ -137,3 +137,5 @@ deployed in another `.war` application):
 from("vm:order.email").bean(MyOrderEmailSender.class);
 ----
 
+
+include::camel-spring-boot::page$vm-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/weather-component.adoc b/docs/components/modules/ROOT/pages/weather-component.adoc
index dbee107..23bdd80 100644
--- a/docs/components/modules/ROOT/pages/weather-component.adoc
+++ b/docs/components/modules/ROOT/pages/weather-component.adoc
@@ -207,3 +207,5 @@ And to get the weather at the current location, then:
 --------------------------------------------------------------------------------------------------------------------------------
   String json = template.requestBodyAndHeader("direct:start", "", "CamelWeatherLocation", "current&appid=APIKEY", String.class);
 --------------------------------------------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$weather-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/web3j-component.adoc b/docs/components/modules/ROOT/pages/web3j-component.adoc
index 18f2364..f31fd42 100644
--- a/docs/components/modules/ROOT/pages/web3j-component.adoc
+++ b/docs/components/modules/ROOT/pages/web3j-component.adoc
@@ -163,3 +163,5 @@ Read the balance of an address at a specific block number:
 from("direct:start")
     .to("web3j://http://127.0.0.1:7545?operation=ETH_GET_BALANCE&address=0xc8CDceCE5d006dAB638029EBCf6Dd666efF5A952&atBlock=10");
 --------------------------------------------------------
+
+include::camel-spring-boot::page$web3j-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/webhook-component.adoc b/docs/components/modules/ROOT/pages/webhook-component.adoc
index a43810b2..d63003f 100644
--- a/docs/components/modules/ROOT/pages/webhook-component.adoc
+++ b/docs/components/modules/ROOT/pages/webhook-component.adoc
@@ -103,3 +103,5 @@ You can append query options to the URI in the following format,
 == Examples
 
 Examples of webhook component are provided in the documentation of the delegate components that support it.
+
+include::camel-spring-boot::page$webhook-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/websocket-component.adoc b/docs/components/modules/ROOT/pages/websocket-component.adoc
index 4a6a286..2530d2b 100644
--- a/docs/components/modules/ROOT/pages/websocket-component.adoc
+++ b/docs/components/modules/ROOT/pages/websocket-component.adoc
@@ -246,3 +246,5 @@ Java DSL based configuration of endpoint
 ...
 ----------------------------------------------------------------------------------------------------------
 
+
+include::camel-spring-boot::page$websocket-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/websocket-jsr356-component.adoc b/docs/components/modules/ROOT/pages/websocket-jsr356-component.adoc
index 04f7e81..bd1c645 100644
--- a/docs/components/modules/ROOT/pages/websocket-jsr356-component.adoc
+++ b/docs/components/modules/ROOT/pages/websocket-jsr356-component.adoc
@@ -85,3 +85,5 @@ with the following path and query parameters:
 |===
 // endpoint options: END
 
+
+include::camel-spring-boot::page$websocket-jsr356-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/weka-component.adoc b/docs/components/modules/ROOT/pages/weka-component.adoc
index 41ae8f2..18323b0 100644
--- a/docs/components/modules/ROOT/pages/weka-component.adoc
+++ b/docs/components/modules/ROOT/pages/weka-component.adoc
@@ -255,3 +255,5 @@ try (CamelContext camelctx = new DefaultCamelContext()) {
 * https://www.cs.waikato.ac.nz/ml/weka/courses.html[Machine Learning Courses,window=_blank]
 * https://waikato.github.io/weka-wiki/documentation/[Weka Documentation,window=_blank]
 * https://tdiesler.github.io/nessus-weka[Nessus-Weka,window=_blank]
+
+include::camel-spring-boot::page$weka-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/wordpress-component.adoc b/docs/components/modules/ROOT/pages/wordpress-component.adoc
index 6908e0b..330d165 100644
--- a/docs/components/modules/ROOT/pages/wordpress-component.adoc
+++ b/docs/components/modules/ROOT/pages/wordpress-component.adoc
@@ -125,3 +125,5 @@ At this time, `camel-wordpress` only supports Basic Authentication (more to come
 `from("direct:deletePost").to("wordpress:post:delete?id=9&user=ben&password=password123").to("mock:resultDelete");`
 
 **It's not recommend to use Basic Authentication in production without TLS!!**
+
+include::camel-spring-boot::page$wordpress-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/workday-component.adoc b/docs/components/modules/ROOT/pages/workday-component.adoc
index e6bda26..e5ad278 100644
--- a/docs/components/modules/ROOT/pages/workday-component.adoc
+++ b/docs/components/modules/ROOT/pages/workday-component.adoc
@@ -79,3 +79,5 @@ with the following path and query parameters:
 | *tenant* (tenant) | *Required* Workday Tenant name. |  | String
 |===
 // endpoint options: END
+
+include::camel-spring-boot::page$workday-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xchange-component.adoc b/docs/components/modules/ROOT/pages/xchange-component.adoc
index 3706a31..8f597f9 100644
--- a/docs/components/modules/ROOT/pages/xchange-component.adoc
+++ b/docs/components/modules/ROOT/pages/xchange-component.adoc
@@ -116,3 +116,5 @@ In this sample we find the current Bitcoin market price in USDT:
 ---------------------------------------------------------------------------------------------
 from("direct:ticker").to("xchange:binance?service=market&method=ticker&currencyPair=BTC/USDT")
 ---------------------------------------------------------------------------------------------
+
+include::camel-spring-boot::page$xchange-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xj-component.adoc b/docs/components/modules/ROOT/pages/xj-component.adoc
index f297a50..e2ec19f 100644
--- a/docs/components/modules/ROOT/pages/xj-component.adoc
+++ b/docs/components/modules/ROOT/pages/xj-component.adoc
@@ -492,3 +492,5 @@ that aren't allowed in XML element names.
 | boolean | Generate a json boolean
 | null | Generate an empty value, using the word null
 |===
+
+include::camel-spring-boot::page$xj-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xmlsecurity-component.adoc b/docs/components/modules/ROOT/pages/xmlsecurity-component.adoc
index 5e63f8b..0a4d7fd 100644
--- a/docs/components/modules/ROOT/pages/xmlsecurity-component.adoc
+++ b/docs/components/modules/ROOT/pages/xmlsecurity-component.adoc
@@ -715,3 +715,5 @@ the XML signer endpoint).
 * The `AllDataObjectsTimeStamp` element is not supported
 * The `IndividualDataObjectsTimeStamp` element is not supported
 
+
+include::camel-spring-boot::page$xmlsecurity-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xmpp-component.adoc b/docs/components/modules/ROOT/pages/xmpp-component.adoc
index 624a2fc..b9ffce7 100644
--- a/docs/components/modules/ROOT/pages/xmpp-component.adoc
+++ b/docs/components/modules/ROOT/pages/xmpp-component.adoc
@@ -182,3 +182,5 @@ from("direct:start").
 
  
 
+
+include::camel-spring-boot::page$xmpp-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xpath-language.adoc b/docs/components/modules/ROOT/pages/xpath-language.adoc
index b05dcee..bc06df8 100644
--- a/docs/components/modules/ROOT/pages/xpath-language.adoc
+++ b/docs/components/modules/ROOT/pages/xpath-language.adoc
@@ -492,3 +492,5 @@ eg to refer to a file on the classpath you can do:
 == Dependencies
 
 The XPath language is part of camel-core.
+
+include::camel-spring-boot::page$xpath-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xquery-component.adoc b/docs/components/modules/ROOT/pages/xquery-component.adoc
index 6e6f8a2..03ce442 100644
--- a/docs/components/modules/ROOT/pages/xquery-component.adoc
+++ b/docs/components/modules/ROOT/pages/xquery-component.adoc
@@ -297,3 +297,5 @@ substituting the version number for the latest & greatest release.
   <version>x.x.x</version>
 </dependency>
 --------------------------------------
+
+include::camel-spring-boot::page$saxon-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xquery-language.adoc b/docs/components/modules/ROOT/pages/xquery-language.adoc
index d6d8dd6..ee8505b 100644
--- a/docs/components/modules/ROOT/pages/xquery-language.adoc
+++ b/docs/components/modules/ROOT/pages/xquery-language.adoc
@@ -155,3 +155,5 @@ the download page for the latest versions).
   <version>x.x.x</version>
 </dependency>
 --------------------------------------
+
+include::camel-spring-boot::page$saxon-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xslt-component.adoc b/docs/components/modules/ROOT/pages/xslt-component.adoc
index eaba1b2..50ab8e1 100644
--- a/docs/components/modules/ROOT/pages/xslt-component.adoc
+++ b/docs/components/modules/ROOT/pages/xslt-component.adoc
@@ -234,3 +234,5 @@ xsl:message.
 The exception is stored on the Exchange as a warning with the
 key `Exchange.XSLT_WARNING.`
 
+
+include::camel-spring-boot::page$xslt-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xslt-saxon-component.adoc b/docs/components/modules/ROOT/pages/xslt-saxon-component.adoc
index ff5958f..ba33dc6 100644
--- a/docs/components/modules/ROOT/pages/xslt-saxon-component.adoc
+++ b/docs/components/modules/ROOT/pages/xslt-saxon-component.adoc
@@ -279,3 +279,5 @@ xsl:message.
 
 The exception is stored on the Exchange as a warning with the
 key `Exchange.XSLT_WARNING.`
+
+include::camel-spring-boot::page$xslt-saxon-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/xstream-dataformat.adoc b/docs/components/modules/ROOT/pages/xstream-dataformat.adoc
index 951ac02..1f71ae7d 100644
--- a/docs/components/modules/ROOT/pages/xstream-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/xstream-dataformat.adoc
@@ -141,3 +141,5 @@ DataFormat instance by setting its type permissions property.
         ...
 
 -------------------------------------------------------------------
+
+include::camel-spring-boot::page$xstream-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/yaml-snakeyaml-dataformat.adoc b/docs/components/modules/ROOT/pages/yaml-snakeyaml-dataformat.adoc
index ad348e4..21761bc 100644
--- a/docs/components/modules/ROOT/pages/yaml-snakeyaml-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/yaml-snakeyaml-dataformat.adoc
@@ -148,3 +148,5 @@ substituting the version number for the latest & greatest release
  
 
  
+
+include::camel-spring-boot::page$snakeyaml-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/yammer-component.adoc b/docs/components/modules/ROOT/pages/yammer-component.adoc
index 519f7f8..8d8ecc6 100644
--- a/docs/components/modules/ROOT/pages/yammer-component.adoc
+++ b/docs/components/modules/ROOT/pages/yammer-component.adoc
@@ -340,4 +340,5 @@ from("direct:start")
     .to("mock:result");
 ----
 
-This will go out and fetch the current user's `User` object and set it as the Camel message body.
\ No newline at end of file
+This will go out and fetch the current user's `User` object and set it as the Camel message body.
+include::camel-spring-boot::page$yammer-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/zendesk-component.adoc b/docs/components/modules/ROOT/pages/zendesk-component.adoc
index 5745c3e..c3c974c 100644
--- a/docs/components/modules/ROOT/pages/zendesk-component.adoc
+++ b/docs/components/modules/ROOT/pages/zendesk-component.adoc
@@ -137,3 +137,5 @@ the arugument name of each API methods on the original `org.zendesk.client.v2.Ze
 All result message bodies utilize objects provided by the Zendesk Java Client.
 Producer endpoints can specify the option name for incoming message body
 in the *inBody* endpoint parameter.
+
+include::camel-spring-boot::page$zendesk-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/zipdeflater-dataformat.adoc b/docs/components/modules/ROOT/pages/zipdeflater-dataformat.adoc
index 574cb48..01d9f17 100644
--- a/docs/components/modules/ROOT/pages/zipdeflater-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/zipdeflater-dataformat.adoc
@@ -65,3 +65,5 @@ unmarshalling to avoid errors.
 ----
 from("activemq:queue:MY_QUEUE").unmarshal().zipDeflater().process(new UnZippedMessageProcessor()); 
 ----
+
+include::camel-spring-boot::page$zip-deflater-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/zipfile-dataformat.adoc b/docs/components/modules/ROOT/pages/zipfile-dataformat.adoc
index 1d03f14..b67ef40 100644
--- a/docs/components/modules/ROOT/pages/zipfile-dataformat.adoc
+++ b/docs/components/modules/ROOT/pages/zipfile-dataformat.adoc
@@ -166,3 +166,5 @@ the download page for the latest versions).
   <!-- use the same version as your Camel core version -->
 </dependency>
 ----
+
+include::camel-spring-boot::page$zipfile-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/zipkin.adoc b/docs/components/modules/ROOT/pages/zipkin.adoc
index cc78465..8c082ad 100644
--- a/docs/components/modules/ROOT/pages/zipkin.adoc
+++ b/docs/components/modules/ROOT/pages/zipkin.adoc
@@ -277,3 +277,5 @@ If you are using Spring Boot then you can add the `camel-zipkin-starter` depende
 You can then configure camel-zipkin in the `application.properties` file where you can configure the hostname and port number for the Zipkin Server, and all the other options as listed in the options table above.
 
 You can find an example of this in the https://github.com/apache/camel/tree/master/examples/camel-example-zipkin[camel-example-zipkin]
+
+include::camel-spring-boot::page$zipkin-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/zookeeper-component.adoc b/docs/components/modules/ROOT/pages/zookeeper-component.adoc
index b5b5a91..724dde6 100644
--- a/docs/components/modules/ROOT/pages/zookeeper-component.adoc
+++ b/docs/components/modules/ROOT/pages/zookeeper-component.adoc
@@ -226,3 +226,5 @@ Object testPayload = ...
 template.sendBodyAndHeader("direct:create-and-write-to-persistent-znode", testPayload, "CamelZooKeeperCreateMode", "PERSISTENT");
 ----
 
+
+include::camel-spring-boot::page$zookeeper-starter.adoc[]
diff --git a/docs/components/modules/ROOT/pages/zookeeper-master-component.adoc b/docs/components/modules/ROOT/pages/zookeeper-master-component.adoc
index 6cc460a..f580738 100644
--- a/docs/components/modules/ROOT/pages/zookeeper-master-component.adoc
+++ b/docs/components/modules/ROOT/pages/zookeeper-master-component.adoc
@@ -153,3 +153,5 @@ A little example
         .to("file:target/outbox");
 ----
 
+
+include::camel-spring-boot::page$zookeeper-master-starter.adoc[]