public final class ClusterProperty extends Object
| Modifier and Type | Field and Description | 
|---|---|
| static HazelcastProperty | AGGREGATION_ACCUMULATION_PARALLEL_EVALUATIONRun aggregation accumulation for multiple entries in parallel. | 
| 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 | 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 | CHANNEL_COUNTNumber of parallel connection between members. | 
| static HazelcastProperty | CLIENT_CLEANUP_PERIODTime period to check if a client is still part of the cluster. | 
| static HazelcastProperty | CLIENT_CLEANUP_TIMEOUTTimeout duration to decide if a client is still part of 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 the query engine. | 
| 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_SECONDSTime after which the member assumes the client is dead and closes its
 connections to the client. | 
| static HazelcastProperty | CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTESClient protocol message size limit (in bytes) for unverified connections
 (i.e. | 
| static HazelcastProperty | CLUSTER_SHUTDOWN_TIMEOUT_SECONDSOnce a member initiates cluster shutdown, it will either wait for all
 members to leave the cluster before shutting itself down. | 
| static HazelcastProperty | CONCURRENT_WINDOW_MSProperty needed for concurrency detection so that write through can be
 done correctly. | 
| static HazelcastProperty | CONNECT_ALL_WAIT_SECONDSTimeout to connect all other cluster members when a member is joining to a cluster. | 
| static HazelcastProperty | CONNECTION_MONITOR_INTERVALMinimum interval in milliseconds to consider a connection error as critical. | 
| static HazelcastProperty | CONNECTION_MONITOR_MAX_FAULTSMaximum I/O error count before disconnecting from a member. | 
| static HazelcastProperty | DISABLE_STALE_READ_ON_PARTITION_MIGRATIONHazelcast allows read operations to be performed while a partition is
 being migrated. | 
| static HazelcastProperty | DISCOVERY_SPI_ENABLEDEnables the Discovery SPI lookup | 
| static HazelcastProperty | DISCOVERY_SPI_PUBLIC_IP_ENABLEDEnables the Discovery Joiner to use public IP from DiscoveredNode. | 
| static HazelcastProperty | ENABLE_JMXEnable JMX agent. | 
| static HazelcastProperty | ENTERPRISE_LICENSE_KEYHazelcast IMDG 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 | GLOBAL_HD_INDEX_ENABLEDEnables use of the concurrent HD index introduced in 4.1 for the IMDG
 predicate API (old query engine) and reverts to using the per-partition
 indexes. | 
| static HazelcastProperty | GRACEFUL_SHUTDOWN_MAX_WAITMaximum wait in seconds during graceful shutdown. | 
| static HazelcastProperty | HEALTH_MONITORING_DELAY_SECONDSHealth monitoring logging interval in seconds. | 
| static HazelcastProperty | HEALTH_MONITORING_LEVELHealth monitoring log level. | 
| static HazelcastProperty | HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGEWhen the health monitoring level is SILENT, logs are printed only when
 the CPU usage exceeds this threshold. | 
| static HazelcastProperty | HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGEWhen the health monitoring level is SILENT, logs are printed only when the
 memory usage exceeds this threshold. | 
| static HazelcastProperty | HEARTBEAT_FAILURE_DETECTOR_TYPEHeartbeat failure detector type. | 
| static HazelcastProperty | HEARTBEAT_INTERVAL_SECONDSThe interval at which member heartbeat messages are sent | 
| 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_SIZEInitial expected cluster size to wait before member to start completely. | 
| static HazelcastProperty | INITIAL_WAIT_SECONDSInitial time in seconds to wait before member to start completely. | 
| 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 | IO_WRITE_THROUGH_ENABLEDOptimization that allows sending of packets over the network to be done
 on the calling thread if the conditions are right. | 
| static HazelcastProperty | JCACHE_PROVIDER_TYPEForces the JCache provider, which can have values client or server, to
 force the provider type. | 
| static HazelcastProperty | JET_IDLE_COOPERATIVE_MAX_MICROSECONDSThe maximum time in microseconds the cooperative worker threads will
 sleep if none of the tasklets made any progress. | 
| static HazelcastProperty | JET_IDLE_COOPERATIVE_MIN_MICROSECONDSThe minimum time in microseconds the cooperative worker threads will
 sleep if none of the tasklets made any progress. | 
| static HazelcastProperty | JET_IDLE_NONCOOPERATIVE_MAX_MICROSECONDSThe maximum time in microseconds the non-cooperative worker threads will
 sleep if none of the tasklets made any progress. | 
| static HazelcastProperty | JET_IDLE_NONCOOPERATIVE_MIN_MICROSECONDSThe minimum time in microseconds the non-cooperative worker threads will
 sleep if none of the tasklets made any progress. | 
| static HazelcastProperty | JMX_UPDATE_INTERVAL_SECONDSSome JMX MBeans are cached (e.g. | 
| static HazelcastProperty | JOB_RESULTS_MAX_SIZEMaximum number of job results to keep in the cluster, the oldest
 results will be automatically deleted after this size is reached. | 
| static HazelcastProperty | JOB_RESULTS_TTL_SECONDSMaximum number of time in seconds the job results will be kept in
 the cluster. | 
| static HazelcastProperty | JOB_SCAN_PERIODJet will periodically check for new jobs to start and perform cleanup of
 unused resources. | 
| static HazelcastProperty | LOCK_MAX_LEASE_TIME_SECONDSAll locks which are acquired without an explicit lease time use this value
 (in seconds) as the lease time. | 
| static HazelcastProperty | LOG_EMOJI_ENABLEDControls whether cluster emojis can be used in log messages. | 
| static HazelcastProperty | LOGGING_ENABLE_DETAILSControls whether cluster name, ip and version should be included in all
 log messages. | 
| static HazelcastProperty | LOGGING_TYPEName of logging framework type to send logging events. | 
| 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_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_SECONDSScheduler delay for map tasks those are executed on backup members. | 
| static HazelcastProperty | MAP_WRITE_BEHIND_QUEUE_CAPACITYSetting this capacity is valid if you set  writeCoalescingtofalse(seeMapStoreConfig.setWriteCoalescing(boolean)). | 
| 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_SECONDSSplit-brain merge timeout for a specific target. | 
| static HazelcastProperty | MAX_JOIN_SECONDSJoin timeout, maximum time to try to join before giving up. | 
| 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_WAIT_SECONDS_BEFORE_JOINThe maximum time that a newly-appointed master node waits before forming a
 cluster. | 
| static HazelcastProperty | MC_EXECUTOR_THREAD_COUNTThe number of threads that the Management Center service has available
 for processing operations sent from connected Management Center instance. | 
| static HazelcastProperty | MC_MAX_VISIBLE_SLOW_OPERATION_COUNTManagement Center maximum visible slow operations count. | 
| 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 | MERGE_FIRST_RUN_DELAY_SECONDSThe delay until the first run of the split-brain handler. | 
| static HazelcastProperty | MERGE_NEXT_RUN_DELAY_SECONDSThe interval between invocations of the split-brain handler. | 
| static HazelcastProperty | METRICS_COLLECTION_FREQUENCYSets the metrics collection frequency in seconds. | 
| static HazelcastProperty | METRICS_DATASTRUCTURESEnables/disables collecting metrics from the distributed data structures. | 
| static HazelcastProperty | METRICS_DEBUGEnables collecting debug metrics. | 
| static HazelcastProperty | METRICS_ENABLEDEnables/disables metrics collection altogether. | 
| static HazelcastProperty | METRICS_JMX_ENABLEDEnables/disables exposing metrics on JMX. | 
| static HazelcastProperty | METRICS_MC_ENABLEDEnables/disables collecting metrics for Management Center. | 
| static HazelcastProperty | METRICS_MC_RETENTIONSets the duration in seconds for which the collected metrics are retained
 and Management Center can consume them. | 
| static HazelcastProperty | MOBY_NAMING_ENABLEDDefines whether Moby Names should be used for instance name generating
 when it is not provided by user. | 
| static HazelcastProperty | MULTICAST_GROUPIP address of a multicast group. | 
| static HazelcastProperty | MULTICAST_SOCKET_SET_INTERFACEAllows explicitly control if the  MulticastSocket.setInterface(java.net.InetAddress)method is called in
 the Hazelcast multicast discovery service. | 
| static HazelcastProperty | NETWORK_STATS_REFRESH_INTERVAL_SECONDSThe interval at which network stats (bytes sent and received) are
 re-calculated and published. | 
| 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_MILLISTimeout to wait for a response when a remote call is sent, in milliseconds. | 
| static HazelcastProperty | PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_ALGORITHM_TIMEOUT_SECONDSThe partial member disconnection resolution mechanism uses a graph algorithm
 that finds a max-clique in non-polynomial time. | 
| static HazelcastProperty | PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_HEARTBEAT_COUNTThe master member, i.e, the first member in the cluster member list
 administrates the cluster and kicks unreachable members with the heartbeat
 mechanism. | 
| static HazelcastProperty | PARTITION_BACKUP_SYNC_INTERVALInterval for syncing backup replicas in seconds. | 
| static HazelcastProperty | PARTITION_CHUNKED_MAX_MIGRATING_DATA_IN_MBTotal size of all chunks in bytes during a single partition migration. | 
| static HazelcastProperty | PARTITION_CHUNKED_MIGRATION_ENABLEDEnable to subdivide fragments into chunks. | 
| static HazelcastProperty | PARTITION_COUNTTotal number of partitions in the Hazelcast cluster. | 
| static HazelcastProperty | PARTITION_FRAGMENTED_MIGRATION_ENABLEDWhen enabled, which is the default behavior, partitions are migrated/replicated
 in small fragments instead of one big chunk. | 
| static HazelcastProperty | PARTITION_MAX_PARALLEL_MIGRATIONSMaximum number of partition migrations to be executed concurrently on a member. | 
| static HazelcastProperty | PARTITION_MAX_PARALLEL_REPLICATIONSMaximum number of anti-entropy partition replications to be executed on a member. | 
| 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_INTERVALInterval for publishing partition table periodically to all cluster members
 in seconds. | 
| static HazelcastProperty | PARTITIONING_STRATEGY_CLASSClass name implementing  PartitioningStrategy, which
 defines key to partition mapping. | 
| static HazelcastProperty | PHONE_HOME_ENABLEDEnable or disable the sending of phone home data to Hazelcast’s phone home
 server. | 
| static HazelcastProperty | PREFER_IPv4_STACKPrefer IPv4 network interface when picking a local address. | 
| static HazelcastProperty | PRIORITY_GENERIC_OPERATION_THREAD_COUNTThe number of priority generic operation handler threads per member. | 
| static HazelcastProperty | PROCESSOR_CUSTOM_LIB_DIRThe directory containing jars, that can be used to specify custom classpath for
 a stage in a pipeline. | 
| static HazelcastProperty | QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECKMaximum value of local partitions to trigger local pre-check for
  Predicates.alwaysTrue()predicate query 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 | 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 | SECURITY_RECOMMENDATIONSWhen set to any not- nullvalue, security recommendations are logged on INFO level during the node start. | 
| static HazelcastProperty | SERIALIZATION_VERSIONHazelcast serialization version. | 
| static HazelcastProperty | SHUTDOWNHOOK_ENABLEDEnable Hazelcast shutdownhook thread. | 
| static HazelcastProperty | SHUTDOWNHOOK_POLICYBehaviour when JVM is about to exit while Hazelcast instance is still running. | 
| 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_ANYBind both server-socket and client-sockets to any local interface. | 
| 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_BINDBind client socket to an interface when connecting to a remote server
 socket. | 
| static HazelcastProperty | SOCKET_CLIENT_BIND_ANYBind client-sockets to any local interface. | 
| static HazelcastProperty | SOCKET_CLIENT_BUFFER_DIRECTIf the bytebuffers used in the socket should be a direct bytebuffer ( true)
 or a regular bytebuffer (false). | 
| 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_SECONDSSocket connection timeout in seconds. | 
| static HazelcastProperty | SOCKET_KEEP_ALIVESocket set keep alive (SO_KEEPALIVE). | 
| static HazelcastProperty | SOCKET_LINGER_SECONDSSet socket SO_LINGER option. | 
| static HazelcastProperty | SOCKET_NO_DELAYSocket set TCP no delay. | 
| static HazelcastProperty | SOCKET_RECEIVE_BUFFER_SIZESocket receive buffer (SO_RCVBUF) size in KB. | 
| static HazelcastProperty | SOCKET_SEND_BUFFER_SIZESocket send buffer (SO_SNDBUF) size in KB. | 
| static HazelcastProperty | SOCKET_SERVER_BIND_ANYBind server-socket to any local interface. | 
| static HazelcastProperty | SQL_CUSTOM_TYPES_ENABLEDEnable experimental support for accessing nested fields by using custom
 types in SQL. | 
| 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 | TCP_PREVIOUSLY_JOINED_MEMBER_ADDRESS_RETENTION_DURATIONSpecifies how long the address of a member that has previously joined the
 cluster will be retained/remembered in the TcpIpJoiner after it leaves the
 cluster. | 
| static HazelcastProperty | WAIT_SECONDS_BEFORE_JOINThe time that a newly-appointed master node waits before forming a cluster. | 
| 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 NETWORK_STATS_REFRESH_INTERVAL_SECONDS
public static final HazelcastProperty CHANNEL_COUNT
There is no point in having more connections than IO threads.
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
public static final HazelcastProperty SOCKET_BIND_ANY
public static final HazelcastProperty SOCKET_SERVER_BIND_ANY
SOCKET_BIND_ANY is used as the default.public static final HazelcastProperty SOCKET_CLIENT_BIND_ANY
SOCKET_BIND_ANY is used as the default.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
true)
 or a regular bytebuffer (false).public static final HazelcastProperty SOCKET_CLIENT_RECEIVE_BUFFER_SIZE
 Hazelcast creates all connections with receive buffer size set according
 to SOCKET_RECEIVE_BUFFER_SIZE.
 When it detects a connection was opened by a client then it adjusts receive
 buffer size according to this property.
 
Size is in kilobytes.
The default is -1 (same as receive buffer size for connections opened by members).
public static final HazelcastProperty SOCKET_CLIENT_SEND_BUFFER_SIZE
 Hazelcast creates all connections with send buffer size set according to
 SOCKET_SEND_BUFFER_SIZE.
 When it detects a connection was opened by a client then it adjusts send
 buffer size according to this property.
 
Size is in kilobytes.
The default is -1 (same as receive buffer size for connections opened by members).
public static final HazelcastProperty SOCKET_CLIENT_BUFFER_DIRECT
true)
 or a regular bytebuffer (false).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 IO_THREAD_COUNT
 E.g., if 3 is configured, then you get 3 threads doing input and 3 doing
 output. For individual control, check IO_INPUT_THREAD_COUNT and
 IO_OUTPUT_THREAD_COUNT.
 
The default is depends on the number of available processors. If the available processors count is smaller than 20, there will be 3+3 io threads, otherwise 4+4.
If SSL is enabled, then the default number of IO threads will be corecount/2.
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_WRITE_THROUGH_ENABLED
It is enabled by default.
public static final HazelcastProperty CONCURRENT_WINDOW_MS
Normally in a concurrent system the window keeps sliding forward so it will always remain concurrent.
Setting it too high effectively disables the optimization because once concurrency has been detected it will keep that way. Setting it too low could lead to suboptimal performance because the system will try write through and other optimizations even though the system is concurrent.
public static final HazelcastProperty CONNECTION_MONITOR_INTERVAL
public static final HazelcastProperty CONNECTION_MONITOR_MAX_FAULTS
public static final HazelcastProperty CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTES
public static final HazelcastProperty PARTITION_COUNT
public 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 TCP_PREVIOUSLY_JOINED_MEMBER_ADDRESS_RETENTION_DURATION
public static final HazelcastProperty MULTICAST_SOCKET_SET_INTERFACE
MulticastSocket.setInterface(java.net.InetAddress) method is called in
 the Hazelcast multicast discovery service. This configuration may affect the multicast behavior on some platforms. The
 default value is not specified here and in such case Hazelcast multicast service itself decides if the
 setInterface() call should be called.public static final HazelcastProperty MULTICAST_GROUP
MulticastConfig configuration.public static final HazelcastProperty CONNECT_ALL_WAIT_SECONDS
public static final HazelcastProperty DISCOVERY_SPI_ENABLED
Enables the Discovery SPI lookup
Discovery SPI is disabled by default
public static final HazelcastProperty DISCOVERY_SPI_PUBLIC_IP_ENABLED
Enables the Discovery Joiner to use public IP from DiscoveredNode.
Discovery SPI is disabled by default
public static final HazelcastProperty MERGE_FIRST_RUN_DELAY_SECONDS
public static final HazelcastProperty MERGE_NEXT_RUN_DELAY_SECONDS
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 PARTITION_CHUNKED_MIGRATION_ENABLED
Default enabled.
PARTITION_FRAGMENTED_MIGRATION_ENABLEDpublic static final HazelcastProperty PARTITION_CHUNKED_MAX_MIGRATING_DATA_IN_MB
If you have parallel migrations, max migrating data equals number-of-parallel-migrations times this value.
Default is 250 MB.
public static final HazelcastProperty WAIT_SECONDS_BEFORE_JOIN
MAX_WAIT_SECONDS_BEFORE_JOIN seconds, the master node will proceed
 with processing the join requests and forming the cluster, regardless of the
 time elapsed since the last join request.
 After the master node has started processing join requests, it will no longer introduce any more waiting and join requests will be processed as they arrive. The only exception to this is if the master state is reset, which may happen in some cases like split-brain healing.
public static final HazelcastProperty MAX_WAIT_SECONDS_BEFORE_JOIN
WAIT_SECONDS_BEFORE_JOIN seconds have passed since
 the last join request, the master node will proceed with processing the join
 requests and forming the cluster, regardless of the time elapsed since the
 first join request.
 After the master node has started processing join requests, it will no longer introduce any more waiting and join requests will be processed as they arrive. The only exception to this is if the master state is reset, which may happen in some cases like split-brain healing.
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
public static final HazelcastProperty PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_HEARTBEAT_COUNT
When the master receives a heartbeat problem report from another member, it first waits for a number of heartbeat rounds to allow other members to report their problems if there is any. After that, it takes all reports received so far and checks if it can update the cluster member in a way that the minimum number of members will be kicked from the cluster and there won't be any heartbeat problem between the remaining members.
If this configuration option is set to 0, this functionality is disabled. It is recommended to be set to at least 3 or 5 so that the master will wait long enough to collect heartbeat problem reports. Otherwise, the master member can make sub-optimal decisions.
public static final HazelcastProperty PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_ALGORITHM_TIMEOUT_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.
 
 Default failure detector is 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 GRACEFUL_SHUTDOWN_MAX_WAIT
public static final HazelcastProperty PARTITION_TABLE_SEND_INTERVAL
public static final HazelcastProperty PARTITION_BACKUP_SYNC_INTERVAL
public static final HazelcastProperty PARTITION_MAX_PARALLEL_MIGRATIONS
public static final HazelcastProperty PARTITION_MAX_PARALLEL_REPLICATIONS
PARTITION_MAX_PARALLEL_MIGRATIONS.public static final HazelcastProperty PARTITIONING_STRATEGY_CLASS
PartitioningStrategy, which
 defines key to partition mapping.public static final HazelcastProperty CLIENT_CLEANUP_PERIOD
public static final HazelcastProperty CLIENT_CLEANUP_TIMEOUT
public static final HazelcastProperty INIT_CLUSTER_VERSION
public static final HazelcastProperty METRICS_ENABLED
 NOTE: This property overrides BaseMetricsConfig.isEnabled().
 
 Using BaseMetricsConfig.setEnabled(boolean) and the declarative
 counterparts are preferred over using this property. The main purpose
 of making metrics collection configurable from properties too is
 allowing operators to configure the metrics subsystem from the outside
 during investigation without touching or copying the configuration
 potentially embedded into a signed artifact.
public static final HazelcastProperty METRICS_MC_ENABLED
 NOTE: This property overrides MetricsManagementCenterConfig.isEnabled().
 
 Using MetricsManagementCenterConfig.setEnabled(boolean) and the declarative
 counterparts are preferred over using this property. The main purpose
 of making metrics collection configurable from properties too is
 allowing operators to configure the metrics subsystem from the outside
 during investigation without touching or copying the configuration
 potentially embedded into a signed artifact.
public static final HazelcastProperty METRICS_MC_RETENTION
 NOTE: This property overrides MetricsManagementCenterConfig.getRetentionSeconds().
 
 Using MetricsManagementCenterConfig.setRetentionSeconds(int) and the declarative
 counterparts are preferred over using this property. The main purpose
 of making metrics collection configurable from properties too is
 allowing operators to configure the metrics subsystem from the outside
 during investigation without touching or copying the configuration
 potentially embedded into a signed artifact.
public static final HazelcastProperty METRICS_JMX_ENABLED
 NOTE: This property overrides MetricsJmxConfig.isEnabled().
 
 Using MetricsJmxConfig.setEnabled(boolean) and the declarative
 counterparts are preferred over using this property. The main purpose
 of making metrics collection configurable from properties too is
 allowing operators to configure the metrics subsystem from the outside
 during investigation without touching or copying the configuration
 potentially embedded into a signed artifact.
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 ENABLE_JMX
public static final HazelcastProperty JMX_UPDATE_INTERVAL_SECONDS
public static final HazelcastProperty MC_MAX_VISIBLE_SLOW_OPERATION_COUNT
public static final HazelcastProperty MC_EXECUTOR_THREAD_COUNT
public static final HazelcastProperty METRICS_DEBUG
public static final HazelcastProperty METRICS_DATASTRUCTURES
public static final HazelcastProperty METRICS_COLLECTION_FREQUENCY
 NOTE: This property overrides BaseMetricsConfig.getCollectionFrequencySeconds().
 
 Using BaseMetricsConfig.setCollectionFrequencySeconds(int) and the declarative
 counterparts are preferred over using this property. The main purpose
 of making metrics collection configurable from properties too is
 allowing operators to configure the metrics subsystem from the outside
 during investigation without touching or copying the configuration
 potentially embedded into a signed artifact.
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
If an invocation is older than this value, it will be purged from the log to prevent unlimited memory usage. When all invocations are purged from a log, the log itself will be deleted.
public static final HazelcastProperty SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
public static final HazelcastProperty SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
public static final HazelcastProperty QUERY_PREDICATE_PARALLEL_EVALUATION
Each Hazelcast member evaluates query predicates using a single thread by default. In most cases the overhead of inter-thread communication overweight benefit of parallel execution.
 When you have a large dataset and/or slow predicate you may benefit from
 parallel predicate evaluations.
 Set to true if you are using slow predicates or have < 100,000s
 entries per member.
 
 The default is false.
public static final HazelcastProperty AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION
Each Hazelcast member executes the accumulation stage of an aggregation using a single thread by default. In most cases it pays off to do it in parallel.
 The default is true.
public static final HazelcastProperty GLOBAL_HD_INDEX_ENABLED
 The newly introduced SQL engine (see SqlService)
 will still use the concurrent HD index since it cannot use the partitioned
 indexes.
public static final HazelcastProperty QUERY_RESULT_SIZE_LIMIT
 This value defines the maximum number of returned elements for a single
 query result. If a query exceeds this number of elements, a
 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
 Predicates.alwaysTrue() predicate. 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
Predicates.alwaysTrue() predicate query operations on maps.
 
 To limit the result size of a query (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
Values are case sensitive
public static final HazelcastProperty INDEX_COPY_BEHAVIOR
-> Copying on-read means that each index-read operation will copy the result of the query before returning it to the caller.This copying may be expensive, depending on the size of the result, since the result is stored in a map, which means that all entries need to have the hash calculated before being stored in a bucket. Each index-write operation however will be fast, since there will be no copying taking place.
-> Copying on-write means that each index-write operation will completely copy the underlying map to provide the copy-on-write semantics. Depending on the index size, it may be a very expensive operation. Each index-read operation will be very fast, however, since it may just access the map and return it to the caller.
-> Never copying is tricky. It means that the internal data structures of the index are concurrently modified without copy-on-write semantics. Index reads never copy the results of a query to a separate map. It means that the results backed by the underlying index-map can change after the query has been executed. Specifically an entry might have been added / removed from an index, or it might have been remapped. Should be used in cases when a the caller expects "mostly correct" results - specifically, if it's ok if some entries returned in the result set do not match the initial query criteria. The fastest solution for read and writes, since no copying takes place.
It's a tuneable trade-off - the user may decide.
Valid Values:
public static final HazelcastProperty CLIENT_ENGINE_QUERY_THREAD_COUNT
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.public static final HazelcastProperty MAP_LOAD_CHUNK_SIZE
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
Default: 1
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
 When the number of events do not come up to
 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 MAP_WRITE_BEHIND_QUEUE_CAPACITY
writeCoalescing to false
 (see MapStoreConfig.setWriteCoalescing(boolean)).
 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_VALUE
public 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 BACKPRESSURE_ENABLED
With back-pressure enabled, this can't happen.
Back pressure is implemented by making asynchronous backups operations synchronous. This prevents the internal queues from overflowing because the invoker will wait for the primary and for the backups to complete. The frequency of this is determined by the sync-window.
 To deal with overloads of backups, the property
 OPERATION_BACKUP_TIMEOUT_MILLIS should be set to a larger value;
 above 60000 is recommended. Otherwise it can still happen backups
 accumulate.
public static final HazelcastProperty BACKPRESSURE_SYNCWINDOW
A sync window of 10 means that 1 in 10 BackupAwareOperations get their async backups convert to sync backups.
A sync window of 1 means that every BackupAwareOperation get their async backups converted to sync backups. 1 is also the smallest legal value for the sync window.
There is some randomization going on to prevent resonance. Therefore, with a sync window of n, not every Nth BackupAwareOperation operation gets its async backups converted to sync.
This property only has meaning when backpressure is enabled.
public static final HazelcastProperty BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
 If an invocation can't be made because there are too many pending invocations,
 then an exponential backoff is done to give the system time to deal with
 the backlog of invocations. This property controls how long an invocation
 is allowed to wait before getting a HazelcastOverloadException.
 
The value needs to be equal or larger than 0.
public static final HazelcastProperty BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
To prevent the system from overloading, HZ can apply a constraint on the number of concurrent invocations. If the maximum number of concurrent invocations has been exceeded and a new invocation comes in, then an exponential back-off is applied till eventually a timeout happens or there is room for the invocation.
By default it is configured as 100. With 271 partitions, that would give (271 + 1) * 100 = 27200 concurrent invocations from a single member. The +1 is for generic operations. The reasons why 100 is chosen are: - there can be concurrent operations that touch a lot of partitions which consume more than 1 invocation, and - certain methods like those from the IExecutor are also invocations and they can be very long running.
No promise is made for the invocations being tracked per partition, or if there is a general pool of invocations.
public static final HazelcastProperty DISABLE_STALE_READ_ON_PARTITION_MIGRATION
public static final HazelcastProperty PARTITION_OPERATION_THREAD_COUNT
If this is less than the number of partitions on a member, partition operations will queue behind other operations of different partitions.
public static final HazelcastProperty GENERIC_OPERATION_THREAD_COUNT
The default is max(2, processors/2);
public static final HazelcastProperty PRIORITY_GENERIC_OPERATION_THREAD_COUNT
The default is 1.
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 CACHE_INVALIDATION_MESSAGE_BATCH_ENABLED
public static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_SIZE
public static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS
 When the number of events do not come up to
 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 JCACHE_PROVIDER_TYPE
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-size.
public static final HazelcastProperty CLIENT_ENGINE_BLOCKING_THREAD_COUNT
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 PHONE_HOME_ENABLED
public static final HazelcastProperty SHUTDOWNHOOK_ENABLED
public static final HazelcastProperty SHUTDOWNHOOK_POLICY
Possible values: TERMINATE: Terminate Hazelcast immediately GRACEFUL: Initiate graceful shutdown. This can significantly slow-down JVM exit process, but it's tries to retain data safety.
Default: TERMINATE
 You should always shutdown Hazelcast explicitly via HazelcastInstance.shutdown()
 It's not recommended to rely on shutdown hook, this is a last-effort measure.
public static final HazelcastProperty LOGGING_TYPE
public static final HazelcastProperty LOGGING_ENABLE_DETAILS
public static final HazelcastProperty LOCK_MAX_LEASE_TIME_SECONDS
public static final HazelcastProperty ENTERPRISE_LICENSE_KEY
public static final HazelcastProperty SERIALIZATION_VERSION
BuildInfo.getSerializationVersion()public static final HazelcastProperty SEARCH_DYNAMIC_CONFIG_FIRST
true, search algorithm changes to:
 public static final HazelcastProperty MOBY_NAMING_ENABLED
Moby Name is a short human-readable name consisting of randomly chosen adjective and the surname of a famous person.
 If set to true, Moby Name will be chosen, otherwise a name that
 is concatenation of static prefix, number and cluster name.
 
 By default is true.
public static final HazelcastProperty JOB_SCAN_PERIOD
public static final HazelcastProperty JOB_RESULTS_TTL_SECONDS
Default value is 7 days.
public static final HazelcastProperty JOB_RESULTS_MAX_SIZE
Default value is 1,000 jobs.
public static final HazelcastProperty JET_IDLE_COOPERATIVE_MIN_MICROSECONDS
 The default is value is 25µs.
 
 Note: the underlying LockSupport.parkNanos(long) call may
 actually sleep longer depending on the operating system (up to 15000µs
 on Windows). See the 
 Hazelcast blog post about this subject for more details.
 
 See also: JET_IDLE_COOPERATIVE_MAX_MICROSECONDS
public static final HazelcastProperty JET_IDLE_COOPERATIVE_MAX_MICROSECONDS
 The default is value is 500µs.
 
 Note: the underlying LockSupport.parkNanos(long) call may
 actually sleep longer depending on the operating system (up to 15000µs on
 Windows). See the 
 Hazelcast blog post about this subject for more details.
 
 See also: JET_IDLE_COOPERATIVE_MIN_MICROSECONDS
public static final HazelcastProperty JET_IDLE_NONCOOPERATIVE_MIN_MICROSECONDS
 The default is value is 25µs.
 
 Note: the underlying LockSupport.parkNanos(long) call may actually
 sleep longer depending on the operating system (up to 15000µs on Windows).
 See the 
 Hazelcast blog post about this subject for more details.
 
 See also: JET_IDLE_NONCOOPERATIVE_MAX_MICROSECONDS
public static final HazelcastProperty JET_IDLE_NONCOOPERATIVE_MAX_MICROSECONDS
 The default is value is 5000µs.
 
 Note: the underlying LockSupport.parkNanos(long) call may actually
 sleep longer depending on the operating system (up to 15000µs on Windows).
 See the 
 Hazelcast blog post about this subject for more details.
 
 See also: JET_IDLE_NONCOOPERATIVE_MIN_MICROSECONDS
public static final HazelcastProperty PROCESSOR_CUSTOM_LIB_DIR
public static final HazelcastProperty LOG_EMOJI_ENABLED
public static final HazelcastProperty SECURITY_RECOMMENDATIONS
null value, security recommendations are logged on INFO level during the node start. The
 default value is null.@Beta public static final HazelcastProperty SQL_CUSTOM_TYPES_ENABLED
Copyright © 2022 Hazelcast, Inc.. All rights reserved.