public final class GroupProperty extends Object
| Modifier and Type | Field and Description | 
|---|---|
| static HazelcastProperty | AGGREGATION_ACCUMULATION_PARALLEL_EVALUATIONRun aggregation accumulation for multiple entries in parallel. | 
| static HazelcastProperty | APPLICATION_VALIDATION_TOKENUse this property to verify that Hazelcast nodes only join the cluster when their 'application' level configuration is the
 same. | 
| static HazelcastProperty | BACKPRESSURE_BACKOFF_TIMEOUT_MILLISControl the maximum timeout in millis to wait for an invocation space to be available. | 
| static HazelcastProperty | BACKPRESSURE_ENABLEDUsing back pressure, you can prevent an overload of pending asynchronous backups. | 
| static HazelcastProperty | BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITIONThe maximum number of concurrent invocations per partition. | 
| static HazelcastProperty | BACKPRESSURE_SYNCWINDOWControls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups. | 
| static HazelcastProperty | BIND_SPOOFING_CHECKSControls whether we apply more strict checks upon BIND requests towards a cluster member. | 
| static HazelcastProperty | CACHE_INVALIDATION_MESSAGE_BATCH_ENABLEDDefines cache invalidation event batch sending is enabled or not. | 
| static HazelcastProperty | CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDSDefines the cache invalidation event batch sending frequency in seconds. | 
| static HazelcastProperty | CACHE_INVALIDATION_MESSAGE_BATCH_SIZEDefines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch. | 
| static HazelcastProperty | CLIENT_ENDPOINT_REMOVE_DELAY_SECONDSTime after which client connection is removed or owner node of a client is removed from the cluster. | 
| static HazelcastProperty | CLIENT_ENGINE_BLOCKING_THREAD_COUNTThe number of threads that the client engine has available for processing requests that are blocking
 (example: related to transactions)
 When not set it is set as core-size * 20. | 
| static HazelcastProperty | CLIENT_ENGINE_QUERY_THREAD_COUNTThe number of threads that the client engine has available for processing requests that are related to transactions
 When not set it is set as core-size. | 
| static HazelcastProperty | CLIENT_ENGINE_THREAD_COUNTThe number of threads that the client engine has available for processing requests that are not partition specific. | 
| static HazelcastProperty | CLIENT_HEARTBEAT_TIMEOUT_SECONDS | 
| static HazelcastProperty | CLUSTER_SHUTDOWN_TIMEOUT_SECONDS | 
| static HazelcastProperty | COMPATIBILITY_3_6_CLIENT_ENABLEDWhen this property is true, if the server can not determine the connected client version, it shall assume that it is of
 3.6.x version client. | 
| static HazelcastProperty | CONNECT_ALL_WAIT_SECONDS | 
| static HazelcastProperty | CONNECTION_MONITOR_INTERVAL | 
| static HazelcastProperty | CONNECTION_MONITOR_MAX_FAULTS | 
| static HazelcastProperty | DISABLE_STALE_READ_ON_PARTITION_MIGRATION | 
| static HazelcastProperty | DISCOVERY_SPI_ENABLEDEnables the Discovery SPI lookup over the old native implementations. | 
| static HazelcastProperty | DISCOVERY_SPI_PUBLIC_IP_ENABLEDEnables the Discovery Joiner to use public ips from DiscoveredNode. | 
| static HazelcastProperty | ENABLE_JMX | 
| static HazelcastProperty | ENTERPRISE_LICENSE_KEY | 
| static HazelcastProperty | EVENT_QUEUE_CAPACITYThe capacity of the  EventServiceImplexecutor. | 
| static HazelcastProperty | EVENT_QUEUE_TIMEOUT_MILLISThe timeout for offering an event to the event executor for processing. | 
| static HazelcastProperty | EVENT_SYNC_TIMEOUT_MILLISTo prevent overloading of the outbound connections, once in a while an event is made synchronous by wrapping it in a
 fake operation and waiting for a fake response. | 
| static HazelcastProperty | EVENT_THREAD_COUNTNumber of threads for the  EventServiceImplexecutor. | 
| static HazelcastProperty | FAIL_ON_INDETERMINATE_OPERATION_STATEWhen this configuration is enabled, if an operation has sync backups and acks are not received from backup replicas
 in time, or the member which owns primary replica of the target partition leaves the cluster, then the invocation fails
 with  IndeterminateOperationStateException. | 
| static HazelcastProperty | GENERIC_OPERATION_THREAD_COUNTThe number of generic operation handler threads per member. | 
| static HazelcastProperty | GRACEFUL_SHUTDOWN_MAX_WAIT | 
| static HazelcastProperty | HEALTH_MONITORING_DELAY_SECONDS | 
| static HazelcastProperty | HEALTH_MONITORING_LEVEL | 
| static HazelcastProperty | HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE | 
| static HazelcastProperty | HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE | 
| static HazelcastProperty | HEARTBEAT_FAILURE_DETECTOR_TYPEHeartbeat failure detector type. | 
| static HazelcastProperty | HEARTBEAT_INTERVAL_SECONDSThe interval at which member heartbeat messages are sent | 
| static HazelcastProperty | HTTP_HEALTHCHECK_ENABLEDDeprecated. 
 Enable or disable the  RestEndpointGroup.HEALTH_CHECKgroup inRestApiConfiginstead. | 
| static HazelcastProperty | ICMP_ECHO_FAIL_FASTDeprecated. 
 as of 3.10 this can be configured through  IcmpFailureDetectorConfigThis will be removed in future versions. Until this is done,
 if theIcmpFailureDetectorConfigis null we will still fall back to this | 
| static HazelcastProperty | ICMP_ENABLEDDeprecated. 
 as of 3.10 this can be configured through  IcmpFailureDetectorConfigThis will be removed in future versions. Until this is done,
 if theIcmpFailureDetectorConfigis null we will still fall back to this | 
| static HazelcastProperty | ICMP_INTERVALDeprecated. 
 as of 3.10 this can be configured through  IcmpFailureDetectorConfigThis will be removed in future versions. Until this is done,
 if theIcmpFailureDetectorConfigis null we will still fall back to this | 
| static HazelcastProperty | ICMP_MAX_ATTEMPTSDeprecated. 
 as of 3.10 this can be configured through  IcmpFailureDetectorConfigThis will be removed in future versions. Until this is done,
 if theIcmpFailureDetectorConfigis null we will still fall back to this | 
| static HazelcastProperty | ICMP_PARALLEL_MODEDeprecated. 
 as of 3.10 this can be configured through  IcmpFailureDetectorConfigThis will be removed in future versions. Until this is done,
 if theIcmpFailureDetectorConfigis null we will still fall back to this | 
| static HazelcastProperty | ICMP_TIMEOUTDeprecated. 
 as of 3.10 this can be configured through  IcmpFailureDetectorConfigThis will be removed in future versions. Until this is done,
 if theIcmpFailureDetectorConfigis null we will still fall back to this | 
| static HazelcastProperty | ICMP_TTLDeprecated. 
 as of 3.10 this can be configured through  IcmpFailureDetectorConfigThis will be removed in future versions. Until this is done,
 if theIcmpFailureDetectorConfigis null we will still fall back to this | 
| static HazelcastProperty | INDEX_COPY_BEHAVIORType of Query Index result copying behavior. | 
| static HazelcastProperty | INIT_CLUSTER_VERSIONOverride cluster version to use while node is not yet member of a cluster. | 
| static HazelcastProperty | INITIAL_MIN_CLUSTER_SIZE | 
| static HazelcastProperty | INITIAL_WAIT_SECONDS | 
| static HazelcastProperty | INVOCATION_MAX_RETRY_COUNTMaximum number of retries for an invocation. | 
| static HazelcastProperty | INVOCATION_RETRY_PAUSEPause time between each retry cycle of an invocation in milliseconds. | 
| static HazelcastProperty | IO_BALANCER_INTERVAL_SECONDSThe interval in seconds between  IOBalancerexecutions. | 
| static HazelcastProperty | IO_INPUT_THREAD_COUNTControls the number of socket input threads. | 
| static HazelcastProperty | IO_OUTPUT_THREAD_COUNTControls the number of socket output threads. | 
| static HazelcastProperty | IO_THREAD_COUNTThe number of threads doing socket input and the number of threads doing socket output. | 
| static HazelcastProperty | JCACHE_PROVIDER_TYPEForces the JCache provider, which can have values client or server, to force the provider type. | 
| static HazelcastProperty | JMX_UPDATE_INTERVAL_SECONDS | 
| static HazelcastProperty | LOCK_MAX_LEASE_TIME_SECONDS | 
| static HazelcastProperty | LOGGING_TYPE | 
| static HazelcastProperty | MAP_EVICTION_BATCH_SIZEMaximum number of IMap entries Hazelcast will evict during a
 single eviction cycle. | 
| static HazelcastProperty | MAP_EXPIRY_DELAY_SECONDSYou can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible
 edge cases, such as using EntryProcessor. | 
| static HazelcastProperty | MAP_INVALIDATION_MESSAGE_BATCH_ENABLEDDefines Near Cache invalidation event batch sending is enabled or not. | 
| static HazelcastProperty | MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDSDefines the Near Cache invalidation event batch sending frequency in seconds. | 
| static HazelcastProperty | MAP_INVALIDATION_MESSAGE_BATCH_SIZEDefines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch. | 
| static HazelcastProperty | MAP_LOAD_ALL_PUBLISHES_ADDED_EVENTThis property is a switch between old and new event publishing
 behavior of map#loadAll. | 
| static HazelcastProperty | MAP_LOAD_CHUNK_SIZEThe maximum size of the key batch sent to the partition owners for value loading
 and the maximum size of a key batch for which values are loaded in a single partition. | 
| static HazelcastProperty | MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS | 
| static HazelcastProperty | MAP_WRITE_BEHIND_QUEUE_CAPACITYSetting this capacity is valid if you set  MapStoreConfig.writeCoalescingtofalse. | 
| static HazelcastProperty | MASTER_CONFIRMATION_INTERVAL_SECONDSDeprecated. 
 since 3.10 | 
| static HazelcastProperty | MASTERSHIP_CLAIM_TIMEOUT_SECONDSThe timeout which defines when master candidate gives up waiting for response to its mastership claim. | 
| static HazelcastProperty | MAX_JOIN_MERGE_TARGET_SECONDS | 
| static HazelcastProperty | MAX_JOIN_SECONDS | 
| static HazelcastProperty | MAX_NO_HEARTBEAT_SECONDSThe timeout which defines when a cluster member is removed because it has not sent any heartbeats. | 
| static HazelcastProperty | MAX_NO_MASTER_CONFIRMATION_SECONDSDeprecated. 
 since 3.10 | 
| static HazelcastProperty | MAX_WAIT_SECONDS_BEFORE_JOIN | 
| static HazelcastProperty | MC_MAX_VISIBLE_SLOW_OPERATION_COUNT | 
| static HazelcastProperty | MC_URL_CHANGE_ENABLEDDeprecated. 
 Enable or disable the  RestEndpointGroup.CLUSTER_WRITEgroup inRestApiConfiginstead. | 
| static HazelcastProperty | MEMBER_LIST_PUBLISH_INTERVAL_SECONDSThe interval at which the master sends the member lists are sent to other non-master members | 
| static HazelcastProperty | MEMCACHE_ENABLEDDeprecated. 
 Use  MemcacheProtocolConfiginstead. | 
| static HazelcastProperty | MERGE_FIRST_RUN_DELAY_SECONDSThe delay until the first run of the  SplitBrainHandler | 
| static HazelcastProperty | MERGE_NEXT_RUN_DELAY_SECONDSThe interval between invocations of the  SplitBrainHandler | 
| static HazelcastProperty | OPERATION_BACKUP_TIMEOUT_MILLISIf an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas. | 
| static HazelcastProperty | OPERATION_CALL_TIMEOUT_MILLIS | 
| static HazelcastProperty | PARTITION_BACKUP_SYNC_INTERVAL | 
| static HazelcastProperty | PARTITION_COUNTTotal number of partitions in the Hazelcast cluster. | 
| static HazelcastProperty | PARTITION_FRAGMENTED_MIGRATION_ENABLED | 
| static HazelcastProperty | PARTITION_MAX_PARALLEL_REPLICATIONS | 
| static HazelcastProperty | PARTITION_MIGRATION_INTERVALTime in seconds to sleep after a migration task. | 
| static HazelcastProperty | PARTITION_MIGRATION_TIMEOUTTimeout in seconds for all migration operations. | 
| static HazelcastProperty | PARTITION_OPERATION_THREAD_COUNTThe number of partition operation handler threads per member. | 
| static HazelcastProperty | PARTITION_TABLE_SEND_INTERVAL | 
| static HazelcastProperty | PARTITIONING_STRATEGY_CLASS | 
| static HazelcastProperty | PHONE_HOME_ENABLED | 
| static HazelcastProperty | PREFER_IPv4_STACK | 
| static HazelcastProperty | PRIORITY_GENERIC_OPERATION_THREAD_COUNTThe number of priority generic operation handler threads per member. | 
| static HazelcastProperty | QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECKMaximum value of local partitions to trigger local pre-check for  TruePredicatequery operations on maps. | 
| static HazelcastProperty | QUERY_OPTIMIZER_TYPEType of Query Optimizer. | 
| static HazelcastProperty | QUERY_PREDICATE_PARALLEL_EVALUATIONRun Query Evaluations for multiple partitions in parallel. | 
| static HazelcastProperty | QUERY_RESULT_SIZE_LIMITResult size limit for query operations on maps. | 
| static HazelcastProperty | RESPONSE_THREAD_COUNTThe number of threads that process responses. | 
| static HazelcastProperty | REST_ENABLEDDeprecated. 
 Use  RestEndpointGroupsinRestApiConfiginstead. | 
| static HazelcastProperty | SEARCH_DYNAMIC_CONFIG_FIRSTBy default, search for data structures config is performed within static configuration first:
 
 Exact match in static config
 Wildcard match in static config
 Exact match in dynamic config
 Wildcard match in dynamic config
 Fallback to default
 
 But sometimes it makes sense to perform search within dynamic configs first. | 
| static HazelcastProperty | SERIALIZATION_VERSIONHazelcast serialization version. | 
| static HazelcastProperty | SHUTDOWNHOOK_ENABLED | 
| static HazelcastProperty | SHUTDOWNHOOK_POLICYBehaviour when JVM is about to exit while Hazelcast instance is still running. | 
| static HazelcastProperty | SLOW_INVOCATION_DETECTOR_THRESHOLD_MILLISDeprecated.  | 
| static HazelcastProperty | SLOW_OPERATION_DETECTOR_ENABLEDEnables or disables the  SlowOperationDetector. | 
| static HazelcastProperty | SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDSPurge interval for slow operation logs. | 
| static HazelcastProperty | SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDSThis value defines the retention time of invocations in slow operation logs. | 
| static HazelcastProperty | SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLEDDefines if the stacktraces of slow operations are logged in the log file. | 
| static HazelcastProperty | SLOW_OPERATION_DETECTOR_THRESHOLD_MILLISDefines a threshold above which a running operation in  OperationServiceis considered to be slow. | 
| static HazelcastProperty | SOCKET_BIND_ANY | 
| static HazelcastProperty | SOCKET_BUFFER_DIRECTIf the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false). | 
| static HazelcastProperty | SOCKET_CLIENT_BIND | 
| static HazelcastProperty | SOCKET_CLIENT_BIND_ANY | 
| static HazelcastProperty | SOCKET_CLIENT_BUFFER_DIRECT | 
| static HazelcastProperty | SOCKET_CLIENT_RECEIVE_BUFFER_SIZEOverrides receive buffer size for connections opened by clients. | 
| static HazelcastProperty | SOCKET_CLIENT_SEND_BUFFER_SIZEOverrides send buffer size for connections opened by clients. | 
| static HazelcastProperty | SOCKET_CONNECT_TIMEOUT_SECONDS | 
| static HazelcastProperty | SOCKET_KEEP_ALIVE | 
| static HazelcastProperty | SOCKET_LINGER_SECONDS | 
| static HazelcastProperty | SOCKET_NO_DELAY | 
| static HazelcastProperty | SOCKET_RECEIVE_BUFFER_SIZE | 
| static HazelcastProperty | SOCKET_SEND_BUFFER_SIZE | 
| static HazelcastProperty | SOCKET_SERVER_BIND_ANY | 
| static HazelcastProperty | TASK_SCHEDULER_REMOVE_ON_CANCELThis is a Java 6 specific property. | 
| static HazelcastProperty | TCP_JOIN_PORT_TRY_COUNTThe number of incremental ports, starting with port number defined in network configuration,
 that will be used to connect to a host which is defined without a port in the TCP-IP member list
 while a node is searching for a cluster. | 
| static HazelcastProperty | USE_LEGACY_MEMBER_LIST_FORMATEnables legacy (pre-3.9) member list format which is printed in logs. | 
| static HazelcastProperty | VERSION_CHECK_ENABLEDDeprecated.  | 
| static HazelcastProperty | WAIT_SECONDS_BEFORE_JOIN | 
| static HazelcastProperty | WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MSDefines the initial backoff delay for the Enterprise WAN
 implementation's consumer. | 
| static HazelcastProperty | WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MSDefines the maximum backoff delay for the Enterprise WAN
 implementation's consumer. | 
| static HazelcastProperty | WAN_CONSUMER_ACK_DELAY_BACKOFF_MULTIPLIERDefines the multiplier (the speed of the function) for the backoff
 delay for the Enterprise WAN implementation's consumer. | 
| static HazelcastProperty | WAN_CONSUMER_INVOCATION_THRESHOLDDefines the pending invocation threshold for the Enterprise WAN
 replication implementation. | 
public static final HazelcastProperty APPLICATION_VALIDATION_TOKEN
public static final HazelcastProperty PARTITION_COUNT
public static final HazelcastProperty PARTITION_OPERATION_THREAD_COUNT
public static final HazelcastProperty GENERIC_OPERATION_THREAD_COUNT
public static final HazelcastProperty PRIORITY_GENERIC_OPERATION_THREAD_COUNT
Having at least 1 priority generic operation thread helps to improve cluster stability since a lot of cluster operations are generic priority operations and they should get executed as soon as possible. If there is a dedicated generic operation thread then these operations don't get delayed because the generic threads are busy executing regular user operations. So unless memory consumption is an issue, make sure there is at least 1 thread.
public static final HazelcastProperty RESPONSE_THREAD_COUNT
By default there are 2 response threads; this gives stable and good performance.
If set to 0, the response threads are bypassed and the response handling is done on the IO threads. Under certain conditions this can give a higher throughput, but setting it to 0 should be regarded an experimental feature.
public static final HazelcastProperty CLIENT_ENGINE_THREAD_COUNT
map.put and map.get, are partition specific and will use a
 partition-specific operation thread, but there are also requests that can't be executed on a partition-specific operation
 thread, such as multimap.containsValue(value), because they need to access all partitions on a given
 member.
 When not set it is set as core-sizepublic static final HazelcastProperty CLIENT_ENGINE_QUERY_THREAD_COUNT
public static final HazelcastProperty CLIENT_ENGINE_BLOCKING_THREAD_COUNT
public static final HazelcastProperty CLIENT_ENDPOINT_REMOVE_DELAY_SECONDS
ClientDisconnectionOperation runs and cleans all resources of a client (listeners are removed, locks/txn are released). With this property, client has a window to connect back and prevent cleaning up its resources.
public static final HazelcastProperty EVENT_THREAD_COUNT
EventServiceImpl executor.
 The executor is responsible for executing the events. If you process a lot of events and have many cores, setting
 a higher value is a good practice. This way, more events can be processed in parallel.public static final HazelcastProperty EVENT_QUEUE_CAPACITY
EventServiceImpl executor.
 The executor is responsible for executing the events. If the events are produced at a higher rate than they are
 consumed, the queue grows in size. This can lead to an OutOfMemoryError if the accumulated events
 are not small enough to fit in memory. This capacity is shared between event topics.
 When the maximum capacity is reached, the items are dropped. This means that the event system is a 'best effort' system
 and there is no guarantee that you are going to get an event.
 Since the capacity is shared between topics, one topic might fill the entire queue and cause
 other topics to drop their messages.public static final HazelcastProperty EVENT_QUEUE_TIMEOUT_MILLIS
public static final HazelcastProperty EVENT_SYNC_TIMEOUT_MILLIS
This timeout configures the maximum amount of waiting time for this fake response. Setting it to a too low value can lead to an uncontrolled growth of the outbound write queue of the connection.
public static final HazelcastProperty HEALTH_MONITORING_LEVEL
public static final HazelcastProperty HEALTH_MONITORING_DELAY_SECONDS
public static final HazelcastProperty HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE
public static final HazelcastProperty HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE
public static final HazelcastProperty IO_THREAD_COUNT
IO_INPUT_THREAD_COUNT and IO_OUTPUT_THREAD_COUNT.
 
 The default is 3 (i.e. 6 threads).public static final HazelcastProperty IO_INPUT_THREAD_COUNT
IO_THREAD_COUNT.public static final HazelcastProperty IO_OUTPUT_THREAD_COUNT
IO_THREAD_COUNT.public static final HazelcastProperty IO_BALANCER_INTERVAL_SECONDS
IOBalancer
 executions. The shorter intervals will catch I/O Imbalance faster, but they will cause higher overhead.
 
 Please see the documentation of IOBalancer
 for a detailed explanation of the problem.
 
 The default is 20 seconds. A value smaller than 1 disables the balancer.public static final HazelcastProperty PREFER_IPv4_STACK
@Deprecated public static final HazelcastProperty VERSION_CHECK_ENABLED
public static final HazelcastProperty PHONE_HOME_ENABLED
public static final HazelcastProperty CONNECT_ALL_WAIT_SECONDS
@Deprecated public static final HazelcastProperty MEMCACHE_ENABLED
MemcacheProtocolConfig instead.@Deprecated public static final HazelcastProperty REST_ENABLED
RestEndpointGroups in
             RestApiConfig instead.@Deprecated public static final HazelcastProperty HTTP_HEALTHCHECK_ENABLED
RestEndpointGroup.HEALTH_CHECK group in
             RestApiConfig instead.public static final HazelcastProperty MAP_LOAD_CHUNK_SIZE
public static final HazelcastProperty MERGE_FIRST_RUN_DELAY_SECONDS
SplitBrainHandlerpublic static final HazelcastProperty MERGE_NEXT_RUN_DELAY_SECONDS
SplitBrainHandlerpublic static final HazelcastProperty OPERATION_CALL_TIMEOUT_MILLIS
public static final HazelcastProperty OPERATION_BACKUP_TIMEOUT_MILLIS
public static final HazelcastProperty FAIL_ON_INDETERMINATE_OPERATION_STATE
IndeterminateOperationStateException. However, even if the invocation fails,
 there will not be any rollback on other successful replicas.public static final HazelcastProperty INVOCATION_MAX_RETRY_COUNT
public static final HazelcastProperty INVOCATION_RETRY_PAUSE
public static final HazelcastProperty SOCKET_BIND_ANY
public static final HazelcastProperty SOCKET_SERVER_BIND_ANY
public static final HazelcastProperty SOCKET_CLIENT_BIND_ANY
public static final HazelcastProperty SOCKET_CLIENT_BIND
public static final HazelcastProperty SOCKET_RECEIVE_BUFFER_SIZE
public static final HazelcastProperty SOCKET_SEND_BUFFER_SIZE
public static final HazelcastProperty SOCKET_BUFFER_DIRECT
public static final HazelcastProperty SOCKET_CLIENT_RECEIVE_BUFFER_SIZE
public static final HazelcastProperty SOCKET_CLIENT_SEND_BUFFER_SIZE
public static final HazelcastProperty SOCKET_CLIENT_BUFFER_DIRECT
public static final HazelcastProperty SOCKET_LINGER_SECONDS
public static final HazelcastProperty SOCKET_CONNECT_TIMEOUT_SECONDS
public static final HazelcastProperty SOCKET_KEEP_ALIVE
public static final HazelcastProperty SOCKET_NO_DELAY
public static final HazelcastProperty SHUTDOWNHOOK_ENABLED
public static final HazelcastProperty SHUTDOWNHOOK_POLICY
HazelcastInstance.shutdown()
 It's not recommended to rely on shutdown hook, this is a last-effort measure.public static final HazelcastProperty WAIT_SECONDS_BEFORE_JOIN
public static final HazelcastProperty MAX_WAIT_SECONDS_BEFORE_JOIN
public static final HazelcastProperty MAX_JOIN_SECONDS
public static final HazelcastProperty MAX_JOIN_MERGE_TARGET_SECONDS
public static final HazelcastProperty HEARTBEAT_INTERVAL_SECONDS
public static final HazelcastProperty MASTERSHIP_CLAIM_TIMEOUT_SECONDS
public static final HazelcastProperty MAX_NO_HEARTBEAT_SECONDS
@Deprecated public static final HazelcastProperty MASTER_CONFIRMATION_INTERVAL_SECONDS
@Deprecated public static final HazelcastProperty MAX_NO_MASTER_CONFIRMATION_SECONDS
public static final HazelcastProperty HEARTBEAT_FAILURE_DETECTOR_TYPE
deadline:  A deadline based failure detector uses an absolute timeout
 for missing/lost heartbeats. After timeout member is considered as dead/unavailable.
 phi-accrual: Implementation of 'The Phi Accrual Failure Detector' by Hayashibara et al.
 as defined in their paper. Phi Accrual Failure Detector is adaptive to network/environment conditions,
 that's why a lower MAX_NO_HEARTBEAT_SECONDS (for example 10 or 15 seconds) can be used to provide
 faster detection of unavailable members.
 deadline.public static final HazelcastProperty MEMBER_LIST_PUBLISH_INTERVAL_SECONDS
public static final HazelcastProperty CLIENT_HEARTBEAT_TIMEOUT_SECONDS
public static final HazelcastProperty CLUSTER_SHUTDOWN_TIMEOUT_SECONDS
public static final HazelcastProperty ICMP_ENABLED
IcmpFailureDetectorConfig
 This will be removed in future versions. Until this is done,
 if the IcmpFailureDetectorConfig is null we will still fall back to thispublic static final HazelcastProperty ICMP_PARALLEL_MODE
IcmpFailureDetectorConfig
 This will be removed in future versions. Until this is done,
 if the IcmpFailureDetectorConfig is null we will still fall back to thispublic static final HazelcastProperty ICMP_ECHO_FAIL_FAST
IcmpFailureDetectorConfig
 This will be removed in future versions. Until this is done,
 if the IcmpFailureDetectorConfig is null we will still fall back to thispublic static final HazelcastProperty ICMP_TIMEOUT
IcmpFailureDetectorConfig
 This will be removed in future versions. Until this is done,
 if the IcmpFailureDetectorConfig is null we will still fall back to thispublic static final HazelcastProperty ICMP_INTERVAL
IcmpFailureDetectorConfig
 This will be removed in future versions. Until this is done,
 if the IcmpFailureDetectorConfig is null we will still fall back to thispublic static final HazelcastProperty ICMP_MAX_ATTEMPTS
IcmpFailureDetectorConfig
 This will be removed in future versions. Until this is done,
 if the IcmpFailureDetectorConfig is null we will still fall back to thispublic static final HazelcastProperty ICMP_TTL
IcmpFailureDetectorConfig
 This will be removed in future versions. Until this is done,
 if the IcmpFailureDetectorConfig is null we will still fall back to thispublic static final HazelcastProperty INITIAL_MIN_CLUSTER_SIZE
public static final HazelcastProperty INITIAL_WAIT_SECONDS
public static final HazelcastProperty TCP_JOIN_PORT_TRY_COUNT
public static final HazelcastProperty MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS
public static final HazelcastProperty MAP_EXPIRY_DELAY_SECONDS
public static final HazelcastProperty MAP_EVICTION_BATCH_SIZE
public static final HazelcastProperty MAP_LOAD_ALL_PUBLISHES_ADDED_EVENT
public static final HazelcastProperty LOGGING_TYPE
public static final HazelcastProperty ENABLE_JMX
public static final HazelcastProperty JMX_UPDATE_INTERVAL_SECONDS
public static final HazelcastProperty MC_MAX_VISIBLE_SLOW_OPERATION_COUNT
@Deprecated public static final HazelcastProperty MC_URL_CHANGE_ENABLED
RestEndpointGroup.CLUSTER_WRITE group in
             RestApiConfig instead.public static final HazelcastProperty CONNECTION_MONITOR_INTERVAL
public static final HazelcastProperty CONNECTION_MONITOR_MAX_FAULTS
public static final HazelcastProperty PARTITION_MIGRATION_INTERVAL
public static final HazelcastProperty PARTITION_MIGRATION_TIMEOUT
public static final HazelcastProperty PARTITION_FRAGMENTED_MIGRATION_ENABLED
public static final HazelcastProperty DISABLE_STALE_READ_ON_PARTITION_MIGRATION
public static final HazelcastProperty PARTITION_TABLE_SEND_INTERVAL
public static final HazelcastProperty PARTITION_BACKUP_SYNC_INTERVAL
public static final HazelcastProperty PARTITION_MAX_PARALLEL_REPLICATIONS
public static final HazelcastProperty PARTITIONING_STRATEGY_CLASS
public static final HazelcastProperty GRACEFUL_SHUTDOWN_MAX_WAIT
public static final HazelcastProperty SLOW_OPERATION_DETECTOR_ENABLED
SlowOperationDetector.public static final HazelcastProperty SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS
OperationService is considered to be slow.
 These operations will log a warning and will be shown in the Management Center with detailed information, e.g. stacktrace.public static final HazelcastProperty SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
public static final HazelcastProperty SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
public static final HazelcastProperty SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
@Deprecated public static final HazelcastProperty SLOW_INVOCATION_DETECTOR_THRESHOLD_MILLIS
public static final HazelcastProperty LOCK_MAX_LEASE_TIME_SECONDS
public static final HazelcastProperty ENTERPRISE_LICENSE_KEY
public static final HazelcastProperty MAP_WRITE_BEHIND_QUEUE_CAPACITY
MapStoreConfig.writeCoalescing to false.
 Otherwise its value will not be taken into account.
 
 The per node maximum write-behind queue capacity is the total of all write-behind queue sizes in a node, including backups.
 
 The maximum value which can be set is Integer.MAX_VALUEpublic static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_ENABLED
public static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_SIZE
public static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS
CACHE_INVALIDATION_MESSAGE_BATCH_SIZE in the given time period (which
 is defined by this property); those events are gathered into a batch and sent to target.public static final HazelcastProperty MAP_INVALIDATION_MESSAGE_BATCH_ENABLED
public static final HazelcastProperty MAP_INVALIDATION_MESSAGE_BATCH_SIZE
public static final HazelcastProperty MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS
MAP_INVALIDATION_MESSAGE_BATCH_SIZE in the given time period (which
 is defined by this property); those events are gathered into a batch and sent to target.public static final HazelcastProperty BACKPRESSURE_ENABLED
public static final HazelcastProperty BACKPRESSURE_SYNCWINDOW
public static final HazelcastProperty BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
HazelcastOverloadException.
 
 The value needs to be equal or larger than 0.public static final HazelcastProperty BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
public static final HazelcastProperty QUERY_PREDICATE_PARALLEL_EVALUATION
public static final HazelcastProperty AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION
public static final HazelcastProperty QUERY_RESULT_SIZE_LIMIT
QueryResultSizeExceededException will be thrown.
 
 This feature prevents an OOME if a single node is requesting the whole data set of the cluster, such as by
 executing a query with TruePredicate. This applies internally for the IMap.values(), IMap.keySet()
 and IMap.entrySet() methods, which are good candidates for OOME in large clusters.
 
 This feature depends on an equal distribution of the data on the cluster nodes to calculate the result size limit per node.
 Therefore, there is a minimum value of  defined in
 QueryResultSizeLimiter. Configured values below the minimum will be increased to the minimum.
 
 The feature can be disabled by setting its value to -1 (which is the default value).public static final HazelcastProperty QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK
TruePredicate query operations on maps.
 
 To limit the result size of a query (PROP_QUERY_RESULT_SIZE_LIMIT); a local pre-check on the requesting node can be
 done before the query is sent to the cluster. Since this may increase the latency, the pre-check is limited to a maximum
 number of local partitions.
 
 By increasing this parameter, you can prevent the execution of the query on the cluster. Increasing this parameter
 increases the latency due to the prolonged local pre-check.
 
 The pre-check can be disabled by setting the value to -1.QUERY_RESULT_SIZE_LIMITpublic static final HazelcastProperty QUERY_OPTIMIZER_TYPE
public static final HazelcastProperty INDEX_COPY_BEHAVIOR
public static final HazelcastProperty JCACHE_PROVIDER_TYPE
public static final HazelcastProperty DISCOVERY_SPI_ENABLED
Enables the Discovery SPI lookup over the old native implementations. This property is temporary and will eventually be removed when the experimental marker is removed.
Discovery SPI is disabled by default
public static final HazelcastProperty DISCOVERY_SPI_PUBLIC_IP_ENABLED
Enables the Discovery Joiner to use public ips from DiscoveredNode. This property is temporary and will eventually be removed when the experimental marker is removed.
Discovery SPI is disabled by default
public static final HazelcastProperty COMPATIBILITY_3_6_CLIENT_ENABLED
public static final HazelcastProperty SERIALIZATION_VERSION
BuildInfo.getSerializationVersion()public static final HazelcastProperty INIT_CLUSTER_VERSION
public static final HazelcastProperty USE_LEGACY_MEMBER_LIST_FORMAT
public static final HazelcastProperty BIND_SPOOFING_CHECKS
public static final HazelcastProperty TASK_SCHEDULER_REMOVE_ON_CANCEL
java.util.concurrent.ScheduledThreadPoolExecutor#setRemoveOnCancelPolicy(boolean)
 and constant time removal.
 In Java 6 there is no out-of-the-box support for removal of cancelled tasks,
 and the only way to implement this is using a linear scan of all pending
 tasks. Therefore in Java 6 there is a performance penalty.
 Using this property, in Java 6, one can control if cancelled tasks are removed.
 By default tasks are removed, because it can lead to temporary retention
 of memory if there a large volume of pending cancelled tasks. And this can
 lead to gc/performance problems as we saw with the transaction tests.
 However if this automatic removal of cancelled tasks start to become a
 performance problem, it can be disabled in Java 6.
 For more information see the LoggingScheduledExecutor.public static final HazelcastProperty SEARCH_DYNAMIC_CONFIG_FIRST
true, search algorithm changes to:
 public static final HazelcastProperty WAN_CONSUMER_INVOCATION_THRESHOLD
public static final HazelcastProperty WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MS
WAN_CONSUMER_INVOCATION_THRESHOLD to a non-negative value
 and that the threshold is exceeded.public static final HazelcastProperty WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MS
WAN_CONSUMER_INVOCATION_THRESHOLD to a non-negative value
 and that the threshold is exceeded.public static final HazelcastProperty WAN_CONSUMER_ACK_DELAY_BACKOFF_MULTIPLIER
WAN_CONSUMER_INVOCATION_THRESHOLD to a non-negative value
 and that the threshold is exceeded.Copyright © 2021 Hazelcast, Inc.. All Rights Reserved.