You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by db...@apache.org on 2020/10/01 18:50:02 UTC

[geode-site] branch asf-site updated: Update User Guides for Geode 1.12 and 1.13 to pick up fixes for compaction-threshold and other topics.

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

dbarnes pushed a commit to branch asf-site
in repository https://gitbox.apache.org/repos/asf/geode-site.git


The following commit(s) were added to refs/heads/asf-site by this push:
     new 1b79104  Update User Guides for Geode 1.12 and 1.13 to pick up fixes for compaction-threshold and other topics.
1b79104 is described below

commit 1b791047660f57b9bf5763ba9be20b8eab85163a
Author: Dave Barnes <db...@apache.org>
AuthorDate: Thu Oct 1 11:49:43 2020 -0700

    Update User Guides for Geode 1.12 and 1.13 to pick up fixes for compaction-threshold and other topics.
---
 docs/guide/112/about_geode.html                    |    3 -
 docs/guide/112/basic_config/book_intro.html        |    3 -
 .../config_concepts/chapter_overview.html          |    3 -
 .../distributed_system_member_configuration.html   |    3 -
 .../config_concepts/local_vs_remote.html           |    3 -
 .../chapter_overview.html                          |    3 -
 .../managing_data_entries.html                     |    3 -
 .../using_custom_classes.html                      |    3 -
 .../data_regions/chapter_overview.html             |    3 -
 .../data_regions/creating_custom_attributes.html   |    3 -
 .../data_regions/managing_data_regions.html        |    3 -
 .../data_regions/managing_region_attributes.html   |    3 -
 .../data_regions/new_region_existing_data.html     |    3 -
 .../basic_config/data_regions/region_naming.html   |    3 -
 .../data_regions/region_shortcuts.html             |    3 -
 .../store_retrieve_region_shortcuts.html           |    3 -
 .../setting_distributed_properties.html            |    3 -
 .../basic_config/the_cache/chapter_overview.html   |    3 -
 .../the_cache/intro_cache_management.html          |    3 -
 .../the_cache/managing_a_client_cache.html         |    3 -
 .../the_cache/managing_a_multiuser_cache.html      |    3 -
 .../the_cache/managing_a_peer_server_cache.html    |    3 -
 .../the_cache/managing_a_secure_cache.html         |    3 -
 .../the_cache/setting_cache_initializer.html       |    3 -
 .../the_cache/setting_cache_properties.html        |    3 -
 docs/guide/112/configuring/chapter_overview.html   |    3 -
 .../cluster_config/deploying_application_jars.html |    3 -
 .../configuring/cluster_config/export-import.html  |    3 -
 .../gfsh_config_troubleshooting.html               |    3 -
 .../configuring/cluster_config/gfsh_persist.html   |    3 -
 .../configuring/cluster_config/gfsh_remote.html    |    3 -
 .../cluster_config/persisting_configurations.html  |    3 -
 .../cluster_config/using_member_groups.html        |    3 -
 .../112/configuring/running/change_file_spec.html  |    3 -
 .../running/cluster-management-service.html        |    3 -
 .../configuring/running/default_file_specs.html    |    3 -
 .../running/deploy_config_files_intro.html         |    3 -
 .../running/deploying_config_files.html            |    3 -
 .../running/deploying_config_jar_files.html        |    3 -
 .../configuring/running/firewall_ports_config.html |    3 -
 .../configuring/running/firewalls_connections.html |    3 -
 .../112/configuring/running/firewalls_ports.html   |    3 -
 .../configuring/running/managing_output_files.html |    3 -
 .../running/running_the_cacheserver.html           |    3 -
 .../configuring/running/running_the_locator.html   |    3 -
 .../running/starting_up_shutting_down.html         |    5 +-
 docs/guide/112/developing/book_intro.html          |    3 -
 .../continuous_querying/chapter_overview.html      |    3 -
 .../continuous_querying_whats_next.html            |    3 -
 .../how_continuous_querying_works.html             |    3 -
 .../implementing_continuous_querying.html          |    3 -
 .../PDX_Serialization_Features.html                |    3 -
 .../data_serialization/auto_serialization.html     |    3 -
 ...toserialization_with_class_pattern_strings.html |    3 -
 .../data_serialization/chapter_overview.html       |    3 -
 .../data_serialization_options.html                |    3 -
 .../extending_the_autoserializer.html              |    3 -
 .../gemfire_data_serialization.html                |    3 -
 .../gemfire_pdx_serialization.html                 |    3 -
 .../data_serialization/java_serialization.html     |    3 -
 .../jsonformatter_pdxinstances.html                |    3 -
 .../persist_pdx_metadata_to_disk.html              |    3 -
 .../program_application_for_pdx.html               |    3 -
 .../use_pdx_high_level_steps.html                  |    3 -
 .../data_serialization/use_pdx_serializable.html   |    3 -
 .../data_serialization/use_pdx_serializer.html     |    3 -
 .../using_PdxInstanceFactory.html                  |    3 -
 .../using_pdx_region_entry_keys.html               |    3 -
 .../delta_propagation/chapter_overview.html        |    3 -
 .../delta_propagation_example.html                 |    3 -
 .../delta_propagation_properties.html              |    3 -
 .../errors_in_delta_propagation.html               |    3 -
 .../how_delta_propagation_works.html               |    3 -
 .../implementing_delta_propagation.html            |    3 -
 .../delta_propagation/when_to_use_delta_prop.html  |    3 -
 .../distributed_regions/chapter_overview.html      |    3 -
 .../choosing_level_of_dist.html                    |    3 -
 .../how_distribution_works.html                    |    3 -
 .../how_region_versioning_works.html               |    3 -
 .../how_region_versioning_works_wan.html           |    3 -
 .../distributed_regions/how_replication_works.html |    3 -
 .../locking_in_global_regions.html                 |    3 -
 .../managing_distributed_regions.html              |    3 -
 .../distributed_regions/region_entry_versions.html |    3 -
 .../events/cache_event_handler_examples.html       |    3 -
 .../112/developing/events/chapter_overview.html    |    3 -
 .../configure_client_server_event_messaging.html   |    3 -
 .../configure_multisite_event_messaging.html       |    3 -
 .../events/configure_p2p_event_messaging.html      |    3 -
 .../configuring_gateway_concurrency_levels.html    |    3 -
 ...onfiguring_highly_available_gateway_queues.html |    3 -
 .../configuring_highly_available_servers.html      |    3 -
 .../events/conflate_multisite_gateway_queue.html   |    3 -
 .../events/conflate_server_subscription_queue.html |    3 -
 .../developing/events/event_handler_overview.html  |    3 -
 .../events/filtering_multisite_events.html         |    3 -
 .../events/ha_event_messaging_whats_next.html      |    3 -
 .../developing/events/how_cache_events_work.html   |    3 -
 .../how_client_server_distribution_works.html      |    3 -
 .../112/developing/events/how_events_work.html     |    3 -
 .../events/how_multisite_distribution_works.html   |    3 -
 .../events/implementing_cache_event_handlers.html  |    3 -
 ...plementing_durable_client_server_messaging.html |    3 -
 .../implementing_write_behind_event_handler.html   |    3 -
 .../limit_server_subscription_queue_size.html      |    3 -
 .../events/list_of_event_handlers_and_events.html  |    3 -
 .../events/resolving_multisite_conflicts.html      |    3 -
 .../tune_client_message_tracking_timeout.html      |    3 -
 .../events/tune_client_server_event_messaging.html |    3 -
 .../writing_callbacks_that_modify_the_cache.html   |    3 -
 .../112/developing/eviction/chapter_overview.html  |    3 -
 .../eviction/configuring_data_eviction.html        |    3 -
 .../developing/eviction/how_eviction_works.html    |    3 -
 .../developing/expiration/chapter_overview.html    |    3 -
 .../expiration/configuring_data_expiration.html    |    3 -
 .../expiration/how_expiration_works.html           |    3 -
 .../developing/function_exec/chapter_overview.html |    3 -
 .../function_exec/function_execution.html          |    3 -
 .../how_function_execution_works.html              |    3 -
 .../developing/general_region_data_management.html |    3 -
 .../outside_data_sources/chapter_overview.html     |    3 -
 .../configuring_db_connections_using_JNDI.html     |    3 -
 .../how_data_loaders_work.html                     |    3 -
 .../implementing_data_loaders.html                 |    3 -
 .../outside_data_sources/sync_outside_data.html    |    3 -
 .../partitioned_regions/automated_rebalance.html   |    3 -
 .../partitioned_regions/chapter_overview.html      |    3 -
 .../checking_region_redundancy.html                |    3 -
 .../colocating_partitioned_region_data.html        |    3 -
 .../configure_pr_single_hop.html                   |    3 -
 .../configuring_bucket_for_pr.html                 |    3 -
 .../partitioned_regions/configuring_ha_for_pr.html |    3 -
 .../custom_partitioning_and_data_colocation.html   |    3 -
 .../fixed_custom_partitioning.html                 |    3 -
 .../how_partitioning_works.html                    |    3 -
 .../partitioned_regions/how_pr_ha_works.html       |    3 -
 .../how_pr_single_hop_works.html                   |    3 -
 .../join_query_partitioned_regions.html            |    3 -
 .../managing_partitioned_regions.html              |    3 -
 .../moving_partitioned_data.html                   |    3 -
 ...ew_custom_partitioning_and_data_colocation.html |    3 -
 .../overview_how_pr_ha_works.html                  |    3 -
 .../overview_how_pr_single_hop_works.html          |    3 -
 .../partitioned_regions/rebalancing_pr_data.html   |    3 -
 .../set_crash_redundancy_recovery.html             |    3 -
 .../set_enforce_unique_host.html                   |    3 -
 .../set_join_redundancy_recovery.html              |    3 -
 .../partitioned_regions/set_pr_redundancy.html     |    3 -
 .../partitioned_regions/set_redundancy_zones.html  |    3 -
 .../standard_custom_partitioning.html              |    3 -
 .../using_custom_partition_resolvers.html          |    3 -
 .../query_additional/advanced_querying.html        |    3 -
 .../query_additional/case_sensitivity.html         |    3 -
 .../112/developing/query_additional/literals.html  |    3 -
 .../112/developing/query_additional/operators.html |    3 -
 .../order_by_on_partitioned_regions.html           |    3 -
 .../partitioned_region_key_or_field_value.html     |    3 -
 .../partitioned_region_query_restrictions.html     |    3 -
 .../query_additional/query_debugging.html          |    3 -
 .../query_additional/query_language_features.html  |    3 -
 .../query_additional/query_on_a_single_node.html   |    3 -
 .../developing/query_additional/query_timeout.html |    3 -
 .../query_additional/supported_keywords.html       |    3 -
 .../using_query_bind_parameters.html               |    3 -
 .../query_index/create_multiple_indexes.html       |    3 -
 .../developing/query_index/creating_an_index.html  |    3 -
 .../query_index/creating_hash_indexes.html         |    3 -
 .../query_index/creating_key_indexes.html          |    3 -
 .../query_index/creating_map_indexes.html          |    3 -
 .../112/developing/query_index/index_samples.html  |    3 -
 .../indexes_on_single_region_queries.html          |    3 -
 .../query_index/indexes_with_overflow_regions.html |    3 -
 .../query_index/indexing_guidelines.html           |    3 -
 .../query_index/maintaining_indexes.html           |    3 -
 .../112/developing/query_index/query_index.html    |    3 -
 .../developing/query_index/query_index_hints.html  |    3 -
 .../using_indexes_with_equijoin_queries.html       |    3 -
 ...xes_with_equijoin_queries_multiple_regions.html |    3 -
 .../112/developing/query_select/aggregates.html    |    3 -
 .../developing/query_select/the_from_clause.html   |    3 -
 .../query_select/the_import_statement.html         |    3 -
 .../query_select/the_select_statement.html         |    3 -
 .../developing/query_select/the_where_clause.html  |    3 -
 .../querying_basics/chapter_overview.html          |    3 -
 .../querying_basics/comments_in_query_strings.html |    3 -
 .../monitor_queries_for_low_memory.html            |    3 -
 .../querying_basics/oql_compared_to_sql.html       |    3 -
 .../performance_considerations.html                |    3 -
 .../developing/querying_basics/query_basics.html   |    3 -
 .../query_grammar_and_reserved_words.html          |    3 -
 .../querying_partitioned_regions.html              |    3 -
 .../developing/querying_basics/reserved_words.html |    3 -
 .../restrictions_and_unsupported_features.html     |    3 -
 .../querying_basics/running_a_query.html           |    3 -
 .../querying_basics/supported_character_sets.html  |    3 -
 .../querying_basics/what_is_a_query_string.html    |    3 -
 .../region_options/chapter_overview.html           |    3 -
 .../region_options/data_hosts_and_accessors.html   |    3 -
 .../region_options/dynamic_region_creation.html    |    3 -
 .../developing/region_options/region_types.html    |    3 -
 .../storage_distribution_options.html              |    3 -
 .../storing_data_on_disk/chapter_overview.html     |    3 -
 .../how_persist_overflow_work.html                 |    3 -
 .../overflow_config_examples.html                  |    3 -
 .../storing_data_on_disk/storing_data_on_disk.html |    3 -
 .../developing/transactions/chapter_overview.html  |    3 -
 .../transactions/design_considerations.html        |    3 -
 .../developing/transactions/directed_example.html  |    3 -
 .../transactions/transactions_intro.html           |    3 -
 .../getting_started/15_minute_quickstart_gfsh.html |    3 -
 docs/guide/112/getting_started/book_intro.html     |    3 -
 docs/guide/112/getting_started/geode_overview.html |    3 -
 .../installation/install_standalone.html           |    3 -
 docs/guide/112/getting_started/product_intro.html  |    3 -
 .../getting_started/querying_quick_reference.html  |    3 -
 .../guide/112/getting_started/setup_classpath.html |    3 -
 .../system_requirements/host_machine.html          |    3 -
 .../guide/112/getting_started/uninstall_geode.html |    3 -
 docs/guide/112/managing/book_intro.html            |    3 -
 .../managing/cache_snapshots/chapter_overview.html |    3 -
 .../cache_snapshots/exporting_a_snapshot.html      |    3 -
 .../filtering_snapshot_entries.html                |    3 -
 .../cache_snapshots/importing_a_snapshot.html      |    3 -
 .../read_snapshots_programmatically.html           |    3 -
 .../using_cache_and_region_snapshots.html          |    3 -
 .../disk_storage/backup_restore_disk_store.html    |    3 -
 .../managing/disk_storage/chapter_overview.html    |    3 -
 .../disk_storage/compacting_disk_stores.html       |   25 +-
 .../disk_storage/disk_free_space_monitoring.html   |    3 -
 .../disk_store_configuration_params.html           |   10 +-
 .../disk_storage/file_names_and_extensions.html    |    3 -
 .../disk_storage/handling_missing_disk_stores.html |    3 -
 .../disk_storage/how_disk_stores_work.html         |    3 -
 .../keeping_offline_disk_store_in_sync.html        |    3 -
 .../disk_storage/managing_disk_buffer_flushes.html |    3 -
 .../disk_storage/managing_disk_stores.html         |    3 -
 .../disk_storage/managing_disk_stores_cmds.html    |    3 -
 .../112/managing/disk_storage/operation_logs.html  |    3 -
 .../optimize_availability_and_performance.html     |    3 -
 .../disk_storage/overview_using_disk_stores.html   |    3 -
 .../starting_system_with_disk_stores.html          |    3 -
 .../managing/disk_storage/using_disk_stores.html   |    9 +-
 .../disk_storage/using_the_default_disk_store.html |    3 -
 .../disk_storage/validating_disk_store.html        |    3 -
 .../heap_use/heap_and_off_heap_management.html     |    3 -
 .../112/managing/heap_use/heap_management.html     |    3 -
 docs/guide/112/managing/heap_use/lock_memory.html  |    3 -
 .../112/managing/heap_use/off_heap_management.html |    3 -
 .../112/managing/logging/configuring_log4j2.html   |    3 -
 .../112/managing/logging/how_logging_works.html    |    3 -
 docs/guide/112/managing/logging/logging.html       |    3 -
 .../112/managing/logging/logging_categories.html   |    3 -
 .../112/managing/logging/logging_whats_next.html   |    3 -
 .../112/managing/logging/setting_up_logging.html   |    3 -
 .../management/configuring_rmi_connector.html      |    3 -
 .../management/gfsh_and_management_api.html        |    3 -
 .../112/managing/management/jmx_manager_node.html  |    5 +-
 .../management/jmx_manager_operations.html         |    3 -
 .../management/list_of_mbean_notifications.html    |    3 -
 .../112/managing/management/list_of_mbeans.html    |    3 -
 .../managing/management/list_of_mbeans_full.html   |    3 -
 .../management/management_and_monitoring.html      |    3 -
 .../management_and_monitoring_features.html        |    3 -
 .../management/management_system_overview.html     |    3 -
 .../managing/management/mbean_architecture.html    |    3 -
 .../managing/management/mbean_notifications.html   |    3 -
 .../112/managing/management/mbeans_jconsole.html   |    3 -
 .../guide/112/managing/management/mm_overview.html |    3 -
 .../notification_federation_and_alerts.html        |    3 -
 docs/guide/112/managing/member-reconnect.html      |    3 -
 .../managing/monitor_tune/cache_consistency.html   |    3 -
 .../managing/monitor_tune/chapter_overview.html    |    3 -
 .../monitor_tune/disabling_tcp_syn_cookies.html    |    3 -
 .../monitor_tune/multicast_communication.html      |    3 -
 ...ast_communication_configuring_speed_limits.html |    3 -
 ...icast_communication_provisioning_bandwidth.html |    3 -
 ...icast_communication_runtime_considerations.html |    3 -
 ...mmunication_testing_multicast_speed_limits.html |    3 -
 .../multicast_communication_troubleshooting.html   |    3 -
 .../monitor_tune/performance_controls.html         |    3 -
 ...erformance_controls_controlling_socket_use.html |    3 -
 .../performance_controls_data_serialization.html   |    3 -
 ...performance_controls_increasing_cache_hits.html |    3 -
 ...rformance_controls_managing_slow_receivers.html |    3 -
 ...erformance_controls_setting_cache_timeouts.html |    3 -
 .../monitor_tune/performance_on_vsphere.html       |    3 -
 .../112/managing/monitor_tune/slow_messages.html   |    3 -
 .../112/managing/monitor_tune/slow_receivers.html  |    3 -
 .../monitor_tune/slow_receivers_managing.html      |    3 -
 .../slow_receivers_preventing_problems.html        |    3 -
 .../monitor_tune/socket_communication.html         |    3 -
 ...et_communication_ephemeral_tcp_port_limits.html |    3 -
 .../socket_communication_have_enough_sockets.html  |    3 -
 ..._communication_setting_socket_buffer_sizes.html |    3 -
 ...communication_tcpip_p2p_handshake_timeouts.html |    3 -
 .../monitor_tune/socket_tcp_keepalive.html         |    3 -
 .../monitor_tune/sockets_and_gateways.html         |    3 -
 .../monitor_tune/system_member_performance.html    |    6 -
 ...ber_performance_connection_thread_settings.html | 2677 --------------------
 ...mber_performance_distributed_system_member.html |    3 -
 .../system_member_performance_garbage.html         |    3 -
 ...system_member_performance_jvm_mem_settings.html |    3 -
 .../managing/monitor_tune/udp_communication.html   |    3 -
 .../network_partitioning/chapter_overview.html     |    3 -
 .../network_partitioning/failure_detection.html    |    3 -
 .../handling_network_partitioning.html             |    3 -
 .../how_network_partitioning_management_works.html |    3 -
 ...ip_coordinators_lead_members_and_weighting.html |    3 -
 .../network_partitioning_scenarios.html            |    3 -
 .../preventing_network_partitions.html             |    3 -
 docs/guide/112/managing/region_compression.html    |    3 -
 .../managing/security/authentication_examples.html |    3 -
 .../managing/security/authentication_overview.html |    3 -
 .../managing/security/authorization_example.html   |    3 -
 .../managing/security/authorization_overview.html  |    3 -
 .../112/managing/security/chapter_overview.html    |    3 -
 .../112/managing/security/enable_security.html     |    3 -
 .../security/implementing_authentication.html      |    3 -
 .../security/implementing_authorization.html       |    3 -
 .../managing/security/implementing_security.html   |    3 -
 .../112/managing/security/implementing_ssl.html    |    3 -
 .../security/method_invocation_authorizers.html    |    3 -
 .../112/managing/security/post_processing.html     |    3 -
 .../112/managing/security/properties_file.html     |    3 -
 .../112/managing/security/security-audit.html      |    3 -
 .../managing/security/security_audit_overview.html |    3 -
 docs/guide/112/managing/security/ssl_example.html  |    3 -
 docs/guide/112/managing/security/ssl_overview.html |    3 -
 .../statistics/application_defined_statistics.html |    3 -
 .../112/managing/statistics/chapter_overview.html  |    3 -
 .../managing/statistics/how_statistics_work.html   |    3 -
 .../managing/statistics/setting_up_statistics.html |    3 -
 .../transient_region_and_entry_statistics.html     |    3 -
 .../managing/statistics/viewing_statistics.html    |    3 -
 .../managing/troubleshooting/chapter_overview.html |    3 -
 .../troubleshooting/diagnosing_system_probs.html   |    3 -
 .../prevent_and_recover_disk_full_errors.html      |    3 -
 .../producing_troubleshooting_artifacts.html       |    3 -
 .../recovering_conflicting_data_exceptions.html    |    3 -
 .../recovering_from_app_crashes.html               |    3 -
 .../recovering_from_cs_crashes.html                |    3 -
 .../recovering_from_machine_crashes.html           |    3 -
 .../recovering_from_network_outages.html           |    3 -
 .../recovering_from_p2p_crashes.html               |    3 -
 .../system_failure_and_recovery.html               |    3 -
 docs/guide/112/prereq_and_install.html             |    3 -
 .../archive_transactions/JTA_transactions.html     |    3 -
 .../cache_plugins_with_jta.html                    |    3 -
 .../archive_transactions/chapter_overview.html     |    3 -
 .../archive_transactions/turning_off_jta.html      |    3 -
 docs/guide/112/reference/book_intro.html           |    3 -
 docs/guide/112/reference/statistics_list.html      |    3 -
 .../112/reference/topics/cache-elements-list.html  |    3 -
 docs/guide/112/reference/topics/cache_xml.html     |    3 -
 .../topics/chapter_overview_cache_xml.html         |    3 -
 .../topics/chapter_overview_regionshortcuts.html   |    3 -
 .../topics/client-cache-elements-list.html         |    3 -
 docs/guide/112/reference/topics/client-cache.html  |    3 -
 docs/guide/112/reference/topics/elements_ref.html  |    3 -
 .../112/reference/topics/gemfire_properties.html   |    3 -
 docs/guide/112/reference/topics/glossary.html      |    3 -
 .../topics/handling_exceptions_and_failures.html   |    3 -
 .../topics/memory_requirements_for_cache_data.html |    3 -
 .../topics/non-ascii_strings_in_config_files.html  |    3 -
 .../topics/region_shortcuts_reference.html         |    3 -
 .../reference/topics/region_shortcuts_table.html   |    3 -
 docs/guide/112/rest_apps/book_intro.html           |    3 -
 docs/guide/112/rest_apps/chapter_overview.html     |    3 -
 docs/guide/112/rest_apps/delete_all_data.html      |    3 -
 docs/guide/112/rest_apps/delete_data_for_key.html  |    3 -
 .../rest_apps/delete_data_for_multiple_keys.html   |    3 -
 docs/guide/112/rest_apps/delete_named_query.html   |    3 -
 docs/guide/112/rest_apps/develop_rest_apps.html    |    3 -
 .../112/rest_apps/get_execute_adhoc_query.html     |    3 -
 docs/guide/112/rest_apps/get_functions.html        |    3 -
 docs/guide/112/rest_apps/get_queries.html          |    3 -
 docs/guide/112/rest_apps/get_region_data.html      |    3 -
 .../get_region_data_for_multiple_keys.html         |    3 -
 docs/guide/112/rest_apps/get_region_key_data.html  |    3 -
 docs/guide/112/rest_apps/get_region_keys.html      |    3 -
 docs/guide/112/rest_apps/get_regions.html          |    3 -
 docs/guide/112/rest_apps/get_servers.html          |    3 -
 docs/guide/112/rest_apps/head_region_size.html     |    3 -
 docs/guide/112/rest_apps/ping_service.html         |    3 -
 docs/guide/112/rest_apps/post_create_query.html    |    3 -
 .../112/rest_apps/post_execute_functions.html      |    3 -
 docs/guide/112/rest_apps/post_execute_query.html   |    3 -
 docs/guide/112/rest_apps/post_if_absent_data.html  |    3 -
 .../rest_apps/put_multiple_values_for_keys.html    |    3 -
 docs/guide/112/rest_apps/put_replace_data.html     |    3 -
 docs/guide/112/rest_apps/put_update_cas_data.html  |    3 -
 docs/guide/112/rest_apps/put_update_data.html      |    3 -
 docs/guide/112/rest_apps/put_update_query.html     |    3 -
 docs/guide/112/rest_apps/rest_admin.html           |    3 -
 docs/guide/112/rest_apps/rest_api_reference.html   |    3 -
 docs/guide/112/rest_apps/rest_examples.html        |    3 -
 docs/guide/112/rest_apps/rest_functions.html       |    3 -
 docs/guide/112/rest_apps/rest_prereqs.html         |    3 -
 docs/guide/112/rest_apps/rest_queries.html         |    3 -
 docs/guide/112/rest_apps/rest_regions.html         |    3 -
 docs/guide/112/rest_apps/setup_config.html         |    3 -
 docs/guide/112/rest_apps/troubleshooting.html      |    3 -
 docs/guide/112/rest_apps/using_swagger.html        |    3 -
 docs/guide/112/tools_modules/book_intro.html       |    3 -
 .../tools_modules/gemcached/about_gemcached.html   |    3 -
 .../112/tools_modules/gemcached/advantages.html    |    3 -
 .../tools_modules/gemcached/chapter_overview.html  |    3 -
 .../gemcached/deploying_gemcached.html             |    3 -
 docs/guide/112/tools_modules/gfsh/about_gfsh.html  |    3 -
 .../112/tools_modules/gfsh/cache_xml_2_gfsh.html   |    3 -
 .../112/tools_modules/gfsh/chapter_overview.html   |    3 -
 .../tools_modules/gfsh/command-pages/alter.html    |    3 -
 .../tools_modules/gfsh/command-pages/backup.html   |    3 -
 .../tools_modules/gfsh/command-pages/change.html   |    3 -
 .../tools_modules/gfsh/command-pages/clear.html    |    3 -
 .../tools_modules/gfsh/command-pages/close.html    |    3 -
 .../tools_modules/gfsh/command-pages/compact.html  |   15 +-
 .../gfsh/command-pages/configure.html              |    3 -
 .../tools_modules/gfsh/command-pages/connect.html  |    3 -
 .../tools_modules/gfsh/command-pages/create.html   |    5 +-
 .../tools_modules/gfsh/command-pages/debug.html    |    3 -
 .../tools_modules/gfsh/command-pages/define.html   |    3 -
 .../tools_modules/gfsh/command-pages/deploy.html   |    3 -
 .../tools_modules/gfsh/command-pages/describe.html |    3 -
 .../tools_modules/gfsh/command-pages/destroy.html  |    3 -
 .../gfsh/command-pages/disconnect.html             |    3 -
 .../112/tools_modules/gfsh/command-pages/echo.html |    3 -
 .../tools_modules/gfsh/command-pages/execute.html  |    3 -
 .../112/tools_modules/gfsh/command-pages/exit.html |    3 -
 .../tools_modules/gfsh/command-pages/export.html   |    3 -
 .../112/tools_modules/gfsh/command-pages/gc.html   |    7 +-
 .../112/tools_modules/gfsh/command-pages/get.html  |    3 -
 .../112/tools_modules/gfsh/command-pages/help.html |    3 -
 .../112/tools_modules/gfsh/command-pages/hint.html |    3 -
 .../tools_modules/gfsh/command-pages/history.html  |    3 -
 .../tools_modules/gfsh/command-pages/import.html   |    3 -
 .../112/tools_modules/gfsh/command-pages/list.html |    3 -
 .../gfsh/command-pages/load-balance.html           |    3 -
 .../tools_modules/gfsh/command-pages/locate.html   |    3 -
 .../tools_modules/gfsh/command-pages/netstat.html  |    3 -
 .../tools_modules/gfsh/command-pages/pause.html    |    3 -
 .../112/tools_modules/gfsh/command-pages/pdx.html  |    3 -
 .../112/tools_modules/gfsh/command-pages/put.html  |    3 -
 .../tools_modules/gfsh/command-pages/query.html    |    3 -
 .../gfsh/command-pages/rebalance.html              |    3 -
 .../tools_modules/gfsh/command-pages/remove.html   |    3 -
 .../tools_modules/gfsh/command-pages/resume.html   |    3 -
 .../tools_modules/gfsh/command-pages/revoke.html   |    3 -
 .../112/tools_modules/gfsh/command-pages/run.html  |    3 -
 .../tools_modules/gfsh/command-pages/search.html   |    3 -
 .../112/tools_modules/gfsh/command-pages/set.html  |    3 -
 .../112/tools_modules/gfsh/command-pages/sh.html   |    3 -
 .../112/tools_modules/gfsh/command-pages/show.html |    3 -
 .../tools_modules/gfsh/command-pages/shutdown.html |    3 -
 .../tools_modules/gfsh/command-pages/sleep.html    |    3 -
 .../tools_modules/gfsh/command-pages/start.html    |    3 -
 .../tools_modules/gfsh/command-pages/status.html   |    3 -
 .../112/tools_modules/gfsh/command-pages/stop.html |    3 -
 .../tools_modules/gfsh/command-pages/undeploy.html |    3 -
 .../tools_modules/gfsh/command-pages/validate.html |    3 -
 .../tools_modules/gfsh/command-pages/version.html  |    3 -
 .../112/tools_modules/gfsh/command_scripting.html  |    3 -
 .../112/tools_modules/gfsh/configuring_gfsh.html   |    3 -
 .../tools_modules/gfsh/getting_started_gfsh.html   |    3 -
 .../112/tools_modules/gfsh/gfsh_command_index.html |    3 -
 .../tools_modules/gfsh/gfsh_quick_reference.html   |    3 -
 .../guide/112/tools_modules/gfsh/json_in_gfsh.html |    3 -
 .../gfsh/os_command_line_execution.html            |    3 -
 .../gfsh/quick_ref_commands_by_area.html           |    5 +-
 .../112/tools_modules/gfsh/starting_gfsh.html      |    3 -
 .../guide/112/tools_modules/gfsh/tour_of_gfsh.html |    3 -
 .../gfsh/useful_gfsh_shell_variables.html          |    3 -
 .../http_session_mgmt/chapter_overview.html        |    3 -
 .../common_gemfire_topologies.html                 |    3 -
 .../configuring_non_sticky_sessions.html           |    3 -
 .../http_session_mgmt/http_why_use_gemfire.html    |    3 -
 .../http_session_mgmt/interactive_mode_ref.html    |    3 -
 .../http_session_mgmt/quick_start.html             |    3 -
 .../http_session_mgmt/session_mgmt_tcserver.html   |    3 -
 .../http_session_mgmt/session_mgmt_tomcat.html     |    3 -
 .../http_session_mgmt/session_mgmt_weblogic.html   |    3 -
 .../http_session_mgmt/session_state_log_files.html |    3 -
 .../http_session_mgmt/tc_additional_info.html      |    3 -
 .../tc_changing_gf_default_cfg.html                |    3 -
 .../tc_installing_the_module.html                  |    3 -
 .../tc_setting_up_the_module.html                  |    3 -
 .../tomcat_changing_gf_default_cfg.html            |    3 -
 .../tomcat_installing_the_module.html              |    3 -
 .../tomcat_setting_up_the_module.html              |    3 -
 .../weblogic_changing_gf_default_cfg.html          |    3 -
 .../weblogic_common_configuration_changes.html     |    3 -
 .../weblogic_setting_up_the_module.html            |    3 -
 .../112/tools_modules/lucene_integration.html      |    3 -
 .../micrometer/micrometer-configuration.html       |    5 -
 .../micrometer/micrometer-meters.html              |    3 -
 .../micrometer/micrometer-overview.html            |    6 +-
 docs/guide/112/tools_modules/pulse/pulse-auth.html |    3 -
 .../112/tools_modules/pulse/pulse-embedded.html    |    3 -
 .../112/tools_modules/pulse/pulse-hosted.html      |    3 -
 .../112/tools_modules/pulse/pulse-overview.html    |    3 -
 .../tools_modules/pulse/pulse-requirements.html    |    3 -
 .../guide/112/tools_modules/pulse/pulse-views.html |    3 -
 docs/guide/112/tools_modules/redis_adapter.html    |    3 -
 docs/guide/112/topologies_and_comm/book_intro.html |    3 -
 .../cs_configuration/chapter_overview.html         |    3 -
 .../client_server_example_configurations.html      |    3 -
 .../cs_configuration/client_server_whats_next.html |    3 -
 .../configure_servers_into_logical_groups.html     |    3 -
 .../setting_up_a_client_server_system.html         |    3 -
 .../standard_client_server_deployment.html         |    3 -
 .../multi_site_configuration/chapter_overview.html |    3 -
 .../multisite_topologies.html                      |    3 -
 .../setting_up_a_multisite_system.html             |    3 -
 .../p2p_configuration/chapter_overview.html        |    3 -
 .../configuring_peer_member_groups.html            |    3 -
 .../p2p_configuration/setting_up_a_p2p_system.html |    3 -
 .../setting_up_peer_communication.html             |    3 -
 .../topology_concepts/IPv4_and_IPv6.html           |    3 -
 .../topology_concepts/chapter_overview.html        |    3 -
 .../topology_concepts/how_communication_works.html |    3 -
 .../how_member_discovery_works.html                |    3 -
 .../how_multisite_systems_work.html                |    3 -
 .../how_server_discovery_works.html                |    3 -
 .../how_the_pool_manages_connections.html          |    3 -
 .../topology_concepts/member_communication.html    |    3 -
 .../topology_concepts/multisite_overview.html      |    3 -
 .../topology_concepts/topology_types.html          |    3 -
 .../topology_concepts/using_bind_addresses.html    |    3 -
 docs/guide/112/use_cases/book_intro.html           |    3 -
 docs/guide/112/use_cases/inline-cache.html         |    3 -
 .../disk_storage/compacting_disk_stores.html       |   22 +-
 .../disk_store_configuration_params.html           |    7 +-
 .../managing/disk_storage/using_disk_stores.html   |    6 +-
 .../113/reference/topics/gemfire_properties.html   |    7 +
 .../tools_modules/gfsh/command-pages/compact.html  |   12 +-
 .../tools_modules/gfsh/command-pages/create.html   |    2 +-
 536 files changed, 78 insertions(+), 4309 deletions(-)

diff --git a/docs/guide/112/about_geode.html b/docs/guide/112/about_geode.html
index 53b8ba1..0d38f68 100644
--- a/docs/guide/112/about_geode.html
+++ b/docs/guide/112/about_geode.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/book_intro.html b/docs/guide/112/basic_config/book_intro.html
index fd98b76..2790f21 100644
--- a/docs/guide/112/basic_config/book_intro.html
+++ b/docs/guide/112/basic_config/book_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/config_concepts/chapter_overview.html b/docs/guide/112/basic_config/config_concepts/chapter_overview.html
index fc4399a..c343d79 100644
--- a/docs/guide/112/basic_config/config_concepts/chapter_overview.html
+++ b/docs/guide/112/basic_config/config_concepts/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/config_concepts/distributed_system_member_configuration.html b/docs/guide/112/basic_config/config_concepts/distributed_system_member_configuration.html
index 90b7c2c..6d101f0 100644
--- a/docs/guide/112/basic_config/config_concepts/distributed_system_member_configuration.html
+++ b/docs/guide/112/basic_config/config_concepts/distributed_system_member_configuration.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/config_concepts/local_vs_remote.html b/docs/guide/112/basic_config/config_concepts/local_vs_remote.html
index f3daf49..18f91c4 100644
--- a/docs/guide/112/basic_config/config_concepts/local_vs_remote.html
+++ b/docs/guide/112/basic_config/config_concepts/local_vs_remote.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_entries_custom_classes/chapter_overview.html b/docs/guide/112/basic_config/data_entries_custom_classes/chapter_overview.html
index 7e60720..d4a1fe4 100644
--- a/docs/guide/112/basic_config/data_entries_custom_classes/chapter_overview.html
+++ b/docs/guide/112/basic_config/data_entries_custom_classes/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_entries_custom_classes/managing_data_entries.html b/docs/guide/112/basic_config/data_entries_custom_classes/managing_data_entries.html
index b03958c..aa4d5e0 100644
--- a/docs/guide/112/basic_config/data_entries_custom_classes/managing_data_entries.html
+++ b/docs/guide/112/basic_config/data_entries_custom_classes/managing_data_entries.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_entries_custom_classes/using_custom_classes.html b/docs/guide/112/basic_config/data_entries_custom_classes/using_custom_classes.html
index 00235cb..a5484ad 100644
--- a/docs/guide/112/basic_config/data_entries_custom_classes/using_custom_classes.html
+++ b/docs/guide/112/basic_config/data_entries_custom_classes/using_custom_classes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/chapter_overview.html b/docs/guide/112/basic_config/data_regions/chapter_overview.html
index 1db2173..f106eb1 100644
--- a/docs/guide/112/basic_config/data_regions/chapter_overview.html
+++ b/docs/guide/112/basic_config/data_regions/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/creating_custom_attributes.html b/docs/guide/112/basic_config/data_regions/creating_custom_attributes.html
index 685a546..29d91dd 100644
--- a/docs/guide/112/basic_config/data_regions/creating_custom_attributes.html
+++ b/docs/guide/112/basic_config/data_regions/creating_custom_attributes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/managing_data_regions.html b/docs/guide/112/basic_config/data_regions/managing_data_regions.html
index 3b6d98b..6245d63 100644
--- a/docs/guide/112/basic_config/data_regions/managing_data_regions.html
+++ b/docs/guide/112/basic_config/data_regions/managing_data_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/managing_region_attributes.html b/docs/guide/112/basic_config/data_regions/managing_region_attributes.html
index 30d2f4b..3afbdcd 100644
--- a/docs/guide/112/basic_config/data_regions/managing_region_attributes.html
+++ b/docs/guide/112/basic_config/data_regions/managing_region_attributes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/new_region_existing_data.html b/docs/guide/112/basic_config/data_regions/new_region_existing_data.html
index 4b4dbcd..b3e28b3 100644
--- a/docs/guide/112/basic_config/data_regions/new_region_existing_data.html
+++ b/docs/guide/112/basic_config/data_regions/new_region_existing_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/region_naming.html b/docs/guide/112/basic_config/data_regions/region_naming.html
index 78db51c..7677eb8 100644
--- a/docs/guide/112/basic_config/data_regions/region_naming.html
+++ b/docs/guide/112/basic_config/data_regions/region_naming.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/region_shortcuts.html b/docs/guide/112/basic_config/data_regions/region_shortcuts.html
index da366d8..294c012 100644
--- a/docs/guide/112/basic_config/data_regions/region_shortcuts.html
+++ b/docs/guide/112/basic_config/data_regions/region_shortcuts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/data_regions/store_retrieve_region_shortcuts.html b/docs/guide/112/basic_config/data_regions/store_retrieve_region_shortcuts.html
index d5485f9..788c4ee 100644
--- a/docs/guide/112/basic_config/data_regions/store_retrieve_region_shortcuts.html
+++ b/docs/guide/112/basic_config/data_regions/store_retrieve_region_shortcuts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/gemfire_properties/setting_distributed_properties.html b/docs/guide/112/basic_config/gemfire_properties/setting_distributed_properties.html
index b827fbf..b2dfc8d 100644
--- a/docs/guide/112/basic_config/gemfire_properties/setting_distributed_properties.html
+++ b/docs/guide/112/basic_config/gemfire_properties/setting_distributed_properties.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/chapter_overview.html b/docs/guide/112/basic_config/the_cache/chapter_overview.html
index 549f20d..252bece 100644
--- a/docs/guide/112/basic_config/the_cache/chapter_overview.html
+++ b/docs/guide/112/basic_config/the_cache/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/intro_cache_management.html b/docs/guide/112/basic_config/the_cache/intro_cache_management.html
index 0090923..cd1377c 100644
--- a/docs/guide/112/basic_config/the_cache/intro_cache_management.html
+++ b/docs/guide/112/basic_config/the_cache/intro_cache_management.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/managing_a_client_cache.html b/docs/guide/112/basic_config/the_cache/managing_a_client_cache.html
index 60bf5d6..14c1eec 100644
--- a/docs/guide/112/basic_config/the_cache/managing_a_client_cache.html
+++ b/docs/guide/112/basic_config/the_cache/managing_a_client_cache.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/managing_a_multiuser_cache.html b/docs/guide/112/basic_config/the_cache/managing_a_multiuser_cache.html
index 63e5870..bf3b62d 100644
--- a/docs/guide/112/basic_config/the_cache/managing_a_multiuser_cache.html
+++ b/docs/guide/112/basic_config/the_cache/managing_a_multiuser_cache.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/managing_a_peer_server_cache.html b/docs/guide/112/basic_config/the_cache/managing_a_peer_server_cache.html
index 5761d48..fbee040 100644
--- a/docs/guide/112/basic_config/the_cache/managing_a_peer_server_cache.html
+++ b/docs/guide/112/basic_config/the_cache/managing_a_peer_server_cache.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/managing_a_secure_cache.html b/docs/guide/112/basic_config/the_cache/managing_a_secure_cache.html
index dc1f9e9..029e6ac 100644
--- a/docs/guide/112/basic_config/the_cache/managing_a_secure_cache.html
+++ b/docs/guide/112/basic_config/the_cache/managing_a_secure_cache.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/setting_cache_initializer.html b/docs/guide/112/basic_config/the_cache/setting_cache_initializer.html
index 847b940..5fa66fc 100644
--- a/docs/guide/112/basic_config/the_cache/setting_cache_initializer.html
+++ b/docs/guide/112/basic_config/the_cache/setting_cache_initializer.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/basic_config/the_cache/setting_cache_properties.html b/docs/guide/112/basic_config/the_cache/setting_cache_properties.html
index a207e47..9b58207 100644
--- a/docs/guide/112/basic_config/the_cache/setting_cache_properties.html
+++ b/docs/guide/112/basic_config/the_cache/setting_cache_properties.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/chapter_overview.html b/docs/guide/112/configuring/chapter_overview.html
index 323e57f..0778335 100644
--- a/docs/guide/112/configuring/chapter_overview.html
+++ b/docs/guide/112/configuring/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/cluster_config/deploying_application_jars.html b/docs/guide/112/configuring/cluster_config/deploying_application_jars.html
index ef9d6de..da4ec99 100644
--- a/docs/guide/112/configuring/cluster_config/deploying_application_jars.html
+++ b/docs/guide/112/configuring/cluster_config/deploying_application_jars.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/cluster_config/export-import.html b/docs/guide/112/configuring/cluster_config/export-import.html
index 8bacd36..7898d7f 100644
--- a/docs/guide/112/configuring/cluster_config/export-import.html
+++ b/docs/guide/112/configuring/cluster_config/export-import.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/cluster_config/gfsh_config_troubleshooting.html b/docs/guide/112/configuring/cluster_config/gfsh_config_troubleshooting.html
index b5fcbb3..bf5c5b0 100644
--- a/docs/guide/112/configuring/cluster_config/gfsh_config_troubleshooting.html
+++ b/docs/guide/112/configuring/cluster_config/gfsh_config_troubleshooting.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/cluster_config/gfsh_persist.html b/docs/guide/112/configuring/cluster_config/gfsh_persist.html
index 1e8424d..d9c9193 100644
--- a/docs/guide/112/configuring/cluster_config/gfsh_persist.html
+++ b/docs/guide/112/configuring/cluster_config/gfsh_persist.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/cluster_config/gfsh_remote.html b/docs/guide/112/configuring/cluster_config/gfsh_remote.html
index 5207af3..e86c8b4 100644
--- a/docs/guide/112/configuring/cluster_config/gfsh_remote.html
+++ b/docs/guide/112/configuring/cluster_config/gfsh_remote.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/cluster_config/persisting_configurations.html b/docs/guide/112/configuring/cluster_config/persisting_configurations.html
index e83d8d3..f017436 100644
--- a/docs/guide/112/configuring/cluster_config/persisting_configurations.html
+++ b/docs/guide/112/configuring/cluster_config/persisting_configurations.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/cluster_config/using_member_groups.html b/docs/guide/112/configuring/cluster_config/using_member_groups.html
index 3d04255..c9f3d15 100644
--- a/docs/guide/112/configuring/cluster_config/using_member_groups.html
+++ b/docs/guide/112/configuring/cluster_config/using_member_groups.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/change_file_spec.html b/docs/guide/112/configuring/running/change_file_spec.html
index 02f1b6e..a70dd6d 100644
--- a/docs/guide/112/configuring/running/change_file_spec.html
+++ b/docs/guide/112/configuring/running/change_file_spec.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/cluster-management-service.html b/docs/guide/112/configuring/running/cluster-management-service.html
index e1944df..4408b22 100644
--- a/docs/guide/112/configuring/running/cluster-management-service.html
+++ b/docs/guide/112/configuring/running/cluster-management-service.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/default_file_specs.html b/docs/guide/112/configuring/running/default_file_specs.html
index 4b11b71..801b090 100644
--- a/docs/guide/112/configuring/running/default_file_specs.html
+++ b/docs/guide/112/configuring/running/default_file_specs.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/deploy_config_files_intro.html b/docs/guide/112/configuring/running/deploy_config_files_intro.html
index be40872..5c58f11 100644
--- a/docs/guide/112/configuring/running/deploy_config_files_intro.html
+++ b/docs/guide/112/configuring/running/deploy_config_files_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/deploying_config_files.html b/docs/guide/112/configuring/running/deploying_config_files.html
index 5d813b4..85206ac 100644
--- a/docs/guide/112/configuring/running/deploying_config_files.html
+++ b/docs/guide/112/configuring/running/deploying_config_files.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/deploying_config_jar_files.html b/docs/guide/112/configuring/running/deploying_config_jar_files.html
index d03a543..b6efc0e 100644
--- a/docs/guide/112/configuring/running/deploying_config_jar_files.html
+++ b/docs/guide/112/configuring/running/deploying_config_jar_files.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/firewall_ports_config.html b/docs/guide/112/configuring/running/firewall_ports_config.html
index 55512bf..01a4b27 100644
--- a/docs/guide/112/configuring/running/firewall_ports_config.html
+++ b/docs/guide/112/configuring/running/firewall_ports_config.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/firewalls_connections.html b/docs/guide/112/configuring/running/firewalls_connections.html
index a5cc477..9182081 100644
--- a/docs/guide/112/configuring/running/firewalls_connections.html
+++ b/docs/guide/112/configuring/running/firewalls_connections.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/firewalls_ports.html b/docs/guide/112/configuring/running/firewalls_ports.html
index 9796db8..52cb7d1 100644
--- a/docs/guide/112/configuring/running/firewalls_ports.html
+++ b/docs/guide/112/configuring/running/firewalls_ports.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/managing_output_files.html b/docs/guide/112/configuring/running/managing_output_files.html
index 3604fe1..6b85579 100644
--- a/docs/guide/112/configuring/running/managing_output_files.html
+++ b/docs/guide/112/configuring/running/managing_output_files.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/running_the_cacheserver.html b/docs/guide/112/configuring/running/running_the_cacheserver.html
index 896ad03..d97d509 100644
--- a/docs/guide/112/configuring/running/running_the_cacheserver.html
+++ b/docs/guide/112/configuring/running/running_the_cacheserver.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/running_the_locator.html b/docs/guide/112/configuring/running/running_the_locator.html
index 1d77cfe..3543178 100644
--- a/docs/guide/112/configuring/running/running_the_locator.html
+++ b/docs/guide/112/configuring/running/running_the_locator.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/configuring/running/starting_up_shutting_down.html b/docs/guide/112/configuring/running/starting_up_shutting_down.html
index bc10c2f..7479a1c 100644
--- a/docs/guide/112/configuring/running/starting_up_shutting_down.html
+++ b/docs/guide/112/configuring/running/starting_up_shutting_down.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2670,7 +2667,7 @@ gfsh&gt;revoke missing-disk-store --id=60399215-532b-406f-b81f-9b5bd8d1b55a
 </code></pre>
 
 <p><strong>Note:</strong>
-This <code>gfsh</code> commands require that you are connected to the cluster via a JMX Manager node.</p>
+This <code>gfsh</code> command requires that you be connected to the cluster via a JMX Manager node.</p>
 
 <h2 id="shutting-down-the-system"><a id="starting_up_shutting_down__section_mnx_4cp_cv" class="no-quick-link"></a>Shutting Down the System</h2>
 
diff --git a/docs/guide/112/developing/book_intro.html b/docs/guide/112/developing/book_intro.html
index 1ed00c7..6ef20b6 100644
--- a/docs/guide/112/developing/book_intro.html
+++ b/docs/guide/112/developing/book_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/continuous_querying/chapter_overview.html b/docs/guide/112/developing/continuous_querying/chapter_overview.html
index 9a34d36..bd4331a 100644
--- a/docs/guide/112/developing/continuous_querying/chapter_overview.html
+++ b/docs/guide/112/developing/continuous_querying/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/continuous_querying/continuous_querying_whats_next.html b/docs/guide/112/developing/continuous_querying/continuous_querying_whats_next.html
index 872be3e..036769a 100644
--- a/docs/guide/112/developing/continuous_querying/continuous_querying_whats_next.html
+++ b/docs/guide/112/developing/continuous_querying/continuous_querying_whats_next.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/continuous_querying/how_continuous_querying_works.html b/docs/guide/112/developing/continuous_querying/how_continuous_querying_works.html
index 4a96823..6a6828c 100644
--- a/docs/guide/112/developing/continuous_querying/how_continuous_querying_works.html
+++ b/docs/guide/112/developing/continuous_querying/how_continuous_querying_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/continuous_querying/implementing_continuous_querying.html b/docs/guide/112/developing/continuous_querying/implementing_continuous_querying.html
index dc11242..cf9a595 100644
--- a/docs/guide/112/developing/continuous_querying/implementing_continuous_querying.html
+++ b/docs/guide/112/developing/continuous_querying/implementing_continuous_querying.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/PDX_Serialization_Features.html b/docs/guide/112/developing/data_serialization/PDX_Serialization_Features.html
index 399db45..3a794a1 100644
--- a/docs/guide/112/developing/data_serialization/PDX_Serialization_Features.html
+++ b/docs/guide/112/developing/data_serialization/PDX_Serialization_Features.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/auto_serialization.html b/docs/guide/112/developing/data_serialization/auto_serialization.html
index 0a74f8e..f6b548f 100644
--- a/docs/guide/112/developing/data_serialization/auto_serialization.html
+++ b/docs/guide/112/developing/data_serialization/auto_serialization.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/autoserialization_with_class_pattern_strings.html b/docs/guide/112/developing/data_serialization/autoserialization_with_class_pattern_strings.html
index fe02c77..b268cd5 100644
--- a/docs/guide/112/developing/data_serialization/autoserialization_with_class_pattern_strings.html
+++ b/docs/guide/112/developing/data_serialization/autoserialization_with_class_pattern_strings.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/chapter_overview.html b/docs/guide/112/developing/data_serialization/chapter_overview.html
index 9d822f4..3253c4f 100644
--- a/docs/guide/112/developing/data_serialization/chapter_overview.html
+++ b/docs/guide/112/developing/data_serialization/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/data_serialization_options.html b/docs/guide/112/developing/data_serialization/data_serialization_options.html
index 9c76151..4adf66b 100644
--- a/docs/guide/112/developing/data_serialization/data_serialization_options.html
+++ b/docs/guide/112/developing/data_serialization/data_serialization_options.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/extending_the_autoserializer.html b/docs/guide/112/developing/data_serialization/extending_the_autoserializer.html
index e89c3ea..ebea8fe 100644
--- a/docs/guide/112/developing/data_serialization/extending_the_autoserializer.html
+++ b/docs/guide/112/developing/data_serialization/extending_the_autoserializer.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/gemfire_data_serialization.html b/docs/guide/112/developing/data_serialization/gemfire_data_serialization.html
index 2959793..56e7034 100644
--- a/docs/guide/112/developing/data_serialization/gemfire_data_serialization.html
+++ b/docs/guide/112/developing/data_serialization/gemfire_data_serialization.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/gemfire_pdx_serialization.html b/docs/guide/112/developing/data_serialization/gemfire_pdx_serialization.html
index 27d80ea..1a282d3 100644
--- a/docs/guide/112/developing/data_serialization/gemfire_pdx_serialization.html
+++ b/docs/guide/112/developing/data_serialization/gemfire_pdx_serialization.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/java_serialization.html b/docs/guide/112/developing/data_serialization/java_serialization.html
index b927b72..4a99507 100644
--- a/docs/guide/112/developing/data_serialization/java_serialization.html
+++ b/docs/guide/112/developing/data_serialization/java_serialization.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/jsonformatter_pdxinstances.html b/docs/guide/112/developing/data_serialization/jsonformatter_pdxinstances.html
index 6e25b61..8630500 100644
--- a/docs/guide/112/developing/data_serialization/jsonformatter_pdxinstances.html
+++ b/docs/guide/112/developing/data_serialization/jsonformatter_pdxinstances.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/persist_pdx_metadata_to_disk.html b/docs/guide/112/developing/data_serialization/persist_pdx_metadata_to_disk.html
index d8d26f4..ee618b2 100644
--- a/docs/guide/112/developing/data_serialization/persist_pdx_metadata_to_disk.html
+++ b/docs/guide/112/developing/data_serialization/persist_pdx_metadata_to_disk.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/program_application_for_pdx.html b/docs/guide/112/developing/data_serialization/program_application_for_pdx.html
index b4deaae..ecc0ebc 100644
--- a/docs/guide/112/developing/data_serialization/program_application_for_pdx.html
+++ b/docs/guide/112/developing/data_serialization/program_application_for_pdx.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/use_pdx_high_level_steps.html b/docs/guide/112/developing/data_serialization/use_pdx_high_level_steps.html
index 8ad9389..6ced235 100644
--- a/docs/guide/112/developing/data_serialization/use_pdx_high_level_steps.html
+++ b/docs/guide/112/developing/data_serialization/use_pdx_high_level_steps.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/use_pdx_serializable.html b/docs/guide/112/developing/data_serialization/use_pdx_serializable.html
index 1963432..fd44b6b 100644
--- a/docs/guide/112/developing/data_serialization/use_pdx_serializable.html
+++ b/docs/guide/112/developing/data_serialization/use_pdx_serializable.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/use_pdx_serializer.html b/docs/guide/112/developing/data_serialization/use_pdx_serializer.html
index 3ecb211..cffed5b 100644
--- a/docs/guide/112/developing/data_serialization/use_pdx_serializer.html
+++ b/docs/guide/112/developing/data_serialization/use_pdx_serializer.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/using_PdxInstanceFactory.html b/docs/guide/112/developing/data_serialization/using_PdxInstanceFactory.html
index d0e0152..a57633e 100644
--- a/docs/guide/112/developing/data_serialization/using_PdxInstanceFactory.html
+++ b/docs/guide/112/developing/data_serialization/using_PdxInstanceFactory.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/data_serialization/using_pdx_region_entry_keys.html b/docs/guide/112/developing/data_serialization/using_pdx_region_entry_keys.html
index 79fe056..063c725 100644
--- a/docs/guide/112/developing/data_serialization/using_pdx_region_entry_keys.html
+++ b/docs/guide/112/developing/data_serialization/using_pdx_region_entry_keys.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/delta_propagation/chapter_overview.html b/docs/guide/112/developing/delta_propagation/chapter_overview.html
index 8965d1e..134caf4 100644
--- a/docs/guide/112/developing/delta_propagation/chapter_overview.html
+++ b/docs/guide/112/developing/delta_propagation/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/delta_propagation/delta_propagation_example.html b/docs/guide/112/developing/delta_propagation/delta_propagation_example.html
index 261b32c..10d6d2d 100644
--- a/docs/guide/112/developing/delta_propagation/delta_propagation_example.html
+++ b/docs/guide/112/developing/delta_propagation/delta_propagation_example.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/delta_propagation/delta_propagation_properties.html b/docs/guide/112/developing/delta_propagation/delta_propagation_properties.html
index 60d3e36..883aa92 100644
--- a/docs/guide/112/developing/delta_propagation/delta_propagation_properties.html
+++ b/docs/guide/112/developing/delta_propagation/delta_propagation_properties.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/delta_propagation/errors_in_delta_propagation.html b/docs/guide/112/developing/delta_propagation/errors_in_delta_propagation.html
index d50d237..d4e0cf6 100644
--- a/docs/guide/112/developing/delta_propagation/errors_in_delta_propagation.html
+++ b/docs/guide/112/developing/delta_propagation/errors_in_delta_propagation.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/delta_propagation/how_delta_propagation_works.html b/docs/guide/112/developing/delta_propagation/how_delta_propagation_works.html
index 14e290f..42c2a7f 100644
--- a/docs/guide/112/developing/delta_propagation/how_delta_propagation_works.html
+++ b/docs/guide/112/developing/delta_propagation/how_delta_propagation_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/delta_propagation/implementing_delta_propagation.html b/docs/guide/112/developing/delta_propagation/implementing_delta_propagation.html
index 02f60b0..599902a 100644
--- a/docs/guide/112/developing/delta_propagation/implementing_delta_propagation.html
+++ b/docs/guide/112/developing/delta_propagation/implementing_delta_propagation.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/delta_propagation/when_to_use_delta_prop.html b/docs/guide/112/developing/delta_propagation/when_to_use_delta_prop.html
index 592fd33..920d190 100644
--- a/docs/guide/112/developing/delta_propagation/when_to_use_delta_prop.html
+++ b/docs/guide/112/developing/delta_propagation/when_to_use_delta_prop.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/chapter_overview.html b/docs/guide/112/developing/distributed_regions/chapter_overview.html
index 3dd40ad..2743aaf 100644
--- a/docs/guide/112/developing/distributed_regions/chapter_overview.html
+++ b/docs/guide/112/developing/distributed_regions/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/choosing_level_of_dist.html b/docs/guide/112/developing/distributed_regions/choosing_level_of_dist.html
index df560f2..6ddad4b 100644
--- a/docs/guide/112/developing/distributed_regions/choosing_level_of_dist.html
+++ b/docs/guide/112/developing/distributed_regions/choosing_level_of_dist.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/how_distribution_works.html b/docs/guide/112/developing/distributed_regions/how_distribution_works.html
index a1369d2..096a4eb 100644
--- a/docs/guide/112/developing/distributed_regions/how_distribution_works.html
+++ b/docs/guide/112/developing/distributed_regions/how_distribution_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html b/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html
index cd4cb45..753eccf 100644
--- a/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html
+++ b/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/how_region_versioning_works_wan.html b/docs/guide/112/developing/distributed_regions/how_region_versioning_works_wan.html
index 8aa49ae..597b346 100644
--- a/docs/guide/112/developing/distributed_regions/how_region_versioning_works_wan.html
+++ b/docs/guide/112/developing/distributed_regions/how_region_versioning_works_wan.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/how_replication_works.html b/docs/guide/112/developing/distributed_regions/how_replication_works.html
index 060aafc..cd10680 100644
--- a/docs/guide/112/developing/distributed_regions/how_replication_works.html
+++ b/docs/guide/112/developing/distributed_regions/how_replication_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/locking_in_global_regions.html b/docs/guide/112/developing/distributed_regions/locking_in_global_regions.html
index 889a23c..21d61f1 100644
--- a/docs/guide/112/developing/distributed_regions/locking_in_global_regions.html
+++ b/docs/guide/112/developing/distributed_regions/locking_in_global_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/managing_distributed_regions.html b/docs/guide/112/developing/distributed_regions/managing_distributed_regions.html
index e170081..a25d59b 100644
--- a/docs/guide/112/developing/distributed_regions/managing_distributed_regions.html
+++ b/docs/guide/112/developing/distributed_regions/managing_distributed_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/distributed_regions/region_entry_versions.html b/docs/guide/112/developing/distributed_regions/region_entry_versions.html
index 99ff8f6..77f5a31 100644
--- a/docs/guide/112/developing/distributed_regions/region_entry_versions.html
+++ b/docs/guide/112/developing/distributed_regions/region_entry_versions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/cache_event_handler_examples.html b/docs/guide/112/developing/events/cache_event_handler_examples.html
index 2ce9453..2db68f3 100644
--- a/docs/guide/112/developing/events/cache_event_handler_examples.html
+++ b/docs/guide/112/developing/events/cache_event_handler_examples.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/chapter_overview.html b/docs/guide/112/developing/events/chapter_overview.html
index 9ab72e3..8501b41 100644
--- a/docs/guide/112/developing/events/chapter_overview.html
+++ b/docs/guide/112/developing/events/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/configure_client_server_event_messaging.html b/docs/guide/112/developing/events/configure_client_server_event_messaging.html
index 2c5bbbd..70049f6 100644
--- a/docs/guide/112/developing/events/configure_client_server_event_messaging.html
+++ b/docs/guide/112/developing/events/configure_client_server_event_messaging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/configure_multisite_event_messaging.html b/docs/guide/112/developing/events/configure_multisite_event_messaging.html
index 37ad208..8f0b982 100644
--- a/docs/guide/112/developing/events/configure_multisite_event_messaging.html
+++ b/docs/guide/112/developing/events/configure_multisite_event_messaging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/configure_p2p_event_messaging.html b/docs/guide/112/developing/events/configure_p2p_event_messaging.html
index 6cc6c10..863ecf2 100644
--- a/docs/guide/112/developing/events/configure_p2p_event_messaging.html
+++ b/docs/guide/112/developing/events/configure_p2p_event_messaging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/configuring_gateway_concurrency_levels.html b/docs/guide/112/developing/events/configuring_gateway_concurrency_levels.html
index 494db1e..f4eec50 100644
--- a/docs/guide/112/developing/events/configuring_gateway_concurrency_levels.html
+++ b/docs/guide/112/developing/events/configuring_gateway_concurrency_levels.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/configuring_highly_available_gateway_queues.html b/docs/guide/112/developing/events/configuring_highly_available_gateway_queues.html
index 8bfdbbb..e917a77 100644
--- a/docs/guide/112/developing/events/configuring_highly_available_gateway_queues.html
+++ b/docs/guide/112/developing/events/configuring_highly_available_gateway_queues.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/configuring_highly_available_servers.html b/docs/guide/112/developing/events/configuring_highly_available_servers.html
index a267c55..9ea581e 100644
--- a/docs/guide/112/developing/events/configuring_highly_available_servers.html
+++ b/docs/guide/112/developing/events/configuring_highly_available_servers.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/conflate_multisite_gateway_queue.html b/docs/guide/112/developing/events/conflate_multisite_gateway_queue.html
index dd6ee8c..12651fd 100644
--- a/docs/guide/112/developing/events/conflate_multisite_gateway_queue.html
+++ b/docs/guide/112/developing/events/conflate_multisite_gateway_queue.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/conflate_server_subscription_queue.html b/docs/guide/112/developing/events/conflate_server_subscription_queue.html
index 0838125..2bf998e 100644
--- a/docs/guide/112/developing/events/conflate_server_subscription_queue.html
+++ b/docs/guide/112/developing/events/conflate_server_subscription_queue.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/event_handler_overview.html b/docs/guide/112/developing/events/event_handler_overview.html
index e4043e9..5c7a4f6 100644
--- a/docs/guide/112/developing/events/event_handler_overview.html
+++ b/docs/guide/112/developing/events/event_handler_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/filtering_multisite_events.html b/docs/guide/112/developing/events/filtering_multisite_events.html
index ea6f572..16d5dbb 100644
--- a/docs/guide/112/developing/events/filtering_multisite_events.html
+++ b/docs/guide/112/developing/events/filtering_multisite_events.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/ha_event_messaging_whats_next.html b/docs/guide/112/developing/events/ha_event_messaging_whats_next.html
index a2fdd12..95034b8 100644
--- a/docs/guide/112/developing/events/ha_event_messaging_whats_next.html
+++ b/docs/guide/112/developing/events/ha_event_messaging_whats_next.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/how_cache_events_work.html b/docs/guide/112/developing/events/how_cache_events_work.html
index b2a4d7c..794cae8 100644
--- a/docs/guide/112/developing/events/how_cache_events_work.html
+++ b/docs/guide/112/developing/events/how_cache_events_work.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/how_client_server_distribution_works.html b/docs/guide/112/developing/events/how_client_server_distribution_works.html
index 16df904..1d72f40 100644
--- a/docs/guide/112/developing/events/how_client_server_distribution_works.html
+++ b/docs/guide/112/developing/events/how_client_server_distribution_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/how_events_work.html b/docs/guide/112/developing/events/how_events_work.html
index eb1b084..25eec96 100644
--- a/docs/guide/112/developing/events/how_events_work.html
+++ b/docs/guide/112/developing/events/how_events_work.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/how_multisite_distribution_works.html b/docs/guide/112/developing/events/how_multisite_distribution_works.html
index d8a4ee0..6f10c76 100644
--- a/docs/guide/112/developing/events/how_multisite_distribution_works.html
+++ b/docs/guide/112/developing/events/how_multisite_distribution_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/implementing_cache_event_handlers.html b/docs/guide/112/developing/events/implementing_cache_event_handlers.html
index 2206f92..baa1c14 100644
--- a/docs/guide/112/developing/events/implementing_cache_event_handlers.html
+++ b/docs/guide/112/developing/events/implementing_cache_event_handlers.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/implementing_durable_client_server_messaging.html b/docs/guide/112/developing/events/implementing_durable_client_server_messaging.html
index c7c2807..71717fc 100644
--- a/docs/guide/112/developing/events/implementing_durable_client_server_messaging.html
+++ b/docs/guide/112/developing/events/implementing_durable_client_server_messaging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/implementing_write_behind_event_handler.html b/docs/guide/112/developing/events/implementing_write_behind_event_handler.html
index 8649c70..62ca6e1 100644
--- a/docs/guide/112/developing/events/implementing_write_behind_event_handler.html
+++ b/docs/guide/112/developing/events/implementing_write_behind_event_handler.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/limit_server_subscription_queue_size.html b/docs/guide/112/developing/events/limit_server_subscription_queue_size.html
index 8b65916..ed4f013 100644
--- a/docs/guide/112/developing/events/limit_server_subscription_queue_size.html
+++ b/docs/guide/112/developing/events/limit_server_subscription_queue_size.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/list_of_event_handlers_and_events.html b/docs/guide/112/developing/events/list_of_event_handlers_and_events.html
index 7167d5d..6e3d0a2 100644
--- a/docs/guide/112/developing/events/list_of_event_handlers_and_events.html
+++ b/docs/guide/112/developing/events/list_of_event_handlers_and_events.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/resolving_multisite_conflicts.html b/docs/guide/112/developing/events/resolving_multisite_conflicts.html
index 4e9e2b2..8f2ff79 100644
--- a/docs/guide/112/developing/events/resolving_multisite_conflicts.html
+++ b/docs/guide/112/developing/events/resolving_multisite_conflicts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/tune_client_message_tracking_timeout.html b/docs/guide/112/developing/events/tune_client_message_tracking_timeout.html
index 3ce8c7e..addbe90 100644
--- a/docs/guide/112/developing/events/tune_client_message_tracking_timeout.html
+++ b/docs/guide/112/developing/events/tune_client_message_tracking_timeout.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/tune_client_server_event_messaging.html b/docs/guide/112/developing/events/tune_client_server_event_messaging.html
index 04a4c0e..770f4b2 100644
--- a/docs/guide/112/developing/events/tune_client_server_event_messaging.html
+++ b/docs/guide/112/developing/events/tune_client_server_event_messaging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/events/writing_callbacks_that_modify_the_cache.html b/docs/guide/112/developing/events/writing_callbacks_that_modify_the_cache.html
index c1d3221..aa8b6f1 100644
--- a/docs/guide/112/developing/events/writing_callbacks_that_modify_the_cache.html
+++ b/docs/guide/112/developing/events/writing_callbacks_that_modify_the_cache.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/eviction/chapter_overview.html b/docs/guide/112/developing/eviction/chapter_overview.html
index 6d3733e..36a40c8 100644
--- a/docs/guide/112/developing/eviction/chapter_overview.html
+++ b/docs/guide/112/developing/eviction/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/eviction/configuring_data_eviction.html b/docs/guide/112/developing/eviction/configuring_data_eviction.html
index 444c8f7..9ed31e6 100644
--- a/docs/guide/112/developing/eviction/configuring_data_eviction.html
+++ b/docs/guide/112/developing/eviction/configuring_data_eviction.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/eviction/how_eviction_works.html b/docs/guide/112/developing/eviction/how_eviction_works.html
index 386bae1..ca16170 100644
--- a/docs/guide/112/developing/eviction/how_eviction_works.html
+++ b/docs/guide/112/developing/eviction/how_eviction_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/expiration/chapter_overview.html b/docs/guide/112/developing/expiration/chapter_overview.html
index 53876d8..ce08839 100644
--- a/docs/guide/112/developing/expiration/chapter_overview.html
+++ b/docs/guide/112/developing/expiration/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/expiration/configuring_data_expiration.html b/docs/guide/112/developing/expiration/configuring_data_expiration.html
index 076df76..03f0087 100644
--- a/docs/guide/112/developing/expiration/configuring_data_expiration.html
+++ b/docs/guide/112/developing/expiration/configuring_data_expiration.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/expiration/how_expiration_works.html b/docs/guide/112/developing/expiration/how_expiration_works.html
index 05a1b88..c45bee8 100644
--- a/docs/guide/112/developing/expiration/how_expiration_works.html
+++ b/docs/guide/112/developing/expiration/how_expiration_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/function_exec/chapter_overview.html b/docs/guide/112/developing/function_exec/chapter_overview.html
index 06e8a90..ae84933 100644
--- a/docs/guide/112/developing/function_exec/chapter_overview.html
+++ b/docs/guide/112/developing/function_exec/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/function_exec/function_execution.html b/docs/guide/112/developing/function_exec/function_execution.html
index 9d6f8be..271d614 100644
--- a/docs/guide/112/developing/function_exec/function_execution.html
+++ b/docs/guide/112/developing/function_exec/function_execution.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/function_exec/how_function_execution_works.html b/docs/guide/112/developing/function_exec/how_function_execution_works.html
index 79dc6f3..c8e19ba 100644
--- a/docs/guide/112/developing/function_exec/how_function_execution_works.html
+++ b/docs/guide/112/developing/function_exec/how_function_execution_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/general_region_data_management.html b/docs/guide/112/developing/general_region_data_management.html
index 0d98aa7..ef60e89 100644
--- a/docs/guide/112/developing/general_region_data_management.html
+++ b/docs/guide/112/developing/general_region_data_management.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/outside_data_sources/chapter_overview.html b/docs/guide/112/developing/outside_data_sources/chapter_overview.html
index eb40960..68ef2a3 100644
--- a/docs/guide/112/developing/outside_data_sources/chapter_overview.html
+++ b/docs/guide/112/developing/outside_data_sources/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/outside_data_sources/configuring_db_connections_using_JNDI.html b/docs/guide/112/developing/outside_data_sources/configuring_db_connections_using_JNDI.html
index 6f56511..c476f60 100644
--- a/docs/guide/112/developing/outside_data_sources/configuring_db_connections_using_JNDI.html
+++ b/docs/guide/112/developing/outside_data_sources/configuring_db_connections_using_JNDI.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/outside_data_sources/how_data_loaders_work.html b/docs/guide/112/developing/outside_data_sources/how_data_loaders_work.html
index a6606ba..6e785d4 100644
--- a/docs/guide/112/developing/outside_data_sources/how_data_loaders_work.html
+++ b/docs/guide/112/developing/outside_data_sources/how_data_loaders_work.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/outside_data_sources/implementing_data_loaders.html b/docs/guide/112/developing/outside_data_sources/implementing_data_loaders.html
index 948f170..f74797d 100644
--- a/docs/guide/112/developing/outside_data_sources/implementing_data_loaders.html
+++ b/docs/guide/112/developing/outside_data_sources/implementing_data_loaders.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/outside_data_sources/sync_outside_data.html b/docs/guide/112/developing/outside_data_sources/sync_outside_data.html
index 423f7ba..99ea39a 100644
--- a/docs/guide/112/developing/outside_data_sources/sync_outside_data.html
+++ b/docs/guide/112/developing/outside_data_sources/sync_outside_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/automated_rebalance.html b/docs/guide/112/developing/partitioned_regions/automated_rebalance.html
index f752e06..c6154fd 100644
--- a/docs/guide/112/developing/partitioned_regions/automated_rebalance.html
+++ b/docs/guide/112/developing/partitioned_regions/automated_rebalance.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/chapter_overview.html b/docs/guide/112/developing/partitioned_regions/chapter_overview.html
index f3734d5..bf113d3 100644
--- a/docs/guide/112/developing/partitioned_regions/chapter_overview.html
+++ b/docs/guide/112/developing/partitioned_regions/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/checking_region_redundancy.html b/docs/guide/112/developing/partitioned_regions/checking_region_redundancy.html
index b95ddf0..9ea6be2 100644
--- a/docs/guide/112/developing/partitioned_regions/checking_region_redundancy.html
+++ b/docs/guide/112/developing/partitioned_regions/checking_region_redundancy.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/colocating_partitioned_region_data.html b/docs/guide/112/developing/partitioned_regions/colocating_partitioned_region_data.html
index 117072d..6efb8f0 100644
--- a/docs/guide/112/developing/partitioned_regions/colocating_partitioned_region_data.html
+++ b/docs/guide/112/developing/partitioned_regions/colocating_partitioned_region_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/configure_pr_single_hop.html b/docs/guide/112/developing/partitioned_regions/configure_pr_single_hop.html
index 5fc4d38..714488c 100644
--- a/docs/guide/112/developing/partitioned_regions/configure_pr_single_hop.html
+++ b/docs/guide/112/developing/partitioned_regions/configure_pr_single_hop.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/configuring_bucket_for_pr.html b/docs/guide/112/developing/partitioned_regions/configuring_bucket_for_pr.html
index 1b23d88..28b759f 100644
--- a/docs/guide/112/developing/partitioned_regions/configuring_bucket_for_pr.html
+++ b/docs/guide/112/developing/partitioned_regions/configuring_bucket_for_pr.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/configuring_ha_for_pr.html b/docs/guide/112/developing/partitioned_regions/configuring_ha_for_pr.html
index 8c672e1..b16ce9a 100644
--- a/docs/guide/112/developing/partitioned_regions/configuring_ha_for_pr.html
+++ b/docs/guide/112/developing/partitioned_regions/configuring_ha_for_pr.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/custom_partitioning_and_data_colocation.html b/docs/guide/112/developing/partitioned_regions/custom_partitioning_and_data_colocation.html
index f925891..8bdf5a6 100644
--- a/docs/guide/112/developing/partitioned_regions/custom_partitioning_and_data_colocation.html
+++ b/docs/guide/112/developing/partitioned_regions/custom_partitioning_and_data_colocation.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/fixed_custom_partitioning.html b/docs/guide/112/developing/partitioned_regions/fixed_custom_partitioning.html
index 4469d9a..0e8eca7 100644
--- a/docs/guide/112/developing/partitioned_regions/fixed_custom_partitioning.html
+++ b/docs/guide/112/developing/partitioned_regions/fixed_custom_partitioning.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/how_partitioning_works.html b/docs/guide/112/developing/partitioned_regions/how_partitioning_works.html
index 726a4a0..e15b2f4 100644
--- a/docs/guide/112/developing/partitioned_regions/how_partitioning_works.html
+++ b/docs/guide/112/developing/partitioned_regions/how_partitioning_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/how_pr_ha_works.html b/docs/guide/112/developing/partitioned_regions/how_pr_ha_works.html
index e395534..21f7e32 100644
--- a/docs/guide/112/developing/partitioned_regions/how_pr_ha_works.html
+++ b/docs/guide/112/developing/partitioned_regions/how_pr_ha_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/how_pr_single_hop_works.html b/docs/guide/112/developing/partitioned_regions/how_pr_single_hop_works.html
index 92376d8..cafa71b 100644
--- a/docs/guide/112/developing/partitioned_regions/how_pr_single_hop_works.html
+++ b/docs/guide/112/developing/partitioned_regions/how_pr_single_hop_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/join_query_partitioned_regions.html b/docs/guide/112/developing/partitioned_regions/join_query_partitioned_regions.html
index a65a0b3..a428a42 100644
--- a/docs/guide/112/developing/partitioned_regions/join_query_partitioned_regions.html
+++ b/docs/guide/112/developing/partitioned_regions/join_query_partitioned_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/managing_partitioned_regions.html b/docs/guide/112/developing/partitioned_regions/managing_partitioned_regions.html
index 18b6db0..4b27293 100644
--- a/docs/guide/112/developing/partitioned_regions/managing_partitioned_regions.html
+++ b/docs/guide/112/developing/partitioned_regions/managing_partitioned_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/moving_partitioned_data.html b/docs/guide/112/developing/partitioned_regions/moving_partitioned_data.html
index 88c31e0..b1d6efd 100644
--- a/docs/guide/112/developing/partitioned_regions/moving_partitioned_data.html
+++ b/docs/guide/112/developing/partitioned_regions/moving_partitioned_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/overview_custom_partitioning_and_data_colocation.html b/docs/guide/112/developing/partitioned_regions/overview_custom_partitioning_and_data_colocation.html
index 0250200..a55f62c 100644
--- a/docs/guide/112/developing/partitioned_regions/overview_custom_partitioning_and_data_colocation.html
+++ b/docs/guide/112/developing/partitioned_regions/overview_custom_partitioning_and_data_colocation.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/overview_how_pr_ha_works.html b/docs/guide/112/developing/partitioned_regions/overview_how_pr_ha_works.html
index 95d963c..36c4be7 100644
--- a/docs/guide/112/developing/partitioned_regions/overview_how_pr_ha_works.html
+++ b/docs/guide/112/developing/partitioned_regions/overview_how_pr_ha_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/overview_how_pr_single_hop_works.html b/docs/guide/112/developing/partitioned_regions/overview_how_pr_single_hop_works.html
index af60325..539ed80 100644
--- a/docs/guide/112/developing/partitioned_regions/overview_how_pr_single_hop_works.html
+++ b/docs/guide/112/developing/partitioned_regions/overview_how_pr_single_hop_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/rebalancing_pr_data.html b/docs/guide/112/developing/partitioned_regions/rebalancing_pr_data.html
index 30c04cd..0cb65b8 100644
--- a/docs/guide/112/developing/partitioned_regions/rebalancing_pr_data.html
+++ b/docs/guide/112/developing/partitioned_regions/rebalancing_pr_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/set_crash_redundancy_recovery.html b/docs/guide/112/developing/partitioned_regions/set_crash_redundancy_recovery.html
index 4a56557..b7f4c14 100644
--- a/docs/guide/112/developing/partitioned_regions/set_crash_redundancy_recovery.html
+++ b/docs/guide/112/developing/partitioned_regions/set_crash_redundancy_recovery.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/set_enforce_unique_host.html b/docs/guide/112/developing/partitioned_regions/set_enforce_unique_host.html
index 8b3d418..2dbee76 100644
--- a/docs/guide/112/developing/partitioned_regions/set_enforce_unique_host.html
+++ b/docs/guide/112/developing/partitioned_regions/set_enforce_unique_host.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/set_join_redundancy_recovery.html b/docs/guide/112/developing/partitioned_regions/set_join_redundancy_recovery.html
index 976062d..0e3151d 100644
--- a/docs/guide/112/developing/partitioned_regions/set_join_redundancy_recovery.html
+++ b/docs/guide/112/developing/partitioned_regions/set_join_redundancy_recovery.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/set_pr_redundancy.html b/docs/guide/112/developing/partitioned_regions/set_pr_redundancy.html
index 491d262..983bc4c 100644
--- a/docs/guide/112/developing/partitioned_regions/set_pr_redundancy.html
+++ b/docs/guide/112/developing/partitioned_regions/set_pr_redundancy.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/set_redundancy_zones.html b/docs/guide/112/developing/partitioned_regions/set_redundancy_zones.html
index 0152a0a..18e596b 100644
--- a/docs/guide/112/developing/partitioned_regions/set_redundancy_zones.html
+++ b/docs/guide/112/developing/partitioned_regions/set_redundancy_zones.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/standard_custom_partitioning.html b/docs/guide/112/developing/partitioned_regions/standard_custom_partitioning.html
index eb24320..c2aa9ec 100644
--- a/docs/guide/112/developing/partitioned_regions/standard_custom_partitioning.html
+++ b/docs/guide/112/developing/partitioned_regions/standard_custom_partitioning.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/partitioned_regions/using_custom_partition_resolvers.html b/docs/guide/112/developing/partitioned_regions/using_custom_partition_resolvers.html
index 0b769be..7a1520f 100644
--- a/docs/guide/112/developing/partitioned_regions/using_custom_partition_resolvers.html
+++ b/docs/guide/112/developing/partitioned_regions/using_custom_partition_resolvers.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/advanced_querying.html b/docs/guide/112/developing/query_additional/advanced_querying.html
index c65b3a9..3169fd9 100644
--- a/docs/guide/112/developing/query_additional/advanced_querying.html
+++ b/docs/guide/112/developing/query_additional/advanced_querying.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/case_sensitivity.html b/docs/guide/112/developing/query_additional/case_sensitivity.html
index e510b14..9924afa 100644
--- a/docs/guide/112/developing/query_additional/case_sensitivity.html
+++ b/docs/guide/112/developing/query_additional/case_sensitivity.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/literals.html b/docs/guide/112/developing/query_additional/literals.html
index 9e5cf8c..4390907 100644
--- a/docs/guide/112/developing/query_additional/literals.html
+++ b/docs/guide/112/developing/query_additional/literals.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/operators.html b/docs/guide/112/developing/query_additional/operators.html
index a11141f..30e5069 100644
--- a/docs/guide/112/developing/query_additional/operators.html
+++ b/docs/guide/112/developing/query_additional/operators.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/order_by_on_partitioned_regions.html b/docs/guide/112/developing/query_additional/order_by_on_partitioned_regions.html
index 4f90dbb..b3a5c55 100644
--- a/docs/guide/112/developing/query_additional/order_by_on_partitioned_regions.html
+++ b/docs/guide/112/developing/query_additional/order_by_on_partitioned_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/partitioned_region_key_or_field_value.html b/docs/guide/112/developing/query_additional/partitioned_region_key_or_field_value.html
index 11c5dfa..4cf7e41 100644
--- a/docs/guide/112/developing/query_additional/partitioned_region_key_or_field_value.html
+++ b/docs/guide/112/developing/query_additional/partitioned_region_key_or_field_value.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/partitioned_region_query_restrictions.html b/docs/guide/112/developing/query_additional/partitioned_region_query_restrictions.html
index baa8b0c..73b5cb5 100644
--- a/docs/guide/112/developing/query_additional/partitioned_region_query_restrictions.html
+++ b/docs/guide/112/developing/query_additional/partitioned_region_query_restrictions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/query_debugging.html b/docs/guide/112/developing/query_additional/query_debugging.html
index 1c26132..08c8dd9 100644
--- a/docs/guide/112/developing/query_additional/query_debugging.html
+++ b/docs/guide/112/developing/query_additional/query_debugging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/query_language_features.html b/docs/guide/112/developing/query_additional/query_language_features.html
index 7a8a49e..494d4e4 100644
--- a/docs/guide/112/developing/query_additional/query_language_features.html
+++ b/docs/guide/112/developing/query_additional/query_language_features.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/query_on_a_single_node.html b/docs/guide/112/developing/query_additional/query_on_a_single_node.html
index ee8616f..2ce3b3f 100644
--- a/docs/guide/112/developing/query_additional/query_on_a_single_node.html
+++ b/docs/guide/112/developing/query_additional/query_on_a_single_node.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/query_timeout.html b/docs/guide/112/developing/query_additional/query_timeout.html
index 1a70f29..ac593fe 100644
--- a/docs/guide/112/developing/query_additional/query_timeout.html
+++ b/docs/guide/112/developing/query_additional/query_timeout.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/supported_keywords.html b/docs/guide/112/developing/query_additional/supported_keywords.html
index 1340e59..0455c18 100644
--- a/docs/guide/112/developing/query_additional/supported_keywords.html
+++ b/docs/guide/112/developing/query_additional/supported_keywords.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_additional/using_query_bind_parameters.html b/docs/guide/112/developing/query_additional/using_query_bind_parameters.html
index 5dff2c4..002565d 100644
--- a/docs/guide/112/developing/query_additional/using_query_bind_parameters.html
+++ b/docs/guide/112/developing/query_additional/using_query_bind_parameters.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/create_multiple_indexes.html b/docs/guide/112/developing/query_index/create_multiple_indexes.html
index 40304a5..24fa9da 100644
--- a/docs/guide/112/developing/query_index/create_multiple_indexes.html
+++ b/docs/guide/112/developing/query_index/create_multiple_indexes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/creating_an_index.html b/docs/guide/112/developing/query_index/creating_an_index.html
index 75358ae..0b42ecb 100644
--- a/docs/guide/112/developing/query_index/creating_an_index.html
+++ b/docs/guide/112/developing/query_index/creating_an_index.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/creating_hash_indexes.html b/docs/guide/112/developing/query_index/creating_hash_indexes.html
index aaa26f2..fefc8c8 100644
--- a/docs/guide/112/developing/query_index/creating_hash_indexes.html
+++ b/docs/guide/112/developing/query_index/creating_hash_indexes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/creating_key_indexes.html b/docs/guide/112/developing/query_index/creating_key_indexes.html
index 10d9a27..86348a3 100644
--- a/docs/guide/112/developing/query_index/creating_key_indexes.html
+++ b/docs/guide/112/developing/query_index/creating_key_indexes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/creating_map_indexes.html b/docs/guide/112/developing/query_index/creating_map_indexes.html
index a6ac7e9..f2779cb 100644
--- a/docs/guide/112/developing/query_index/creating_map_indexes.html
+++ b/docs/guide/112/developing/query_index/creating_map_indexes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/index_samples.html b/docs/guide/112/developing/query_index/index_samples.html
index b8a5eb7..7a6c1e4 100644
--- a/docs/guide/112/developing/query_index/index_samples.html
+++ b/docs/guide/112/developing/query_index/index_samples.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/indexes_on_single_region_queries.html b/docs/guide/112/developing/query_index/indexes_on_single_region_queries.html
index 0d28728..e139c89 100644
--- a/docs/guide/112/developing/query_index/indexes_on_single_region_queries.html
+++ b/docs/guide/112/developing/query_index/indexes_on_single_region_queries.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/indexes_with_overflow_regions.html b/docs/guide/112/developing/query_index/indexes_with_overflow_regions.html
index 87c0180..da7f596 100644
--- a/docs/guide/112/developing/query_index/indexes_with_overflow_regions.html
+++ b/docs/guide/112/developing/query_index/indexes_with_overflow_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/indexing_guidelines.html b/docs/guide/112/developing/query_index/indexing_guidelines.html
index 72498f3..647ca38 100644
--- a/docs/guide/112/developing/query_index/indexing_guidelines.html
+++ b/docs/guide/112/developing/query_index/indexing_guidelines.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/maintaining_indexes.html b/docs/guide/112/developing/query_index/maintaining_indexes.html
index 7e2476c..fd99dd9 100644
--- a/docs/guide/112/developing/query_index/maintaining_indexes.html
+++ b/docs/guide/112/developing/query_index/maintaining_indexes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/query_index.html b/docs/guide/112/developing/query_index/query_index.html
index 2e36725..74bc4a7 100644
--- a/docs/guide/112/developing/query_index/query_index.html
+++ b/docs/guide/112/developing/query_index/query_index.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/query_index_hints.html b/docs/guide/112/developing/query_index/query_index_hints.html
index 3c0c89e..e3d3bcb 100644
--- a/docs/guide/112/developing/query_index/query_index_hints.html
+++ b/docs/guide/112/developing/query_index/query_index_hints.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries.html b/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries.html
index 853dce8..795b711 100644
--- a/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries.html
+++ b/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries_multiple_regions.html b/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries_multiple_regions.html
index 3f84f32..01acc02 100644
--- a/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries_multiple_regions.html
+++ b/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries_multiple_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_select/aggregates.html b/docs/guide/112/developing/query_select/aggregates.html
index 1a0b268..d49009d 100644
--- a/docs/guide/112/developing/query_select/aggregates.html
+++ b/docs/guide/112/developing/query_select/aggregates.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_select/the_from_clause.html b/docs/guide/112/developing/query_select/the_from_clause.html
index a600dfa..b68d1d6 100644
--- a/docs/guide/112/developing/query_select/the_from_clause.html
+++ b/docs/guide/112/developing/query_select/the_from_clause.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_select/the_import_statement.html b/docs/guide/112/developing/query_select/the_import_statement.html
index d3e24c5..c1a421a 100644
--- a/docs/guide/112/developing/query_select/the_import_statement.html
+++ b/docs/guide/112/developing/query_select/the_import_statement.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_select/the_select_statement.html b/docs/guide/112/developing/query_select/the_select_statement.html
index e865f48..f90fdf5 100644
--- a/docs/guide/112/developing/query_select/the_select_statement.html
+++ b/docs/guide/112/developing/query_select/the_select_statement.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/query_select/the_where_clause.html b/docs/guide/112/developing/query_select/the_where_clause.html
index cb5dbfb..3024afd 100644
--- a/docs/guide/112/developing/query_select/the_where_clause.html
+++ b/docs/guide/112/developing/query_select/the_where_clause.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/chapter_overview.html b/docs/guide/112/developing/querying_basics/chapter_overview.html
index 8d0d15e..670c31b 100644
--- a/docs/guide/112/developing/querying_basics/chapter_overview.html
+++ b/docs/guide/112/developing/querying_basics/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/comments_in_query_strings.html b/docs/guide/112/developing/querying_basics/comments_in_query_strings.html
index fb52676..30494e6 100644
--- a/docs/guide/112/developing/querying_basics/comments_in_query_strings.html
+++ b/docs/guide/112/developing/querying_basics/comments_in_query_strings.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/monitor_queries_for_low_memory.html b/docs/guide/112/developing/querying_basics/monitor_queries_for_low_memory.html
index c4eb5d3..ff2124d 100644
--- a/docs/guide/112/developing/querying_basics/monitor_queries_for_low_memory.html
+++ b/docs/guide/112/developing/querying_basics/monitor_queries_for_low_memory.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/oql_compared_to_sql.html b/docs/guide/112/developing/querying_basics/oql_compared_to_sql.html
index 2d13228..4298984 100644
--- a/docs/guide/112/developing/querying_basics/oql_compared_to_sql.html
+++ b/docs/guide/112/developing/querying_basics/oql_compared_to_sql.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/performance_considerations.html b/docs/guide/112/developing/querying_basics/performance_considerations.html
index fc85807..0411b65 100644
--- a/docs/guide/112/developing/querying_basics/performance_considerations.html
+++ b/docs/guide/112/developing/querying_basics/performance_considerations.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/query_basics.html b/docs/guide/112/developing/querying_basics/query_basics.html
index bfc2112..9526d82 100644
--- a/docs/guide/112/developing/querying_basics/query_basics.html
+++ b/docs/guide/112/developing/querying_basics/query_basics.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/query_grammar_and_reserved_words.html b/docs/guide/112/developing/querying_basics/query_grammar_and_reserved_words.html
index baec713..c386c81 100644
--- a/docs/guide/112/developing/querying_basics/query_grammar_and_reserved_words.html
+++ b/docs/guide/112/developing/querying_basics/query_grammar_and_reserved_words.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/querying_partitioned_regions.html b/docs/guide/112/developing/querying_basics/querying_partitioned_regions.html
index 69d1d8a..3254403 100644
--- a/docs/guide/112/developing/querying_basics/querying_partitioned_regions.html
+++ b/docs/guide/112/developing/querying_basics/querying_partitioned_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/reserved_words.html b/docs/guide/112/developing/querying_basics/reserved_words.html
index 77919e3..87a7dfc 100644
--- a/docs/guide/112/developing/querying_basics/reserved_words.html
+++ b/docs/guide/112/developing/querying_basics/reserved_words.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/restrictions_and_unsupported_features.html b/docs/guide/112/developing/querying_basics/restrictions_and_unsupported_features.html
index 560a31d..eaa61fb 100644
--- a/docs/guide/112/developing/querying_basics/restrictions_and_unsupported_features.html
+++ b/docs/guide/112/developing/querying_basics/restrictions_and_unsupported_features.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/running_a_query.html b/docs/guide/112/developing/querying_basics/running_a_query.html
index 9b4c1a4..6c19427 100644
--- a/docs/guide/112/developing/querying_basics/running_a_query.html
+++ b/docs/guide/112/developing/querying_basics/running_a_query.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/supported_character_sets.html b/docs/guide/112/developing/querying_basics/supported_character_sets.html
index bf5cdc5..c2cf9e4 100644
--- a/docs/guide/112/developing/querying_basics/supported_character_sets.html
+++ b/docs/guide/112/developing/querying_basics/supported_character_sets.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/querying_basics/what_is_a_query_string.html b/docs/guide/112/developing/querying_basics/what_is_a_query_string.html
index 3f46a70..aab8a4c 100644
--- a/docs/guide/112/developing/querying_basics/what_is_a_query_string.html
+++ b/docs/guide/112/developing/querying_basics/what_is_a_query_string.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/region_options/chapter_overview.html b/docs/guide/112/developing/region_options/chapter_overview.html
index 7e0f148..c50b195 100644
--- a/docs/guide/112/developing/region_options/chapter_overview.html
+++ b/docs/guide/112/developing/region_options/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/region_options/data_hosts_and_accessors.html b/docs/guide/112/developing/region_options/data_hosts_and_accessors.html
index 664b0ba..3b61081 100644
--- a/docs/guide/112/developing/region_options/data_hosts_and_accessors.html
+++ b/docs/guide/112/developing/region_options/data_hosts_and_accessors.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/region_options/dynamic_region_creation.html b/docs/guide/112/developing/region_options/dynamic_region_creation.html
index 933dad8..658d880 100644
--- a/docs/guide/112/developing/region_options/dynamic_region_creation.html
+++ b/docs/guide/112/developing/region_options/dynamic_region_creation.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/region_options/region_types.html b/docs/guide/112/developing/region_options/region_types.html
index 3429376..3fcbb1d 100644
--- a/docs/guide/112/developing/region_options/region_types.html
+++ b/docs/guide/112/developing/region_options/region_types.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/region_options/storage_distribution_options.html b/docs/guide/112/developing/region_options/storage_distribution_options.html
index c90d927..0e810ef 100644
--- a/docs/guide/112/developing/region_options/storage_distribution_options.html
+++ b/docs/guide/112/developing/region_options/storage_distribution_options.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/storing_data_on_disk/chapter_overview.html b/docs/guide/112/developing/storing_data_on_disk/chapter_overview.html
index 35d7fa8..ceba43a 100644
--- a/docs/guide/112/developing/storing_data_on_disk/chapter_overview.html
+++ b/docs/guide/112/developing/storing_data_on_disk/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/storing_data_on_disk/how_persist_overflow_work.html b/docs/guide/112/developing/storing_data_on_disk/how_persist_overflow_work.html
index 41266b1..f655a89 100644
--- a/docs/guide/112/developing/storing_data_on_disk/how_persist_overflow_work.html
+++ b/docs/guide/112/developing/storing_data_on_disk/how_persist_overflow_work.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/storing_data_on_disk/overflow_config_examples.html b/docs/guide/112/developing/storing_data_on_disk/overflow_config_examples.html
index 90cd801..46b69fa 100644
--- a/docs/guide/112/developing/storing_data_on_disk/overflow_config_examples.html
+++ b/docs/guide/112/developing/storing_data_on_disk/overflow_config_examples.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/storing_data_on_disk/storing_data_on_disk.html b/docs/guide/112/developing/storing_data_on_disk/storing_data_on_disk.html
index 0b41fb1..967741c 100644
--- a/docs/guide/112/developing/storing_data_on_disk/storing_data_on_disk.html
+++ b/docs/guide/112/developing/storing_data_on_disk/storing_data_on_disk.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/transactions/chapter_overview.html b/docs/guide/112/developing/transactions/chapter_overview.html
index a0086bb..d64bdd5 100644
--- a/docs/guide/112/developing/transactions/chapter_overview.html
+++ b/docs/guide/112/developing/transactions/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/transactions/design_considerations.html b/docs/guide/112/developing/transactions/design_considerations.html
index 7e5da31..dacc648 100644
--- a/docs/guide/112/developing/transactions/design_considerations.html
+++ b/docs/guide/112/developing/transactions/design_considerations.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/transactions/directed_example.html b/docs/guide/112/developing/transactions/directed_example.html
index 367dca0..06885d5 100644
--- a/docs/guide/112/developing/transactions/directed_example.html
+++ b/docs/guide/112/developing/transactions/directed_example.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/developing/transactions/transactions_intro.html b/docs/guide/112/developing/transactions/transactions_intro.html
index 183520b..b87bade 100644
--- a/docs/guide/112/developing/transactions/transactions_intro.html
+++ b/docs/guide/112/developing/transactions/transactions_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/15_minute_quickstart_gfsh.html b/docs/guide/112/getting_started/15_minute_quickstart_gfsh.html
index e0e699d..9b3e607 100644
--- a/docs/guide/112/getting_started/15_minute_quickstart_gfsh.html
+++ b/docs/guide/112/getting_started/15_minute_quickstart_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/book_intro.html b/docs/guide/112/getting_started/book_intro.html
index ec926ff..2ba2327 100644
--- a/docs/guide/112/getting_started/book_intro.html
+++ b/docs/guide/112/getting_started/book_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/geode_overview.html b/docs/guide/112/getting_started/geode_overview.html
index 15a024a..19a7b2e 100644
--- a/docs/guide/112/getting_started/geode_overview.html
+++ b/docs/guide/112/getting_started/geode_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/installation/install_standalone.html b/docs/guide/112/getting_started/installation/install_standalone.html
index 60fa95b..8933779 100644
--- a/docs/guide/112/getting_started/installation/install_standalone.html
+++ b/docs/guide/112/getting_started/installation/install_standalone.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/product_intro.html b/docs/guide/112/getting_started/product_intro.html
index 292f4bd..f6d881e 100644
--- a/docs/guide/112/getting_started/product_intro.html
+++ b/docs/guide/112/getting_started/product_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/querying_quick_reference.html b/docs/guide/112/getting_started/querying_quick_reference.html
index 1a144d0..42e3bf9 100644
--- a/docs/guide/112/getting_started/querying_quick_reference.html
+++ b/docs/guide/112/getting_started/querying_quick_reference.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/setup_classpath.html b/docs/guide/112/getting_started/setup_classpath.html
index 3e59273..d49ede6 100644
--- a/docs/guide/112/getting_started/setup_classpath.html
+++ b/docs/guide/112/getting_started/setup_classpath.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/system_requirements/host_machine.html b/docs/guide/112/getting_started/system_requirements/host_machine.html
index 6b3f69c..1d666b0 100644
--- a/docs/guide/112/getting_started/system_requirements/host_machine.html
+++ b/docs/guide/112/getting_started/system_requirements/host_machine.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/getting_started/uninstall_geode.html b/docs/guide/112/getting_started/uninstall_geode.html
index b653a55..bb801c2 100644
--- a/docs/guide/112/getting_started/uninstall_geode.html
+++ b/docs/guide/112/getting_started/uninstall_geode.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/book_intro.html b/docs/guide/112/managing/book_intro.html
index 2b1182e..0f333bd 100644
--- a/docs/guide/112/managing/book_intro.html
+++ b/docs/guide/112/managing/book_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/cache_snapshots/chapter_overview.html b/docs/guide/112/managing/cache_snapshots/chapter_overview.html
index a35bc7e..6d6a97c 100644
--- a/docs/guide/112/managing/cache_snapshots/chapter_overview.html
+++ b/docs/guide/112/managing/cache_snapshots/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/cache_snapshots/exporting_a_snapshot.html b/docs/guide/112/managing/cache_snapshots/exporting_a_snapshot.html
index 1f8d901..7a0b373 100644
--- a/docs/guide/112/managing/cache_snapshots/exporting_a_snapshot.html
+++ b/docs/guide/112/managing/cache_snapshots/exporting_a_snapshot.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/cache_snapshots/filtering_snapshot_entries.html b/docs/guide/112/managing/cache_snapshots/filtering_snapshot_entries.html
index 0b70c67..1326cf3 100644
--- a/docs/guide/112/managing/cache_snapshots/filtering_snapshot_entries.html
+++ b/docs/guide/112/managing/cache_snapshots/filtering_snapshot_entries.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/cache_snapshots/importing_a_snapshot.html b/docs/guide/112/managing/cache_snapshots/importing_a_snapshot.html
index 6b63cc9..a8b8fbd 100644
--- a/docs/guide/112/managing/cache_snapshots/importing_a_snapshot.html
+++ b/docs/guide/112/managing/cache_snapshots/importing_a_snapshot.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/cache_snapshots/read_snapshots_programmatically.html b/docs/guide/112/managing/cache_snapshots/read_snapshots_programmatically.html
index bcc4b7b..9aa8cd4 100644
--- a/docs/guide/112/managing/cache_snapshots/read_snapshots_programmatically.html
+++ b/docs/guide/112/managing/cache_snapshots/read_snapshots_programmatically.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/cache_snapshots/using_cache_and_region_snapshots.html b/docs/guide/112/managing/cache_snapshots/using_cache_and_region_snapshots.html
index 939c036..c0b6fb7 100644
--- a/docs/guide/112/managing/cache_snapshots/using_cache_and_region_snapshots.html
+++ b/docs/guide/112/managing/cache_snapshots/using_cache_and_region_snapshots.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/backup_restore_disk_store.html b/docs/guide/112/managing/disk_storage/backup_restore_disk_store.html
index 6ad475c..89f740e 100644
--- a/docs/guide/112/managing/disk_storage/backup_restore_disk_store.html
+++ b/docs/guide/112/managing/disk_storage/backup_restore_disk_store.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/chapter_overview.html b/docs/guide/112/managing/disk_storage/chapter_overview.html
index 15c1961..06bb51e 100644
--- a/docs/guide/112/managing/disk_storage/chapter_overview.html
+++ b/docs/guide/112/managing/disk_storage/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/compacting_disk_stores.html b/docs/guide/112/managing/disk_storage/compacting_disk_stores.html
index d333178..288f656 100644
--- a/docs/guide/112/managing/disk_storage/compacting_disk_stores.html
+++ b/docs/guide/112/managing/disk_storage/compacting_disk_stores.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2628,24 +2625,36 @@ limitations under the License.
 -->
 
 <p><a id="compacting_disk_stores__section_64BA304595364E38A28098EB09494531"></a>
-When a cache operation is added to a disk store, any preexisting operation record for the same entry becomes obsolete, and Apache Geode marks it as garbage. For example, when you create an entry, the create operation is added to the store. If you update the entry later, the update operation is added and the create operation becomes garbage. Geode does not remove garbage records as it goes, but it tracks the percentage of garbage in each operation log, and provides mechanisms for removing [...]
+When a cache operation is added to a disk store, any preexisting operation record for the same entry
+becomes obsolete, and Apache Geode marks it as garbage. For example, when you create
+an entry, the create operation is added to the store. If you update the entry later, the update
+operation is added and the create operation becomes garbage. Geode does not remove
+garbage records as it goes, but it tracks the percentage of non-garbage (live data) remaining in each operation log, and
+provides mechanisms for removing garbage to compact your log files.</p>
 
 <p>Geode compacts an old operation log by copying all non-garbage records into the current log and discarding the old files. As with logging, oplogs are rolled as needed during compaction to stay within the max oplog setting.</p>
 
-<p>You can configure the system to automatically compact any closed operation log when its garbage content reaches a certain percentage. You can also manually request compaction for online and offline disk stores. For the online disk store, the current operation log is not available for compaction, no matter how much garbage it contains.</p>
+<p>The system is configured by default to automatically compact any closed operation log when its non-garbage
+content drops below a certain percentage. This automatic compaction is well suited to most Geode implementations.
+In some circumstances, you may choose to  manually initiate compaction for online and
+offline disk stores.</p>
 
 <h2 id="log-file-compaction-for-the-online-disk-store"><a id="compacting_disk_stores__section_98C6B6F48E4F4F0CB7749E426AF4D647" class="no-quick-link"></a>Log File Compaction for the Online Disk Store</h2>
 
 <p><img src="../../images/diskStores-3.gif" id="compacting_disk_stores__image_7E34CC58B13548B196DAA15F5B0A0ECA" class="image" /></p>
 
-<p>Offline compaction runs essentially in the same way, but without the incoming cache operations. Also, because there is no current open log, the compaction creates a new one to get started.</p>
+<p>For the online disk store, the current operation log is not available for
+compaction, no matter how much garbage it contains. You can use <code>DiskStore.forceRoll</code> to close the current oplog, making it eligible for compaction.
+See <a href="/docs/guide/112/managing/disk_storage/operation_logs.html">Disk Store Operation Logs</a> for details.</p>
+
+<p>Offline compaction runs essentially in the same way, but without the incoming cache operations. Also, because there is no currently open log, the compaction creates a new one to get started.</p>
 
 <h2 id="run-online-compaction"><a id="compacting_disk_stores__section_96E774B5502648458E7742B37CA235FF" class="no-quick-link"></a>Run Online Compaction</h2>
 
-<p>Old log files become eligible for online compaction when their garbage content surpasses a configured percentage of the total file. A record is garbage when its operation is superseded by a more recent operation for the same object. During compaction, the non-garbage records are added to the current log along with new cache operations. Online compaction does not block current system operations.</p>
+<p>Old log files become eligible for online compaction when their live data (non-garbage) content drops below a configured percentage of the total file. A record is garbage when its operation is superseded by a more recent operation for the same object. During compaction, the non-garbage records are added to the current log along with new cache operations. Online compaction does not block current system operations.</p>
 
 <ul>
-<li>  <strong>Automatic compaction</strong>. When <code>auto-compact</code> is true, Geode automatically compacts each oplog when its garbage content surpasses the <code>compaction-threshold</code>. This takes cycles from your other operations, so you may want to disable this and only do manual compaction, to control the timing.</li>
+<li>  <strong>Automatic compaction</strong>. When <code>auto-compact</code> is true, Geode automatically compacts each oplog when its non-garbage (live data) content drops below the <code>compaction-threshold</code>. This takes cycles from your other operations, so you may want to disable this and only do manual compaction, to control the timing.</li>
 <li><p><strong>Manual compaction</strong>. To run manual compaction:</p>
 
 <ul>
diff --git a/docs/guide/112/managing/disk_storage/disk_free_space_monitoring.html b/docs/guide/112/managing/disk_storage/disk_free_space_monitoring.html
index 40d1861..e476389 100644
--- a/docs/guide/112/managing/disk_storage/disk_free_space_monitoring.html
+++ b/docs/guide/112/managing/disk_storage/disk_free_space_monitoring.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/disk_store_configuration_params.html b/docs/guide/112/managing/disk_storage/disk_store_configuration_params.html
index 0614675..df24a83 100644
--- a/docs/guide/112/managing/disk_storage/disk_store_configuration_params.html
+++ b/docs/guide/112/managing/disk_storage/disk_store_configuration_params.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2659,12 +2656,15 @@ limitations under the License.
 </tr>
 <tr>
 <td><code class="ph codeph">auto-compact</code></td>
-<td>Boolean indicating whether to automatically compact a file when it reaches the <code class="ph codeph">compaction-threshold</code>.</td>
+<td>Boolean indicating whether to automatically compact a file when its live data content percentage drops below the <code class="ph codeph">compaction-threshold</code>.</td>
 <td>true</td>
 </tr>
 <tr>
 <td><code class="ph codeph">compaction-threshold</code></td>
-<td>Percentage of garbage allowed in the file before it is eligible for compaction. Garbage is created by entry destroys, entry updates, and region destroys and creates. Surpassing this percentage does not make compaction occur—it makes the file eligible to be compacted when a compaction is done.</td>
+<td>Percentage (0..100) of live data (non-garbage content) remaining in the operation log, below which it is eligible for
+compaction. As garbage is created (by entry destroys, entry updates, and region destroys and
+creates) the percentage of remaining live data declines. Falling below this percentage initiates compaction
+if auto-compaction is turned on. If not, the file will be eligible for manual compaction at a later time.</td>
 <td>50</td>
 </tr>
 <tr>
diff --git a/docs/guide/112/managing/disk_storage/file_names_and_extensions.html b/docs/guide/112/managing/disk_storage/file_names_and_extensions.html
index 64fa34a..4a34d7e 100644
--- a/docs/guide/112/managing/disk_storage/file_names_and_extensions.html
+++ b/docs/guide/112/managing/disk_storage/file_names_and_extensions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/handling_missing_disk_stores.html b/docs/guide/112/managing/disk_storage/handling_missing_disk_stores.html
index 5c97cfa..3584e68 100644
--- a/docs/guide/112/managing/disk_storage/handling_missing_disk_stores.html
+++ b/docs/guide/112/managing/disk_storage/handling_missing_disk_stores.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/how_disk_stores_work.html b/docs/guide/112/managing/disk_storage/how_disk_stores_work.html
index f2f3a80..55e76ca 100644
--- a/docs/guide/112/managing/disk_storage/how_disk_stores_work.html
+++ b/docs/guide/112/managing/disk_storage/how_disk_stores_work.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/keeping_offline_disk_store_in_sync.html b/docs/guide/112/managing/disk_storage/keeping_offline_disk_store_in_sync.html
index aff530c..cb584e4 100644
--- a/docs/guide/112/managing/disk_storage/keeping_offline_disk_store_in_sync.html
+++ b/docs/guide/112/managing/disk_storage/keeping_offline_disk_store_in_sync.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/managing_disk_buffer_flushes.html b/docs/guide/112/managing/disk_storage/managing_disk_buffer_flushes.html
index 20b3086..aeb8669 100644
--- a/docs/guide/112/managing/disk_storage/managing_disk_buffer_flushes.html
+++ b/docs/guide/112/managing/disk_storage/managing_disk_buffer_flushes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/managing_disk_stores.html b/docs/guide/112/managing/disk_storage/managing_disk_stores.html
index ef0243b..f1ed5c3 100644
--- a/docs/guide/112/managing/disk_storage/managing_disk_stores.html
+++ b/docs/guide/112/managing/disk_storage/managing_disk_stores.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/managing_disk_stores_cmds.html b/docs/guide/112/managing/disk_storage/managing_disk_stores_cmds.html
index 5fb8c52..eed7bc4 100644
--- a/docs/guide/112/managing/disk_storage/managing_disk_stores_cmds.html
+++ b/docs/guide/112/managing/disk_storage/managing_disk_stores_cmds.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/operation_logs.html b/docs/guide/112/managing/disk_storage/operation_logs.html
index 529b6f2..e4eb225 100644
--- a/docs/guide/112/managing/disk_storage/operation_logs.html
+++ b/docs/guide/112/managing/disk_storage/operation_logs.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/optimize_availability_and_performance.html b/docs/guide/112/managing/disk_storage/optimize_availability_and_performance.html
index 97e227b..bda7fb0 100644
--- a/docs/guide/112/managing/disk_storage/optimize_availability_and_performance.html
+++ b/docs/guide/112/managing/disk_storage/optimize_availability_and_performance.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/overview_using_disk_stores.html b/docs/guide/112/managing/disk_storage/overview_using_disk_stores.html
index ab9f9ee..e7fefb1 100644
--- a/docs/guide/112/managing/disk_storage/overview_using_disk_stores.html
+++ b/docs/guide/112/managing/disk_storage/overview_using_disk_stores.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/starting_system_with_disk_stores.html b/docs/guide/112/managing/disk_storage/starting_system_with_disk_stores.html
index c381f33..33ff280 100644
--- a/docs/guide/112/managing/disk_storage/starting_system_with_disk_stores.html
+++ b/docs/guide/112/managing/disk_storage/starting_system_with_disk_stores.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/using_disk_stores.html b/docs/guide/112/managing/disk_storage/using_disk_stores.html
index a3facc6..5d5669f 100644
--- a/docs/guide/112/managing/disk_storage/using_disk_stores.html
+++ b/docs/guide/112/managing/disk_storage/using_disk_stores.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2648,11 +2645,11 @@ Besides the disk stores you specify, Apache Geode has a default disk store that
 
 <ul>
 <li>  For efficiency, separate data that is only overflowed in separate disk stores from data that is persisted or persisted and overflowed. Regions can be overflowed, persisted, or both. Server subscription queues are only overflowed.</li>
-<li><p>When calculating your disk requirements, figure in your data modification patterns and your compaction strategy. Geode creates each oplog file at the max-oplog-size, which defaults to 1 GB. Obsolete operations are only removed from the oplogs during compaction, so you need enough space to store all operations that are done between compactions. For regions where you are doing a mix of updates and deletes, if you use automatic compaction, a good upper bound for the required disk spa [...]
-<pre class="highlight plaintext"><code>(1 / (1 - (compaction_threshold/100)) ) * data size
+<li><p>When calculating your disk requirements, figure in your data modification patterns and your compaction strategy. Geode creates each oplog file at the max-oplog-size, which defaults to 1 GB. Obsolete operations are removed from the oplogs only during compaction, so you need enough space to store all operations that are done between compactions. For regions where you are doing a mix of updates and deletes, if you use automatic compaction, a good upper bound for the required disk spa [...]
+<pre class="highlight plaintext"><code>(1 / (compaction_threshold/100) ) * data size
 </code></pre>
 
-<p>where data size is the total size of all the data you store in the disk store. So, for the default compaction-threshold of 50, the disk space is roughly twice your data size. Note that the compaction thread could lag behind other operations, causing disk use to rise above the threshold temporarily. If you disable automatic compaction, the amount of disk required depends on how many obsolete operations accumulate between manual compactions.</p></li>
+<p>where data size is the total size of all the data you store in the disk store. So, for the default compaction-threshold of 50, the disk space is roughly twice your data size. Note that the compaction thread could lag behind other operations, causing disk use to rise temporarily above the upper bound. If you disable automatic compaction, the amount of disk required depends on how many obsolete operations accumulate between manual compactions.</p></li>
 </ul></li>
 <li><p>Work with your host system administrators to determine where to place your disk store directories, based on your anticipated disk storage requirements and the available disks on your host systems.</p>
 
diff --git a/docs/guide/112/managing/disk_storage/using_the_default_disk_store.html b/docs/guide/112/managing/disk_storage/using_the_default_disk_store.html
index 546eda8..9fcbe4a 100644
--- a/docs/guide/112/managing/disk_storage/using_the_default_disk_store.html
+++ b/docs/guide/112/managing/disk_storage/using_the_default_disk_store.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/disk_storage/validating_disk_store.html b/docs/guide/112/managing/disk_storage/validating_disk_store.html
index 69ca671..a296518 100644
--- a/docs/guide/112/managing/disk_storage/validating_disk_store.html
+++ b/docs/guide/112/managing/disk_storage/validating_disk_store.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/heap_use/heap_and_off_heap_management.html b/docs/guide/112/managing/heap_use/heap_and_off_heap_management.html
index 718be60..4850a66 100644
--- a/docs/guide/112/managing/heap_use/heap_and_off_heap_management.html
+++ b/docs/guide/112/managing/heap_use/heap_and_off_heap_management.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/heap_use/heap_management.html b/docs/guide/112/managing/heap_use/heap_management.html
index 1fc3b30..e2c7bad 100644
--- a/docs/guide/112/managing/heap_use/heap_management.html
+++ b/docs/guide/112/managing/heap_use/heap_management.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/heap_use/lock_memory.html b/docs/guide/112/managing/heap_use/lock_memory.html
index 524ebd8..5b9bb0f 100644
--- a/docs/guide/112/managing/heap_use/lock_memory.html
+++ b/docs/guide/112/managing/heap_use/lock_memory.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/heap_use/off_heap_management.html b/docs/guide/112/managing/heap_use/off_heap_management.html
index dae01ab..935d57d 100644
--- a/docs/guide/112/managing/heap_use/off_heap_management.html
+++ b/docs/guide/112/managing/heap_use/off_heap_management.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/logging/configuring_log4j2.html b/docs/guide/112/managing/logging/configuring_log4j2.html
index dc77466..ba332f9 100644
--- a/docs/guide/112/managing/logging/configuring_log4j2.html
+++ b/docs/guide/112/managing/logging/configuring_log4j2.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/logging/how_logging_works.html b/docs/guide/112/managing/logging/how_logging_works.html
index 4640773..31539b1 100644
--- a/docs/guide/112/managing/logging/how_logging_works.html
+++ b/docs/guide/112/managing/logging/how_logging_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/logging/logging.html b/docs/guide/112/managing/logging/logging.html
index 78f2b20..7bf8470 100644
--- a/docs/guide/112/managing/logging/logging.html
+++ b/docs/guide/112/managing/logging/logging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/logging/logging_categories.html b/docs/guide/112/managing/logging/logging_categories.html
index 2c66f8a..527e84f 100644
--- a/docs/guide/112/managing/logging/logging_categories.html
+++ b/docs/guide/112/managing/logging/logging_categories.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/logging/logging_whats_next.html b/docs/guide/112/managing/logging/logging_whats_next.html
index 31a7e79..a43c484 100644
--- a/docs/guide/112/managing/logging/logging_whats_next.html
+++ b/docs/guide/112/managing/logging/logging_whats_next.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/logging/setting_up_logging.html b/docs/guide/112/managing/logging/setting_up_logging.html
index 3a7175d..bc7bbbc 100644
--- a/docs/guide/112/managing/logging/setting_up_logging.html
+++ b/docs/guide/112/managing/logging/setting_up_logging.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/configuring_rmi_connector.html b/docs/guide/112/managing/management/configuring_rmi_connector.html
index 128bf23..af4dcea 100644
--- a/docs/guide/112/managing/management/configuring_rmi_connector.html
+++ b/docs/guide/112/managing/management/configuring_rmi_connector.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/gfsh_and_management_api.html b/docs/guide/112/managing/management/gfsh_and_management_api.html
index 47d09e0..d848212 100644
--- a/docs/guide/112/managing/management/gfsh_and_management_api.html
+++ b/docs/guide/112/managing/management/gfsh_and_management_api.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/jmx_manager_node.html b/docs/guide/112/managing/management/jmx_manager_node.html
index 2dcf806..4fc0000 100644
--- a/docs/guide/112/managing/management/jmx_manager_node.html
+++ b/docs/guide/112/managing/management/jmx_manager_node.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2633,6 +2630,8 @@ limitations under the License.
 
 <p>You need to have a JMX Manager started in your cluster in order to use Geode management and monitoring tools such as <a href="/docs/guide/112/tools_modules/gfsh/chapter_overview.html">gfsh</a> and <a href="/docs/guide/112/tools_modules/pulse/pulse-overview.html">Geode Pulse</a>.</p>
 
+<p>To create MBeans, a Security Manager must be enabled. See <a href="/docs/guide/112/managing/security/enable_security.html">Enable Security with Property Definitions</a> for more information.</p>
+
 <p><strong>Note:</strong>
 Each node that acts as the JMX Manager has additional memory requirements depending on the number of resources that it is managing and monitoring. Being a JMX Manager can increase the memory footprint of any process, including locator processes. See <a href="/docs/guide/112/reference/topics/memory_requirements_for_cache_data.html#calculating_memory_requirements">Memory Requirements for Cached Data</a> for more information on calculating memory overhead on your Geode processes.</p>
 
diff --git a/docs/guide/112/managing/management/jmx_manager_operations.html b/docs/guide/112/managing/management/jmx_manager_operations.html
index 8448f86..c27510f 100644
--- a/docs/guide/112/managing/management/jmx_manager_operations.html
+++ b/docs/guide/112/managing/management/jmx_manager_operations.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/list_of_mbean_notifications.html b/docs/guide/112/managing/management/list_of_mbean_notifications.html
index 506bd0a..d3e0252 100644
--- a/docs/guide/112/managing/management/list_of_mbean_notifications.html
+++ b/docs/guide/112/managing/management/list_of_mbean_notifications.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/list_of_mbeans.html b/docs/guide/112/managing/management/list_of_mbeans.html
index f8a7793..57748ef 100644
--- a/docs/guide/112/managing/management/list_of_mbeans.html
+++ b/docs/guide/112/managing/management/list_of_mbeans.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/list_of_mbeans_full.html b/docs/guide/112/managing/management/list_of_mbeans_full.html
index e326f3c..e7e92c2 100644
--- a/docs/guide/112/managing/management/list_of_mbeans_full.html
+++ b/docs/guide/112/managing/management/list_of_mbeans_full.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/management_and_monitoring.html b/docs/guide/112/managing/management/management_and_monitoring.html
index f52adcf..b106e97 100644
--- a/docs/guide/112/managing/management/management_and_monitoring.html
+++ b/docs/guide/112/managing/management/management_and_monitoring.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/management_and_monitoring_features.html b/docs/guide/112/managing/management/management_and_monitoring_features.html
index dd0e582..9f2ea1a 100644
--- a/docs/guide/112/managing/management/management_and_monitoring_features.html
+++ b/docs/guide/112/managing/management/management_and_monitoring_features.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/management_system_overview.html b/docs/guide/112/managing/management/management_system_overview.html
index 77e64fb..4f4fae9 100644
--- a/docs/guide/112/managing/management/management_system_overview.html
+++ b/docs/guide/112/managing/management/management_system_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/mbean_architecture.html b/docs/guide/112/managing/management/mbean_architecture.html
index 216a249..8953618 100644
--- a/docs/guide/112/managing/management/mbean_architecture.html
+++ b/docs/guide/112/managing/management/mbean_architecture.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/mbean_notifications.html b/docs/guide/112/managing/management/mbean_notifications.html
index fa81e2c..9d0aba2 100644
--- a/docs/guide/112/managing/management/mbean_notifications.html
+++ b/docs/guide/112/managing/management/mbean_notifications.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/mbeans_jconsole.html b/docs/guide/112/managing/management/mbeans_jconsole.html
index 84a37d6..1036002 100644
--- a/docs/guide/112/managing/management/mbeans_jconsole.html
+++ b/docs/guide/112/managing/management/mbeans_jconsole.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/mm_overview.html b/docs/guide/112/managing/management/mm_overview.html
index 1f0c60c..67e6f2d 100644
--- a/docs/guide/112/managing/management/mm_overview.html
+++ b/docs/guide/112/managing/management/mm_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/management/notification_federation_and_alerts.html b/docs/guide/112/managing/management/notification_federation_and_alerts.html
index 100577f..5188e6b 100644
--- a/docs/guide/112/managing/management/notification_federation_and_alerts.html
+++ b/docs/guide/112/managing/management/notification_federation_and_alerts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/member-reconnect.html b/docs/guide/112/managing/member-reconnect.html
index 116afa7..db0977e 100644
--- a/docs/guide/112/managing/member-reconnect.html
+++ b/docs/guide/112/managing/member-reconnect.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/cache_consistency.html b/docs/guide/112/managing/monitor_tune/cache_consistency.html
index a6b9093..79bd91e 100644
--- a/docs/guide/112/managing/monitor_tune/cache_consistency.html
+++ b/docs/guide/112/managing/monitor_tune/cache_consistency.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/chapter_overview.html b/docs/guide/112/managing/monitor_tune/chapter_overview.html
index 03fba74..7aae10c 100644
--- a/docs/guide/112/managing/monitor_tune/chapter_overview.html
+++ b/docs/guide/112/managing/monitor_tune/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/disabling_tcp_syn_cookies.html b/docs/guide/112/managing/monitor_tune/disabling_tcp_syn_cookies.html
index b5ab138..c718404 100644
--- a/docs/guide/112/managing/monitor_tune/disabling_tcp_syn_cookies.html
+++ b/docs/guide/112/managing/monitor_tune/disabling_tcp_syn_cookies.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/multicast_communication.html b/docs/guide/112/managing/monitor_tune/multicast_communication.html
index 2996aca..5cda0de 100644
--- a/docs/guide/112/managing/monitor_tune/multicast_communication.html
+++ b/docs/guide/112/managing/monitor_tune/multicast_communication.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/multicast_communication_configuring_speed_limits.html b/docs/guide/112/managing/monitor_tune/multicast_communication_configuring_speed_limits.html
index db425c8..f267262 100644
--- a/docs/guide/112/managing/monitor_tune/multicast_communication_configuring_speed_limits.html
+++ b/docs/guide/112/managing/monitor_tune/multicast_communication_configuring_speed_limits.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/multicast_communication_provisioning_bandwidth.html b/docs/guide/112/managing/monitor_tune/multicast_communication_provisioning_bandwidth.html
index f5fb00c..46dba12 100644
--- a/docs/guide/112/managing/monitor_tune/multicast_communication_provisioning_bandwidth.html
+++ b/docs/guide/112/managing/monitor_tune/multicast_communication_provisioning_bandwidth.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/multicast_communication_runtime_considerations.html b/docs/guide/112/managing/monitor_tune/multicast_communication_runtime_considerations.html
index 7f98ac7..3db6ced 100644
--- a/docs/guide/112/managing/monitor_tune/multicast_communication_runtime_considerations.html
+++ b/docs/guide/112/managing/monitor_tune/multicast_communication_runtime_considerations.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/multicast_communication_testing_multicast_speed_limits.html b/docs/guide/112/managing/monitor_tune/multicast_communication_testing_multicast_speed_limits.html
index ccf5b32..2ee2936 100644
--- a/docs/guide/112/managing/monitor_tune/multicast_communication_testing_multicast_speed_limits.html
+++ b/docs/guide/112/managing/monitor_tune/multicast_communication_testing_multicast_speed_limits.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/multicast_communication_troubleshooting.html b/docs/guide/112/managing/monitor_tune/multicast_communication_troubleshooting.html
index 9378fb4..07d53d1 100644
--- a/docs/guide/112/managing/monitor_tune/multicast_communication_troubleshooting.html
+++ b/docs/guide/112/managing/monitor_tune/multicast_communication_troubleshooting.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/performance_controls.html b/docs/guide/112/managing/monitor_tune/performance_controls.html
index 75d1568..9414b8c 100644
--- a/docs/guide/112/managing/monitor_tune/performance_controls.html
+++ b/docs/guide/112/managing/monitor_tune/performance_controls.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/performance_controls_controlling_socket_use.html b/docs/guide/112/managing/monitor_tune/performance_controls_controlling_socket_use.html
index 88577b6..54d320d 100644
--- a/docs/guide/112/managing/monitor_tune/performance_controls_controlling_socket_use.html
+++ b/docs/guide/112/managing/monitor_tune/performance_controls_controlling_socket_use.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/performance_controls_data_serialization.html b/docs/guide/112/managing/monitor_tune/performance_controls_data_serialization.html
index e7fcac2..61d7240 100644
--- a/docs/guide/112/managing/monitor_tune/performance_controls_data_serialization.html
+++ b/docs/guide/112/managing/monitor_tune/performance_controls_data_serialization.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/performance_controls_increasing_cache_hits.html b/docs/guide/112/managing/monitor_tune/performance_controls_increasing_cache_hits.html
index 580d6c6..ed7b5ed 100644
--- a/docs/guide/112/managing/monitor_tune/performance_controls_increasing_cache_hits.html
+++ b/docs/guide/112/managing/monitor_tune/performance_controls_increasing_cache_hits.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/performance_controls_managing_slow_receivers.html b/docs/guide/112/managing/monitor_tune/performance_controls_managing_slow_receivers.html
index 2e82825..d60197e 100644
--- a/docs/guide/112/managing/monitor_tune/performance_controls_managing_slow_receivers.html
+++ b/docs/guide/112/managing/monitor_tune/performance_controls_managing_slow_receivers.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/performance_controls_setting_cache_timeouts.html b/docs/guide/112/managing/monitor_tune/performance_controls_setting_cache_timeouts.html
index 1bddf72..25b860f 100644
--- a/docs/guide/112/managing/monitor_tune/performance_controls_setting_cache_timeouts.html
+++ b/docs/guide/112/managing/monitor_tune/performance_controls_setting_cache_timeouts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/performance_on_vsphere.html b/docs/guide/112/managing/monitor_tune/performance_on_vsphere.html
index cb21d40..46fa322 100644
--- a/docs/guide/112/managing/monitor_tune/performance_on_vsphere.html
+++ b/docs/guide/112/managing/monitor_tune/performance_on_vsphere.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/slow_messages.html b/docs/guide/112/managing/monitor_tune/slow_messages.html
index 25cd203..a6faa56 100644
--- a/docs/guide/112/managing/monitor_tune/slow_messages.html
+++ b/docs/guide/112/managing/monitor_tune/slow_messages.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/slow_receivers.html b/docs/guide/112/managing/monitor_tune/slow_receivers.html
index a57076d..e54c995 100644
--- a/docs/guide/112/managing/monitor_tune/slow_receivers.html
+++ b/docs/guide/112/managing/monitor_tune/slow_receivers.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/slow_receivers_managing.html b/docs/guide/112/managing/monitor_tune/slow_receivers_managing.html
index d1fe31c..21072f1 100644
--- a/docs/guide/112/managing/monitor_tune/slow_receivers_managing.html
+++ b/docs/guide/112/managing/monitor_tune/slow_receivers_managing.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/slow_receivers_preventing_problems.html b/docs/guide/112/managing/monitor_tune/slow_receivers_preventing_problems.html
index fa73a43..2b89041 100644
--- a/docs/guide/112/managing/monitor_tune/slow_receivers_preventing_problems.html
+++ b/docs/guide/112/managing/monitor_tune/slow_receivers_preventing_problems.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/socket_communication.html b/docs/guide/112/managing/monitor_tune/socket_communication.html
index ed4d76e..f48a79a 100644
--- a/docs/guide/112/managing/monitor_tune/socket_communication.html
+++ b/docs/guide/112/managing/monitor_tune/socket_communication.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/socket_communication_ephemeral_tcp_port_limits.html b/docs/guide/112/managing/monitor_tune/socket_communication_ephemeral_tcp_port_limits.html
index d18a51e..e4deaaa 100644
--- a/docs/guide/112/managing/monitor_tune/socket_communication_ephemeral_tcp_port_limits.html
+++ b/docs/guide/112/managing/monitor_tune/socket_communication_ephemeral_tcp_port_limits.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/socket_communication_have_enough_sockets.html b/docs/guide/112/managing/monitor_tune/socket_communication_have_enough_sockets.html
index ae1cb93..9da2b2b 100644
--- a/docs/guide/112/managing/monitor_tune/socket_communication_have_enough_sockets.html
+++ b/docs/guide/112/managing/monitor_tune/socket_communication_have_enough_sockets.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/socket_communication_setting_socket_buffer_sizes.html b/docs/guide/112/managing/monitor_tune/socket_communication_setting_socket_buffer_sizes.html
index 8056211..515f7ca 100644
--- a/docs/guide/112/managing/monitor_tune/socket_communication_setting_socket_buffer_sizes.html
+++ b/docs/guide/112/managing/monitor_tune/socket_communication_setting_socket_buffer_sizes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/socket_communication_tcpip_p2p_handshake_timeouts.html b/docs/guide/112/managing/monitor_tune/socket_communication_tcpip_p2p_handshake_timeouts.html
index 1dd8254..4639c4d 100644
--- a/docs/guide/112/managing/monitor_tune/socket_communication_tcpip_p2p_handshake_timeouts.html
+++ b/docs/guide/112/managing/monitor_tune/socket_communication_tcpip_p2p_handshake_timeouts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/socket_tcp_keepalive.html b/docs/guide/112/managing/monitor_tune/socket_tcp_keepalive.html
index b9eda16..ba46f82 100644
--- a/docs/guide/112/managing/monitor_tune/socket_tcp_keepalive.html
+++ b/docs/guide/112/managing/monitor_tune/socket_tcp_keepalive.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/sockets_and_gateways.html b/docs/guide/112/managing/monitor_tune/sockets_and_gateways.html
index 66c52f7..cf1b93f 100644
--- a/docs/guide/112/managing/monitor_tune/sockets_and_gateways.html
+++ b/docs/guide/112/managing/monitor_tune/sockets_and_gateways.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/system_member_performance.html b/docs/guide/112/managing/monitor_tune/system_member_performance.html
index b96d8a3..df5d5e3 100644
--- a/docs/guide/112/managing/monitor_tune/system_member_performance.html
+++ b/docs/guide/112/managing/monitor_tune/system_member_performance.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2641,9 +2638,6 @@ limitations under the License.
 <li><p><strong><a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a></strong></p>
 
 <p>If your application exhibits unacceptably high latencies, you might improve performance by modifying your JVM’s garbage collection behavior.</p></li>
-<li><p><strong><a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a></strong></p>
-
-<p>When many peer processes are started concurrently, you can improve the cluster connect time can by setting the p2p.HANDSHAKE_POOL_SIZE system property value to the expected number of members.</p></li>
 </ul>
 
         
diff --git a/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html b/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html
deleted file mode 100644
index ec8cdde..0000000
--- a/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html
+++ /dev/null
@@ -1,2677 +0,0 @@
-<!doctype html>
-<html>
-<head>
-  <meta charset="utf-8">
-  <!-- Always force latest IE rendering engine or request Chrome Frame -->
-  <meta content="IE=edge,chrome=1" http-equiv="X-UA-Compatible">
-
-  
-  <link href='https://fonts.googleapis.com/css?family=Source+Sans+Pro:300,300italic,400italic,400,600' rel='stylesheet' type='text/css'>
-  <!-- Use title if it's in the page YAML frontmatter -->
-  <title>
-      Connection Thread Settings and Performance |
-    Geode Docs
-  </title>
-  <meta name="viewport" content="width=device-width, initial-scale=1.0">
-  <link href="/stylesheets/all.css" rel="stylesheet" media="screen, print" />
-  <link href="/stylesheets/print.css" rel="stylesheet" media="print" />
-  <link href='/images/favicon.ico' rel='shortcut icon'>
-
-  <script src="/javascripts/all.js"></script>
-  
-</head>
-
-<body class="docs docs_guide docs_guide_112 docs_guide_112_managing docs_guide_112_managing_monitor_tune docs_guide_112_managing_monitor_tune_system_member_performance_connection_thread_settings has-subnav">
-
-<div class="viewport">
-  <div class='wrap'>
-    <script type="text/javascript">
-      document.domain = "apache.org";
-    </script>
-
-     
-  <header class="header header-layout">
-    <h1 class="logo">
-      <a href="/">Apache Geode Documentation</a>
-    </h1>
-    
-    <div class="header-links js-bar-links">
-      <div class="btn-menu" data-behavior="MenuMobile"></div>
-      <div class="header-item"><a href="http://geode.apache.org/">Back to Geode Page</a></div>
-      <div class="header-item">
-        <a href="http://geode.apache.org/community" target="_blank">Community</a>
-      </div>
-      
-    </div>
-  </header>
-
-
-    <div class="container">
-
-      <!--googleoff: index-->
-      <!--
-Licensed to the Apache Software Foundation (ASF) under one or more
-contributor license agreements.  See the NOTICE file distributed with
-this work for additional information regarding copyright ownership.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
--->
-<div id="sub-nav" class="js-sidenav nav-container" role="navigation">
-    <a class="sidenav-title" data-behavior="SubMenuMobile">
-        Doc Index
-    </a>
-    <div class="nav-content">
-        <ul>
-            <li>
-                <a href="/docs/guide/112/about_geode.html">Apache Geode Documentation</a>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/getting_started/book_intro.html">Getting Started with Apache Geode</a>
-                <ul>
-                    <li>
-                        <a href="/docs/guide/112/getting_started/geode_overview.html">About Apache Geode</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/getting_started/product_intro.html">Main Features of Apache Geode</a>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/prereq_and_install.html">Prerequisites and Installation Instructions</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/getting_started/system_requirements/host_machine.html">Host Machine Requirements</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/getting_started/installation/install_standalone.html">How to Install</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/getting_started/setup_classpath.html">Setting Up the CLASSPATH</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/getting_started/uninstall_geode.html">How to Uninstall</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/getting_started/15_minute_quickstart_gfsh.html">Apache Geode in 15 Minutes or Less</a>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/configuring/chapter_overview.html">Configuring and Running a Cluster</a>
-                <ul>
-                    <li>
-                        <a href="/docs/guide/112/configuring/cluster_config/gfsh_persist.html">Overview of the Cluster Configuration Service</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/cluster_config/persisting_configurations.html">Tutorial—Creating and Using a Cluster Configuration</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/cluster_config/deploying_application_jars.html">Deploying Application JARs to Apache Geode Members</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/cluster_config/using_member_groups.html">Using Member Groups</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/cluster_config/export-import.html">Exporting and Importing Cluster Configurations</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/cluster_config/gfsh_config_troubleshooting.html">Cluster Configuration Files and Troubleshooting</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/cluster_config/gfsh_remote.html">Using gfsh to Manage a Remote Cluster Over HTTP or HTTPS</a>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/configuring/running/deploying_config_files.html">Deploying Configuration Files without the Cluster Configuration Service</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/configuring/running/deploy_config_files_intro.html">Main Steps to Deploying Configuration Files</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/configuring/running/default_file_specs.html">Default File Specifications and Search Locations</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/configuring/running/change_file_spec.html">Changing the File Specifications</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/configuring/running/deploying_config_jar_files.html">Deploying Configuration Files in JAR Files</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/running/starting_up_shutting_down.html">Starting Up and Shutting Down Your System</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/running/running_the_locator.html">Running Geode Locator Processes</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/running/running_the_cacheserver.html">Running Geode Server Processes</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/configuring/running/managing_output_files.html">Managing System Output Files</a>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/configuring/running/firewall_ports_config.html">Firewall Considerations</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/configuring/running/firewalls_connections.html">Firewalls and Connections</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/configuring/running/firewalls_ports.html">Firewalls and Ports</a>
-                            </li>
-                        </ul>
-                    </li>
-                <li>
-                    <a href="/docs/guide/112/configuring/running/cluster-management-service.html">Cluster Management Service (Experimental)</a>
-                </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/basic_config/book_intro.html">Basic Configuration and Programming</a>
-                <ul>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/basic_config/config_concepts/chapter_overview.html">
-                            Cluster and Cache Configuration</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/config_concepts/distributed_system_member_configuration.html">Cluster Members</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/gemfire_properties/setting_distributed_properties.html">Setting Properties</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/the_cache/setting_cache_properties.html">Options for Configuring the Cache and Data Regions
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/config_concepts/local_vs_remote.html">Local and Remote Membership and Caching</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/basic_config/the_cache/chapter_overview.html">Cache Management</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/the_cache/intro_cache_management.html">Introduction to Cache Management</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/the_cache/managing_a_peer_server_cache.html">Managing a Peer or Server Cache</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/the_cache/managing_a_client_cache.html">Managing a Client Cache</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/the_cache/managing_a_secure_cache.html">Managing a Cache in a Secure System</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/the_cache/managing_a_multiuser_cache.html">Managing RegionServices for Multiple Secure Users</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/the_cache/setting_cache_initializer.html">Launching an Application after Initializing the Cache</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/basic_config/data_regions/chapter_overview.html">Data Regions</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_regions/managing_data_regions.html">Region Management</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_regions/region_naming.html">Region Naming</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_regions/region_shortcuts.html">Region Shortcuts and Custom Named Region Attributes</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_regions/store_retrieve_region_shortcuts.html">Storing and Retrieving Region Shortcuts and Custom Named Region Attributes</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_regions/managing_region_attributes.html">Managing Region Attributes</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_regions/creating_custom_attributes.html">Creating Custom Attributes for Regions and Entries</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_regions/new_region_existing_data.html">Building a New Region with Existing Content</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/basic_config/data_entries_custom_classes/chapter_overview.html">
-                            Data Entries
-                        </a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_entries_custom_classes/managing_data_entries.html">Managing Data Entries</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/basic_config/data_entries_custom_classes/using_custom_classes.html">Requirements for Using Custom Classes in Data Caching</a>
-                            </li>
-                        </ul>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/topologies_and_comm/book_intro.html">Topologies and Communication</a>
-                <ul>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/topologies_and_comm/topology_concepts/chapter_overview.html">Topology and Communication General Concepts</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/topology_types.html">Topology Types</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/member_communication.html">Planning Topology and Communication
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/how_member_discovery_works.html">How Member Discovery Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/how_communication_works.html">How Communication Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/using_bind_addresses.html">Using Bind Addresses</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/IPv4_and_IPv6.html">Choosing Between IPv4 and IPv6</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/topologies_and_comm/p2p_configuration/chapter_overview.html">Peer-to-Peer Configuration</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/p2p_configuration/setting_up_a_p2p_system.html">Configuring Peer-to-Peer Discovery</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/p2p_configuration/setting_up_peer_communication.html">Configuring Peer Communication</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/p2p_configuration/configuring_peer_member_groups.html">Organizing Peers into Logical Member Groups</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/topologies_and_comm/cs_configuration/chapter_overview.html">Client/Server Configuration</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/cs_configuration/standard_client_server_deployment.html">Standard Client/Server Deployment</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/how_server_discovery_works.html">How Server Discovery Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/how_the_pool_manages_connections.html">How Client/Server Connections Work</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/cs_configuration/setting_up_a_client_server_system.html">Configuring a Client/Server System</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/cs_configuration/configure_servers_into_logical_groups.html">Organizing Servers Into Logical Member Groups</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/cs_configuration/client_server_example_configurations.html">Client/Server Example Configurations</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/cs_configuration/client_server_whats_next.html">Fine-Tuning Your Client/Server Configuration</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/topologies_and_comm/multi_site_configuration/chapter_overview.html">Multi-site (WAN) Configuration</a>
-                        <ul>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/topologies_and_comm/topology_concepts/how_multisite_systems_work.html">How Multi-site (WAN) Systems Work</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/topologies_and_comm/topology_concepts/multisite_overview.html#topic_70045702D3994BC692E75102CE01BD7C">
-                                            Overview of Multi-site Caching</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/topologies_and_comm/topology_concepts/multisite_overview.html#topic_C74A0961937640B199396DC925D8D782">Consistency for WAN Updates</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/topologies_and_comm/topology_concepts/multisite_overview.html#topic_1742957C8D4B4F7590847EB8DB6CD4F7">Discovery for Multi-Site Systems</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/topologies_and_comm/topology_concepts/multisite_overview.html#topic_9AA37B43642D4DE19072CA3367C849BA">Gateway Senders</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/topologies_and_comm/topology_concepts/multisite_overview.html#topic_4DB3D9CF01AD4F4899457D1250468D00">Gateway Receivers</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/multi_site_configuration/multisite_topologies.html">Multi-site (WAN) Topologies</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/topologies_and_comm/multi_site_configuration/setting_up_a_multisite_system.html">Configuring a Multi-site (WAN) System</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/events/filtering_multisite_events.html">Filtering Events for Multi-Site (WAN) Distribution</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/events/resolving_multisite_conflicts.html">Resolving Conflicting Events</a>
-                            </li>
-                        </ul>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/managing/book_intro.html">Managing Apache Geode</a>
-                <ul>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/management/management_and_monitoring.html">Apache Geode Management and Monitoring</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/management/management_and_monitoring_features.html">Management and Monitoring Features</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/management/mm_overview.html">Overview of Geode Management and Monitoring Tools</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/management/management_system_overview.html">
-                                    Architecture and Components</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/management/jmx_manager_node.html">JMX Manager Operations</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/management/jmx_manager_operations.html">Starting a JMX Manager</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/management/jmx_manager_operations.html#topic_263072624B8D4CDBAD18B82E07AA44B6">Configuring a JMX Manager</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/management/jmx_manager_operations.html#topic_5B6DF783A14241399DC25C6EE8D0048A">Stopping a JMX Manager</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/management/mbean_architecture.html">Federated MBean Architecture</a>
-                                <ul>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/managing/management/list_of_mbeans.html">List of Geode JMX MBeans</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/managing/management/list_of_mbeans_full.html">JMX Manager MBeans</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/managing/management/list_of_mbeans_full.html#topic_48194A5BDF3F40F68E95A114DD702413">Managed Node MBeans</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/management/mbeans_jconsole.html">Browsing Geode MBeans through JConsole</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/managing/management/mbean_notifications.html">Geode JMX MBean Notifications</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/managing/management/notification_federation_and_alerts.html">Notification Federation</a>
-                                            </li>
-                                            <li class="has_submenu">
-                                                <a href="/docs/guide/112/managing/management/list_of_mbean_notifications.html">List of JMX MBean Notifications</a>
-                                                <ul>
-                                                    <li>
-                                                        <a href="/docs/guide/112/managing/management/list_of_mbean_notifications.html#reference_czt_hq2_vj">MemberMXBean Notifications</a>
-                                                    </li>
-                                                    <li>
-                                                        <a href="/docs/guide/112/managing/management/list_of_mbean_notifications.html#reference_dzt_hq2_vj">MemberMXBean Gateway Notifications</a>
-                                                    </li>
-                                                    <li>
-                                                        <a href="/docs/guide/112/managing/management/list_of_mbean_notifications.html#cacheservermxbean_notifications">CacheServerMXBean Notifications</a>
-                                                    </li>
-                                                    <li>
-                                                        <a href="/docs/guide/112/managing/management/list_of_mbean_notifications.html#distributedsystemmxbean_notifications">DistributedSystemMXBean Notifications</a>
-                                                    </li>
-                                                </ul>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/management/configuring_rmi_connector.html">Configuring RMI Registry Ports and RMI Connectors</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/management/gfsh_and_management_api.html">Executing gfsh Commands through the Management API</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/heap_use/heap_and_off_heap_management.html">Managing Heap and Off-heap Memory</a>
-                        <ul>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/heap_use/heap_management.html">Managing Heap Memory</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/heap_use/heap_management.html#how_the_resource_manager_works">Using the Geode Resource Manager</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/heap_use/heap_management.html#how_the_resource_manager_works__section_EA5E52E65923486488A71E3E6F0DE9DA">How Background Eviction Is Performed</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/heap_use/heap_management.html#configuring_resource_manager_controlling_heap_use">Controlling Heap Use with the Resource Manager</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/heap_use/heap_management.html#configuring_resource_manager__section_4949882892DA46F6BB8588FA97037F45">Configure Geode for Heap LRU Management</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/heap_use/heap_management.html#tuning_jvm_gc_parameters">Tuning the JVM's Garbage Collection Parameters</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/heap_use/heap_management.html#configuring_resource_manager__section_DE1CC494C2B547B083AA00821250972A">Monitor and Tune Heap LRU Configurations</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/heap_use/heap_management.html#resource_manager_example_configurations">Resource Manager Example Configurations</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/heap_use/off_heap_management.html">Managing Off-Heap Memory</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/heap_use/lock_memory.html">Locking Memory (Linux Systems Only)</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/disk_storage/chapter_overview.html">Disk Storage</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/disk_storage/how_disk_stores_work.html">How Disk Stores Work</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/disk_storage/file_names_and_extensions.html">Disk Store File Names and Extensions</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/disk_storage/operation_logs.html">Disk Store Operation Logs</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/disk_storage/overview_using_disk_stores.html">Configuring Disk Stores</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/using_disk_stores.html">Designing and Configuring Disk Stores</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/disk_store_configuration_params.html">Disk Store Configuration Parameters</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/using_the_default_disk_store.html">Modifying the Default Disk Store</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/disk_storage/optimize_availability_and_performance.html">
-                                    Optimizing a System with Disk Stores</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/disk_storage/starting_system_with_disk_stores.html">Start Up and Shut Down with Disk Stores</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/disk_storage/managing_disk_stores.html">Disk Store Management</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/managing_disk_stores_cmds.html">Disk Store Management Commands and Operations</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/validating_disk_store.html">Validating a Disk Store</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/compacting_disk_stores.html">Running Compaction on Disk Store Log Files</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/keeping_offline_disk_store_in_sync.html">Keeping a Disk Store Synchronized with the Cache</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/disk_free_space_monitoring.html">Configuring Disk Free Space Monitoring
-                                        </a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/handling_missing_disk_stores.html">Handling Missing Disk Stores</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/disk_storage/managing_disk_buffer_flushes.html">Altering When Buffers Are Flushed to Disk</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/disk_storage/backup_restore_disk_store.html">Creating Backups for System Recovery and Operational Management</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/cache_snapshots/chapter_overview.html">Cache and Region Snapshots</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/cache_snapshots/using_cache_and_region_snapshots.html">Usage and Performance Notes</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/cache_snapshots/exporting_a_snapshot.html">Exporting Cache and Region Snapshots</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/cache_snapshots/importing_a_snapshot.html">Importing Cache and Region Snapshots</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/cache_snapshots/filtering_snapshot_entries.html">Filtering Entries During Import or Export</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/cache_snapshots/read_snapshots_programmatically.html">Reading Snapshots Programmatically</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/region_compression.html">Region Compression</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/region_compression.html#concept_a2c_rhc_gl">Guidelines on Using Compression</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/region_compression.html#topic_inm_whc_gl">How to Enable Compression in a Region</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/region_compression.html#topic_hqf_syj_g4">Working with Compressors
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/region_compression.html#topic_omw_j3c_gl">Comparing Performance of Compressed and Non-Compressed Regions</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/network_partitioning/chapter_overview.html">Network Partitioning</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/network_partitioning/how_network_partitioning_management_works.html">How Network Partitioning Management Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/network_partitioning/failure_detection.html">Failure Detection and Membership Views</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/network_partitioning/membership_coordinators_lead_members_and_weighting.html">Membership Coordinators, Lead Members and Member Weighting</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/network_partitioning/network_partitioning_scenarios.html">Network Partitioning Scenarios</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/network_partitioning/handling_network_partitioning.html">Configure Apache Geode to Handle Network Partitioning</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/network_partitioning/preventing_network_partitions.html">Preventing Network Partitions</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/security/chapter_overview.html">Security</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/security/implementing_security.html">Security Implementation Introduction and Overview</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/security/security_audit_overview.html">Security Detail Considerations</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/security-audit.html">External Interfaces, Ports, and Services</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/security-audit.html#topic_263072624B8D4CDBAD18B82E07AA44B6">Resources That Must Be Protected</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/security-audit.html#topic_5B6DF783A14241399DC25C6EE8D0048A">Log File Locations</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/properties_file.html">Where to Place Security Configuration Settings</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/security/enable_security.html">Enable Security with Property Definitions</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/security/authentication_overview.html">Authentication</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/implementing_authentication.html">Implementing Authentication</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/authentication_examples.html">Authentication Example</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/security/authorization_overview.html">Authorization</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/implementing_authorization.html">Implementing Authorization</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/method_invocation_authorizers.html">Method Invocation Authorizers</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/authorization_example.html">Authorization Examples</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/security/post_processing.html">Post Processing of Region Data</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/security/ssl_overview.html">SSL</a>
-                                <ul>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/managing/security/implementing_ssl.html">Configuring SSL</a>
-                                    <ul>
-                                        <li>
-                                        <a href="/docs/guide/112/managing/security/implementing_ssl.html#ssl_configurable_components">SSL-Configurable Components</a>
-                                        </li>
-                                        <li>
-                                        <a href="/docs/guide/112/managing/security/implementing_ssl.html#ssl_configuration_properties">SSL Configuration Properties</a>
-                                        </li>
-                                        <li>
-                                        <a href="/docs/guide/112/managing/security/implementing_ssl.html#ssl_property_reference_tables">SSL Property Reference Tables</a>
-                                        </li>
-                                        <li>
-                                        <a href="/docs/guide/112/managing/security/implementing_ssl.html#implementing_ssl__sec_ssl_impl_proc">Procedure</a>
-                                        </li>
-                                    </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/security/ssl_example.html">SSL Sample Implementation</a>
-                                    </li>
-                                </ul>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/monitor_tune/chapter_overview.html">Performance Tuning and Configuration</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/monitor_tune/disabling_tcp_syn_cookies.html">Disabling TCP SYN Cookies</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/monitor_tune/performance_on_vsphere.html">Improving Performance on vSphere</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/monitor_tune/performance_controls.html">Performance Controls</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/performance_controls_data_serialization.html">Data Serialization</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/performance_controls_setting_cache_timeouts.html">Setting Cache Timeouts</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/performance_controls_controlling_socket_use.html">Controlling Socket Use</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/performance_controls_managing_slow_receivers.html">Management of Slow Receivers</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/performance_controls_increasing_cache_hits.html">Increasing the Ratio of Cache Hits</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/monitor_tune/system_member_performance.html">System Member Performance</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_distributed_system_member.html">Member Properties</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_jvm_mem_settings.html">JVM Memory Settings and System Performance</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/monitor_tune/slow_receivers.html">Slow Receivers with TCP/IP</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/slow_receivers_preventing_problems.html">Preventing Slow Receivers</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/slow_receivers_managing.html">Managing Slow Receivers</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/monitor_tune/slow_messages.html">Slow distributed-ack Messages</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/monitor_tune/socket_communication.html">Socket Communication</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/socket_communication_setting_socket_buffer_sizes.html">Setting Socket Buffer Sizes</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/socket_communication_ephemeral_tcp_port_limits.html">Ephemeral TCP Port Limits</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/socket_communication_have_enough_sockets.html">Making Sure You Have Enough Sockets</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/socket_tcp_keepalive.html">TCP/IP KeepAlive Configuration</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/socket_communication_tcpip_p2p_handshake_timeouts.html">TCP/IP Peer-to-Peer Handshake Timeouts</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/sockets_and_gateways.html">Configuring Sockets in Multi-Site (WAN) Deployments</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/monitor_tune/udp_communication.html">UDP Communication</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/monitor_tune/multicast_communication.html">Multicast Communication</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/multicast_communication_provisioning_bandwidth.html">Provisioning Bandwidth for Multicast</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/multicast_communication_testing_multicast_speed_limits.html">Testing Multicast Speed Limits</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/multicast_communication_configuring_speed_limits.html">Configuring Multicast Speed Limits</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/multicast_communication_runtime_considerations.html">Run-time Considerations for Multicast</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/multicast_communication_troubleshooting.html">Troubleshooting the Multicast Tuning Process</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/monitor_tune/cache_consistency.html">Maintaining Cache Consistency</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/logging/logging.html">Logging</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/logging/how_logging_works.html">How Geode Logging Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/logging/logging_categories.html">Understanding Log Messages and Their Categories</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/logging/logging_whats_next.html">Naming, Searching, and Creating Log Files</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/logging/setting_up_logging.html">Set Up Logging</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/logging/configuring_log4j2.html">Advanced Users—Configuring Log4j 2 for Geode</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/statistics/chapter_overview.html">Statistics</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/statistics/how_statistics_work.html">How Statistics Work</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/statistics/transient_region_and_entry_statistics.html">Transient Region and Entry Statistics</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/statistics/application_defined_statistics.html">Application-Defined and Custom Statistics</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/statistics/setting_up_statistics.html">Configuring and Using Statistics</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/statistics/viewing_statistics.html">Viewing Archived Statistics</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/managing/troubleshooting/chapter_overview.html">Troubleshooting and System Recovery</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/managing/troubleshooting/producing_troubleshooting_artifacts.html">Producing Artifacts for Troubleshooting</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/troubleshooting/diagnosing_system_probs.html">Diagnosing System Problems</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/troubleshooting/system_failure_and_recovery.html">System Failure and Recovery</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/member-reconnect.html">Handling Forced Cache Disconnection Using Autoreconnect</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/managing/troubleshooting/recovering_from_app_crashes.html">Recovering from Application and Cache Server Crashes</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/troubleshooting/recovering_from_p2p_crashes.html">Recovering from Crashes with a Peer-to-Peer Configuration</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/troubleshooting/recovering_from_cs_crashes.html">Recovering from Crashes with a Client/Server Configuration</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/troubleshooting/recovering_from_machine_crashes.html">Recovering from Machine Crashes</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/troubleshooting/recovering_conflicting_data_exceptions.html">Recovering from ConfictingPersistentDataExceptions</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/troubleshooting/prevent_and_recover_disk_full_errors.html">Preventing and Recovering from Disk Full Errors</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/managing/troubleshooting/recovering_from_network_outages.html">Understanding and Recovering from Network Outages</a>
-                            </li>
-                        </ul>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/developing/book_intro.html">Developing with Apache Geode</a>
-                <ul>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/region_options/chapter_overview.html">
-                            Region Data Storage and Distribution</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/region_options/storage_distribution_options.html">
-                                    Storage and Distribution Options</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/region_options/region_types.html">Region Types</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/region_options/data_hosts_and_accessors.html">Region Data Stores and Data Accessors</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/region_options/dynamic_region_creation.html">Creating Regions Dynamically</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/partitioned_regions/chapter_overview.html">Partitioned Regions</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/partitioned_regions/how_partitioning_works.html">Understanding Partitioning</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/partitioned_regions/managing_partitioned_regions.html">Configuring Partitioned Regions</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/partitioned_regions/configuring_bucket_for_pr.html">Configuring the Number of Buckets for a Partitioned Region</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/partitioned_regions/overview_custom_partitioning_and_data_colocation.html">Custom-Partitioning and Colocating Data</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/partitioned_regions/custom_partitioning_and_data_colocation.html">Understanding Custom Partitioning and Data Colocation</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/partitioned_regions/standard_custom_partitioning.html">Standard Custom Partitioning</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/partitioned_regions/fixed_custom_partitioning.html">Fixed Custom Partitioning</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/partitioned_regions/colocating_partitioned_region_data.html">Colocate Data from Different Partitioned Regions</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/partitioned_regions/overview_how_pr_ha_works.html">Configuring High Availability for Partitioned Regions</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/partitioned_regions/how_pr_ha_works.html">Understanding High Availability for Partitioned Regions</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/developing/partitioned_regions/configuring_ha_for_pr.html">Configure High Availability for a Partitioned Region</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/partitioned_regions/set_pr_redundancy.html">Set the Number of Redundant Copies</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/partitioned_regions/set_redundancy_zones.html">Configure Redundancy Zones for Members</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/partitioned_regions/set_enforce_unique_host.html">Set Enforce Unique Host</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/partitioned_regions/set_crash_redundancy_recovery.html">Configure Member Crash Redundancy Recovery for a Partitioned Region</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/partitioned_regions/set_join_redundancy_recovery.html">Configure Member Join Redundancy Recovery for a Partitioned Region</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/partitioned_regions/overview_how_pr_single_hop_works.html">Configuring Single-Hop Client Access to Server-Partitioned Regions</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/partitioned_regions/how_pr_single_hop_works.html">Understanding Client Single-Hop Access to Server-Partitioned Regions</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/partitioned_regions/configure_pr_single_hop.html">Configure Client Single-Hop Access to Server-Partitioned Regions</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/partitioned_regions/rebalancing_pr_data.html">Rebalancing Partitioned Region Data</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/partitioned_regions/checking_region_redundancy.html">Checking Redundancy in Partitioned Regions</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/partitioned_regions/moving_partitioned_data.html">Moving Partitioned Region Data to Another Member</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/distributed_regions/chapter_overview.html">
-                            Distributed and Replicated Regions</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_distribution_works.html">How Distribution Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/choosing_level_of_dist.html">Options for Region Distribution</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_replication_works.html">How Replication and Preloading Work</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/managing_distributed_regions.html">Configure Distributed, Replicated, and Preloaded Regions</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/locking_in_global_regions.html">Locking in Global Regions</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/distributed_regions/region_entry_versions.html">Consistency for Region Updates</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html#topic_7A4B6C6169BD4B1ABD356294F744D236">
-                                    Consistency Checking by Region Type</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html#topic_B64891585E7F4358A633C792F10FA23E">Configuring Consistency Checking</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html#topic_0BDACA590B2C4974AC9C450397FE70B2">Overhead for Consistency Checks</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html#topic_C5B74CCDD909403C815639339AA03758">How Consistency Checking Works for Replicated Regions</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html#topic_321B05044B6641FCAEFABBF5066BD399">How Destroy and Clear Operations Are Resolved</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/distributed_regions/how_region_versioning_works.html#topic_32ACFA5542C74F3583ECD30467F352B0">Transactions with Consistent Regions</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/general_region_data_management.html">General Region Data Management</a>
-                        <ul>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/storing_data_on_disk/chapter_overview.html">Persistence and Overflow</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/storing_data_on_disk/how_persist_overflow_work.html">How Persistence and Overflow Work</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/storing_data_on_disk/storing_data_on_disk.html">Configure Region Persistence and Overflow</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/storing_data_on_disk/overflow_config_examples.html">Overflow Configuration Examples</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/eviction/chapter_overview.html">Eviction</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/eviction/how_eviction_works.html">How Eviction Works</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/eviction/configuring_data_eviction.html">Configure Data Eviction</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/expiration/chapter_overview.html">Expiration</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/expiration/how_expiration_works.html">How Expiration Works</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/expiration/configuring_data_expiration.html">Configure Data Expiration</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/outside_data_sources/sync_outside_data.html">Keeping the Cache in Sync with Outside Data Sources</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/outside_data_sources/chapter_overview.html">Overview of Outside Data Sources</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/outside_data_sources/configuring_db_connections_using_JNDI.html">Configuring Database Connections Using JNDI</a>
-                                    </li>
-
-                                    <li>
-                                        <a href="/docs/guide/112/developing/outside_data_sources/how_data_loaders_work.html">How Data Loaders Work</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/outside_data_sources/implementing_data_loaders.html">Implement a Data Loader</a>
-                                    </li>
-                                </ul>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/data_serialization/chapter_overview.html">Data Serialization</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/data_serialization/data_serialization_options.html">Overview of Data Serialization</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/data_serialization/gemfire_pdx_serialization.html">Geode PDX Serialization</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/PDX_Serialization_Features.html">Geode PDX Serialization Features</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/use_pdx_high_level_steps.html">High Level Steps for Using PDX Serialization
-                                        </a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/developing/data_serialization/auto_serialization.html">Using Automatic Reflection-Based PDX Serialization</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/data_serialization/autoserialization_with_class_pattern_strings.html">Customizing Serialization with Class Pattern Strings</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/data_serialization/extending_the_autoserializer.html">Extending the ReflectionBasedAutoSerializer</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/use_pdx_serializer.html">Serializing Your Domain Object with a PdxSerializer</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/use_pdx_serializable.html">Implementing PdxSerializable in Your Domain Object</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/program_application_for_pdx.html">Programming Your Application to Use PdxInstances</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/jsonformatter_pdxinstances.html">Adding JSON Documents to the Geode Cache</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/using_PdxInstanceFactory.html">Using PdxInstanceFactory to Create PdxInstances</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/persist_pdx_metadata_to_disk.html">Persisting PDX Metadata to Disk</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/data_serialization/using_pdx_region_entry_keys.html">Using PDX Objects as Region Entry Keys</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/data_serialization/gemfire_data_serialization.html">Geode Data Serialization (DataSerializable and DataSerializer)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/data_serialization/java_serialization.html">Standard Java Serialization</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/events/chapter_overview.html">Events and Event Handling</a>
-                        <ul>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/events/how_events_work.html">How Events Work</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/how_cache_events_work.html">Peer-to-Peer Event Distribution</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/how_client_server_distribution_works.html">Client-to-Server Event Distribution</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/how_multisite_distribution_works.html">
-                                            Multi-Site (WAN) Event Distribution</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/list_of_event_handlers_and_events.html">List of Event Handlers and Events</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/events/event_handler_overview.html">Implementing Geode Event Handlers</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/implementing_cache_event_handlers.html">Implementing Cache Event Handlers</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/implementing_write_behind_event_handler.html">Implementing an AsyncEventListener for Write-Behind Cache Event Handling</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/writing_callbacks_that_modify_the_cache.html">How to Safely Modify the Cache from an Event Handler Callback</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/cache_event_handler_examples.html">Cache Event Handler Examples</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/events/configure_p2p_event_messaging.html">Configuring Peer-to-Peer Event Messaging</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/events/configure_client_server_event_messaging.html">Configuring Client/Server Event Messaging
-                                </a>
-                                <ul>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/developing/events/configuring_highly_available_servers.html">Configuring Highly Available Servers</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/events/ha_event_messaging_whats_next.html">Highly Available Client/Server Event Messaging</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/implementing_durable_client_server_messaging.html">Implementing Durable Client/Server Messaging</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/developing/events/tune_client_server_event_messaging.html">Tuning Client/Server Event Messaging</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/events/conflate_server_subscription_queue.html">Conflate the Server Subscription Queue</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/events/limit_server_subscription_queue_size.html">Limit the Server's Subscription Queue Memory Use
-                                                </a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/events/tune_client_message_tracking_timeout.html">Tune the Client's Subscription Message Tracking Timeout</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/events/configure_multisite_event_messaging.html">Configuring Multi-Site (WAN) Event Queues</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/configuring_highly_available_gateway_queues.html">Persisting an Event Queue</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/configuring_gateway_concurrency_levels.html">Configuring Dispatcher Threads and Order Policy for Event Distribution</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/events/conflate_multisite_gateway_queue.html">Conflating Events in a Queue</a>
-                                    </li>
-                                </ul>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/delta_propagation/chapter_overview.html">
-                            Delta Propagation</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/delta_propagation/how_delta_propagation_works.html">How Delta Propagation Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/delta_propagation/when_to_use_delta_prop.html">When to Avoid Delta Propagation</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/delta_propagation/delta_propagation_properties.html">Delta Propagation Properties</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/delta_propagation/implementing_delta_propagation.html">Implementing Delta Propagation</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/delta_propagation/errors_in_delta_propagation.html">Errors In Delta Propagation</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/delta_propagation/delta_propagation_example.html">Delta Propagation Example</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/querying_basics/chapter_overview.html">Querying</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/getting_started/querying_quick_reference.html">Geode Querying FAQ and Examples</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/querying_basics/query_basics.html">Querying with OQL</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/querying_basics/oql_compared_to_sql.html">Advantages of OQL</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/querying_basics/running_a_query.html">Writing and Executing a Query in Geode</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/developing/querying_basics/what_is_a_query_string.html">Building a Query String</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_select/the_import_statement.html">IMPORT Statement</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_select/the_from_clause.html">FROM Clause</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_select/the_where_clause.html">WHERE Clause</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_select/the_select_statement.html">SELECT Statement</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_select/aggregates.html">OQL Aggregate Functions</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/developing/query_additional/query_language_features.html">OQL Syntax and Semantics</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/querying_basics/supported_character_sets.html">Supported Character Sets</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/supported_keywords.html">Supported Keywords</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/case_sensitivity.html">Case Sensitivity</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/querying_basics/comments_in_query_strings.html">Comments in Query Strings</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/querying_basics/query_grammar_and_reserved_words.html">Query Language Grammar</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/operators.html">Operators</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/querying_basics/reserved_words.html">Reserved Words</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/literals.html">Supported Literals</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/querying_basics/restrictions_and_unsupported_features.html">Query Language Restrictions and Unsupported Features</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/query_additional/advanced_querying.html">Advanced Querying</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/querying_basics/performance_considerations.html">Performance Considerations</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/querying_basics/monitor_queries_for_low_memory.html">Monitoring Low Memory When Querying</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_additional/query_timeout.html">Timeouts for Long-Running Queries</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_additional/using_query_bind_parameters.html">Using Query Bind Parameters</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/developing/querying_basics/querying_partitioned_regions.html">
-                                            Querying Partitioned Regions</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/order_by_on_partitioned_regions.html">Using ORDER BY on Partitioned Regions</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/query_on_a_single_node.html">Querying a Partitioned Region on a Single Node</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/partitioned_region_key_or_field_value.html">Optimizing Queries on Data Partitioned by a Key or Field Value</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/partitioned_regions/join_query_partitioned_regions.html">Performing an Equi-Join Query on Partitioned Regions</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/developing/query_additional/partitioned_region_query_restrictions.html">Partitioned Region Query Restrictions</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_additional/query_debugging.html">Query Debugging</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/developing/query_index/query_index.html">Working with Indexes</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/indexing_guidelines.html">Tips and Guidelines on Using Indexes</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/creating_an_index.html">Creating, Listing and Removing Indexes</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/creating_key_indexes.html">Creating Key Indexes</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/creating_hash_indexes.html">Creating Hash Indexes</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/creating_map_indexes.html">Creating Indexes on Map Fields ("Map Indexes")</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/create_multiple_indexes.html">Creating Multiple Indexes at Once</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/maintaining_indexes.html">Maintaining Indexes (Synchronously or Asynchronously) and Index Storage</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/query_index_hints.html">Using Query Index Hints</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/indexes_on_single_region_queries.html">Using Indexes on Single Region Queries</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries.html">Using Indexes with Equi-Join Queries</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/indexes_with_overflow_regions.html">Using Indexes with Overflow Regions</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/using_indexes_with_equijoin_queries_multiple_regions.html">Using Indexes on Equi-Join Queries using Multiple Regions</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/developing/query_index/index_samples.html">Index Samples</a>
-                                    </li>
-                                </ul>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/continuous_querying/chapter_overview.html">
-                            Continuous Querying</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/continuous_querying/how_continuous_querying_works.html">How Continuous Querying Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/continuous_querying/implementing_continuous_querying.html">Implementing Continuous Querying</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/continuous_querying/continuous_querying_whats_next.html">Managing Continuous Querying</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/transactions/chapter_overview.html">Transactions</a>
-                        <ul>
-                           <li>
-                           <a href="/docs/guide/112/developing/transactions/transactions_intro.html">Adherence to ACID Promises</a>
-                           </li>
-                           <li>
-                           <a href="/docs/guide/112/developing/transactions/directed_example.html">Code Examples</a>
-                           </li>
-                           <li>
-                           <a href="/docs/guide/112/developing/transactions/design_considerations.html">Design Considerations</a>
-                           </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/developing/function_exec/chapter_overview.html">Function Execution</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/developing/function_exec/how_function_execution_works.html">How Function Execution Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/developing/function_exec/function_execution.html">Executing a Function in Apache Geode</a>
-                            </li>
-                        </ul>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/rest_apps/book_intro.html">Developing REST Applications for Apache Geode</a>
-                <ul>
-                    <li>
-                        <a href="/docs/guide/112/rest_apps/chapter_overview.html">Geode REST API Overview</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/rest_apps/rest_prereqs.html">Prerequisites and Limitations for Writing REST Applications</a>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/rest_apps/setup_config.html">Setup and Configuration</a>
-                        <ul>
-                        <li><a href="/docs/guide/112/rest_apps/setup_config.html#setup_config_enabling_rest">Enabling the REST API</a></li>
-                        <li><a href="/docs/guide/112/rest_apps/setup_config.html#setup_config_starting_rest">Starting the REST API Service</a></li>
-                        <li><a href="/docs/guide/112/rest_apps/setup_config.html#setup_config_implementing_auth">Implementing Authentication</a></li>
-                        <li><a href="/docs/guide/112/rest_apps/setup_config.html#setup_config_implementing_auth">Programmatic Startup</a></li>
-                        </ul>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/rest_apps/using_swagger.html">Using the Swagger UI to Browse REST APIs</a>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/rest_apps/develop_rest_apps.html">Developing REST Applications</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/rest_apps/develop_rest_apps.html#topic_qhs_f25_m4">Working with Regions</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/rest_apps/develop_rest_apps.html#topic_fcn_g25_m4">Working with Queries</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/rest_apps/develop_rest_apps.html#topic_rbc_h25_m4">Working with Functions</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/rest_apps/rest_examples.html">Sample REST Applications</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/rest_apps/troubleshooting.html">Troubleshooting and FAQ</a>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/rest_apps/rest_api_reference.html">Apache Geode REST API Reference</a>
-                        <ul>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/rest_apps/rest_regions.html">Region Endpoints</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_regions.html">GET /geode/v1</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_region_data.html">GET /geode/v1/{region}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_region_keys.html">GET /geode/v1/{region}/keys</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_region_key_data.html">GET /geode/v1/{region}/{key}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_region_data_for_multiple_keys.html">GET /geode/v1/{region}/{key1},{key2},...,{keyN}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/head_region_size.html">HEAD /geode/v1/{region}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/post_if_absent_data.html">POST /geode/v1/{region}?key=&lt;key&gt;</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/put_update_data.html">PUT /geode/v1/{region}/{key}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/put_multiple_values_for_keys.html">PUT /geode/v1/{region}/{key1},{key2},...{keyN}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/put_replace_data.html">PUT /geode/v1/{region}/{key}?op=REPLACE</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/put_update_cas_data.html">PUT /geode/v1/{region}/{key}?op=CAS</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/delete_all_data.html">DELETE /geode/v1/{region}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/delete_data_for_key.html">DELETE /geode/v1/{region}/{key}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/delete_data_for_multiple_keys.html">DELETE /geode/v1/{region}/{key1},{key2},...{keyN}</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/rest_apps/rest_queries.html">Query Endpoints</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_queries.html">GET /geode/v1/queries</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/post_create_query.html">POST /geode/v1/queries?id=&lt;queryId&gt;&amp;q=&lt;OQL-statement&gt;</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/post_execute_query.html">POST /geode/v1/queries/{queryId}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/put_update_query.html">PUT /geode/v1/queries/{queryId}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/delete_named_query.html">DELETE /geode/v1/queries/{queryId}</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_execute_adhoc_query.html">GET /geode/v1/queries/adhoc?q=&lt;OQL-statement&gt;</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/rest_apps/rest_functions.html">Function Endpoints</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_functions.html">GET /geode/v1/functions</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/post_execute_functions.html">POST /geode/v1/functions/{functionId}</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/rest_apps/rest_admin.html">Administrative Endpoints</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/ping_service.html">[HEAD | GET] /geode/v1/ping</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/rest_apps/get_servers.html">GET /geode/v1/servers</a>
-                                    </li>
-                                </ul>
-                            </li>
-                        </ul>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/tools_modules/book_intro.html">Tools and Modules</a>
-                <ul>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/tools_modules/gfsh/chapter_overview.html">
-gfsh</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/about_gfsh.html">What You Can Do with gfsh</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/starting_gfsh.html">Starting gfsh</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/configuring_gfsh.html">Configuring the gfsh Environment</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/useful_gfsh_shell_variables.html">Useful gfsh Shell Variables</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/getting_started_gfsh.html">Basic Shell Features and Command-Line Usage</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/json_in_gfsh.html">Specifying JSON within Command-Line Options</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/tour_of_gfsh.html">Tutorial—Performing Common Tasks with gfsh</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/tools_modules/gfsh/gfsh_quick_reference.html">Quick Reference of gfsh Commands by Functional Area</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_77DA6E3929404EB4AC24230CC7C21493">Basic Geode gfsh Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_EB854534301A477BB01058B3B142AE1D">Configuration Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_C7DB8A800D6244AE8FF3ADDCF139DCE4">Data Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_1B47A0E120124EB6BF08A467EB510412">Deployment Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_1ACC91B493EE446E89EC7DBFBBAE00EA">Disk Store Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_10613D4850F04A3EB507F6B441AD3413">Durable CQ and Client Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_8BB061D1A7A9488C819FE2B7881A1278">Function Execution Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_F0AE5CE40D6D49BF92247F5EF4F871D2">Gateway (WAN) Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_B742E9E862BA457082E2346581C97D03">Geode Monitoring Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_688C66526B4649AFA51C0F72F34FA45E">Index Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_2A6DA4078E4E496A9F725A29BC4CFD0D">JMX Connection Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_1C82E6F1B2AF4A65A8DA6B3C846BAC13">Locator Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_lucene_commands">Lucene Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_cvg_bls_5q">PDX Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_EF03129A40EE492984F3B6248596E1DD">Region Commands</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html#topic_8A341FF86958466E9E64CF06CD21FED9">Server Commands</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/tools_modules/gfsh/gfsh_command_index.html">gfsh Command Help</a>
-                                <ul>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/alter.html">alter</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/alter.html#topic_alter_async_event_queue">alter async-event-queue</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/alter.html#topic_99BCAD98BDB5470189662D2F308B68EB">alter disk-store</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/alter.html#topic_alter_query_service">alter query-service</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/alter.html#topic_E74ED23CB60342538B2175C326E7D758">alter region</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/alter.html#topic_7E6B7E1B972D4F418CB45354D1089C2B">alter runtime</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/backup.html">backup disk-store</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/change.html">change loglevel</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/clear.html">clear defined indexes</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/close.html">close</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/close.html#topic_4125AAAB9FE44CD787166E48B694C41D">close durable-client</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/close.html#topic_1BC15B3132BA480DB227921A9B3ABDD1">close durable-cq</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/compact.html">compact</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/compact.html#topic_F123C95C076F424E9AA8AC4F1F6324CC">compact disk-store</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/compact.html#topic_9CCFCB2FA2154E16BD775439C8ABC8FB">compact offline-disk-store</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/configure.html">configure</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/connect.html">connect</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html">create</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#topic_ryz_pb1_dk">create async-event-queue</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#topic_w2t_l3m_qq">create defined indexes</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#topic_bkn_zty_ck">create disk-store</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#topic_a4x_pb1_dk">create gateway-receiver</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#topic_hg2_bjz_ck">create gateway-sender</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#topic_960A5B6FD3D84E1881EE128E299DD12D">create index</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#create_jndi-binding">create jndi-binding</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#create_lucene_index">create lucene index</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/create.html#topic_54B0985FEC5241CA9D26B0CE0A5EA863">create region</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/debug.html">debug</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/define.html">define index</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/deploy.html">deploy</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html">describe</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_gyr_jgz_ck">describe client</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_3C2C817D999C4E40AF788808B7B6AF99">describe config</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_591DC6B781B641268E6173E69AC6D201">describe connection
-                                                </a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_C635B500BE6A4F1D9572D0BC98A224F2">describe disk-store</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#describe_jndi-binding">describe jndi-binding</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#describe_lucene_index">describe lucene index</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_D62F3D42B1D84CF68F03D54D5122806A">describe member</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_kys_yvk_2l">describe offline-disk-store</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_describe_query_service">describe query-service</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/describe.html#topic_DECF7D3D33F54071B6B8AD4EA7E3F90B">describe region
-                                                </a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html">destroy</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#topic_destroy-async-event-queue">destroy async-event-queue</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#topic_yfr_l2z_ck">destroy disk-store</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#topic_E48C2DF809054C12A162026D8A2139BB">destroy function</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#destroy-gr">destroy gateway-receiver</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#destroy-gs">destroy gateway-sender</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#topic_D00219CCD6F64C1582A0802AC5CDF3F3">destroy index</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#destroy_jndi-binding">destroy jndi-binding</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#destroy_lucene_index">destroy lucene index</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html#topic_BEDACECF4599407794ACBC0E56B30F65">destroy region</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/disconnect.html">disconnect</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/echo.html">echo</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/execute.html">execute function</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/exit.html">exit</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/export.html">export</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/export.html#topic_mdv_jgz_ck">export cluster-configuration
-                                                </a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/export.html#topic_C7C69306F93743459E65D46537F4A1EE">export config</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/export.html#topic_263B70069BFC4A7185F86B3272011734">export data</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/export.html#topic_B80978CC659244AE91E2B8CE56EBDFE3">export logs</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/export.html#topic_sjg_bvt_gq">export offline-disk-store</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/export.html#topic_195D27B8B2B64A4E84CF2256636D54BD">export stack-traces</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/gc.html">gc</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/get.html">get</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/help.html">help</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/hint.html">hint</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/history.html">history</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/import.html">import</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/import.html#topic_vnv_grz_ck">import cluster-configuration</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/import.html#topic_jw2_2ld_2l">import data</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html">list</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_j22_kzk_2l">list async-event-queues</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_ts1_qb1_dk">list clients</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_59DF60DE71AD4097B281749425254BFF">list deployed
-                                                </a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_BC14AD57EA304FB3845766898D01BD04">list disk-stores</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_66016A698C334F4EBA19B99F51B0204B">list durable-cqs</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_DCC7CCBBEF5942B783A8F2A4A5B2FABF">list functions</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_B1D89671C7B74074899C7D52F15849ED">list gateways</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_B3B51B6DEA484EE086C4F657EC9831F2">list indexes</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#list_jndi-binding">list jndi-binding</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#list_lucene_indexes">list lucene indexes</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_5B5BFB2E5F314210858641BE3A689637">list members</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/list.html#topic_F0ECEFF26086474498598035DD83C588">list regions</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/load-balance.html">load-balance gateway-sender</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/locate.html">locate entry</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/netstat.html">netstat</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/pause.html">pause gateway-sender</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/pdx.html">pdx rename</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/put.html">put</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/query.html">query</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/rebalance.html">rebalance</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/remove.html">remove</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/resume.html">resume</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/resume.html#topic_resume_async_event_queue_dispatcher">resume async-event-queue-dispatcher</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/resume.html#topic_resume_gateway_sender">resume gateway-sender</a>
-                                            </li>
-                                        </ul>
-                                        </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/revoke.html">revoke missing-disk-store</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/run.html">run</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/search.html">search lucene</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/set.html">set variable</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/sh.html">sh</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/show.html">show</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/show.html#topic_1225347FAD6541DF995C9999650165B1">show dead-locks</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/show.html#topic_45AAEDAC3AFF46EC9BB68B24FC9A32B3">show log</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/show.html#topic_6EB786C63AEB46179EEE8FA18624295A">show metrics</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/show.html#topic_7B3D624D5B4F41D1A0F8A9C3C8B2E780">show missing-disk-stores</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/show.html#topic_395C96B500AD430CBF3D3C8886A4CD2E">show subscription-queue-size</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/shutdown.html">shutdown</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/sleep.html">sleep</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html">start</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html#topic_67738A5B68E84DEE95D1C92DAB2E26E5">start gateway-receiver</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html#topic_AB8BA3F42B9645A8BE9BD97CE2F839A8">start gateway-sender</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html#topic_D00507416F3944DFAB48D2FA2B9E4A31">start jconsole</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html#topic_5B5BF8BEE905463D8B7762B89E2D65E7">start jvisualvm
-                                                </a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html#topic_591260CF25D64562A0EDD7260D2AC6D4">start locator</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html#topic_E906BA7D9E7F4C5890FEFA7ECD40DD77">start pulse</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/start.html#topic_3764EE2DB18B4AE4A625E0354471738A">start server</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/status.html">status</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/status.html#topic_ts1_qb1_dk2">status cluster-config-service</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/status.html#topic_B0F45DC2D5F64FB1A2F738206BC6539E">status gateway-receiver</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/status.html#topic_6F539877F0564F05AF264A9E704EC842">status gateway-sender</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/status.html#topic_E96D0EFA513C4CD79B833FCCDD69C832">status locator</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/status.html#topic_E5DB49044978404D9D6B1971BF5D400D">status server</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/stop.html">stop</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/stop.html#topic_CD1D526FD6F84A7B80B25C741229ED30">stop gateway-receiver
-                                                </a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/stop.html#topic_0BBDD4B3B8A44A65A610F766C9E85519">stop gateway-sender</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/stop.html#topic_EF61C54B35BA4AB7B14E58CF912F283E">stop locator</a>
-                                            </li>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/gfsh/command-pages/stop.html#topic_723EE395A63A40D6819618AFC2902125">stop server</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/undeploy.html">undeploy</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/validate.html">validate offline-disk-store</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/gfsh/command-pages/version.html">version</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/command_scripting.html">Creating and Running gfsh Command Scripts</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/os_command_line_execution.html">Running gfsh Commands on the OS Command Line</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gfsh/cache_xml_2_gfsh.html">Mapping cache.xml Elements to gfsh Configuration Commands</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/tools_modules/gemcached/chapter_overview.html">Gemcached</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gemcached/about_gemcached.html">How Gemcached Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gemcached/deploying_gemcached.html">Deploying and Configuring a Gemcached Server</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/gemcached/advantages.html">Advantages of Gemcached over Memcached</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/chapter_overview.html">HTTP Session Management Modules</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/quick_start.html">HTTP Session Management Quick Start</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/http_why_use_gemfire.html">Advantages of Using Geode for Session Management</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/common_gemfire_topologies.html">Common Topologies for HTTP Session Management</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/tc_additional_info.html">General Information on HTTP Session Management</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/session_state_log_files.html">Session State Log Files</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/configuring_non_sticky_sessions.html">Configuring Non-Sticky Sessions</a>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/session_mgmt_tcserver.html">HTTP Session Management Module for Pivotal tc Server</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/tc_installing_the_module.html">Installing the HTTP Module for tc Server</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/tc_setting_up_the_module.html">Setting Up the HTTP Module for tc Server</a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/tc_changing_gf_default_cfg.html">Changing the Default Geode Configuration in the tc Server Module</a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/interactive_mode_ref.html">Interactive Configuration Reference for the tc Server Module
-                                                </a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/session_mgmt_tomcat.html">HTTP Session Management Module for Tomcat</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/tomcat_installing_the_module.html">Installing the HTTP Module for Tomcat</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/tomcat_setting_up_the_module.html">Setting Up the HTTP Module for Tomcat</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/tomcat_changing_gf_default_cfg.html">Changing the Default Geode Configuration in the Tomcat Module</a>
-                                    </li>
-                                </ul>
-                            </li>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/session_mgmt_weblogic.html">HTTP Session Management Module for AppServers</a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/weblogic_setting_up_the_module.html">Setting Up the HTTP Module for AppServers
-                                        </a>
-                                    </li>
-                                    <li class="has_submenu">
-                                        <a href="/docs/guide/112/tools_modules/http_session_mgmt/weblogic_changing_gf_default_cfg.html">Changing the Default Geode Configuration in the AppServers Module
-                                        </a>
-                                        <ul>
-                                            <li>
-                                                <a href="/docs/guide/112/tools_modules/http_session_mgmt/weblogic_common_configuration_changes.html">Common Geode Configuration Changes for AppServers</a>
-                                            </li>
-                                        </ul>
-                                    </li>
-                                </ul>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/tools_modules/pulse/pulse-overview.html">Geode Pulse</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/pulse/pulse-requirements.html">Pulse System Requirements</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/pulse/pulse-embedded.html">Running Pulse in Embedded Mode (Quick Start)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/pulse/pulse-hosted.html">Hosting Pulse on a Web Application Server</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/pulse/pulse-auth.html">Configuring Pulse Authentication</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/pulse/pulse-views.html">Using Pulse Views</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/tools_modules/redis_adapter.html">Geode Redis Adapter</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/redis_adapter.html#using-the-redis-adapter">Using the Redis Adapter</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/redis_adapter.html#how-the-redis-adapter-works">How the Redis Adapter Works</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/redis_adapter.html#advantages-of-geode-over-redis">Advantages of Geode over a Redis Server</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/tools_modules/lucene_integration.html">Apache Lucene Integration</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/lucene_integration.html#using-the-apache-lucene-integration">Using the Apache Lucene Integration</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/lucene_integration.html#LuceneRandC">Requirements and Caveats</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/tools_modules/micrometer/micrometer-overview.html">Micrometer</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/micrometer/micrometer-configuration.html">Configuration and Publishing</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/tools_modules/micrometer/micrometer-meters.html">Micrometer Meters and Tags</a>
-                            </li>                    
-                        </ul>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/use_cases/book_intro.html">Use Cases</a>
-                <ul>
-                    <li>
-                        <a href="/docs/guide/112/use_cases/inline-cache.html">The Inline Cache</a>
-                    </li>
-                </ul>
-            </li>
-            <li class="has_submenu">
-                <a href="/docs/guide/112/reference/book_intro.html">Reference</a>
-                <ul>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/reference/topics/gemfire_properties.html">gemfire.properties and gfsecurity.properties (Geode Properties)</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/non-ascii_strings_in_config_files.html">Using Non-ASCII Strings in Apache Geode Property Files</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/reference/topics/chapter_overview_cache_xml.html">cache.xml
-                        </a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/elements_ref.html">cache.xml Quick Reference</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/cache-elements-list.html">&lt;cache&gt; Element Hierarchy</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/cache_xml.html">&lt;cache&gt; Element Reference</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/client-cache-elements-list.html">
-                                    &lt;client-cache&gt; Element Hierarchy</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/client-cache.html">&lt;client-cache&gt; Element Reference</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/reference/topics/chapter_overview_regionshortcuts.html">Region Shortcuts</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_table.html">Region Shortcuts Quick Reference</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_w2h_3cd_lk">
-                                    LOCAL
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_wd5_lpy_lk">
-                                    LOCAL_HEAP_LRU
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_adk_y4y_lk">
-                                    LOCAL_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_l5r_y4y_lk">
-                                    LOCAL_PERSISTENT
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_a45_y4y_lk">
-                                    LOCAL_PERSISTENT_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_ow5_4qy_lk">
-                                    PARTITION
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_twx_y4y_lk">
-                                    PARTITION_HEAP_LRU
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_js1_z4y_lk">
-                                    PARTITION_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_d4k_jpy_lk">
-                                    PARTITION_PERSISTENT
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_v5l_jpy_lk">
-                                    PARTITION_PERSISTENT_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_v4m_jpy_lk">
-                                    PARTITION_PROXY
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_c1n_jpy_lk">
-                                    PARTITION_PROXY_REDUNDANT
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_shn_jpy_lk">
-                                    PARTITION_REDUNDANT
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_m4n_jpy_lk">
-                                    PARTITION_REDUNDANT_HEAP_LRU
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_own_jpy_lk">
-                                    PARTITION_REDUNDANT_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_bd4_jpy_lk">
-                                    PARTITION_REDUNDANT_PERSISTENT
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_xqq_tvc_lk">
-                                    PARTITION_REDUNDANT_PERSISTENT_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_wq4_jpy_lk">
-                                    REPLICATE
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_xx4_jpy_lk">
-                                    REPLICATE_HEAP_LRU
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_t2p_jpy_lk">
-                                    REPLICATE_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_emp_jpy_lk">
-                                    REPLICATE_PERSISTENT
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_tsp_jpy_lk">
-                                    REPLICATE_PERSISTENT_OVERFLOW
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/topics/region_shortcuts_reference.html#reference_n1q_jpy_lk">
-                                    REPLICATE_PROXY
-                                </a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/reference/topics/handling_exceptions_and_failures.html">
-                            Exceptions and System Failures</a>
-                    </li>
-                    <li>
-                        <a href="/docs/guide/112/reference/topics/memory_requirements_for_cache_data.html">Memory Requirements for Cached Data</a>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/reference/statistics_list.html">Geode Statistics List</a>
-                        <ul>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_DEF8D3644D3246AB8F06FE09A37DC5C8">Cache Performance (CachePerfStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_EF5C2C59BFC74FFB8607F9571AB9A471">Cache Server (CacheServerStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_B08C0783BBF9489E8BB48B4AEC597C62">Client-Side Notifications (CacheClientUpdaterStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_04B7D7387E584712B7710B5ED1E876BB">Client-to-Server Messaging Performance (ClientStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_6C247F61DB834C079A16BE92789D4692">Client Connection Pool (PoolStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_66C0E7748501480B85209D57D24256D5">Continuous Querying (CQStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_D4ABED3FF94245C0BEE0F6FC9481E867">Delta Propagation (DeltaPropagationStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_6C2BECC63A83456190B029DEDB8F4BE3">Disk Space Usage (DiskDirStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_983BFC6D53C74829A04A91C39E06315F">Disk Usage and Performance (DiskRegionStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_ACB4161F10D64BC0B15871D003FF6FDF">Distributed System Messaging (DistributionStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_78D346A580724E1EA645E31626EECE40">Distributed Lock Services (DLockStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_5E212DDB0E8640689AD0A4659512E17A">Function Execution (FunctionServiceStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_C4199A541B1F4B82B6178C416C0FAE4B">Gateway Queue (GatewayStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_86A61860024B480592DAC67FFB882538">Indexes (IndexStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_607C3867602E410CAE5FAB26A7FF1CB9">JVM Performance</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_C48B654F973E4B44AD825D459C23A6CD">Locator (LocatorStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#LuceneStats">Lucene Indexes (LuceneIndexStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#topic_ohc_tjk_w5">Off-Heap (OffHeapMemoryStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_923B28F01BC3416786D3AFBD87F22A5E">Operating System Statistics - Linux</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_35AC170770C944C3A336D9AEC2D2F7C5">Partitioned Regions (PartitionedRegion&lt;partitioned_region_name&gt;Statistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_374FBD92A3B74F6FA08AA23047929B4F">Region Entry Eviction – Count-Based (LRUStatistics)
-                                </a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_3D2AA2BCE5B6485699A7B6ADD1C49FF7">Region Entry Eviction – Size-based (LRUStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_5362EF9AECBC48D69475697109ABEDFA">Server Notifications for All Clients (CacheClientNotifierStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_E03865F509E543D9B8F9462B3DA6255E">Server Notifications for Single Client (CacheClientProxyStatistics)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_3AB1C0AA55014163A2BBF68E13D25E3A">Server-to-Client Messaging Performance (ClientSubscriptionStats)</a>
-                            </li>
-                            <li>
-                                <a href="/docs/guide/112/reference/statistics_list.html#section_55F3AF6413474317902845EE4996CC21">Statistics Collection (StatSampler)</a>
-                            </li>
-                        </ul>
-                    </li>
-                    <li class="has_submenu">
-                        <a href="/docs/guide/112/reference/archive_transactions/chapter_overview.html">Transaction Reference Material</a>
-                        <ul>
-                            <li class="has_submenu">
-                                <a href="/docs/guide/112/reference/archive_transactions/JTA_transactions.html">JTA Global Transactions with Geode
-                                </a>
-                                <ul>
-                                    <li>
-                                        <a href="/docs/guide/112/reference/archive_transactions/JTA_transactions.html#concept_cp1_zx1_wk">Coordinating with External JTA Transaction Managers</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/reference/archive_transactions/JTA_transactions.html#concept_csy_vfb_wk">Using Geode as the "Last Resource" in a Container-Managed JTA Transaction</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/reference/archive_transactions/cache_plugins_with_jta.html">Behavior of Geode Cache Writers and Loaders Under JTA</a>
-                                    </li>
-                                    <li>
-                                        <a href="/docs/guide/112/reference/archive_transactions/turning_off_jta.html">Turning Off JTA Transactions
-                                        </a>
-                                    </li>
-                                </ul>
-                            </li>
-                        </ul>
-                    </li>
-                </ul>
-            </li>
-            <li>
-                <a href="/docs/guide/112/reference/topics/glossary.html">Glossary</a>
-            </li>
-        </ul>
-    </div>
-</div>
-
-      <!--googleon: index-->
-
-      <main class="content content-layout" id="js-content" role="main">
-        <a id="top"></a>
-        <!--
-Licensed to the Apache Software Foundation (ASF) under one or more
-contributor license agreements.  See the NOTICE file distributed with
-this work for additional information regarding copyright ownership.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
--->
-<span style="font-weight:200;font-size:31px;" style="float:left;">
-    <img src="/images/Apache_Geode_logo_symbol.png" style="height:26px;">
-  Apache Geode
-</span>
-  <span class="local-header version-info" style="float:right;">
-    <a href="https://cwiki.apache.org/confluence/display/GEODE/Release+Notes">CHANGELOG</a>
-  </span>
-
-        <!--
-Licensed to the Apache Software Foundation (ASF) under one or more
-contributor license agreements.  See the NOTICE file distributed with
-this work for additional information regarding copyright ownership.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
--->
-  <h1 class="title-container" >
-    Connection Thread Settings and Performance
-  </h1>
-
-          <div id="js-quick-links" >
-            
-          </div>
-        <div class="to-top" id="js-to-top">
-          <a href="#top" title="back to top"></a>
-        </div>
-        <!--
-Licensed to the Apache Software Foundation (ASF) under one or more
-contributor license agreements.  See the NOTICE file distributed with
-this work for additional information regarding copyright ownership.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
--->
-
-<p>When many peer processes are started concurrently, you can improve the cluster connect time by setting the p2p.HANDSHAKE_POOL_SIZE system property value to the expected number of members.</p>
-
-<p>This property controls the number of threads that can be used to establish new TCP/IP connections between peer caches. The threads are discarded if they are idle for 60 seconds.</p>
-
-<p>The default value for p2p.HANDSHAKE_POOL_SIZE is 10. This command-line specification sets the number of threads to 100:</p>
-<pre class="highlight plaintext"><code>-Dp2p.HANDSHAKE_POOL_SIZE=100
-</code></pre>
-
-        
-
-      </main>
-    </div>
-  </div>
-</div>
-
-<div id="scrim"></div>
-
-<div class="container">
-  <footer class="site-footer-links">
-    <!--
-Licensed to the Apache Software Foundation (ASF) under one or more
-contributor license agreements.  See the NOTICE file distributed with
-this work for additional information regarding copyright ownership.
-The ASF licenses this file to You under the Apache License, Version 2.0
-(the "License"); you may not use this file except in compliance with
-the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
--->
-<div class="copyright">
-  <a href='/'>Apache Geode Documentation</a>
-  &copy; 2020 <a href='http://www.apache.org/'>The Apache Software Foundation</a>.
-</div>
-<div class="support">
-  Need help? <a href="http://geode.apache.org/community" target="_blank">Visit the Community</a>
-</div>
-
-  </footer>
-</div><!--end of container-->
-
-</body>
-</html>
diff --git a/docs/guide/112/managing/monitor_tune/system_member_performance_distributed_system_member.html b/docs/guide/112/managing/monitor_tune/system_member_performance_distributed_system_member.html
index e6988c5..0142e39 100644
--- a/docs/guide/112/managing/monitor_tune/system_member_performance_distributed_system_member.html
+++ b/docs/guide/112/managing/monitor_tune/system_member_performance_distributed_system_member.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html b/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html
index 35f0bff..554ced0 100644
--- a/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html
+++ b/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/system_member_performance_jvm_mem_settings.html b/docs/guide/112/managing/monitor_tune/system_member_performance_jvm_mem_settings.html
index 6d0b58f..e5f6d04 100644
--- a/docs/guide/112/managing/monitor_tune/system_member_performance_jvm_mem_settings.html
+++ b/docs/guide/112/managing/monitor_tune/system_member_performance_jvm_mem_settings.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/monitor_tune/udp_communication.html b/docs/guide/112/managing/monitor_tune/udp_communication.html
index eaf92f7..c50bb89 100644
--- a/docs/guide/112/managing/monitor_tune/udp_communication.html
+++ b/docs/guide/112/managing/monitor_tune/udp_communication.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/network_partitioning/chapter_overview.html b/docs/guide/112/managing/network_partitioning/chapter_overview.html
index 7f3fa73..4d6fb5a 100644
--- a/docs/guide/112/managing/network_partitioning/chapter_overview.html
+++ b/docs/guide/112/managing/network_partitioning/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/network_partitioning/failure_detection.html b/docs/guide/112/managing/network_partitioning/failure_detection.html
index 35c10a8..91deeb3 100644
--- a/docs/guide/112/managing/network_partitioning/failure_detection.html
+++ b/docs/guide/112/managing/network_partitioning/failure_detection.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/network_partitioning/handling_network_partitioning.html b/docs/guide/112/managing/network_partitioning/handling_network_partitioning.html
index 49ea101..616e894 100644
--- a/docs/guide/112/managing/network_partitioning/handling_network_partitioning.html
+++ b/docs/guide/112/managing/network_partitioning/handling_network_partitioning.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/network_partitioning/how_network_partitioning_management_works.html b/docs/guide/112/managing/network_partitioning/how_network_partitioning_management_works.html
index d443c43..ad02555 100644
--- a/docs/guide/112/managing/network_partitioning/how_network_partitioning_management_works.html
+++ b/docs/guide/112/managing/network_partitioning/how_network_partitioning_management_works.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/network_partitioning/membership_coordinators_lead_members_and_weighting.html b/docs/guide/112/managing/network_partitioning/membership_coordinators_lead_members_and_weighting.html
index 4773f9f..9a11364 100644
--- a/docs/guide/112/managing/network_partitioning/membership_coordinators_lead_members_and_weighting.html
+++ b/docs/guide/112/managing/network_partitioning/membership_coordinators_lead_members_and_weighting.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/network_partitioning/network_partitioning_scenarios.html b/docs/guide/112/managing/network_partitioning/network_partitioning_scenarios.html
index bad55dd..88b0090 100644
--- a/docs/guide/112/managing/network_partitioning/network_partitioning_scenarios.html
+++ b/docs/guide/112/managing/network_partitioning/network_partitioning_scenarios.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/network_partitioning/preventing_network_partitions.html b/docs/guide/112/managing/network_partitioning/preventing_network_partitions.html
index 9cde4bd..a96502e 100644
--- a/docs/guide/112/managing/network_partitioning/preventing_network_partitions.html
+++ b/docs/guide/112/managing/network_partitioning/preventing_network_partitions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/region_compression.html b/docs/guide/112/managing/region_compression.html
index 37d2154..688ec67 100644
--- a/docs/guide/112/managing/region_compression.html
+++ b/docs/guide/112/managing/region_compression.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/authentication_examples.html b/docs/guide/112/managing/security/authentication_examples.html
index ba83225..5f8dd48 100644
--- a/docs/guide/112/managing/security/authentication_examples.html
+++ b/docs/guide/112/managing/security/authentication_examples.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/authentication_overview.html b/docs/guide/112/managing/security/authentication_overview.html
index fc5e7c0..d14b48b 100644
--- a/docs/guide/112/managing/security/authentication_overview.html
+++ b/docs/guide/112/managing/security/authentication_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/authorization_example.html b/docs/guide/112/managing/security/authorization_example.html
index 0a906e7..4ff7219 100644
--- a/docs/guide/112/managing/security/authorization_example.html
+++ b/docs/guide/112/managing/security/authorization_example.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/authorization_overview.html b/docs/guide/112/managing/security/authorization_overview.html
index c959b03..4456a45 100644
--- a/docs/guide/112/managing/security/authorization_overview.html
+++ b/docs/guide/112/managing/security/authorization_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/chapter_overview.html b/docs/guide/112/managing/security/chapter_overview.html
index 9a0e2f2..35d20ec 100644
--- a/docs/guide/112/managing/security/chapter_overview.html
+++ b/docs/guide/112/managing/security/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/enable_security.html b/docs/guide/112/managing/security/enable_security.html
index a51e543..881ccba 100644
--- a/docs/guide/112/managing/security/enable_security.html
+++ b/docs/guide/112/managing/security/enable_security.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/implementing_authentication.html b/docs/guide/112/managing/security/implementing_authentication.html
index 92b7b14..20a4d86 100644
--- a/docs/guide/112/managing/security/implementing_authentication.html
+++ b/docs/guide/112/managing/security/implementing_authentication.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/implementing_authorization.html b/docs/guide/112/managing/security/implementing_authorization.html
index 9d2b0b5..50ee917 100644
--- a/docs/guide/112/managing/security/implementing_authorization.html
+++ b/docs/guide/112/managing/security/implementing_authorization.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/implementing_security.html b/docs/guide/112/managing/security/implementing_security.html
index 14a384c..77f5f2c 100644
--- a/docs/guide/112/managing/security/implementing_security.html
+++ b/docs/guide/112/managing/security/implementing_security.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/implementing_ssl.html b/docs/guide/112/managing/security/implementing_ssl.html
index 72888c8..b6ac19c 100644
--- a/docs/guide/112/managing/security/implementing_ssl.html
+++ b/docs/guide/112/managing/security/implementing_ssl.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/method_invocation_authorizers.html b/docs/guide/112/managing/security/method_invocation_authorizers.html
index 450e4a5..977307d 100644
--- a/docs/guide/112/managing/security/method_invocation_authorizers.html
+++ b/docs/guide/112/managing/security/method_invocation_authorizers.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/post_processing.html b/docs/guide/112/managing/security/post_processing.html
index 4c98254..0831363 100644
--- a/docs/guide/112/managing/security/post_processing.html
+++ b/docs/guide/112/managing/security/post_processing.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/properties_file.html b/docs/guide/112/managing/security/properties_file.html
index d7cdf62..526e43f 100644
--- a/docs/guide/112/managing/security/properties_file.html
+++ b/docs/guide/112/managing/security/properties_file.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/security-audit.html b/docs/guide/112/managing/security/security-audit.html
index 081a624..0599e3b 100644
--- a/docs/guide/112/managing/security/security-audit.html
+++ b/docs/guide/112/managing/security/security-audit.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/security_audit_overview.html b/docs/guide/112/managing/security/security_audit_overview.html
index 45e3857..9253638 100644
--- a/docs/guide/112/managing/security/security_audit_overview.html
+++ b/docs/guide/112/managing/security/security_audit_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/ssl_example.html b/docs/guide/112/managing/security/ssl_example.html
index f0427e5..8779ba2 100644
--- a/docs/guide/112/managing/security/ssl_example.html
+++ b/docs/guide/112/managing/security/ssl_example.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/security/ssl_overview.html b/docs/guide/112/managing/security/ssl_overview.html
index 1dfe31b..1664c70 100644
--- a/docs/guide/112/managing/security/ssl_overview.html
+++ b/docs/guide/112/managing/security/ssl_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/statistics/application_defined_statistics.html b/docs/guide/112/managing/statistics/application_defined_statistics.html
index 86bdca6..c0fcb07 100644
--- a/docs/guide/112/managing/statistics/application_defined_statistics.html
+++ b/docs/guide/112/managing/statistics/application_defined_statistics.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/statistics/chapter_overview.html b/docs/guide/112/managing/statistics/chapter_overview.html
index b594369..09c24fe 100644
--- a/docs/guide/112/managing/statistics/chapter_overview.html
+++ b/docs/guide/112/managing/statistics/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/statistics/how_statistics_work.html b/docs/guide/112/managing/statistics/how_statistics_work.html
index fdbd611..37add2d 100644
--- a/docs/guide/112/managing/statistics/how_statistics_work.html
+++ b/docs/guide/112/managing/statistics/how_statistics_work.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/statistics/setting_up_statistics.html b/docs/guide/112/managing/statistics/setting_up_statistics.html
index 60b7304..f52a32b 100644
--- a/docs/guide/112/managing/statistics/setting_up_statistics.html
+++ b/docs/guide/112/managing/statistics/setting_up_statistics.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/statistics/transient_region_and_entry_statistics.html b/docs/guide/112/managing/statistics/transient_region_and_entry_statistics.html
index 6aa0c38..f27185d 100644
--- a/docs/guide/112/managing/statistics/transient_region_and_entry_statistics.html
+++ b/docs/guide/112/managing/statistics/transient_region_and_entry_statistics.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/statistics/viewing_statistics.html b/docs/guide/112/managing/statistics/viewing_statistics.html
index 07b3769..6232df7 100644
--- a/docs/guide/112/managing/statistics/viewing_statistics.html
+++ b/docs/guide/112/managing/statistics/viewing_statistics.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/chapter_overview.html b/docs/guide/112/managing/troubleshooting/chapter_overview.html
index 0f6a8fd..5928a8e 100644
--- a/docs/guide/112/managing/troubleshooting/chapter_overview.html
+++ b/docs/guide/112/managing/troubleshooting/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/diagnosing_system_probs.html b/docs/guide/112/managing/troubleshooting/diagnosing_system_probs.html
index 5db5ac7..479ee78 100644
--- a/docs/guide/112/managing/troubleshooting/diagnosing_system_probs.html
+++ b/docs/guide/112/managing/troubleshooting/diagnosing_system_probs.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/prevent_and_recover_disk_full_errors.html b/docs/guide/112/managing/troubleshooting/prevent_and_recover_disk_full_errors.html
index 52d28c9..d5856d4 100644
--- a/docs/guide/112/managing/troubleshooting/prevent_and_recover_disk_full_errors.html
+++ b/docs/guide/112/managing/troubleshooting/prevent_and_recover_disk_full_errors.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/producing_troubleshooting_artifacts.html b/docs/guide/112/managing/troubleshooting/producing_troubleshooting_artifacts.html
index 94a6e8a..3da9195 100644
--- a/docs/guide/112/managing/troubleshooting/producing_troubleshooting_artifacts.html
+++ b/docs/guide/112/managing/troubleshooting/producing_troubleshooting_artifacts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/recovering_conflicting_data_exceptions.html b/docs/guide/112/managing/troubleshooting/recovering_conflicting_data_exceptions.html
index 9ea3e17..04a798b 100644
--- a/docs/guide/112/managing/troubleshooting/recovering_conflicting_data_exceptions.html
+++ b/docs/guide/112/managing/troubleshooting/recovering_conflicting_data_exceptions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/recovering_from_app_crashes.html b/docs/guide/112/managing/troubleshooting/recovering_from_app_crashes.html
index e1a74a7..93363b2 100644
--- a/docs/guide/112/managing/troubleshooting/recovering_from_app_crashes.html
+++ b/docs/guide/112/managing/troubleshooting/recovering_from_app_crashes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/recovering_from_cs_crashes.html b/docs/guide/112/managing/troubleshooting/recovering_from_cs_crashes.html
index 6920acf..5756c66 100644
--- a/docs/guide/112/managing/troubleshooting/recovering_from_cs_crashes.html
+++ b/docs/guide/112/managing/troubleshooting/recovering_from_cs_crashes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/recovering_from_machine_crashes.html b/docs/guide/112/managing/troubleshooting/recovering_from_machine_crashes.html
index fb64f4c..2eb1804 100644
--- a/docs/guide/112/managing/troubleshooting/recovering_from_machine_crashes.html
+++ b/docs/guide/112/managing/troubleshooting/recovering_from_machine_crashes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/recovering_from_network_outages.html b/docs/guide/112/managing/troubleshooting/recovering_from_network_outages.html
index 0cc8553..569fc39 100644
--- a/docs/guide/112/managing/troubleshooting/recovering_from_network_outages.html
+++ b/docs/guide/112/managing/troubleshooting/recovering_from_network_outages.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/recovering_from_p2p_crashes.html b/docs/guide/112/managing/troubleshooting/recovering_from_p2p_crashes.html
index f946aef..786352d 100644
--- a/docs/guide/112/managing/troubleshooting/recovering_from_p2p_crashes.html
+++ b/docs/guide/112/managing/troubleshooting/recovering_from_p2p_crashes.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/managing/troubleshooting/system_failure_and_recovery.html b/docs/guide/112/managing/troubleshooting/system_failure_and_recovery.html
index f29fe3f..dd7abdb 100644
--- a/docs/guide/112/managing/troubleshooting/system_failure_and_recovery.html
+++ b/docs/guide/112/managing/troubleshooting/system_failure_and_recovery.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/prereq_and_install.html b/docs/guide/112/prereq_and_install.html
index d410e6e..b6f5a42 100644
--- a/docs/guide/112/prereq_and_install.html
+++ b/docs/guide/112/prereq_and_install.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/archive_transactions/JTA_transactions.html b/docs/guide/112/reference/archive_transactions/JTA_transactions.html
index 18fa8d4..c970f6b 100644
--- a/docs/guide/112/reference/archive_transactions/JTA_transactions.html
+++ b/docs/guide/112/reference/archive_transactions/JTA_transactions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/archive_transactions/cache_plugins_with_jta.html b/docs/guide/112/reference/archive_transactions/cache_plugins_with_jta.html
index 560ba40..5ca50ff 100644
--- a/docs/guide/112/reference/archive_transactions/cache_plugins_with_jta.html
+++ b/docs/guide/112/reference/archive_transactions/cache_plugins_with_jta.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/archive_transactions/chapter_overview.html b/docs/guide/112/reference/archive_transactions/chapter_overview.html
index 46981d2..47cef13 100644
--- a/docs/guide/112/reference/archive_transactions/chapter_overview.html
+++ b/docs/guide/112/reference/archive_transactions/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/archive_transactions/turning_off_jta.html b/docs/guide/112/reference/archive_transactions/turning_off_jta.html
index 25fa887..5e6a185 100644
--- a/docs/guide/112/reference/archive_transactions/turning_off_jta.html
+++ b/docs/guide/112/reference/archive_transactions/turning_off_jta.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/book_intro.html b/docs/guide/112/reference/book_intro.html
index cd20c44..21610a8 100644
--- a/docs/guide/112/reference/book_intro.html
+++ b/docs/guide/112/reference/book_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/statistics_list.html b/docs/guide/112/reference/statistics_list.html
index 33927fe..9305756 100644
--- a/docs/guide/112/reference/statistics_list.html
+++ b/docs/guide/112/reference/statistics_list.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/cache-elements-list.html b/docs/guide/112/reference/topics/cache-elements-list.html
index 2fd6a74..cccf7de 100644
--- a/docs/guide/112/reference/topics/cache-elements-list.html
+++ b/docs/guide/112/reference/topics/cache-elements-list.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/cache_xml.html b/docs/guide/112/reference/topics/cache_xml.html
index 1f3260b..75e912e 100644
--- a/docs/guide/112/reference/topics/cache_xml.html
+++ b/docs/guide/112/reference/topics/cache_xml.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/chapter_overview_cache_xml.html b/docs/guide/112/reference/topics/chapter_overview_cache_xml.html
index eb181c0..d034f4e 100644
--- a/docs/guide/112/reference/topics/chapter_overview_cache_xml.html
+++ b/docs/guide/112/reference/topics/chapter_overview_cache_xml.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/chapter_overview_regionshortcuts.html b/docs/guide/112/reference/topics/chapter_overview_regionshortcuts.html
index f9c748b..8e42e86 100644
--- a/docs/guide/112/reference/topics/chapter_overview_regionshortcuts.html
+++ b/docs/guide/112/reference/topics/chapter_overview_regionshortcuts.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/client-cache-elements-list.html b/docs/guide/112/reference/topics/client-cache-elements-list.html
index 287936c..9c786b6 100644
--- a/docs/guide/112/reference/topics/client-cache-elements-list.html
+++ b/docs/guide/112/reference/topics/client-cache-elements-list.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/client-cache.html b/docs/guide/112/reference/topics/client-cache.html
index 1209446..a445571 100644
--- a/docs/guide/112/reference/topics/client-cache.html
+++ b/docs/guide/112/reference/topics/client-cache.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/elements_ref.html b/docs/guide/112/reference/topics/elements_ref.html
index 1b18a5f..9af8cc2 100644
--- a/docs/guide/112/reference/topics/elements_ref.html
+++ b/docs/guide/112/reference/topics/elements_ref.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/gemfire_properties.html b/docs/guide/112/reference/topics/gemfire_properties.html
index 51a6304..03d3fed 100644
--- a/docs/guide/112/reference/topics/gemfire_properties.html
+++ b/docs/guide/112/reference/topics/gemfire_properties.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/glossary.html b/docs/guide/112/reference/topics/glossary.html
index 6e8a39c..13cf030 100644
--- a/docs/guide/112/reference/topics/glossary.html
+++ b/docs/guide/112/reference/topics/glossary.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/handling_exceptions_and_failures.html b/docs/guide/112/reference/topics/handling_exceptions_and_failures.html
index 733b1f4..74662da 100644
--- a/docs/guide/112/reference/topics/handling_exceptions_and_failures.html
+++ b/docs/guide/112/reference/topics/handling_exceptions_and_failures.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/memory_requirements_for_cache_data.html b/docs/guide/112/reference/topics/memory_requirements_for_cache_data.html
index 18fd7b6..8c339a4 100644
--- a/docs/guide/112/reference/topics/memory_requirements_for_cache_data.html
+++ b/docs/guide/112/reference/topics/memory_requirements_for_cache_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/non-ascii_strings_in_config_files.html b/docs/guide/112/reference/topics/non-ascii_strings_in_config_files.html
index efaf793..883f6f5 100644
--- a/docs/guide/112/reference/topics/non-ascii_strings_in_config_files.html
+++ b/docs/guide/112/reference/topics/non-ascii_strings_in_config_files.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/region_shortcuts_reference.html b/docs/guide/112/reference/topics/region_shortcuts_reference.html
index 2608aad..5a6e295 100644
--- a/docs/guide/112/reference/topics/region_shortcuts_reference.html
+++ b/docs/guide/112/reference/topics/region_shortcuts_reference.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/reference/topics/region_shortcuts_table.html b/docs/guide/112/reference/topics/region_shortcuts_table.html
index cf67526..5413c7a 100644
--- a/docs/guide/112/reference/topics/region_shortcuts_table.html
+++ b/docs/guide/112/reference/topics/region_shortcuts_table.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/book_intro.html b/docs/guide/112/rest_apps/book_intro.html
index 96877b4..feacb6d 100644
--- a/docs/guide/112/rest_apps/book_intro.html
+++ b/docs/guide/112/rest_apps/book_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/chapter_overview.html b/docs/guide/112/rest_apps/chapter_overview.html
index 613f6b4..fafab42 100644
--- a/docs/guide/112/rest_apps/chapter_overview.html
+++ b/docs/guide/112/rest_apps/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/delete_all_data.html b/docs/guide/112/rest_apps/delete_all_data.html
index caada1e..d446c19 100644
--- a/docs/guide/112/rest_apps/delete_all_data.html
+++ b/docs/guide/112/rest_apps/delete_all_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/delete_data_for_key.html b/docs/guide/112/rest_apps/delete_data_for_key.html
index d741b14..d60433b 100644
--- a/docs/guide/112/rest_apps/delete_data_for_key.html
+++ b/docs/guide/112/rest_apps/delete_data_for_key.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/delete_data_for_multiple_keys.html b/docs/guide/112/rest_apps/delete_data_for_multiple_keys.html
index 2cb3d9f..7055d7b 100644
--- a/docs/guide/112/rest_apps/delete_data_for_multiple_keys.html
+++ b/docs/guide/112/rest_apps/delete_data_for_multiple_keys.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/delete_named_query.html b/docs/guide/112/rest_apps/delete_named_query.html
index 14c7739..ae59dbd 100644
--- a/docs/guide/112/rest_apps/delete_named_query.html
+++ b/docs/guide/112/rest_apps/delete_named_query.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/develop_rest_apps.html b/docs/guide/112/rest_apps/develop_rest_apps.html
index 2276da8..4745028 100644
--- a/docs/guide/112/rest_apps/develop_rest_apps.html
+++ b/docs/guide/112/rest_apps/develop_rest_apps.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_execute_adhoc_query.html b/docs/guide/112/rest_apps/get_execute_adhoc_query.html
index 29ad10c..80e8a23 100644
--- a/docs/guide/112/rest_apps/get_execute_adhoc_query.html
+++ b/docs/guide/112/rest_apps/get_execute_adhoc_query.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_functions.html b/docs/guide/112/rest_apps/get_functions.html
index df99a16..cceec54 100644
--- a/docs/guide/112/rest_apps/get_functions.html
+++ b/docs/guide/112/rest_apps/get_functions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_queries.html b/docs/guide/112/rest_apps/get_queries.html
index 3bb22a8..983c4f4 100644
--- a/docs/guide/112/rest_apps/get_queries.html
+++ b/docs/guide/112/rest_apps/get_queries.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_region_data.html b/docs/guide/112/rest_apps/get_region_data.html
index a0419a1..130c84c 100644
--- a/docs/guide/112/rest_apps/get_region_data.html
+++ b/docs/guide/112/rest_apps/get_region_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_region_data_for_multiple_keys.html b/docs/guide/112/rest_apps/get_region_data_for_multiple_keys.html
index 296c6f3..6219e9b 100644
--- a/docs/guide/112/rest_apps/get_region_data_for_multiple_keys.html
+++ b/docs/guide/112/rest_apps/get_region_data_for_multiple_keys.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_region_key_data.html b/docs/guide/112/rest_apps/get_region_key_data.html
index 6ce6212..7c54742 100644
--- a/docs/guide/112/rest_apps/get_region_key_data.html
+++ b/docs/guide/112/rest_apps/get_region_key_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_region_keys.html b/docs/guide/112/rest_apps/get_region_keys.html
index 81a9804..c4d1397 100644
--- a/docs/guide/112/rest_apps/get_region_keys.html
+++ b/docs/guide/112/rest_apps/get_region_keys.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_regions.html b/docs/guide/112/rest_apps/get_regions.html
index d51b330..e61426f 100644
--- a/docs/guide/112/rest_apps/get_regions.html
+++ b/docs/guide/112/rest_apps/get_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/get_servers.html b/docs/guide/112/rest_apps/get_servers.html
index 16dc1ad..eaa6db4 100644
--- a/docs/guide/112/rest_apps/get_servers.html
+++ b/docs/guide/112/rest_apps/get_servers.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/head_region_size.html b/docs/guide/112/rest_apps/head_region_size.html
index 0979b2c..8f5d2f1 100644
--- a/docs/guide/112/rest_apps/head_region_size.html
+++ b/docs/guide/112/rest_apps/head_region_size.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/ping_service.html b/docs/guide/112/rest_apps/ping_service.html
index a55d3b2..5025052 100644
--- a/docs/guide/112/rest_apps/ping_service.html
+++ b/docs/guide/112/rest_apps/ping_service.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/post_create_query.html b/docs/guide/112/rest_apps/post_create_query.html
index 1c6299b..2e2b8ef 100644
--- a/docs/guide/112/rest_apps/post_create_query.html
+++ b/docs/guide/112/rest_apps/post_create_query.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/post_execute_functions.html b/docs/guide/112/rest_apps/post_execute_functions.html
index 82569c5..8839745 100644
--- a/docs/guide/112/rest_apps/post_execute_functions.html
+++ b/docs/guide/112/rest_apps/post_execute_functions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/post_execute_query.html b/docs/guide/112/rest_apps/post_execute_query.html
index 43fcbce..4536e9c 100644
--- a/docs/guide/112/rest_apps/post_execute_query.html
+++ b/docs/guide/112/rest_apps/post_execute_query.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/post_if_absent_data.html b/docs/guide/112/rest_apps/post_if_absent_data.html
index 1d3fad3..b6b129d 100644
--- a/docs/guide/112/rest_apps/post_if_absent_data.html
+++ b/docs/guide/112/rest_apps/post_if_absent_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/put_multiple_values_for_keys.html b/docs/guide/112/rest_apps/put_multiple_values_for_keys.html
index 8f8685b..94102a5 100644
--- a/docs/guide/112/rest_apps/put_multiple_values_for_keys.html
+++ b/docs/guide/112/rest_apps/put_multiple_values_for_keys.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/put_replace_data.html b/docs/guide/112/rest_apps/put_replace_data.html
index dfff876..389fd01 100644
--- a/docs/guide/112/rest_apps/put_replace_data.html
+++ b/docs/guide/112/rest_apps/put_replace_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/put_update_cas_data.html b/docs/guide/112/rest_apps/put_update_cas_data.html
index b445052..c73e01a 100644
--- a/docs/guide/112/rest_apps/put_update_cas_data.html
+++ b/docs/guide/112/rest_apps/put_update_cas_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/put_update_data.html b/docs/guide/112/rest_apps/put_update_data.html
index 921c032..bf1a442 100644
--- a/docs/guide/112/rest_apps/put_update_data.html
+++ b/docs/guide/112/rest_apps/put_update_data.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/put_update_query.html b/docs/guide/112/rest_apps/put_update_query.html
index c519f2f..a890dec 100644
--- a/docs/guide/112/rest_apps/put_update_query.html
+++ b/docs/guide/112/rest_apps/put_update_query.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/rest_admin.html b/docs/guide/112/rest_apps/rest_admin.html
index ef0fdb0..c26c4ce 100644
--- a/docs/guide/112/rest_apps/rest_admin.html
+++ b/docs/guide/112/rest_apps/rest_admin.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/rest_api_reference.html b/docs/guide/112/rest_apps/rest_api_reference.html
index cadd32f..2107ed4 100644
--- a/docs/guide/112/rest_apps/rest_api_reference.html
+++ b/docs/guide/112/rest_apps/rest_api_reference.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/rest_examples.html b/docs/guide/112/rest_apps/rest_examples.html
index 1789971..31705f4 100644
--- a/docs/guide/112/rest_apps/rest_examples.html
+++ b/docs/guide/112/rest_apps/rest_examples.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/rest_functions.html b/docs/guide/112/rest_apps/rest_functions.html
index fb2e616..48ca526 100644
--- a/docs/guide/112/rest_apps/rest_functions.html
+++ b/docs/guide/112/rest_apps/rest_functions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/rest_prereqs.html b/docs/guide/112/rest_apps/rest_prereqs.html
index 4860980..ac38bab 100644
--- a/docs/guide/112/rest_apps/rest_prereqs.html
+++ b/docs/guide/112/rest_apps/rest_prereqs.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/rest_queries.html b/docs/guide/112/rest_apps/rest_queries.html
index 3a7e7bb..fd9ca66 100644
--- a/docs/guide/112/rest_apps/rest_queries.html
+++ b/docs/guide/112/rest_apps/rest_queries.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/rest_regions.html b/docs/guide/112/rest_apps/rest_regions.html
index 27a4957..a7c40c2 100644
--- a/docs/guide/112/rest_apps/rest_regions.html
+++ b/docs/guide/112/rest_apps/rest_regions.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/setup_config.html b/docs/guide/112/rest_apps/setup_config.html
index 1f9d806..0991581 100644
--- a/docs/guide/112/rest_apps/setup_config.html
+++ b/docs/guide/112/rest_apps/setup_config.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/troubleshooting.html b/docs/guide/112/rest_apps/troubleshooting.html
index 25900e9..2f23e59 100644
--- a/docs/guide/112/rest_apps/troubleshooting.html
+++ b/docs/guide/112/rest_apps/troubleshooting.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/rest_apps/using_swagger.html b/docs/guide/112/rest_apps/using_swagger.html
index c5d79f7..2700840 100644
--- a/docs/guide/112/rest_apps/using_swagger.html
+++ b/docs/guide/112/rest_apps/using_swagger.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/book_intro.html b/docs/guide/112/tools_modules/book_intro.html
index e50c104..a6efbe6 100644
--- a/docs/guide/112/tools_modules/book_intro.html
+++ b/docs/guide/112/tools_modules/book_intro.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gemcached/about_gemcached.html b/docs/guide/112/tools_modules/gemcached/about_gemcached.html
index 4a846b2..15bfcc8 100644
--- a/docs/guide/112/tools_modules/gemcached/about_gemcached.html
+++ b/docs/guide/112/tools_modules/gemcached/about_gemcached.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gemcached/advantages.html b/docs/guide/112/tools_modules/gemcached/advantages.html
index d303017..9785e61 100644
--- a/docs/guide/112/tools_modules/gemcached/advantages.html
+++ b/docs/guide/112/tools_modules/gemcached/advantages.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gemcached/chapter_overview.html b/docs/guide/112/tools_modules/gemcached/chapter_overview.html
index 646d657..fcebbe6 100644
--- a/docs/guide/112/tools_modules/gemcached/chapter_overview.html
+++ b/docs/guide/112/tools_modules/gemcached/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gemcached/deploying_gemcached.html b/docs/guide/112/tools_modules/gemcached/deploying_gemcached.html
index 037fb27..87bd4cb 100644
--- a/docs/guide/112/tools_modules/gemcached/deploying_gemcached.html
+++ b/docs/guide/112/tools_modules/gemcached/deploying_gemcached.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/about_gfsh.html b/docs/guide/112/tools_modules/gfsh/about_gfsh.html
index bcb06d5..11d0195 100644
--- a/docs/guide/112/tools_modules/gfsh/about_gfsh.html
+++ b/docs/guide/112/tools_modules/gfsh/about_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/cache_xml_2_gfsh.html b/docs/guide/112/tools_modules/gfsh/cache_xml_2_gfsh.html
index 95a2e73..93b8113 100644
--- a/docs/guide/112/tools_modules/gfsh/cache_xml_2_gfsh.html
+++ b/docs/guide/112/tools_modules/gfsh/cache_xml_2_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/chapter_overview.html b/docs/guide/112/tools_modules/gfsh/chapter_overview.html
index 1f619fd..c43303a 100644
--- a/docs/guide/112/tools_modules/gfsh/chapter_overview.html
+++ b/docs/guide/112/tools_modules/gfsh/chapter_overview.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/alter.html b/docs/guide/112/tools_modules/gfsh/command-pages/alter.html
index abf11e1..5b7110e 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/alter.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/alter.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/backup.html b/docs/guide/112/tools_modules/gfsh/command-pages/backup.html
index edd7af5..627a44f 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/backup.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/backup.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/change.html b/docs/guide/112/tools_modules/gfsh/command-pages/change.html
index 85864d0..8000021 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/change.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/change.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/clear.html b/docs/guide/112/tools_modules/gfsh/command-pages/clear.html
index c7806f9..31ae370 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/clear.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/clear.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/close.html b/docs/guide/112/tools_modules/gfsh/command-pages/close.html
index 2142154..1d4458b 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/close.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/close.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/compact.html b/docs/guide/112/tools_modules/gfsh/command-pages/compact.html
index d669148..1729b2b 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/compact.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/compact.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2646,7 +2643,7 @@ limitations under the License.
 
 <p>This command uses the compaction threshold that each member has configured for its disk stores. The disk store must have the <code>allow-force-compaction</code> property set to <code>true</code>.</p>
 
-<p>See <a href="/docs/guide/112/managing/disk_storage/compacting_disk_stores.html#compacting_disk_stores">Running Compaction on Disk Store Log Files</a> for more information.</p>
+<p>See <a href="/docs/guide/112/managing/disk_storage/compacting_disk_stores.html">Running Compaction on Disk Store Log Files</a> for more information.</p>
 
 <p><strong>Availability:</strong> Online. You must be connected in <code>gfsh</code> to a JMX Manager member to use this command.</p>
 
@@ -2654,7 +2651,7 @@ limitations under the License.
 <pre class="highlight plaintext"><code>compact disk-store --name=value [--groups=value(,value)*]
 </code></pre>
 
-<p><a id="topic_F113C95C076F424E9AA8AC4F1F6324CC__table_7039256EA2014AE5BFAB63697FF35AB6"></a></p>
+<p><strong>Parameters, compact disk-store</strong></p>
 
 <table><thead>
 <tr>
@@ -2672,8 +2669,6 @@ limitations under the License.
 </tr>
 </tbody></table>
 
-<p><span class="tablecap">Table 1. Compact Disk-Store Parameters</span></p>
-
 <p><strong>Example Commands:</strong></p>
 <pre class="highlight plaintext"><code>compact disk-store --name=Disk1
 compact disk-store --name=Disk1 --group=MemberGroup1,MemberGroup2
@@ -2693,7 +2688,7 @@ compact disk-store --name=Disk1 --group=MemberGroup1,MemberGroup2
 
 <p>If the disk store is large, you may need to allocate additional memory to the process by using the <code>--J=-XmxNNNm</code> parameter.</p>
 
-<p>See <a href="/docs/guide/112/managing/disk_storage/compacting_disk_stores.html#compacting_disk_stores">Running Compaction on Disk Store Log Files</a> for more information.</p>
+<p>See <a href="/docs/guide/112/managing/disk_storage/compacting_disk_stores.html">Running Compaction on Disk Store Log Files</a> for more information.</p>
 
 <p><strong>Note:</strong>
 Do not perform offline compaction on the baseline directory of an incremental backup.</p>
@@ -2705,7 +2700,7 @@ Do not perform offline compaction on the baseline directory of an incremental ba
 [--max-oplog-size=value] [--J=value(,value)*]
 </code></pre>
 
-<p><a id="topic_9CCFCB2FA2154E16BD775439C8ABC8FB__table_BDB9B26709D841F08BCD75087AF596D8"></a></p>
+<p><strong>Parameters, compact offline-disk-store</strong></p>
 
 <table><thead>
 <tr>
@@ -2736,8 +2731,6 @@ Do not perform offline compaction on the baseline directory of an incremental ba
 </tr>
 </tbody></table>
 
-<p><span class="tablecap">Table 2. Compact Offline-Disk-Store Parameters</span></p>
-
 <p><strong>Example Commands:</strong></p>
 <pre class="highlight plaintext"><code>compact offline-disk-store --name=Disk2 --disk-dirs=/Disks/Disk2
 compact offline-disk-store --name=Disk2 --disk-dirs=/Disks/Disk2 --max-oplog-size=512 -J=-Xmx1024m
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/configure.html b/docs/guide/112/tools_modules/gfsh/command-pages/configure.html
index bdcfa3d..9ec0cf0 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/configure.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/configure.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/connect.html b/docs/guide/112/tools_modules/gfsh/command-pages/connect.html
index 21f8b6f..6f8f766 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/connect.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/connect.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/create.html b/docs/guide/112/tools_modules/gfsh/command-pages/create.html
index bc561ef..c938b44 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/create.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/create.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2900,7 +2897,7 @@ If the specified directory does not exist, the command will create the directory
 </tr>
 <tr>
 <td><span class="keyword parmname">--compaction-threshold</span></td>
-<td>Percentage of garbage allowed before the disk store is eligible for compaction.</td>
+<td>Percentage of non-garbage remaining, below which the disk store is eligible for compaction.</td>
 <td>50</td>
 </tr>
 <tr>
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/debug.html b/docs/guide/112/tools_modules/gfsh/command-pages/debug.html
index 055eca8..7e953f5 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/debug.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/debug.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/define.html b/docs/guide/112/tools_modules/gfsh/command-pages/define.html
index 6a5ddbf..bc7a86e 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/define.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/define.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/deploy.html b/docs/guide/112/tools_modules/gfsh/command-pages/deploy.html
index 272810d..47f4df1 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/deploy.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/deploy.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/describe.html b/docs/guide/112/tools_modules/gfsh/command-pages/describe.html
index 7c52f24..b222b18 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/describe.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/describe.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html b/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html
index 56e4663..6a94681 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/destroy.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/disconnect.html b/docs/guide/112/tools_modules/gfsh/command-pages/disconnect.html
index 38e3ba1..47abc79 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/disconnect.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/disconnect.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/echo.html b/docs/guide/112/tools_modules/gfsh/command-pages/echo.html
index 1d08bf2..2ab8e27 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/echo.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/echo.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/execute.html b/docs/guide/112/tools_modules/gfsh/command-pages/execute.html
index 800df2a..7857aee 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/execute.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/execute.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/exit.html b/docs/guide/112/tools_modules/gfsh/command-pages/exit.html
index 014de93..9c5fc73 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/exit.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/exit.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/export.html b/docs/guide/112/tools_modules/gfsh/command-pages/export.html
index cbd813b..44d75d3 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/export.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/export.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/gc.html b/docs/guide/112/tools_modules/gfsh/command-pages/gc.html
index eea3d55..2da618c 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/gc.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/gc.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -2631,6 +2628,10 @@ limitations under the License.
 
 <p>The default is for garbage collection to occur on all caching members.</p>
 
+<p>The <strong>gfsh gc</strong> command should be used only in non-production environments.
+This is a forced GC event and not always handled well by the garbage collector outside of normal GC processing.
+This can cause slow-responding members to be perceived as unresponsive and disconnected from the cluster.</p>
+
 <p><strong>Availability:</strong> Online. You must be connected in <code>gfsh</code> to a JMX Manager member to use this command.</p>
 
 <p><strong>Syntax:</strong></p>
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/get.html b/docs/guide/112/tools_modules/gfsh/command-pages/get.html
index def1201..defebac 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/get.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/get.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/help.html b/docs/guide/112/tools_modules/gfsh/command-pages/help.html
index 910a040..7b2945e 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/help.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/help.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/hint.html b/docs/guide/112/tools_modules/gfsh/command-pages/hint.html
index 17989c8..13e48c5 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/hint.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/hint.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/history.html b/docs/guide/112/tools_modules/gfsh/command-pages/history.html
index 2f44434..e608a95 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/history.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/history.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/import.html b/docs/guide/112/tools_modules/gfsh/command-pages/import.html
index 849b477..536628c 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/import.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/import.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/list.html b/docs/guide/112/tools_modules/gfsh/command-pages/list.html
index d0249e5..bd702d8 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/list.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/list.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/load-balance.html b/docs/guide/112/tools_modules/gfsh/command-pages/load-balance.html
index 6d37093..1507d0d 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/load-balance.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/load-balance.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/locate.html b/docs/guide/112/tools_modules/gfsh/command-pages/locate.html
index c7716bf..79c87b3 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/locate.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/locate.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/netstat.html b/docs/guide/112/tools_modules/gfsh/command-pages/netstat.html
index 53a66bf..b60959a 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/netstat.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/netstat.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/pause.html b/docs/guide/112/tools_modules/gfsh/command-pages/pause.html
index 509620b..163c4cc 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/pause.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/pause.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/pdx.html b/docs/guide/112/tools_modules/gfsh/command-pages/pdx.html
index 1b7227d..047d233 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/pdx.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/pdx.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/put.html b/docs/guide/112/tools_modules/gfsh/command-pages/put.html
index c65664f..92ce1a2 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/put.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/put.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/query.html b/docs/guide/112/tools_modules/gfsh/command-pages/query.html
index 7a408fa..7baa960 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/query.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/query.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/rebalance.html b/docs/guide/112/tools_modules/gfsh/command-pages/rebalance.html
index c9ad572..1e6e5cc 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/rebalance.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/rebalance.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/remove.html b/docs/guide/112/tools_modules/gfsh/command-pages/remove.html
index 2197305..a2f5b7f 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/remove.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/remove.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/resume.html b/docs/guide/112/tools_modules/gfsh/command-pages/resume.html
index c04a42c..c34668f 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/resume.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/resume.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/revoke.html b/docs/guide/112/tools_modules/gfsh/command-pages/revoke.html
index 1e18a31..123153e 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/revoke.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/revoke.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/run.html b/docs/guide/112/tools_modules/gfsh/command-pages/run.html
index 9e6b85b..1ea19a1 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/run.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/run.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/search.html b/docs/guide/112/tools_modules/gfsh/command-pages/search.html
index d9032d5..c738d72 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/search.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/search.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/set.html b/docs/guide/112/tools_modules/gfsh/command-pages/set.html
index ea473c8..460f7a4 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/set.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/set.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/sh.html b/docs/guide/112/tools_modules/gfsh/command-pages/sh.html
index c13794e..562d726 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/sh.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/sh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/show.html b/docs/guide/112/tools_modules/gfsh/command-pages/show.html
index 86c575d..710f947 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/show.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/show.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/shutdown.html b/docs/guide/112/tools_modules/gfsh/command-pages/shutdown.html
index f9bac16..885bd30 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/shutdown.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/shutdown.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/sleep.html b/docs/guide/112/tools_modules/gfsh/command-pages/sleep.html
index 7fd1248..184cbcc 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/sleep.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/sleep.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/start.html b/docs/guide/112/tools_modules/gfsh/command-pages/start.html
index 75782ce..4cf5b8e 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/start.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/start.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/status.html b/docs/guide/112/tools_modules/gfsh/command-pages/status.html
index f55991d..c49a1e8 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/status.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/status.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/stop.html b/docs/guide/112/tools_modules/gfsh/command-pages/stop.html
index 3bb04de..8f794de 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/stop.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/stop.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/undeploy.html b/docs/guide/112/tools_modules/gfsh/command-pages/undeploy.html
index 9fb006c..f315dc5 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/undeploy.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/undeploy.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/validate.html b/docs/guide/112/tools_modules/gfsh/command-pages/validate.html
index 1c62e73..ee74fd7 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/validate.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/validate.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command-pages/version.html b/docs/guide/112/tools_modules/gfsh/command-pages/version.html
index 8df5bfa..937c97d 100644
--- a/docs/guide/112/tools_modules/gfsh/command-pages/version.html
+++ b/docs/guide/112/tools_modules/gfsh/command-pages/version.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/command_scripting.html b/docs/guide/112/tools_modules/gfsh/command_scripting.html
index eb15731..28599ea 100644
--- a/docs/guide/112/tools_modules/gfsh/command_scripting.html
+++ b/docs/guide/112/tools_modules/gfsh/command_scripting.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/configuring_gfsh.html b/docs/guide/112/tools_modules/gfsh/configuring_gfsh.html
index d69dadc..c77223a 100644
--- a/docs/guide/112/tools_modules/gfsh/configuring_gfsh.html
+++ b/docs/guide/112/tools_modules/gfsh/configuring_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/getting_started_gfsh.html b/docs/guide/112/tools_modules/gfsh/getting_started_gfsh.html
index 5bf8a24..c528dc6 100644
--- a/docs/guide/112/tools_modules/gfsh/getting_started_gfsh.html
+++ b/docs/guide/112/tools_modules/gfsh/getting_started_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/gfsh_command_index.html b/docs/guide/112/tools_modules/gfsh/gfsh_command_index.html
index f89b4d8..df3eae2 100644
--- a/docs/guide/112/tools_modules/gfsh/gfsh_command_index.html
+++ b/docs/guide/112/tools_modules/gfsh/gfsh_command_index.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/gfsh_quick_reference.html b/docs/guide/112/tools_modules/gfsh/gfsh_quick_reference.html
index e6d5e43..20c0d9d 100644
--- a/docs/guide/112/tools_modules/gfsh/gfsh_quick_reference.html
+++ b/docs/guide/112/tools_modules/gfsh/gfsh_quick_reference.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/json_in_gfsh.html b/docs/guide/112/tools_modules/gfsh/json_in_gfsh.html
index e479b84..f8e1423 100644
--- a/docs/guide/112/tools_modules/gfsh/json_in_gfsh.html
+++ b/docs/guide/112/tools_modules/gfsh/json_in_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/os_command_line_execution.html b/docs/guide/112/tools_modules/gfsh/os_command_line_execution.html
index 00e8599..ff2120b 100644
--- a/docs/guide/112/tools_modules/gfsh/os_command_line_execution.html
+++ b/docs/guide/112/tools_modules/gfsh/os_command_line_execution.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html b/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html
index 29cc9c1..e83fc1b 100644
--- a/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html
+++ b/docs/guide/112/tools_modules/gfsh/quick_ref_commands_by_area.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
@@ -3143,7 +3140,7 @@ limitations under the License.
 </tr>
 <tr>
 <td><a href="/docs/guide/112/tools_modules/gfsh/command-pages/gc.html">gc</a></td>
-<td>Force garbage collection on a member or members.</td>
+<td>Force garbage collection on a member or members. (Development only, not advised for production systems.)</td>
 <td>online</td>
 </tr>
 <tr>
diff --git a/docs/guide/112/tools_modules/gfsh/starting_gfsh.html b/docs/guide/112/tools_modules/gfsh/starting_gfsh.html
index bc50a56..cca7ff0 100644
--- a/docs/guide/112/tools_modules/gfsh/starting_gfsh.html
+++ b/docs/guide/112/tools_modules/gfsh/starting_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/tour_of_gfsh.html b/docs/guide/112/tools_modules/gfsh/tour_of_gfsh.html
index b9457dd..b13ee6d 100644
--- a/docs/guide/112/tools_modules/gfsh/tour_of_gfsh.html
+++ b/docs/guide/112/tools_modules/gfsh/tour_of_gfsh.html
@@ -734,9 +734,6 @@ limitations under the License.
                                     <li>
                                         <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_garbage.html">Garbage Collection and System Performance</a>
                                     </li>
-                                    <li>
-                                        <a href="/docs/guide/112/managing/monitor_tune/system_member_performance_connection_thread_settings.html">Connection Thread Settings and Performance</a>
-                                    </li>
                                 </ul>
                             </li>
                             <li class="has_submenu">
diff --git a/docs/guide/112/tools_modules/gfsh/useful_gfsh_shell_variables.html b/docs/guide/112/tools_modules/gfsh/useful_gfsh_shell_variables.html
index f3ba046..221558c 100644
--- a/docs/guide/112/tools_modules/gfsh/useful_gfsh_shell_variables.html
... 1018 lines suppressed ...