Uses of Class
com.hazelcast.spi.properties.HazelcastProperty
Packages that use HazelcastProperty
Package
Description
Contains the Hazelcast client properties implementation.
Contains source/sink connectors that deal with Change Data Capture (CDC)
 events from various databases as well as a generic connector for Debezium
 CDC sources.
Contributes 
gRPC service factories that can be to apply transformations to
 a pipeline which for each input item calls to a gRPC service.Implementation of 
MapStore interface based on Hazelcast SQL engineContains the Hazelcast properties implementation.
- 
Uses of HazelcastProperty in com.hazelcast.client.propertiesFields in com.hazelcast.client.properties declared as HazelcastPropertyModifier and TypeFieldDescriptionstatic final HazelcastPropertyClientProperty.BACKPRESSURE_BACKOFF_TIMEOUT_MILLISControl the maximum timeout in millis to wait for an invocation space to be available.static final HazelcastPropertyClientProperty.CONCURRENT_WINDOW_MSProperty needed for concurrency detection so that write through and dynamic response handling can be done correctly.static final HazelcastPropertyClientProperty.DISCOVERY_SPI_ENABLEDEnables the Discovery SPIstatic final HazelcastPropertyClientProperty.DISCOVERY_SPI_PUBLIC_IP_ENABLEDEnables the Discovery Joiner to use public IP from DiscoveredNode.static final HazelcastPropertyClientProperty.EVENT_QUEUE_CAPACITYCapacity of the executor that handles the incoming event packets.static final HazelcastPropertyClientProperty.EVENT_THREAD_COUNTNumber of the threads to handle the incoming event packets.static final HazelcastPropertyClientProperty.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 withIndeterminateOperationStateException.static final HazelcastPropertyClientProperty.HAZELCAST_CLOUD_DISCOVERY_TOKENToken to use when discovering cluster via hazelcast.cloudstatic final HazelcastPropertyClientProperty.HEARTBEAT_INTERVALTime interval between the heartbeats sent by the client to the nodes.static final HazelcastPropertyClientProperty.HEARTBEAT_TIMEOUTClient sends heartbeat messages to the members and this is the timeout for this sending operations.static final HazelcastPropertyClientProperty.INVOCATION_RETRY_PAUSE_MILLISPause time between each retry cycle of an invocation in milliseconds.static final HazelcastPropertyClientProperty.INVOCATION_TIMEOUT_SECONDSWhen an invocation gets an exception because: - Member throws an exception.static final HazelcastPropertyClientProperty.IO_BALANCER_INTERVAL_SECONDSThe interval in seconds betweenIOBalancerexecutions.static final HazelcastPropertyClientProperty.IO_INPUT_THREAD_COUNTControls the number of IO input threads.static final HazelcastPropertyClientProperty.IO_OUTPUT_THREAD_COUNTControls the number of IO output threads.static final HazelcastPropertyClientProperty.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 final HazelcastPropertyClientProperty.JOB_UPLOAD_PART_SIZEThe default size of multipart job uploadstatic final HazelcastPropertyClientProperty.MAX_CONCURRENT_INVOCATIONSThe maximum number of concurrent invocations allowed.static final HazelcastPropertyClientProperty.METRICS_COLLECTION_FREQUENCYSets the metrics collection frequency in seconds.static final HazelcastPropertyClientProperty.METRICS_DEBUGEnables collecting debug metrics.static final HazelcastPropertyClientProperty.METRICS_ENABLEDEnables/disables metrics collection altogether.static final HazelcastPropertyClientProperty.METRICS_JMX_ENABLEDEnables/disables exposing metrics on JMX.static final HazelcastPropertyClientProperty.OPERATION_BACKUP_TIMEOUT_MILLISIf an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.static final HazelcastPropertyClientProperty.PARTITION_ARGUMENT_CACHE_SIZEParametrized SQL queries touching only a single partition benefit from using the partition owner as the query coordinator, if the partition owner can be determined from one of the query parameters.static final HazelcastPropertyClientProperty.PARTITIONING_STRATEGY_CLASSClass name implementingPartitioningStrategy, which defines key to partition mapping.static final HazelcastPropertyClientProperty.RESPONSE_THREAD_COUNTThe number of response threads.static final HazelcastPropertyClientProperty.RESPONSE_THREAD_DYNAMICEnabled dynamic switching between processing responses on the io threads and offloading the response threads.static final HazelcastPropertyClientProperty.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 final HazelcastPropertyClientProperty.STATISTICS_ENABLEDDeprecated.since 4.0.static final HazelcastPropertyClientProperty.STATISTICS_PERIOD_SECONDSDeprecated.since 4.0.
- 
Uses of HazelcastProperty in com.hazelcast.jet.cdcFields in com.hazelcast.jet.cdc declared as HazelcastPropertyModifier and TypeFieldDescriptionstatic final HazelcastPropertyCdcSinks.SEQUENCE_CACHE_EXPIRATION_SECONDSNumber of seconds for which the sink will remember the last seen sequence number for an input key (used to detect reordering).
- 
Uses of HazelcastProperty in com.hazelcast.jet.grpcFields in com.hazelcast.jet.grpc declared as HazelcastPropertyModifier and TypeFieldDescriptionstatic final HazelcastPropertyGrpcProperties.DESTROY_TIMEOUTTime to wait forStreamObserver.onCompleted()confirmation when destroying aBidirectionalStreamingServiceYou may want to increase this value when your gRPC calls take longer than 1 s to cleanly shutdown the service.static final HazelcastPropertyGrpcProperties.SHUTDOWN_TIMEOUTTime to wait for clean shutdown of aManagedChannel
- 
Uses of HazelcastProperty in com.hazelcast.mapstoreFields in com.hazelcast.mapstore declared as HazelcastPropertyModifier and TypeFieldDescriptionstatic final HazelcastPropertyGenericMapLoader.MAPSTORE_INIT_TIMEOUTTimeout for initialization of GenericMapLoader
- 
Uses of HazelcastProperty in com.hazelcast.spi.propertiesFields in com.hazelcast.spi.properties declared as HazelcastPropertyModifier and TypeFieldDescriptionstatic final HazelcastPropertyClusterProperty.AGGREGATION_ACCUMULATION_PARALLEL_EVALUATIONRun aggregation accumulation for multiple entries in parallel.static final HazelcastPropertyClusterProperty.ASYNC_JOIN_STRATEGY_ENABLEDControls howClusterProperty.WAIT_SECONDS_BEFORE_JOINandClusterProperty.MAX_WAIT_SECONDS_BEFORE_JOINbehave.static final HazelcastPropertyClusterProperty.BACKPRESSURE_BACKOFF_TIMEOUT_MILLISControl the maximum timeout in millis to wait for an invocation space to be available.static final HazelcastPropertyClusterProperty.BACKPRESSURE_ENABLEDUsing back pressure, you can prevent an overload of pending asynchronous backups.static final HazelcastPropertyClusterProperty.BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITIONThe maximum number of concurrent invocations per partition.static final HazelcastPropertyClusterProperty.BACKPRESSURE_SYNCWINDOWControls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups.static final HazelcastPropertyClusterProperty.CACHE_INVALIDATION_MESSAGE_BATCH_ENABLEDDefines cache invalidation event batch sending is enabled or not.static final HazelcastPropertyClusterProperty.CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDSDefines the cache invalidation event batch sending frequency in seconds.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.CHANNEL_COUNTNumber of parallel connection between members.static final HazelcastPropertyClusterProperty.CLIENT_CLEANUP_PERIODTime period to check if a client is still part of the cluster.static final HazelcastPropertyClusterProperty.CLIENT_CLEANUP_TIMEOUTTimeout duration to decide if a client is still part of the cluster.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.CLIENT_ENGINE_THREAD_COUNTThe number of threads that the client engine has available for processing requests that are not partition specific.static final HazelcastPropertyClusterProperty.CLIENT_HEARTBEAT_TIMEOUT_SECONDSTime after which the member assumes the client is dead and closes its connections to the client.static final HazelcastPropertyClusterProperty.CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTESClient protocol message size limit (in bytes) for unverified connections (i.e.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.CONCURRENT_WINDOW_MSProperty needed for concurrency detection so that write through can be done correctly.static final HazelcastPropertyClusterProperty.CONNECT_ALL_WAIT_SECONDSTimeout to connect all other cluster members when a member is joining to a cluster.static final HazelcastPropertyClusterProperty.CONNECTION_MONITOR_INTERVALMinimum interval in milliseconds to consider a connection error as critical.static final HazelcastPropertyClusterProperty.CONNECTION_MONITOR_MAX_FAULTSMaximum I/O error count before disconnecting from a member.static final HazelcastPropertyClusterProperty.DEMOTE_MAX_WAITMaximum wait in seconds during member demotion to a lite member.static final HazelcastPropertyClusterProperty.DISABLE_STALE_READ_ON_PARTITION_MIGRATIONHazelcast allows read operations to be performed while a partition is being migrated.static final HazelcastPropertyClusterProperty.DISCOVERY_SPI_ENABLEDEnables the Discovery SPI lookupstatic final HazelcastPropertyClusterProperty.DISCOVERY_SPI_PUBLIC_IP_ENABLEDEnables the Discovery Joiner to use public IP from DiscoveredNode.static final HazelcastPropertyClusterProperty.ENABLE_JMXEnable JMX agent.static final HazelcastPropertyClusterProperty.ENTERPRISE_LICENSE_KEYHazelcast IMDG Enterprise license key.static final HazelcastPropertyClusterProperty.EVENT_QUEUE_CAPACITYThe capacity of theEventServiceImplexecutor.static final HazelcastPropertyClusterProperty.EVENT_QUEUE_TIMEOUT_MILLISThe timeout for offering an event to the event executor for processing.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.EVENT_THREAD_COUNTNumber of threads for theEventServiceImplexecutor.static final HazelcastPropertyClusterProperty.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 withIndeterminateOperationStateException.static final HazelcastPropertyClusterProperty.GENERIC_OPERATION_THREAD_COUNTThe number of generic operation handler threads per member.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.GRACEFUL_SHUTDOWN_MAX_WAITMaximum wait in seconds during graceful shutdown.static final HazelcastPropertyClusterProperty.HEALTH_MONITORING_DELAY_SECONDSHealth monitoring logging interval in seconds.static final HazelcastPropertyClusterProperty.HEALTH_MONITORING_LEVELHealth monitoring log level.static final HazelcastPropertyClusterProperty.HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGEWhen the health monitoring level is SILENT, logs are printed only when the CPU usage exceeds this threshold.static final HazelcastPropertyClusterProperty.HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGEWhen the health monitoring level is SILENT, logs are printed only when the memory usage exceeds this threshold.static final HazelcastPropertyClusterProperty.HEARTBEAT_FAILURE_DETECTOR_TYPEHeartbeat failure detector type.static final HazelcastPropertyClusterProperty.HEARTBEAT_INTERVAL_SECONDSThe interval at which member heartbeat messages are sentstatic final HazelcastPropertyClusterProperty.INDEX_COPY_BEHAVIORType of Query Index result copying behavior.static final HazelcastPropertyClusterProperty.INIT_CLUSTER_VERSIONOverride cluster version to use while node is not yet member of a cluster.static final HazelcastPropertyClusterProperty.INITIAL_MIN_CLUSTER_SIZEInitial expected cluster size to wait before member to start completely.static final HazelcastPropertyClusterProperty.INITIAL_WAIT_SECONDSInitial time in seconds to wait before member to start completely.static final HazelcastPropertyClusterProperty.INVOCATION_MAX_RETRY_COUNTMaximum number of retries for an invocation.static final HazelcastPropertyClusterProperty.INVOCATION_RETRY_PAUSEPause time between each retry cycle of an invocation in milliseconds.static final HazelcastPropertyClusterProperty.IO_BALANCER_INTERVAL_SECONDSThe interval in seconds betweenIOBalancerexecutions.static final HazelcastPropertyClusterProperty.IO_INPUT_THREAD_COUNTControls the number of socket input threads.static final HazelcastPropertyClusterProperty.IO_OUTPUT_THREAD_COUNTControls the number of socket output threads.static final HazelcastPropertyClusterProperty.IO_THREAD_COUNTThe number of threads doing socket input and the number of threads doing socket output.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.JAR_UPLOAD_DIR_PATHThe directory path to be used for jar uploading.static final HazelcastPropertyClusterProperty.JCACHE_PROVIDER_TYPEForces the JCache provider, which can have values client or server, to force the provider type.static final HazelcastPropertyClusterProperty.JET_IDLE_COOPERATIVE_MAX_MICROSECONDSThe maximum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.static final HazelcastPropertyClusterProperty.JET_IDLE_COOPERATIVE_MIN_MICROSECONDSThe minimum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.JMX_UPDATE_INTERVAL_SECONDSSome JMX MBeans are cached (e.g.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.JOB_RESULTS_TTL_SECONDSMaximum number of time in seconds the job results will be kept in the cluster.static final HazelcastPropertyClusterProperty.JOB_SCAN_PERIODJet will periodically check for new jobs to start and perform cleanup of unused resources.static final HazelcastPropertyClusterProperty.LOCK_MAX_LEASE_TIME_SECONDSAll locks which are acquired without an explicit lease time use this value (in seconds) as the lease time.static final HazelcastPropertyClusterProperty.LOG_EMOJI_ENABLEDControls whether cluster emojis can be used in log messages.static final HazelcastPropertyClusterProperty.LOGGING_ENABLE_DETAILSControls whether cluster name, ip and version should be included in all log messages.static final HazelcastPropertyClusterProperty.LOGGING_SHUTDOWNControls whether Hazelcast will explicitly shutdown the logging implementation as part of Hazelcast graceful shutdown procedure.static final HazelcastPropertyClusterProperty.LOGGING_TYPEName of logging framework type to send logging events.static final HazelcastPropertyClusterProperty.MAP_EVICTION_BATCH_SIZEMaximum number of IMap entries Hazelcast will evict during a single eviction cycle.static final HazelcastPropertyClusterProperty.MAP_EXPIRY_DELAY_SECONDSYou can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.static final HazelcastPropertyClusterProperty.MAP_INVALIDATION_MESSAGE_BATCH_ENABLEDDefines Near Cache invalidation event batch sending is enabled or not.static final HazelcastPropertyClusterProperty.MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDSDefines the Near Cache invalidation event batch sending frequency in seconds.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDSScheduler delay for map tasks those are executed on backup members.static final HazelcastPropertyClusterProperty.MAP_WRITE_BEHIND_QUEUE_CAPACITYSetting this capacity is valid if you setwriteCoalescingtofalse(seeMapStoreConfig.setWriteCoalescing(boolean)).static final HazelcastPropertyClusterProperty.MASTERSHIP_CLAIM_TIMEOUT_SECONDSThe timeout which defines when master candidate gives up waiting for response to its mastership claim.static final HazelcastPropertyClusterProperty.MAX_JOIN_MERGE_TARGET_SECONDSSplit-brain merge timeout for a specific target.static final HazelcastPropertyClusterProperty.MAX_JOIN_SECONDSJoin timeout, maximum time to try to join before giving up.static final HazelcastPropertyClusterProperty.MAX_NO_HEARTBEAT_SECONDSThe timeout which defines when a cluster member is removed because it has not sent any heartbeats.static final HazelcastPropertyClusterProperty.MAX_WAIT_SECONDS_BEFORE_JOINThe maximum time that a newly-appointed master node waits before forming a cluster.static final HazelcastPropertyClusterProperty.MC_EXECUTOR_THREAD_COUNTThe number of threads that the Management Center service has available for processing operations sent from connected Management Center instance.static final HazelcastPropertyClusterProperty.MC_MAX_VISIBLE_SLOW_OPERATION_COUNTManagement Center maximum visible slow operations count.static final HazelcastPropertyClusterProperty.MEMBER_LIST_PUBLISH_INTERVAL_SECONDSThe interval at which the master sends the member lists are sent to other non-master members.static final HazelcastPropertyClusterProperty.MERGE_FIRST_RUN_DELAY_SECONDSThe delay until the first run of the split-brain handler.static final HazelcastPropertyClusterProperty.MERGE_NEXT_RUN_DELAY_SECONDSThe interval between invocations of the split-brain handler.static final HazelcastPropertyClusterProperty.METRICS_COLLECTION_FREQUENCYSets the metrics collection frequency in seconds.static final HazelcastPropertyClusterProperty.METRICS_DATASTRUCTURESEnables/disables collecting metrics from the distributed data structures.static final HazelcastPropertyClusterProperty.METRICS_DEBUGEnables collecting debug metrics.static final HazelcastPropertyClusterProperty.METRICS_ENABLEDEnables/disables metrics collection altogether.static final HazelcastPropertyClusterProperty.METRICS_JMX_ENABLEDEnables/disables exposing metrics on JMX.static final HazelcastPropertyClusterProperty.METRICS_MC_ENABLEDEnables/disables collecting metrics for Management Center.static final HazelcastPropertyClusterProperty.METRICS_MC_RETENTIONSets the duration in seconds for which the collected metrics are retained and Management Center can consume them.static final HazelcastPropertyClusterProperty.METRICS_USER_CODE_NAMESPACESEnables/disables collecting metrics from user code namespaces.static final HazelcastPropertyClusterProperty.MOBY_NAMING_ENABLEDDefines whether Moby Names should be used for instance name generating when it is not provided by user.static final HazelcastPropertyClusterProperty.MULTICAST_GROUPIP address of a multicast group.static final HazelcastPropertyClusterProperty.MULTICAST_SOCKET_SET_INTERFACEAllows explicitly control if theMulticastSocket.setInterface(java.net.InetAddress)method is called in the Hazelcast multicast discovery service.static final HazelcastPropertyClusterProperty.NETWORK_STATS_REFRESH_INTERVAL_SECONDSThe interval at which network stats (bytes sent and received) are re-calculated and published.static final HazelcastPropertyClusterProperty.OPERATION_BACKUP_TIMEOUT_MILLISIf an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.static final HazelcastPropertyClusterProperty.OPERATION_CALL_TIMEOUT_MILLISTimeout to wait for a response when a remote call is sent, in milliseconds.static final HazelcastPropertyThe partial member disconnection resolution mechanism uses a graph algorithm that finds a max-clique in non-polynomial time.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.PARTITION_BACKUP_SYNC_INTERVALInterval for syncing backup replicas in seconds.static final HazelcastPropertyClusterProperty.PARTITION_CHUNKED_MAX_MIGRATING_DATA_IN_MBTotal size of all chunks in bytes during a single partition migration.static final HazelcastPropertyClusterProperty.PARTITION_CHUNKED_MIGRATION_ENABLEDEnable to subdivide fragments into chunks.static final HazelcastPropertyClusterProperty.PARTITION_COUNTTotal number of partitions in the Hazelcast cluster.static final HazelcastPropertyClusterProperty.PARTITION_FRAGMENTED_MIGRATION_ENABLEDWhen enabled, which is the default behavior, partitions are migrated/replicated in small fragments instead of one big chunk.static final HazelcastPropertyClusterProperty.PARTITION_MAX_PARALLEL_MIGRATIONSMaximum number of partition migrations to be executed concurrently on a member.static final HazelcastPropertyClusterProperty.PARTITION_MAX_PARALLEL_REPLICATIONSMaximum number of anti-entropy partition replications to be executed on a member.static final HazelcastPropertyClusterProperty.PARTITION_MIGRATION_INTERVALTime in seconds to sleep after a migration task.static final HazelcastPropertyClusterProperty.PARTITION_MIGRATION_TIMEOUTTimeout in seconds for all migration operations.static final HazelcastPropertyClusterProperty.PARTITION_OPERATION_THREAD_COUNTThe number of partition operation handler threads per member.static final HazelcastPropertyClusterProperty.PARTITION_TABLE_SEND_INTERVALInterval for publishing partition table periodically to all cluster members in seconds.static final HazelcastPropertyClusterProperty.PARTITIONING_STRATEGY_CLASSClass name implementingPartitioningStrategy, which defines key to partition mapping.static final HazelcastPropertyClusterProperty.PERSISTENCE_AUTO_CLUSTER_STATEWhentrue, enables monitoring of the runtime environment to detect the intent of shutdown and automate cluster state management decisions.static final HazelcastPropertyClusterProperty.PERSISTENCE_AUTO_CLUSTER_STATE_STRATEGYSelect which cluster state to use when dealing with missing members in a managed runtime environment.static final HazelcastPropertyClusterProperty.PHONE_HOME_ENABLEDEnable or disable the sending of phone home data to Hazelcast’s phone home server.static final HazelcastPropertyClusterProperty.PREFER_IPv4_STACKPrefer IPv4 network interface when picking a local address.static final HazelcastPropertyClusterProperty.PRIORITY_GENERIC_OPERATION_THREAD_COUNTThe number of priority generic operation handler threads per member.static final HazelcastPropertyClusterProperty.PROCESSOR_CUSTOM_LIB_DIRThe directory containing jars, that can be used to specify custom classpath for a stage in a pipeline.static final HazelcastPropertyClusterProperty.QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECKMaximum value of local partitions to trigger local pre-check forPredicates.alwaysTrue()predicate query operations on maps.static final HazelcastPropertyClusterProperty.QUERY_OPTIMIZER_TYPEType of Query Optimizer.static final HazelcastPropertyClusterProperty.QUERY_PREDICATE_PARALLEL_EVALUATIONRun Query Evaluations for multiple partitions in parallel.static final HazelcastPropertyClusterProperty.QUERY_RESULT_SIZE_LIMITResult size limit for query operations on maps.static final HazelcastPropertyClusterProperty.RESPONSE_THREAD_COUNTThe number of threads that process responses.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.SECURITY_RECOMMENDATIONSWhen set to any not-nullvalue, security recommendations are logged on INFO level during the node start.static final HazelcastPropertyClusterProperty.SERIALIZATION_VERSIONHazelcast serialization version.static final HazelcastPropertyClusterProperty.SHUTDOWNHOOK_ENABLEDEnable Hazelcast shutdownhook thread.static final HazelcastPropertyClusterProperty.SHUTDOWNHOOK_POLICYBehaviour when JVM is about to exit while Hazelcast instance is still running.static final HazelcastPropertyClusterProperty.SLOW_OPERATION_DETECTOR_ENABLEDEnables or disables theSlowOperationDetector.static final HazelcastPropertyClusterProperty.SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDSPurge interval for slow operation logs.static final HazelcastPropertyClusterProperty.SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDSThis value defines the retention time of invocations in slow operation logs.static final HazelcastPropertyClusterProperty.SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLEDDefines if the stacktraces of slow operations are logged in the log file.static final HazelcastPropertyClusterProperty.SLOW_OPERATION_DETECTOR_THRESHOLD_MILLISDefines a threshold above which a running operation inOperationServiceis considered to be slow.static final HazelcastPropertyClusterProperty.SOCKET_BIND_ANYBind both server-socket and client-sockets to any local interface.static final HazelcastPropertyClusterProperty.SOCKET_BUFFER_DIRECTIf the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false).static final HazelcastPropertyClusterProperty.SOCKET_CLIENT_BINDBind client socket to an interface when connecting to a remote server socket.static final HazelcastPropertyClusterProperty.SOCKET_CLIENT_BIND_ANYBind client-sockets to any local interface.static final HazelcastPropertyClusterProperty.SOCKET_CLIENT_BUFFER_DIRECTIf the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false).static final HazelcastPropertyClusterProperty.SOCKET_CLIENT_RECEIVE_BUFFER_SIZEOverrides receive buffer size for connections opened by clients.static final HazelcastPropertyClusterProperty.SOCKET_CLIENT_SEND_BUFFER_SIZEOverrides send buffer size for connections opened by clients.static final HazelcastPropertyClusterProperty.SOCKET_CONNECT_TIMEOUT_SECONDSSocket connection timeout in seconds.static final HazelcastPropertyClusterProperty.SOCKET_KEEP_ALIVESocket set keep alive (SO_KEEPALIVE).static final HazelcastPropertyClusterProperty.SOCKET_KEEP_COUNTKeep-Alive count: the maximum number of TCP keep-alive probes to send before giving up and closing the connection if no response is obtained from the other side.static final HazelcastPropertyClusterProperty.SOCKET_KEEP_IDLEKeep-Alive idle time: the number of seconds of idle time before keep-alive initiates a probe.static final HazelcastPropertyClusterProperty.SOCKET_KEEP_INTERVALKeep-Alive interval: the number of seconds between keep-alive probes.static final HazelcastPropertyClusterProperty.SOCKET_LINGER_SECONDSSet socket SO_LINGER option.static final HazelcastPropertyClusterProperty.SOCKET_NO_DELAYSocket set TCP no delay.static final HazelcastPropertyClusterProperty.SOCKET_RECEIVE_BUFFER_SIZESocket receive buffer (SO_RCVBUF) size in KB.static final HazelcastPropertyClusterProperty.SOCKET_SEND_BUFFER_SIZESocket send buffer (SO_SNDBUF) size in KB.static final HazelcastPropertyClusterProperty.SOCKET_SERVER_BIND_ANYBind server-socket to any local interface.static final HazelcastPropertyClusterProperty.SQL_CUSTOM_CYCLIC_TYPES_ENABLEDEnable experimental support for accessing cyclic nested fields by using custom types in SQL.static final HazelcastPropertyClusterProperty.SQL_TSTORE_ENABLEDEnable experimental support for querying Tiered Storage IMaps via SQL.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.TIERED_STORE_HYBRID_LOG_PAGE_SIZE_IN_MEGABYTESPage size for every instance of Hybrid Log on member.static final HazelcastPropertyClusterProperty.WAIT_SECONDS_BEFORE_JOINThe time that a newly-appointed master node waits before forming a cluster.static final HazelcastPropertyClusterProperty.WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MSDefines the initial backoff delay for the Enterprise WAN implementation's consumer.static final HazelcastPropertyClusterProperty.WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MSDefines the maximum backoff delay for the Enterprise WAN implementation's consumer.static final HazelcastPropertyClusterProperty.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 final HazelcastPropertyClusterProperty.WAN_CONSUMER_INVOCATION_THRESHOLDDefines the pending invocation threshold for the Enterprise WAN replication implementation.static final HazelcastPropertyClusterProperty.WAN_REPLICATE_ICACHE_EVICTIONSDefines whether WAN replication events should be fired when values are evicted fromICacheobjects.static final HazelcastPropertyClusterProperty.WAN_REPLICATE_IMAP_EVICTIONSDefines whether WAN replication events should be fired when values are evicted fromIMapobjects.Methods in com.hazelcast.spi.properties that return HazelcastPropertyModifier and TypeMethodDescriptionHazelcastProperty.getParent()Returns the parentClusterPropertyof the property.HazelcastProperty.setDeprecatedName(String deprecatedName) Sets the deprecated name of this property.Methods in com.hazelcast.spi.properties with parameters of type HazelcastPropertyModifier and TypeMethodDescriptionbooleanHazelcastProperties.containsKey(HazelcastProperty property) Returns true if value for given key is provided (either as a HazelcastProperty or a System property).booleanHazelcastProperties.getBoolean(HazelcastProperty property) Returns the configured boolean value of aHazelcastProperty.doubleHazelcastProperties.getDouble(HazelcastProperty property) Returns the configured double value of aHazelcastProperty.<E extends Enum>
 EHazelcastProperties.getEnum(HazelcastProperty property, Class<E> enumClazz) Returns the configured enum value of aClusterProperty.floatHazelcastProperties.getFloat(HazelcastProperty property) Returns the configured float value of aHazelcastProperty.intHazelcastProperties.getInteger(HazelcastProperty property) Returns the configured int value of aHazelcastProperty.longHazelcastProperties.getLong(HazelcastProperty property) Returns the configured long value of aHazelcastProperty.longHazelcastProperties.getMillis(HazelcastProperty property) Returns the configured value of aHazelcastPropertyconverted to milliseconds.longHazelcastProperties.getNanos(HazelcastProperty property) Returns the configured value of aHazelcastPropertyconverted to nanoseconds.longHazelcastProperties.getPositiveMillisOrDefault(HazelcastProperty property) Returns the configured value of aHazelcastPropertyconverted to milliseconds if it is positive, otherwise returns its default value.longHazelcastProperties.getPositiveMillisOrDefault(HazelcastProperty property, long defaultValue) Returns the configured value of aHazelcastPropertyconverted to milliseconds if it is positive, otherwise returns the passed default value.intHazelcastProperties.getSeconds(HazelcastProperty property) Returns the configured value of aHazelcastPropertyconverted to seconds.HazelcastProperties.getString(HazelcastProperty property) Returns the configured value of aHazelcastPropertyas String.Constructors in com.hazelcast.spi.properties with parameters of type HazelcastPropertyModifierConstructorDescriptionHazelcastProperty(String name, HazelcastProperty property) HazelcastProperty(String name, String defaultValue, TimeUnit timeUnit, HazelcastProperty parent)