You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@couchdb.apache.org by ro...@apache.org on 2022/11/28 09:38:05 UTC

[couchdb] branch format-config-files updated (46fc83b34 -> 0a5c4aaae)

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

ronny pushed a change to branch format-config-files
in repository https://gitbox.apache.org/repos/asf/couchdb.git


 discard 46fc83b34 Format config files
     new 0a5c4aaae Format config files

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (46fc83b34)
            \
             N -- N -- N   refs/heads/format-config-files (0a5c4aaae)

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

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

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


Summary of changes:
 rel/overlay/etc/default.ini | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)


[couchdb] 01/01: Format config files

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

ronny pushed a commit to branch format-config-files
in repository https://gitbox.apache.org/repos/asf/couchdb.git

commit 0a5c4aaae07f0a45f461e485ddf393fa0ffcdbf2
Author: Ronny Berndt <ro...@apache.org>
AuthorDate: Mon Nov 28 10:35:35 2022 +0100

    Format config files
    
    Adjust configuration files to improve readability.
    Adjust all config keys to use the same pattern (semi-colon w/o ws):
    ";key = value"
    Adjust comments (semi-colon with ws):
    "; My comment description"
    Added new-line between description and config key, if config-key
    has a description
---
 rel/overlay/etc/default.ini | 287 +++++++++++++++++++++++++-------------------
 rel/overlay/etc/local.ini   |  13 +-
 2 files changed, 175 insertions(+), 125 deletions(-)

diff --git a/rel/overlay/etc/default.ini b/rel/overlay/etc/default.ini
index e7d4aff24..65b672f7c 100644
--- a/rel/overlay/etc/default.ini
+++ b/rel/overlay/etc/default.ini
@@ -6,8 +6,8 @@ name = {{package_author_name}}
 uuid = {{uuid}}
 database_dir = {{data_dir}}
 view_index_dir = {{view_index_dir}}
-; util_driver_dir =
-; plugin_dir =
+;util_driver_dir =
+;plugin_dir =
 ;os_process_timeout = 5000 ; 5 seconds. for view servers.
 
 ; Maximum number of .couch files to open at once.
@@ -24,55 +24,60 @@ view_index_dir = {{view_index_dir}}
 ; deflate_N    - use zlib's deflate, N is the compression level which ranges from 1 (fastest,
 ;                lowest compression ratio) to 9 (slowest, highest compression ratio)
 ;file_compression = snappy
+
 ; Higher values may give better read performance due to less read operations
 ; and/or more OS page cache hits, but they can also increase overall response
 ; time for writes when there are many attachment write requests in parallel.
 ;attachment_stream_buffer_size = 4096
+
 ; Default security object for databases if not explicitly set
 ; everyone - same as couchdb 1.0, everyone can read/write
 ; admin_only - only admins can read/write
 ; admin_local - sharded dbs on :5984 are read/write for everyone,
 ;               local dbs on :5986 are read/write for admins only
 ;default_security = admin_only
-; btree_chunk_size = 1279
-; maintenance_mode = false
-; stem_interactive_updates = true
-; uri_file =
+
+;btree_chunk_size = 1279
+;maintenance_mode = false
+;stem_interactive_updates = true
+;uri_file =
+
 ; The speed of processing the _changes feed with doc_ids filter can be
 ; influenced directly with this setting - increase for faster processing at the
 ; expense of more memory usage.
 ;changes_doc_ids_optimization_threshold = 100
+
 ; Maximum document ID length. Can be set to an integer or 'infinity'.
 ;max_document_id_length = infinity
-;
+
 ; Limit maximum document size. Requests to create / update documents with a body
 ; size larger than this will fail with a 413 http error. This limit applies to
 ; requests which update a single document as well as individual documents from
 ; a _bulk_docs request. The size limit is approximate due to the nature of JSON
 ; encoding.
 ;max_document_size = 8000000 ; bytes
-;
+
 ; Maximum attachment size.
-; max_attachment_size = 1073741824 ; 1 gibibyte
-;
+;max_attachment_size = 1073741824 ; 1 gibibyte
+
 ; Do not update the least recently used DB cache on reads, only writes
 ;update_lru_on_read = false
-;
+
 ; The default storage engine to use when creating databases
 ; is set as a key into the [couchdb_engines] section.
 ;default_engine = couch
-;
+
 ; Enable this to only "soft-delete" databases when DELETE /{db} requests are
 ; made. This will place a .recovery directory in your data directory and
 ; move deleted databases/shards there instead. You can then manually delete
 ; these files later, as desired.
 ;enable_database_recovery = false
-;
+
 ; Set the maximum size allowed for a partition. This helps users avoid
 ; inadvertently abusing partitions resulting in hot shards. The default
 ; is 10GiB. A value of 0 or less will disable partition size checks.
 ;max_partition_size = 10737418240
-;
+
 ; When true, system databases _users and _replicator are created immediately
 ; on startup if not present.
 ;single_node = false
@@ -90,10 +95,10 @@ view_index_dir = {{view_index_dir}}
 [purge]
 ; Allowed maximum number of documents in one purge request
 ;max_document_id_number = 100
-;
+
 ; Allowed maximum number of accumulated revisions in one purge request
 ;max_revisions_number = 1000
-;
+
 ; Allowed durations when index is not updated for local purge checkpoint
 ; document. Default is 24 hours.
 ;index_lag_warn_seconds = 86400
@@ -115,14 +120,14 @@ couch = couch_bt_engine
 [cluster]
 ;q=2
 ;n=3
-; placement = metro-dc-a:2,metro-dc-b:1
+;placement = metro-dc-a:2,metro-dc-b:1
 
 ; Supply a comma-delimited list of node names that this node should
 ; contact in order to join a cluster. If a seedlist is configured the ``_up``
 ; endpoint will return a 404 until the node has successfully contacted at
 ; least one of the members of the seedlist and replicated an up-to-date copy
 ; of the ``_nodes``, ``_dbs``, and ``_users`` system databases.
-; seedlist = couchdb@node1.example.com,couchdb@node2.example.com
+;seedlist = couchdb@node1.example.com,couchdb@node2.example.com
 
 ; Period in seconds specifying how often to attempt reconnecting to
 ; disconnected nodes. There is a 25% random jitter applied to this
@@ -137,11 +142,12 @@ bind_address = 127.0.0.1
 ;socket_options = [{sndbuf, 262144}, {nodelay, true}]
 ;server_options = [{recbuf, undefined}]
 ;require_valid_user = false
-; require_valid_user_except_for_up = false
+;require_valid_user_except_for_up = false
+
 ; List of headers that will be kept when the header Prefer: return=minimal is included in a request.
 ; If Server header is left out, Mochiweb will add its own one in.
 ;prefer_minimal = Cache-Control, Content-Length, Content-Range, Content-Type, ETag, Server, Transfer-Encoding, Vary
-;
+
 ; Limit maximum number of databases when tying to get detailed information using
 ; _dbs_info in a request
 ;max_db_number_for_dbs_info_req = 100
@@ -150,14 +156,14 @@ bind_address = 127.0.0.1
 ;buffer_response = false
 
 ; authentication handlers
-; authentication_handlers = {chttpd_auth, cookie_authentication_handler}, {chttpd_auth, default_authentication_handler}
+;authentication_handlers = {chttpd_auth, cookie_authentication_handler}, {chttpd_auth, default_authentication_handler}
 ; uncomment the next line to enable proxy authentication
-; authentication_handlers = {chttpd_auth, proxy_authentication_handler}, {chttpd_auth, cookie_authentication_handler}, {chttpd_auth, default_authentication_handler}
+;authentication_handlers = {chttpd_auth, proxy_authentication_handler}, {chttpd_auth, cookie_authentication_handler}, {chttpd_auth, default_authentication_handler}
 ; uncomment the next line to enable JWT authentication
-; authentication_handlers = {chttpd_auth, jwt_authentication_handler}, {chttpd_auth, cookie_authentication_handler}, {chttpd_auth, default_authentication_handler}
+;authentication_handlers = {chttpd_auth, jwt_authentication_handler}, {chttpd_auth, cookie_authentication_handler}, {chttpd_auth, default_authentication_handler}
 
 ; prevent non-admins from accessing /_all_dbs and /_dbs_info
-; admin_only_all_dbs = true
+;admin_only_all_dbs = true
 
 ; These options are moved from [httpd]
 ;secure_rewrites = true
@@ -180,7 +186,7 @@ bind_address = 127.0.0.1
 ;max_http_request_size = 4294967296 ; 4GB
 
 ; Set to true to decode + to space in db and doc_id parts.
-; decode_plus_to_space = true
+;decode_plus_to_space = true
 
 ; Set to false to revert to a previous _bulk_get implementation using single
 ; doc fetches internally. Using batches should be faster, however there may be
@@ -193,10 +199,12 @@ bind_address = 127.0.0.1
 ; can be the name of a claim like "exp" or a tuple if the claim requires
 ; a parameter
 ;required_claims = exp, {iss, "IssuerNameHere"}
+
 ; roles_claim_name is marked as deprecated. Please use roles_claim_path instead!
 ; Values for ``roles_claim_name`` can only be top-level attributes in the JWT
 ; token. If ``roles_claim_path`` is set, then ``roles_claim_name`` is ignored!
 ;roles_claim_name = my-couchdb-roles
+
 ; roles_claim_path was introduced to overcome disadvantages of ``roles_claim_name``,
 ; because it is not possible with ``roles_claim_name`` to map nested role
 ; attributes in the JWT token. There are only two characters with a special meaning.
@@ -220,16 +228,16 @@ bind_address = 127.0.0.1
 ; Configure at least one key here if using the JWT auth handler.
 ; If your JWT tokens do not include a "kid" attribute, use "_default"
 ; as the config key, otherwise use the kid as the config key.
-; Examples
-; hmac:_default = aGVsbG8=
-; hmac:foo = aGVsbG8=
+; Examples:
+;   hmac:_default = aGVsbG8=
+;   hmac:foo = aGVsbG8=
 ; The config values can represent symmetric and asymmetrics keys.
 ; For symmetrics keys, the value is base64 encoded;
 ; hmac:_default = aGVsbG8= # base64-encoded form of "hello"
 ; For asymmetric keys, the value is the PEM encoding of the public
 ; key with newlines replaced with the escape sequence \n.
-; rsa:foo = -----BEGIN PUBLIC KEY-----\nMIIBIjAN...IDAQAB\n-----END PUBLIC KEY-----\n
-; ec:bar = -----BEGIN PUBLIC KEY-----\nMHYwEAYHK...AzztRs\n-----END PUBLIC KEY-----\n
+;   rsa:foo = -----BEGIN PUBLIC KEY-----\nMIIBIjAN...IDAQAB\n-----END PUBLIC KEY-----\n
+;   ec:bar = -----BEGIN PUBLIC KEY-----\nMHYwEAYHK...AzztRs\n-----END PUBLIC KEY-----\n
 
 [couch_peruser]
 ; If enabled, couch_peruser ensures that a private per-user database
@@ -237,12 +245,15 @@ bind_address = 127.0.0.1
 ; by the corresponding user. Databases are in the following form:
 ; userdb-{hex encoded username}
 ;enable = false
+
 ; If set to true and a user is deleted, the respective database gets
 ; deleted as well.
 ;delete_dbs = false
+
 ; Set a default q value for peruser-created databases that is different from
 ; cluster / q
 ;q = 1
+
 ; prefix for user databases. If you change this after user dbs have been
 ; created, the existing databases won't get deleted if the associated user
 ; gets deleted because of the then prefix mismatch.
@@ -255,6 +266,7 @@ bind_address = 127.0.0.1
 
 ; Options for the MochiWeb HTTP server.
 ;server_options = [{backlog, 128}, {acceptor_pool_size, 16}]
+
 ; For more socket options, consult Erlang's module 'inet' man page.
 ;socket_options = [{recbuf, undefined}, {sndbuf, 262144}, {nodelay, true}]
 ;socket_options = [{sndbuf, 262144}]
@@ -264,12 +276,12 @@ bind_address = 127.0.0.1
 ; max_uri_length, changes_timeout, config_whitelist, rewrite_limit,
 ; x_forwarded_host, x_forwarded_proto, x_forwarded_ssl, max_http_request_size
 
-; [httpd_design_handlers]
-; _view = 
+;[httpd_design_handlers]
+;_view =
 
-; [ioq]
-; concurrency = 10
-; ratio = 0.01
+;[ioq]
+;concurrency = 10
+;ratio = 0.01
 
 [ssl]
 ;port = 6984
@@ -286,16 +298,19 @@ bind_address = 127.0.0.1
 ;min_iterations = 1
 ;max_iterations = 1000000000
 ;password_scheme = pbkdf2
+
 ; List of Erlang RegExp or tuples of RegExp and an optional error message.
 ; Where a new password must match all RegExp.
 ; Example: [{".{10,}", "Password min length is 10 characters."}, "\\d+"]
 ;password_regexp = []
 ;proxy_use_secret = false
+
 ; comma-separated list of public fields, 404 if empty
 ;public_fields =
 ;secret =
 ;users_db_public = false
 ;cookie_domain = example.com
+
 ; Set the SameSite cookie property for the auth cookie. If empty, the SameSite property is not set.
 ;same_site =
 
@@ -304,57 +319,56 @@ bind_address = 127.0.0.1
 ;                  blake2b,blake2s,md4,md5,ripemd160
 ; New cookie sessions are generated with the first hash algorithm.
 ; All values can be used to decode the session.
-; Default: sha256, sha
 hash_algorithms = sha256, sha
 
-; [chttpd_auth_cache]
-; max_lifetime = 600000
-; max_objects = 
-; max_size = 104857600
+;[chttpd_auth_cache]
+;max_lifetime = 600000
+;max_objects =
+;max_size = 104857600
+
+;[mem3]
+;nodes_db = _nodes
+;shard_cache_size = 25000
+;shards_db = _dbs
+;sync_concurrency = 10
 
-; [mem3]
-; nodes_db = _nodes
-; shard_cache_size = 25000
-; shards_db = _dbs
-; sync_concurrency = 10
-;
 ; When enabled, internal replicator will replicate purge requests between shard
 ; copies. It may be helpful to disable it temporarily when doing rolling node
 ; upgrades from CouchDB versions before 2.3.0 when clustered purge feature was
 ; introduced
 ;replicate_purges = true
 
-; [fabric]
-; all_docs_concurrency = 10
-; changes_duration = 
-; shard_timeout_factor = 2
-; shard_timeout_min_msec = 100
-; uuid_prefix_len = 7
-; request_timeout = 60000
-; all_docs_timeout = 10000
-; attachments_timeout = 60000
-; view_timeout = 3600000
-; partition_view_timeout = 3600000
-
-; [rexi]
-; buffer_count = 2000
-; server_per_node = true
-; stream_limit = 5
-;
+;[fabric]
+;all_docs_concurrency = 10
+;changes_duration =
+;shard_timeout_factor = 2
+;shard_timeout_min_msec = 100
+;uuid_prefix_len = 7
+;request_timeout = 60000
+;all_docs_timeout = 10000
+;attachments_timeout = 60000
+;view_timeout = 3600000
+;partition_view_timeout = 3600000
+
+;[rexi]
+;buffer_count = 2000
+;server_per_node = true
+;stream_limit = 5
+
 ; Use a single message to kill a group of remote workers. This feature is
 ; available starting with 3.0. When performing a rolling upgrade from 2.x to
 ; 3.x, set this value to false, then after all nodes were upgraded delete it so
 ; it can use the default true value.
 ;use_kill_all = true
 
-; [global_changes]
-; max_event_delay = 25
-; max_write_delay = 500
-; update_db = true
+;[global_changes]
+;max_event_delay = 25
+;max_write_delay = 500
+;update_db = true
 
-; [view_updater]
-; min_writer_items = 100
-; min_writer_size = 16777216
+;[view_updater]
+;min_writer_items = 100
+;min_writer_size = 16777216
 
 [couch_httpd_auth]
 ; WARNING! This only affects the node-local port (5986 by default).
@@ -382,27 +396,32 @@ authentication_db = _users
 ; Origins must include the scheme: http://example.com
 ; You can't set origins: * and credentials = true at the same time.
 ;origins = *
+
 ; List of accepted headers separated by a comma
-; headers =
+;headers =
+
 ; List of accepted methods
-; methods =
+;methods =
 
 ; Configuration for a vhost
 ;[cors:http://example.com]
-; credentials = false
+;credentials = false
 ; List of origins separated by a comma
 ; Origins must include the scheme: http://example.com
 ; You can't set origins: * and credentials = true at the same time.
 ;origins =
+
 ; List of accepted headers separated by a comma
-; headers =
+;headers =
+
 ; List of accepted methods
-; methods =
+;methods =
 
 ; Configuration for the design document cache
 ;[ddoc_cache]
 ; The maximum size of the cache in bytes
 ;max_size = 104857600 ; 100MiB
+
 ; The period each cache entry should wait before
 ; automatically refreshing in milliseconds
 ;refresh_timeout = 67000
@@ -410,24 +429,26 @@ authentication_db = _users
 [x_frame_options]
 ; Settings same-origin will return X-Frame-Options: SAMEORIGIN.
 ; If same origin is set, it will ignore the hosts setting
-; same_origin = true
+;same_origin = true
+
 ; Settings hosts will return X-Frame-Options: ALLOW-FROM https://example.com/
 ; List of hosts separated by a comma. * means accept all
-; hosts =
+;hosts =
 
 [native_query_servers]
-; erlang query server
-; enable_erlang_query_server = false
+; Erlang Query Server
+;enable_erlang_query_server = false
 
 ; Changing reduce_limit to false will disable reduce_limit.
 ; If you think you're hitting reduce_limit with a "good" reduce function,
 ; please let us know on the mailing list so we can fine tune the heuristic.
 [query_server_config]
-; commit_freq = 5
+;commit_freq = 5
 ;reduce_limit = true
 ;os_process_limit = 100
-; os_process_idle_limit = 300
-; os_process_soft_limit = 100
+;os_process_idle_limit = 300
+;os_process_soft_limit = 100
+
 ; Timeout for how long a response from a busy view group server can take.
 ; "infinity" is also a valid configuration value.
 ;group_info_timeout = 5000
@@ -438,8 +459,10 @@ authentication_db = _users
 ; Set to true to disable the "index all fields" text index, which can lead
 ; to out of memory issues when users have documents with nested array fields.
 ;index_all_disabled = false
+
 ; Default limit value for mango _find queries.
 ;default_limit = 25
+
 ; Ratio between documents scanned and results matched that will
 ; generate a warning in the _find response. Setting this to 0 disables
 ; the warning.
@@ -468,10 +491,12 @@ partitioned||* = true
 ;   utc_id - Time since Jan 1, 1970 UTC with microseconds, plus utc_id_suffix string
 ;     First 14 characters are the time in hex. uuids/utc_id_suffix string value is appended to these.
 ;algorithm = sequential
+
 ; The utc_id_suffix value will be appended to uuids generated by the utc_id algorithm.
 ; Replicating instances should have unique utc_id_suffix values to ensure uniqueness of utc_id ids.
 ;utc_id_suffix =
-# Maximum number of UUIDs retrievable from /_uuids in a single request
+
+; Maximum number of UUIDs retrievable from /_uuids in a single request
 ;max_count = 1000
 
 [attachments]
@@ -481,34 +506,47 @@ partitioned||* = true
 [replicator]
 ; Random jitter applied on replication job startup (milliseconds)
 ;startup_jitter = 5000
+
 ; Number of actively running replications
 ;max_jobs = 500
+
 ;Scheduling interval in milliseconds. During each reschedule cycle
 ;interval = 60000
+
 ; Maximum number of replications to start and stop during rescheduling.
 ;max_churn = 20
+
 ; More worker processes can give higher network throughput but can also
 ; imply more disk and network IO.
 ;worker_processes = 4
+
 ; With lower batch sizes checkpoints are done more frequently. Lower batch sizes
 ; also reduce the total amount of used RAM memory.
 ;worker_batch_size = 500
+
 ; Maximum number of HTTP connections per replication.
 ;http_connections = 20
+
 ; HTTP connection timeout per replication.
 ; Even for very fast/reliable networks it might need to be increased if a remote
 ; database is too busy.
 ;connection_timeout = 30000
+
 ; Request timeout
 ;request_timeout = infinity
+
 ; If a request fails, the replicator will retry it up to N times.
 ;retries_per_request = 5
+
 ; Use checkpoints
 ;use_checkpoints = true
+
 ; Attempt to use bulk_get for fetching documents from the source
 ;use_bulk_get = true
+
 ; Checkpoint interval
 ;checkpoint_interval = 30000
+
 ; Some socket options that might boost performance in some scenarios:
 ;       {nodelay, boolean()}
 ;       {sndbuf, integer()}
@@ -516,20 +554,28 @@ partitioned||* = true
 ;       {priority, integer()}
 ; See the `inet` Erlang module's man page for the full list of options.
 ;socket_options = [{keepalive, true}, {nodelay, false}]
+
 ; Path to a file containing the user's certificate.
 ;cert_file = /full/path/to/server_cert.pem
+
 ; Path to file containing user's private PEM encoded key.
 ;key_file = /full/path/to/server_key.pem
+
 ; String containing the user's password. Only used if the private keyfile is password protected.
 ;password = somepassword
+
 ; Set to true to validate peer certificates.
 ;verify_ssl_certificates = false
+
 ; File containing a list of peer trusted certificates (in the PEM format).
 ;ssl_trusted_certificates_file = /etc/ssl/certs/ca-certificates.crt
+
 ; Maximum peer certificate depth (must be set even if certificate validation is off).
 ;ssl_certificate_max_depth = 3
+
 ; Maximum document ID length for replication.
 ;max_document_id_length = infinity
+
 ; How much time to wait before retrying after a missing doc exception. This
 ; exception happens if the document was seen in the changes feed, but internal
 ; replication hasn't caught up yet, and fetching document's revisions
@@ -539,10 +585,12 @@ partitioned||* = true
 ; avoid crashing the whole replication job, which would consume more resources
 ; and add log noise.
 ;missing_doc_retry_msec = 2000
+
 ; Wait this many seconds after startup before attaching changes listeners
-; cluster_start_period = 5
+;cluster_start_period = 5
+
 ; Re-check cluster state at least every cluster_quiet_period seconds
-; cluster_quiet_period = 60
+;cluster_quiet_period = 60
 
 ; List of replicator client authentication plugins to try. Plugins will be
 ; tried in order. The first to initialize successfully will be used for that
@@ -555,6 +603,7 @@ partitioned||* = true
 ; Currently, the new _session cookie authentication is tried first, before
 ; falling back to the old basic authenticaion default:
 ;auth_plugins = couch_replicator_auth_session,couch_replicator_auth_noop
+
 ; To restore the old behaviour, use the following value:
 ;auth_plugins = couch_replicator_auth_noop
 
@@ -584,7 +633,6 @@ partitioned||* = true
 ; interval.
 ;priority_coeff = 0.98
 
-
 [replicator.shares]
 ; Fair share configuration section. More shares result in a higher
 ; chance that jobs from that db get to run. The default value is 100,
@@ -592,7 +640,6 @@ partitioned||* = true
 ; if the database does not exist.
 ;_replicator = 100
 
-
 [log]
 ; Possible log levels:
 ;  debug
@@ -604,20 +651,18 @@ partitioned||* = true
 ;  alert
 ;  emergency, emerg
 ;  none
-;
 ;level = info
-;
+
 ; Set the maximum log message length in bytes that will be
 ; passed through the writer
-;
-; max_message_size = 16000
-;
+;max_message_size = 16000
+
 ; Do not log last message received by terminated process
-; strip_last_msg = true
-;
+;strip_last_msg = true
+
 ; List of fields to remove before logging the crash report
-; filter_fields = [pid, registered_name, error_info, messages]
-;
+;filter_fields = [pid, registered_name, error_info, messages]
+
 ; There are four different log writers that can be configured
 ; to write log messages. The default writes to stderr of the
 ; Erlang VM which is useful for debugging/development as well
@@ -627,8 +672,8 @@ partitioned||* = true
 ; rsyslog writer for deployments that need to have logs sent
 ; over the network, and a journald writer that's more suitable
 ; when using systemd journald.
-;
 ;writer = stderr
+
 ; Journald Writer notes:
 ;
 ; The journald writer doesn't have any options. It still writes
@@ -637,63 +682,57 @@ partitioned||* = true
 ; formatted as per
 ; https://www.freedesktop.org/software/systemd/man/sd-daemon.html
 ;
-;
 ; File Writer Options:
 ;
 ; The file writer will check every 30s to see if it needs
 ; to reopen its file. This is useful for people that configure
 ; logrotate to move log files periodically.
-;
-; file = ./couch.log ; Path name to write logs to
-;
+;file = ./couch.log ; Path name to write logs to
+
 ; Write operations will happen either every write_buffer bytes
 ; or write_delay milliseconds. These are passed directly to the
 ; Erlang file module with the write_delay option documented here:
 ;
 ;     http://erlang.org/doc/man/file.html
 ;
-; write_buffer = 0
-; write_delay = 0
-;
+;write_buffer = 0
+;write_delay = 0
 ;
 ; Syslog Writer Options:
 ;
 ; The syslog writer options all correspond to their obvious
 ; counter parts in rsyslog nomenclature.
-;
-; syslog_host =
-; syslog_port = 514
-; syslog_appid = couchdb
-; syslog_facility = local2
+;syslog_host =
+;syslog_port = 514
+;syslog_appid = couchdb
+;syslog_facility = local2
 
 [stats]
 ; Stats collection interval in seconds. Default 10 seconds.
 ;interval = 10
 
 [smoosh]
-;
 ; More documentation on these is in the Automatic Compaction
 ; section of the documentation.
-;
 ;db_channels = upgrade_dbs,ratio_dbs,slack_dbs
 ;view_channels = upgrade_views,ratio_views,slack_views
-;
+
 ;[smoosh.ratio_dbs]
 ;priority = ratio
 ;min_priority = 2.0
-;
+
 ;[smoosh.ratio_views]
 ;priority = ratio
 ;min_priority = 2.0
-;
+
 ;[smoosh.slack_dbs]
 ;priority = slack
 ;min_priority = 536870912
-;
+
 ;[smoosh.slack_views]
 ;priority = slack
 ;min_priority = 536870912
-;
+
 ; Directory to store the state of smoosh
 state_dir = {{state_dir}}
 
@@ -701,7 +740,7 @@ state_dir = {{state_dir}}
 ;compaction_log_level = debug
 
 ; Enable persistence for smoosh state
-; persist = false
+;persist = false
 
 [ioq]
 ; The maximum number of concurrent in-flight IO requests that
@@ -740,31 +779,31 @@ state_dir = {{state_dir}}
 [dreyfus]
 ; The name and location of the Clouseau Java service required to
 ; enable Search functionality.
-; name = clouseau@127.0.0.1
+;name = clouseau@127.0.0.1
 
 ; CouchDB will try to re-connect to Clouseau using a bounded
 ; exponential backoff with the following number of iterations.
-; retry_limit = 5
+;retry_limit = 5
 
 ; The default number of results returned from a global search query.
-; limit = 25
+;limit = 25
 
 ; The default number of results returned from a search on a partition
 ; of a database.
-; limit_partitions = 2000
- 
+;limit_partitions = 2000
+
 ; The maximum number of results that can be returned from a global
 ; search query (or any search query on a database without user-defined
 ; partitions). Attempts to set ?limit=N higher than this value will
 ; be rejected.
-; max_limit = 200
+;max_limit = 200
 
 ; The maximum number of results that can be returned when searching
 ; a partition of a database. Attempts to set ?limit=N higher than this
 ; value will be rejected. If this config setting is not defined,
 ; CouchDB will use the value of `max_limit` instead. If neither is
 ; defined, the default is 2000 as stated here.
-; max_limit_partitions = 2000
+;max_limit_partitions = 2000
 
 [reshard]
 ;max_jobs = 48
diff --git a/rel/overlay/etc/local.ini b/rel/overlay/etc/local.ini
index 17353a368..ba76ebfdf 100644
--- a/rel/overlay/etc/local.ini
+++ b/rel/overlay/etc/local.ini
@@ -14,9 +14,11 @@
 ; by the corresponding user. Databases are in the following form:
 ; userdb-{hex encoded username}
 ;enable = true
+
 ; If set to true and a user is deleted, the respective database gets
 ; deleted as well.
 ;delete_dbs = true
+
 ; Set a default q value for peruser-created databases that is different from
 ; cluster / q
 ;q = 1
@@ -24,8 +26,10 @@
 [chttpd]
 ;port = 5984
 ;bind_address = 127.0.0.1
+
 ; Options for the MochiWeb HTTP server.
 ;server_options = [{backlog, 128}, {acceptor_pool_size, 16}]
+
 ; For more socket options, consult Erlang's module 'inet' man page.
 ;socket_options = [{sndbuf, 262144}, {nodelay, true}]
 
@@ -48,26 +52,33 @@
 ;cert_file = /full/path/to/server_cert.pem
 ;key_file = /full/path/to/server_key.pem
 ;password = somepassword
+
 ; set to true to validate peer certificates
 ;verify_ssl_certificates = false
+
 ; Set to true to fail if the client does not send a certificate. Only used if verify_ssl_certificates is true.
 ;fail_if_no_peer_cert = false
+
 ; Path to file containing PEM encoded CA certificates (trusted
 ; certificates used for verifying a peer certificate). May be omitted if
 ; you do not want to verify the peer.
 ;cacert_file = /full/path/to/cacertf
+
 ; The verification fun (optional) if not specified, the default
 ; verification fun will be used.
 ;verify_fun = {Module, VerifyFun}
+
 ; maximum peer certificate depth
 ;ssl_certificate_max_depth = 1
-;
+
 ; Reject renegotiations that do not live up to RFC 5746.
 ;secure_renegotiate = true
+
 ; The cipher suites that should be supported.
 ; Can be specified in erlang format "{ecdhe_ecdsa,aes_128_cbc,sha256}"
 ; or in OpenSSL format "ECDHE-ECDSA-AES128-SHA256".
 ;ciphers = ["ECDHE-ECDSA-AES128-SHA256", "ECDHE-ECDSA-AES128-SHA"]
+
 ; The SSL/TLS versions to support
 ;tls_versions = [tlsv1, 'tlsv1.1', 'tlsv1.2']