| Package | Description | 
|---|---|
| com.hazelcast.client.properties | Contains the Hazelcast client properties implementation. | 
| com.hazelcast.spi.properties | Contains the Hazelcast properties implementation. | 
| Modifier and Type | Field and Description | 
|---|---|
| static HazelcastProperty | ClientProperty. BACKPRESSURE_BACKOFF_TIMEOUT_MILLISControl the maximum timeout in millis to wait for an invocation space to be available. | 
| static HazelcastProperty | ClientProperty. CONCURRENT_WINDOW_MSProperty needed for concurrency detection so that write through and dynamic response handling
 can be done correctly. | 
| static HazelcastProperty | ClientProperty. DISCOVERY_SPI_ENABLEDEnables the Discovery SPI | 
| static HazelcastProperty | ClientProperty. DISCOVERY_SPI_PUBLIC_IP_ENABLEDEnables the Discovery Joiner to use public IP from DiscoveredNode. | 
| static HazelcastProperty | ClientProperty. EVENT_QUEUE_CAPACITYCapacity of the executor that handles the incoming event packets. | 
| static HazelcastProperty | ClientProperty. EVENT_THREAD_COUNTNumber of the threads to handle the incoming event packets. | 
| static HazelcastProperty | ClientProperty. 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 | ClientProperty. HAZELCAST_CLOUD_DISCOVERY_TOKENToken to use when discovering cluster via hazelcast.cloud | 
| static HazelcastProperty | ClientProperty. HEARTBEAT_INTERVALTime interval between the heartbeats sent by the client to the nodes. | 
| static HazelcastProperty | ClientProperty. HEARTBEAT_TIMEOUTClient sends heartbeat messages to the members and this is the timeout for this sending operations. | 
| static HazelcastProperty | ClientProperty. INVOCATION_RETRY_PAUSE_MILLISPause time between each retry cycle of an invocation in milliseconds. | 
| static HazelcastProperty | ClientProperty. INVOCATION_TIMEOUT_SECONDSWhen an invocation gets an exception because :
 - Member throws an exception. | 
| static HazelcastProperty | ClientProperty. IO_BALANCER_INTERVAL_SECONDSThe interval in seconds between  IOBalancerexecutions. | 
| static HazelcastProperty | ClientProperty. IO_INPUT_THREAD_COUNTControls the number of IO input threads. | 
| static HazelcastProperty | ClientProperty. IO_OUTPUT_THREAD_COUNTControls the number of IO output threads. | 
| static HazelcastProperty | ClientProperty. 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 | ClientProperty. MAX_CONCURRENT_INVOCATIONSThe maximum number of concurrent invocations allowed. | 
| static HazelcastProperty | ClientProperty. METRICS_COLLECTION_FREQUENCYSets the metrics collection frequency in seconds. | 
| static HazelcastProperty | ClientProperty. METRICS_DEBUGEnables collecting debug metrics. | 
| static HazelcastProperty | ClientProperty. METRICS_ENABLEDEnables/disables metrics collection altogether. | 
| static HazelcastProperty | ClientProperty. METRICS_JMX_ENABLEDEnables/disables exposing metrics on JMX. | 
| static HazelcastProperty | ClientProperty. 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 | ClientProperty. RESPONSE_THREAD_COUNTThe number of response threads. | 
| static HazelcastProperty | ClientProperty. RESPONSE_THREAD_DYNAMICEnabled dynamic switching between processing responses on the io threads
 and offloading the response threads. | 
| static HazelcastProperty | ClientProperty. SHUFFLE_MEMBER_LISTClient shuffles the given member list to prevent all clients to connect to the same node when
 this property is set to true. | 
| static HazelcastProperty | ClientProperty. STATISTICS_ENABLEDUse to enable the client statistics collection. | 
| static HazelcastProperty | ClientProperty. STATISTICS_PERIOD_SECONDSThe period in seconds the statistics run. | 
| Modifier and Type | Field and Description | 
|---|---|
| static HazelcastProperty | ClusterProperty. AGGREGATION_ACCUMULATION_PARALLEL_EVALUATIONRun aggregation accumulation for multiple entries in parallel. | 
| static HazelcastProperty | ClusterProperty. BACKPRESSURE_BACKOFF_TIMEOUT_MILLISControl the maximum timeout in millis to wait for an invocation space to
 be available. | 
| static HazelcastProperty | ClusterProperty. BACKPRESSURE_ENABLEDUsing back pressure, you can prevent an overload of pending asynchronous
 backups. | 
| static HazelcastProperty | ClusterProperty. BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITIONThe maximum number of concurrent invocations per partition. | 
| static HazelcastProperty | ClusterProperty. BACKPRESSURE_SYNCWINDOWControls the frequency of a BackupAwareOperation getting its async backups
 converted to a sync backups. | 
| static HazelcastProperty | ClusterProperty. BIND_SPOOFING_CHECKSControls whether we apply more strict checks upon BIND requests towards
 a cluster member. | 
| static HazelcastProperty | ClusterProperty. CACHE_INVALIDATION_MESSAGE_BATCH_ENABLEDDefines cache invalidation event batch sending is enabled or not. | 
| static HazelcastProperty | ClusterProperty. CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDSDefines the cache invalidation event batch sending frequency in seconds. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. CHANNEL_COUNTNumber of parallel connection between members. | 
| static HazelcastProperty | ClusterProperty. CLIENT_CLEANUP_PERIODTime period to check if a client is still part of the cluster. | 
| static HazelcastProperty | ClusterProperty. CLIENT_CLEANUP_TIMEOUTTimeout duration to decide if a client is still part of the cluster. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. 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 | ClusterProperty. CLIENT_ENGINE_THREAD_COUNTThe number of threads that the client engine has available for processing
 requests that are not partition specific. | 
| static HazelcastProperty | ClusterProperty. CLIENT_HEARTBEAT_TIMEOUT_SECONDSTime after which the member assumes the client is dead and closes its
 connections to the client. | 
| static HazelcastProperty | ClusterProperty. CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTESClient protocol message size limit (in bytes) for unverified connections
 (i.e. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. CONCURRENT_WINDOW_MSProperty needed for concurrency detection so that write through can be
 done correctly. | 
| static HazelcastProperty | ClusterProperty. CONNECT_ALL_WAIT_SECONDSTimeout to connect all other cluster members when a member is joining to a cluster. | 
| static HazelcastProperty | ClusterProperty. CONNECTION_MONITOR_INTERVALMinimum interval in milliseconds to consider a connection error as critical. | 
| static HazelcastProperty | ClusterProperty. CONNECTION_MONITOR_MAX_FAULTSMaximum I/O error count before disconnecting from a member. | 
| static HazelcastProperty | ClusterProperty. DISABLE_STALE_READ_ON_PARTITION_MIGRATIONHazelcast allows read operations to be performed while a partition is
 being migrated. | 
| static HazelcastProperty | ClusterProperty. DISCOVERY_SPI_ENABLEDEnables the Discovery SPI lookup | 
| static HazelcastProperty | ClusterProperty. DISCOVERY_SPI_PUBLIC_IP_ENABLEDEnables the Discovery Joiner to use public IP from DiscoveredNode. | 
| static HazelcastProperty | ClusterProperty. ENABLE_JMXEnable JMX agent. | 
| static HazelcastProperty | ClusterProperty. ENTERPRISE_LICENSE_KEYHazelcast IMDG Enterprise license key. | 
| static HazelcastProperty | ClusterProperty. EVENT_QUEUE_CAPACITYThe capacity of the  EventServiceImplexecutor. | 
| static HazelcastProperty | ClusterProperty. EVENT_QUEUE_TIMEOUT_MILLISThe timeout for offering an event to the event executor for processing. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. EVENT_THREAD_COUNTNumber of threads for the  EventServiceImplexecutor. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. GENERIC_OPERATION_THREAD_COUNTThe number of generic operation handler threads per member. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. GRACEFUL_SHUTDOWN_MAX_WAITMaximum wait in seconds during graceful shutdown. | 
| static HazelcastProperty | ClusterProperty. HEALTH_MONITORING_DELAY_SECONDSHealth monitoring logging interval in seconds. | 
| static HazelcastProperty | ClusterProperty. HEALTH_MONITORING_LEVELHealth monitoring log level. | 
| static HazelcastProperty | ClusterProperty. HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGEWhen the health monitoring level is SILENT, logs are printed only when
 the CPU usage exceeds this threshold. | 
| static HazelcastProperty | ClusterProperty. HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGEWhen the health monitoring level is SILENT, logs are printed only when the
 memory usage exceeds this threshold. | 
| static HazelcastProperty | ClusterProperty. HEARTBEAT_FAILURE_DETECTOR_TYPEHeartbeat failure detector type. | 
| static HazelcastProperty | ClusterProperty. HEARTBEAT_INTERVAL_SECONDSThe interval at which member heartbeat messages are sent | 
| static HazelcastProperty | ClusterProperty. HOT_RESTART_FREE_NATIVE_MEMORY_PERCENTAGEDeprecated. 
 since 4.2 | 
| static HazelcastProperty | ClusterProperty. INDEX_COPY_BEHAVIORType of Query Index result copying behavior. | 
| static HazelcastProperty | ClusterProperty. INIT_CLUSTER_VERSIONOverride cluster version to use while node is not yet member of a cluster. | 
| static HazelcastProperty | ClusterProperty. INITIAL_MIN_CLUSTER_SIZEInitial expected cluster size to wait before member to start completely. | 
| static HazelcastProperty | ClusterProperty. INITIAL_WAIT_SECONDSInitial time in seconds to wait before member to start completely. | 
| static HazelcastProperty | ClusterProperty. INVOCATION_MAX_RETRY_COUNTMaximum number of retries for an invocation. | 
| static HazelcastProperty | ClusterProperty. INVOCATION_RETRY_PAUSEPause time between each retry cycle of an invocation in milliseconds. | 
| static HazelcastProperty | ClusterProperty. IO_BALANCER_INTERVAL_SECONDSThe interval in seconds between
  IOBalancerexecutions. | 
| static HazelcastProperty | ClusterProperty. IO_INPUT_THREAD_COUNTControls the number of socket input threads. | 
| static HazelcastProperty | ClusterProperty. IO_OUTPUT_THREAD_COUNTControls the number of socket output threads. | 
| static HazelcastProperty | ClusterProperty. IO_THREAD_COUNTThe number of threads doing socket input and the number of threads doing
 socket output. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. JCACHE_PROVIDER_TYPEForces the JCache provider, which can have values client or server, to
 force the provider type. | 
| static HazelcastProperty | ClusterProperty. JMX_UPDATE_INTERVAL_SECONDSSome JMX MBeans are cached (e.g. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. LOGGING_ENABLE_DETAILSControls whether cluster name, ip and version should be included in all
 log messages. | 
| static HazelcastProperty | ClusterProperty. LOGGING_TYPEName of logging framework type to send logging events. | 
| static HazelcastProperty | ClusterProperty. MAP_EVICTION_BATCH_SIZEMaximum number of IMap entries Hazelcast will evict during a
 single eviction cycle. | 
| static HazelcastProperty | ClusterProperty. MAP_EXPIRY_DELAY_SECONDSYou can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible
 edge cases, such as using EntryProcessor. | 
| static HazelcastProperty | ClusterProperty. MAP_INVALIDATION_MESSAGE_BATCH_ENABLEDDefines Near Cache invalidation event batch sending is enabled or not. | 
| static HazelcastProperty | ClusterProperty. MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDSDefines the Near Cache invalidation event batch sending frequency in seconds. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. 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 | ClusterProperty. MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDSScheduler delay for map tasks those are executed on backup members. | 
| static HazelcastProperty | ClusterProperty. MAP_WRITE_BEHIND_QUEUE_CAPACITYSetting this capacity is valid if you set  writeCoalescingtofalse(seeMapStoreConfig.setWriteCoalescing(boolean)). | 
| static HazelcastProperty | ClusterProperty. MASTERSHIP_CLAIM_TIMEOUT_SECONDSThe timeout which defines when master candidate gives up waiting for
 response to its mastership claim. | 
| static HazelcastProperty | ClusterProperty. MAX_JOIN_MERGE_TARGET_SECONDSSplit-brain merge timeout for a specific target. | 
| static HazelcastProperty | ClusterProperty. MAX_JOIN_SECONDSJoin timeout, maximum time to try to join before giving up. | 
| static HazelcastProperty | ClusterProperty. MAX_NO_HEARTBEAT_SECONDSThe timeout which defines when a cluster member is removed because it has
 not sent any heartbeats. | 
| static HazelcastProperty | ClusterProperty. MAX_WAIT_SECONDS_BEFORE_JOINThe maximum time that a newly-appointed master node waits before forming a
 cluster. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. MC_MAX_VISIBLE_SLOW_OPERATION_COUNTManagement Center maximum visible slow operations count. | 
| static HazelcastProperty | ClusterProperty. MEMBER_LIST_PUBLISH_INTERVAL_SECONDSThe interval at which the master sends the member lists are sent to other
 non-master members. | 
| static HazelcastProperty | ClusterProperty. MERGE_FIRST_RUN_DELAY_SECONDSThe delay until the first run of the split-brain handler. | 
| static HazelcastProperty | ClusterProperty. MERGE_NEXT_RUN_DELAY_SECONDSThe interval between invocations of the split-brain handler. | 
| static HazelcastProperty | ClusterProperty. METRICS_COLLECTION_FREQUENCYSets the metrics collection frequency in seconds. | 
| static HazelcastProperty | ClusterProperty. METRICS_DATASTRUCTURESEnables/disables collecting metrics from the distributed data structures. | 
| static HazelcastProperty | ClusterProperty. METRICS_DEBUGEnables collecting debug metrics. | 
| static HazelcastProperty | ClusterProperty. METRICS_ENABLEDEnables/disables metrics collection altogether. | 
| static HazelcastProperty | ClusterProperty. METRICS_JMX_ENABLEDEnables/disables exposing metrics on JMX. | 
| static HazelcastProperty | ClusterProperty. METRICS_MC_ENABLEDEnables/disables collecting metrics for Management Center. | 
| static HazelcastProperty | ClusterProperty. METRICS_MC_RETENTIONSets the duration in seconds for which the collected metrics are retained
 and Management Center can consume them. | 
| static HazelcastProperty | ClusterProperty. MOBY_NAMING_ENABLEDDefines whether Moby Names should be used for instance name generating
 when it is not provided by user. | 
| static HazelcastProperty | ClusterProperty. NETWORK_STATS_REFRESH_INTERVAL_SECONDSThe interval at which network stats (bytes sent and received) are
 re-calculated and published. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. OPERATION_CALL_TIMEOUT_MILLISTimeout to wait for a response when a remote call is sent, in milliseconds. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. 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 | ClusterProperty. PARTITION_BACKUP_SYNC_INTERVALInterval for syncing backup replicas in seconds. | 
| static HazelcastProperty | ClusterProperty. PARTITION_COUNTTotal number of partitions in the Hazelcast cluster. | 
| static HazelcastProperty | ClusterProperty. PARTITION_FRAGMENTED_MIGRATION_ENABLEDWhen enabled, which is the default behavior, partitions are migrated/replicated
 in small fragments instead of one big chunk. | 
| static HazelcastProperty | ClusterProperty. PARTITION_MAX_PARALLEL_MIGRATIONSMaximum number of partition migrations to be executed concurrently on a member. | 
| static HazelcastProperty | ClusterProperty. PARTITION_MAX_PARALLEL_REPLICATIONSMaximum number of anti-entropy partition replications to be executed on a member. | 
| static HazelcastProperty | ClusterProperty. PARTITION_MIGRATION_INTERVALTime in seconds to sleep after a migration task. | 
| static HazelcastProperty | ClusterProperty. PARTITION_MIGRATION_TIMEOUTTimeout in seconds for all migration operations. | 
| static HazelcastProperty | ClusterProperty. PARTITION_OPERATION_THREAD_COUNTThe number of partition operation handler threads per member. | 
| static HazelcastProperty | ClusterProperty. PARTITION_TABLE_SEND_INTERVALInterval for publishing partition table periodically to all cluster members
 in seconds. | 
| static HazelcastProperty | ClusterProperty. PARTITIONING_STRATEGY_CLASSClass name implementing  PartitioningStrategy, which
 defines key to partition mapping. | 
| static HazelcastProperty | ClusterProperty. PHONE_HOME_ENABLEDEnable or disable the sending of phone home data to Hazelcast’s phone home
 server. | 
| static HazelcastProperty | ClusterProperty. PREFER_IPv4_STACKPrefer IPv4 network interface when picking a local address. | 
| static HazelcastProperty | ClusterProperty. PRIORITY_GENERIC_OPERATION_THREAD_COUNTThe number of priority generic operation handler threads per member. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. QUERY_OPTIMIZER_TYPEType of Query Optimizer. | 
| static HazelcastProperty | ClusterProperty. QUERY_PREDICATE_PARALLEL_EVALUATIONRun Query Evaluations for multiple partitions in parallel. | 
| static HazelcastProperty | ClusterProperty. QUERY_RESULT_SIZE_LIMITResult size limit for query operations on maps. | 
| static HazelcastProperty | ClusterProperty. RESPONSE_THREAD_COUNTThe number of threads that process responses. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. SERIALIZATION_VERSIONHazelcast serialization version. | 
| static HazelcastProperty | ClusterProperty. SHUTDOWNHOOK_ENABLEDEnable Hazelcast shutdownhook thread. | 
| static HazelcastProperty | ClusterProperty. SHUTDOWNHOOK_POLICYBehaviour when JVM is about to exit while Hazelcast instance is still running. | 
| static HazelcastProperty | ClusterProperty. SLOW_OPERATION_DETECTOR_ENABLEDEnables or disables the
  SlowOperationDetector. | 
| static HazelcastProperty | ClusterProperty. SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDSPurge interval for slow operation logs. | 
| static HazelcastProperty | ClusterProperty. SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDSThis value defines the retention time of invocations in slow operation logs. | 
| static HazelcastProperty | ClusterProperty. SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLEDDefines if the stacktraces of slow operations are logged in the log file. | 
| static HazelcastProperty | ClusterProperty. SLOW_OPERATION_DETECTOR_THRESHOLD_MILLISDefines a threshold above which a running operation in  OperationServiceis considered to be slow. | 
| static HazelcastProperty | ClusterProperty. SOCKET_BIND_ANYBind both server-socket and client-sockets to any local interface. | 
| static HazelcastProperty | ClusterProperty. SOCKET_BUFFER_DIRECTIf the bytebuffers used in the socket should be a direct bytebuffer ( true)
 or a regular bytebuffer (false). | 
| static HazelcastProperty | ClusterProperty. SOCKET_CLIENT_BINDBind client socket to an interface when connecting to a remote server
 socket. | 
| static HazelcastProperty | ClusterProperty. SOCKET_CLIENT_BIND_ANYBind client-sockets to any local interface. | 
| static HazelcastProperty | ClusterProperty. SOCKET_CLIENT_BUFFER_DIRECTIf the bytebuffers used in the socket should be a direct bytebuffer ( true)
 or a regular bytebuffer (false). | 
| static HazelcastProperty | ClusterProperty. SOCKET_CLIENT_RECEIVE_BUFFER_SIZEOverrides receive buffer size for connections opened by clients. | 
| static HazelcastProperty | ClusterProperty. SOCKET_CLIENT_SEND_BUFFER_SIZEOverrides send buffer size for connections opened by clients. | 
| static HazelcastProperty | ClusterProperty. SOCKET_CONNECT_TIMEOUT_SECONDSSocket connection timeout in seconds. | 
| static HazelcastProperty | ClusterProperty. SOCKET_KEEP_ALIVESocket set keep alive (SO_KEEPALIVE). | 
| static HazelcastProperty | ClusterProperty. SOCKET_LINGER_SECONDSSet socket SO_LINGER option. | 
| static HazelcastProperty | ClusterProperty. SOCKET_NO_DELAYSocket set TCP no delay. | 
| static HazelcastProperty | ClusterProperty. SOCKET_RECEIVE_BUFFER_SIZESocket receive buffer (SO_RCVBUF) size in KB. | 
| static HazelcastProperty | ClusterProperty. SOCKET_SEND_BUFFER_SIZESocket send buffer (SO_SNDBUF) size in KB. | 
| static HazelcastProperty | ClusterProperty. SOCKET_SERVER_BIND_ANYBind server-socket to any local interface. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. WAIT_SECONDS_BEFORE_JOINThe time that a newly-appointed master node waits before forming a cluster. | 
| static HazelcastProperty | ClusterProperty. WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MSDefines the initial backoff delay for the Enterprise WAN
 implementation's consumer. | 
| static HazelcastProperty | ClusterProperty. WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MSDefines the maximum backoff delay for the Enterprise WAN
 implementation's consumer. | 
| static HazelcastProperty | ClusterProperty. 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 | ClusterProperty. WAN_CONSUMER_INVOCATION_THRESHOLDDefines the pending invocation threshold for the Enterprise WAN
 replication implementation. | 
| Modifier and Type | Method and Description | 
|---|---|
| HazelcastProperty | HazelcastProperty. getParent()Returns the parent  ClusterPropertyof the property. | 
| HazelcastProperty | HazelcastProperty. setDeprecatedName(String deprecatedName)Sets the deprecated name of ths property. | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | HazelcastProperties. containsKey(HazelcastProperty property)Returns true if value for given key is provided (either as a HazelcastProperty or a System property). | 
| boolean | HazelcastProperties. getBoolean(HazelcastProperty property)Returns the configured boolean value of a  HazelcastProperty. | 
| double | HazelcastProperties. getDouble(HazelcastProperty property)Returns the configured double value of a  HazelcastProperty. | 
| <E extends Enum> | HazelcastProperties. getEnum(HazelcastProperty property,
       Class<E> enumClazz)Returns the configured enum value of a  ClusterProperty. | 
| float | HazelcastProperties. getFloat(HazelcastProperty property)Returns the configured float value of a  HazelcastProperty. | 
| int | HazelcastProperties. getInteger(HazelcastProperty property)Returns the configured int value of a  HazelcastProperty. | 
| long | HazelcastProperties. getLong(HazelcastProperty property)Returns the configured long value of a  HazelcastProperty. | 
| long | HazelcastProperties. getMillis(HazelcastProperty property)Returns the configured value of a  HazelcastPropertyconverted to milliseconds. | 
| long | HazelcastProperties. getNanos(HazelcastProperty property)Returns the configured value of a  HazelcastPropertyconverted to nanoseconds. | 
| long | HazelcastProperties. getPositiveMillisOrDefault(HazelcastProperty property)Returns the configured value of a  HazelcastPropertyconverted to milliseconds if
 it is positive, otherwise returns its default value. | 
| long | HazelcastProperties. getPositiveMillisOrDefault(HazelcastProperty property,
                          long defaultValue)Returns the configured value of a  HazelcastPropertyconverted to milliseconds if
 it is positive, otherwise returns the passed default value. | 
| int | HazelcastProperties. getSeconds(HazelcastProperty property)Returns the configured value of a  HazelcastPropertyconverted to seconds. | 
| String | HazelcastProperties. getString(HazelcastProperty property)Returns the configured value of a  HazelcastPropertyas String. | 
| Constructor and Description | 
|---|
| HazelcastProperty(String name,
                 HazelcastProperty property) | 
| HazelcastProperty(String name,
                 String defaultValue,
                 TimeUnit timeUnit,
                 HazelcastProperty parent) | 
Copyright © 2021 Hazelcast, Inc.. All rights reserved.