|
189 | 189 | %% =====================================================
|
190 | 190 | %%
|
191 | 191 |
|
192 |
| - %% Set the default AMQP heartbeat delay (in seconds). |
| 192 | + %% Sets the default AMQP 0-9-1 heartbeat timeout in seconds. |
| 193 | + %% Values lower than 6 can produce false positives and are not |
| 194 | + %% recommended. |
| 195 | + %% See http://www.rabbitmq.com/heartbeats.html. |
193 | 196 | %%
|
194 | 197 | %% {heartbeat, 60},
|
195 | 198 |
|
|
207 | 210 | %%
|
208 | 211 | %% {channel_max, 0},
|
209 | 212 |
|
210 |
| - %% Customising Socket Options. |
| 213 | + %% TCP socket options. |
211 | 214 | %%
|
212 |
| - %% See (http://www.erlang.org/doc/man/inet.html#setopts-2) for |
213 |
| - %% further documentation. |
| 215 | + %% See http://www.rabbitmq.com/networking.html. |
214 | 216 | %%
|
215 | 217 | %% {tcp_listen_options, [{backlog, 128},
|
216 | 218 | %% {nodelay, true},
|
|
305 | 307 | %%
|
306 | 308 | %% {queue_master_locator, <<"client-local">>},
|
307 | 309 |
|
308 |
| - %% Batch size of messages to synchronise between queue mirrors |
309 |
| - %% See https://www.rabbitmq.com/ha.html#batch-sync |
| 310 | + %% Batch size (number of messages) used during eager queue mirror synchronisation. |
| 311 | + %% See https://www.rabbitmq.com/ha.html#batch-sync. When average message size is relatively large |
| 312 | + %% (say, 10s of kilobytes or greater), reducing this value will decrease peak amount |
| 313 | + %% of RAM used by newly joining nodes that need eager synchronisation. |
310 | 314 | %%
|
311 | 315 | %% {mirroring_sync_batch_size, 4096},
|
312 | 316 |
|
313 |
| - %% Controls flow control between queue mirrors |
314 |
| - %% Be careful with this configuration. |
315 |
| - %% It's dangerous for masters to outpace mirrors and not allow mirrors to catch up. |
316 |
| - %% Mirrors will end up using more and more RAM, |
317 |
| - %% until they will eventually trigger the memory alarm and block publishers. |
318 |
| - %% https://github.com/rabbitmq/rabbitmq-server/pull/133 |
| 317 | + %% Enables flow control between queue mirrors. |
| 318 | + %% Disabling this can be dangerous and is not recommended. |
| 319 | + %% When flow control is disablied, queue masters can outpace mirrors and not allow mirrors to catch up. |
| 320 | + %% Mirrors will end up using increasingly more RAM, eventually triggering a memory alarm. |
319 | 321 | %%
|
320 | 322 | %% {mirroring_flow_control, true},
|
321 | 323 |
|
322 |
| - %% To announce custom properties to clients on connection: |
| 324 | + %% Additional server properties to announce to connecting clients. |
323 | 325 | %%
|
324 | 326 | %% {server_properties, []},
|
325 | 327 |
|
|
358 | 360 | %% {hipe_compile, false},
|
359 | 361 |
|
360 | 362 | %% Number of delegate processes to use for intra-cluster communication.
|
361 |
| - %% On a node which is part of cluster, has 16 cores and plenty of network bandwidth, |
362 |
| - %% you may wish to increase this value. |
| 363 | + %% On a node which is part of cluster, has more than 16 cores and plenty of network bandwidth, |
| 364 | + %% it may make sense to increase this value. |
363 | 365 | %%
|
364 | 366 | %% {delegate_count, 16},
|
365 | 367 |
|
366 |
| - %% Number of times to retry while waiting for Mnesia tables in a cluster to |
367 |
| - %% become available. |
| 368 | + %% Number of times to retry while waiting for internal database tables (Mnesia tables) to sync |
| 369 | + %% from a peer. In deployments where nodes can take a long time to boot, this value |
| 370 | + %% may need increasing. |
368 | 371 | %%
|
369 | 372 | %% {mnesia_table_loading_retry_limit, 10},
|
370 | 373 |
|
371 |
| - %% Time to wait per retry for Mnesia tables in a cluster to become |
372 |
| - %% available. |
| 374 | + %% Amount of time in milliseconds which this node will wait for internal database tables (Mnesia tables) to sync |
| 375 | + %% from a peer. In deployments where nodes can take a long time to boot, this value |
| 376 | + %% may need increasing. |
373 | 377 | %%
|
374 | 378 | %% {mnesia_table_loading_retry_timeout, 30000},
|
375 | 379 |
|
|
379 | 383 | %% {queue_index_embed_msgs_below, 4096},
|
380 | 384 |
|
381 | 385 | %% Maximum number of queue index entries to keep in journal
|
382 |
| - %% See http://www.rabbitmq.com/persistence-conf.html |
| 386 | + %% See http://www.rabbitmq.com/persistence-conf.html. |
383 | 387 | %%
|
384 | 388 | %% {queue_index_max_journal_entries, 32768},
|
385 | 389 |
|
|
397 | 401 | %%
|
398 | 402 | %% {msg_store_io_batch_size, 4096},
|
399 | 403 |
|
400 |
| - %% Number of credits that a connection, channel or queue are given |
| 404 | + %% Number of credits that a connection, channel or queue are given. |
| 405 | + %% |
401 | 406 | %% By default, every connection, channel or queue is given 400 credits,
|
402 |
| - %% and then 200 for every 200 messages that it processes. |
403 |
| - %% Increasing these values may help with throughput, but they can also be dangerous: |
404 |
| - %% very high credit flow values are no different from not having flow control. |
| 407 | + %% and then 200 for every 200 messages that it sends to a peer process. |
| 408 | + %% Increasing these values may help with throughput but also can be dangerous: |
| 409 | + %% high credit flow values are no different from not having flow control at all. |
| 410 | + %% |
405 | 411 | %% See https://www.rabbitmq.com/blog/2015/10/06/new-credit-flow-settings-on-rabbitmq-3-5-5/
|
| 412 | + %% and http://alvaro-videla.com/2013/09/rabbitmq-internals-credit-flow-for-erlang-processes.html. |
406 | 413 | %%
|
407 | 414 | %% {credit_flow_default_credit, {400, 200}},
|
408 | 415 |
|
409 |
| - %% Number of milliseconds before a channel operation times out |
| 416 | + %% Number of milliseconds before a channel operation times out. |
410 | 417 | %%
|
411 | 418 | %% {channel_operation_timeout, 15000},
|
412 | 419 |
|
413 |
| - %% Number of queue operations required to trigger an explicit garbage collection |
| 420 | + %% Number of queue operations required to trigger an explicit garbage collection. |
| 421 | + %% Increasing this value may reduce CPU load and increase peak RAM consumption of queues. |
414 | 422 | %%
|
415 | 423 | %% {queue_explicit_gc_run_operation_threshold, 1000},
|
416 | 424 |
|
417 |
| - %% Number of lazy queue operations required to trigger an explicit garbage collection |
| 425 | + %% Number of lazy queue operations required to trigger an explicit garbage collection. |
| 426 | + %% Increasing this value may reduce CPU load and increase peak RAM consumption of lazy queues. |
418 | 427 | %%
|
419 | 428 | %% {lazy_queue_explicit_gc_run_operation_threshold, 1000},
|
420 | 429 |
|
421 |
| - %% Number of times to retry querying disk space usage |
| 430 | + %% Number of times disk monitor will retry free disk space queries before |
| 431 | + %% giving up. |
422 | 432 | %%
|
423 | 433 | %% {disk_monitor_failure_retries, 10},
|
424 | 434 |
|
425 |
| - %% Milliseconds to wait before retrying to query disk space usage |
| 435 | + %% Milliseconds to wait between disk monitor retries on failures. |
426 | 436 | %%
|
427 | 437 | %% {disk_monitor_failure_retry_interval, 120000},
|
428 | 438 |
|
|
441 | 451 | %%
|
442 | 452 | %% {msg_store_file_size_limit, 16777216},
|
443 | 453 |
|
444 |
| - %% Whether or not to enable write file handle cache buffering |
| 454 | + %% Whether or not to enable file write buffering. |
445 | 455 | %%
|
446 | 456 | %% {fhc_write_buffering, true},
|
447 | 457 |
|
448 |
| - %% Whether or not to enable read file handle cache buffering |
| 458 | + %% Whether or not to enable file read buffering. Enabling |
| 459 | + %% this may slightly speed up reads but will also increase |
| 460 | + %% node's memory consumption, in particular on boot. |
449 | 461 | %%
|
450 | 462 | %% {fhc_read_buffering, false}
|
451 | 463 |
|
|
662 | 674 | %%
|
663 | 675 | %% {prefetch, 10},
|
664 | 676 |
|
665 |
| - %% TCP/SSL Configuration (as per the broker configuration). |
| 677 | + %% TLS listeners. |
| 678 | + %% See http://www.rabbitmq.com/networking.html |
666 | 679 | %%
|
667 | 680 | %% {tcp_listeners, [1883]},
|
668 | 681 | %% {ssl_listeners, []},
|
669 | 682 |
|
670 | 683 | %% Number of Erlang processes that will accept connections for the TCP
|
671 |
| - %% and SSL listeners. |
| 684 | + %% and TLS listeners. |
| 685 | + %% See http://www.rabbitmq.com/networking.html |
672 | 686 | %%
|
673 | 687 | %% {num_tcp_acceptors, 10},
|
674 | 688 | %% {num_ssl_acceptors, 1},
|
675 | 689 |
|
676 |
| - %% TCP/Socket options (as per the broker configuration). |
| 690 | + %% TCP socket options. |
677 | 691 | %% See http://www.rabbitmq.com/networking.html
|
678 | 692 | %%
|
679 | 693 | %% {tcp_listen_options, [
|
|
0 commit comments