Uses of Class
com.hazelcast.spi.properties.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.properties
Modifier and TypeFieldDescriptionstatic final HazelcastProperty
ClientProperty.BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
Control the maximum timeout in millis to wait for an invocation space to be available.static final HazelcastProperty
ClientProperty.CLIENT_CONNECTIVITY_LOGGING_DELAY_SECONDS
Sets the client connectivity logging delay in seconds.static final HazelcastProperty
ClientProperty.CONCURRENT_WINDOW_MS
Property needed for concurrency detection so that write through and dynamic response handling can be done correctly.static final HazelcastProperty
ClientProperty.DISCOVERY_SPI_ENABLED
Enables the Discovery SPIstatic final HazelcastProperty
ClientProperty.DISCOVERY_SPI_PUBLIC_IP_ENABLED
Enables the Discovery Joiner to use public IP from DiscoveredNode.static final HazelcastProperty
ClientProperty.EVENT_QUEUE_CAPACITY
Capacity of the executor that handles the incoming event packets.static final HazelcastProperty
ClientProperty.EVENT_THREAD_COUNT
Number of the threads to handle the incoming event packets.static final HazelcastProperty
ClientProperty.FAIL_ON_INDETERMINATE_OPERATION_STATE
When 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 HazelcastProperty
ClientProperty.HAZELCAST_CLOUD_DISCOVERY_TOKEN
Token to use when discovering cluster via hazelcast.cloudstatic final HazelcastProperty
ClientProperty.HEARTBEAT_INTERVAL
Time interval between the heartbeats sent by the client to the nodes.static final HazelcastProperty
ClientProperty.HEARTBEAT_TIMEOUT
Client sends heartbeat messages to the members and this is the timeout for this sending operations.static final HazelcastProperty
ClientProperty.INVOCATION_RETRY_PAUSE_MILLIS
Pause time between each retry cycle of an invocation in milliseconds.static final HazelcastProperty
ClientProperty.INVOCATION_TIMEOUT_SECONDS
When an invocation gets an exception because: - Member throws an exceptionstatic final HazelcastProperty
ClientProperty.IO_BALANCER_INTERVAL_SECONDS
The interval in seconds betweenIOBalancer
executions.static final HazelcastProperty
ClientProperty.IO_INPUT_THREAD_COUNT
Controls the number of IO input threads.static final HazelcastProperty
ClientProperty.IO_OUTPUT_THREAD_COUNT
Controls the number of IO output threads.static final HazelcastProperty
ClientProperty.IO_WRITE_THROUGH_ENABLED
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.static final HazelcastProperty
ClientProperty.JOB_UPLOAD_PART_SIZE
The default size of multipart job uploadstatic final HazelcastProperty
ClientProperty.MAX_CONCURRENT_INVOCATIONS
The maximum number of concurrent invocations allowed.static final HazelcastProperty
ClientProperty.METRICS_COLLECTION_FREQUENCY
Sets the metrics collection frequency in seconds.static final HazelcastProperty
ClientProperty.METRICS_DEBUG
Enables collecting debug metrics.static final HazelcastProperty
ClientProperty.METRICS_ENABLED
Enables/disables metrics collection altogether.static final HazelcastProperty
ClientProperty.METRICS_JMX_ENABLED
Enables/disables exposing metrics on JMX.static final HazelcastProperty
ClientProperty.OPERATION_BACKUP_TIMEOUT_MILLIS
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.static final HazelcastProperty
ClientProperty.PARTITION_ARGUMENT_CACHE_SIZE
Parametrized 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 HazelcastProperty
ClientProperty.PARTITIONING_STRATEGY_CLASS
Class name implementingPartitioningStrategy
, which defines key to partition mapping.static final HazelcastProperty
ClientProperty.RESPONSE_THREAD_COUNT
The number of response threads.static final HazelcastProperty
ClientProperty.RESPONSE_THREAD_DYNAMIC
Enabled dynamic switching between processing responses on the io threads and offloading the response threads.static final HazelcastProperty
ClientProperty.SHUFFLE_MEMBER_LIST
Client shuffles the given member list to prevent all clients to connect to the same node when this property is set to true.static final HazelcastProperty
ClientProperty.STATISTICS_ENABLED
Deprecated.since 4.0.static final HazelcastProperty
ClientProperty.STATISTICS_PERIOD_SECONDS
Deprecated.since 4.0. -
Uses of HazelcastProperty in com.hazelcast.jet.cdc
Modifier and TypeFieldDescriptionstatic final HazelcastProperty
CdcSinks.SEQUENCE_CACHE_EXPIRATION_SECONDS
Number 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.grpc
Modifier and TypeFieldDescriptionstatic final HazelcastProperty
GrpcProperties.DESTROY_TIMEOUT
Time to wait forStreamObserver.onCompleted()
confirmation when destroying aBidirectionalStreamingService
You may want to increase this value when your gRPC calls take longer than 1 s to cleanly shutdown the service.static final HazelcastProperty
GrpcProperties.SHUTDOWN_TIMEOUT
Time to wait for clean shutdown of aManagedChannel
-
Uses of HazelcastProperty in com.hazelcast.mapstore
Modifier and TypeFieldDescriptionstatic final HazelcastProperty
GenericMapLoader.MAPSTORE_INIT_TIMEOUT
Timeout for initialization of GenericMapLoader -
Uses of HazelcastProperty in com.hazelcast.spi.properties
Modifier and TypeFieldDescriptionstatic final HazelcastProperty
ClusterProperty.AGGREGATION_ACCUMULATION_PARALLEL_EVALUATION
Run aggregation accumulation for multiple entries in parallel.static final HazelcastProperty
ClusterProperty.ASYNC_JOIN_STRATEGY_ENABLED
Controls howClusterProperty.WAIT_SECONDS_BEFORE_JOIN
andClusterProperty.MAX_WAIT_SECONDS_BEFORE_JOIN
behave.static final HazelcastProperty
ClusterProperty.BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
Control the maximum timeout in millis to wait for an invocation space to be available.static final HazelcastProperty
ClusterProperty.BACKPRESSURE_ENABLED
Using back pressure, you can prevent an overload of pending asynchronous backups.static final HazelcastProperty
ClusterProperty.BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
The maximum number of concurrent invocations per partition.static final HazelcastProperty
ClusterProperty.BACKPRESSURE_SYNCWINDOW
Controls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups.static final HazelcastProperty
ClusterProperty.CACHE_INVALIDATION_MESSAGE_BATCH_ENABLED
Defines cache invalidation event batch sending is enabled or not.static final HazelcastProperty
ClusterProperty.CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS
Defines the cache invalidation event batch sending frequency in seconds.static final HazelcastProperty
ClusterProperty.CACHE_INVALIDATION_MESSAGE_BATCH_SIZE
Defines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch.static final HazelcastProperty
ClusterProperty.CHANNEL_COUNT
Number of parallel connection between members.static final HazelcastProperty
ClusterProperty.CLIENT_CLEANUP_PERIOD
Time period to check if a client is still part of the cluster.static final HazelcastProperty
ClusterProperty.CLIENT_CLEANUP_TIMEOUT
Timeout duration to decide if a client is still part of the cluster.static final HazelcastProperty
ClusterProperty.CLIENT_ENGINE_BLOCKING_THREAD_COUNT
The 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 HazelcastProperty
ClusterProperty.CLIENT_ENGINE_QUERY_THREAD_COUNT
The number of threads that the client engine has available for processing requests that are related to the query engine.static final HazelcastProperty
ClusterProperty.CLIENT_ENGINE_THREAD_COUNT
The number of threads that the client engine has available for processing requests that are not partition specific.static final HazelcastProperty
ClusterProperty.CLIENT_HEARTBEAT_TIMEOUT_SECONDS
Time after which the member assumes the client is dead and closes its connections to the client.static final HazelcastProperty
ClusterProperty.CLIENT_PROTOCOL_UNVERIFIED_MESSAGE_BYTES
Client protocol message size limit (in bytes) for unverified connections (i.e. maximal length of authentication message).static final HazelcastProperty
ClusterProperty.CLUSTER_SHUTDOWN_TIMEOUT_SECONDS
Once a member initiates cluster shutdown, it will either wait for all members to leave the cluster before shutting itself down.static final HazelcastProperty
ClusterProperty.CONCURRENT_WINDOW_MS
Property needed for concurrency detection so that write through can be done correctly.static final HazelcastProperty
ClusterProperty.CONNECT_ALL_WAIT_SECONDS
Timeout to connect all other cluster members when a member is joining to a cluster.static final HazelcastProperty
ClusterProperty.CONNECTION_MONITOR_INTERVAL
Minimum interval in milliseconds to consider a connection error as critical.static final HazelcastProperty
ClusterProperty.CONNECTION_MONITOR_MAX_FAULTS
Maximum I/O error count before disconnecting from a member.static final HazelcastProperty
ClusterProperty.DEMOTE_MAX_WAIT
Maximum wait in seconds during member demotion to a lite member.static final HazelcastProperty
ClusterProperty.DISABLE_STALE_READ_ON_PARTITION_MIGRATION
Hazelcast allows read operations to be performed while a partition is being migrated.static final HazelcastProperty
ClusterProperty.DISCOVERY_SPI_ENABLED
Enables the Discovery SPI lookupstatic final HazelcastProperty
ClusterProperty.DISCOVERY_SPI_PUBLIC_IP_ENABLED
Enables the Discovery Joiner to use public IP from DiscoveredNode.static final HazelcastProperty
ClusterProperty.ENABLE_JMX
Enable JMX agent.static final HazelcastProperty
ClusterProperty.ENTERPRISE_LICENSE_KEY
Hazelcast Enterprise license key.static final HazelcastProperty
ClusterProperty.EVENT_QUEUE_CAPACITY
The capacity of theEventServiceImpl
executor.static final HazelcastProperty
ClusterProperty.EVENT_QUEUE_TIMEOUT_MILLIS
The timeout for offering an event to the event executor for processing.static final HazelcastProperty
ClusterProperty.EVENT_SYNC_TIMEOUT_MILLIS
To 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 HazelcastProperty
ClusterProperty.EVENT_THREAD_COUNT
Number of threads for theEventServiceImpl
executor.static final HazelcastProperty
ClusterProperty.FAIL_ON_INDETERMINATE_OPERATION_STATE
When 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 HazelcastProperty
ClusterProperty.GENERIC_OPERATION_THREAD_COUNT
The number of generic operation handler threads per member.static final HazelcastProperty
ClusterProperty.GLOBAL_HD_INDEX_ENABLED
Enables 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 HazelcastProperty
ClusterProperty.GRACEFUL_SHUTDOWN_MAX_WAIT
Maximum wait in seconds during graceful shutdown.static final HazelcastProperty
ClusterProperty.HEALTH_MONITORING_DELAY_SECONDS
Health monitoring logging interval in seconds.static final HazelcastProperty
ClusterProperty.HEALTH_MONITORING_LEVEL
Health monitoring log level.static final HazelcastProperty
ClusterProperty.HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE
When the health monitoring level is SILENT, logs are printed only when the CPU usage exceeds this threshold.static final HazelcastProperty
ClusterProperty.HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE
When the health monitoring level is SILENT, logs are printed only when the memory usage exceeds this threshold.static final HazelcastProperty
ClusterProperty.HEARTBEAT_FAILURE_DETECTOR_TYPE
Heartbeat failure detector type.static final HazelcastProperty
ClusterProperty.HEARTBEAT_INTERVAL_SECONDS
The interval at which member heartbeat messages are sentstatic final HazelcastProperty
ClusterProperty.INDEX_COPY_BEHAVIOR
Type of Query Index result copying behavior.static final HazelcastProperty
ClusterProperty.INIT_CLUSTER_VERSION
Override cluster version to use while node is not yet member of a cluster.static final HazelcastProperty
ClusterProperty.INITIAL_MIN_CLUSTER_SIZE
Initial expected cluster size to wait before member to start completely.static final HazelcastProperty
ClusterProperty.INITIAL_WAIT_SECONDS
Initial time in seconds to wait before member to start completely.static final HazelcastProperty
ClusterProperty.INVOCATION_MAX_RETRY_COUNT
Maximum number of retries for an invocation.static final HazelcastProperty
ClusterProperty.INVOCATION_RETRY_PAUSE
Pause time between each retry cycle of an invocation in milliseconds.static final HazelcastProperty
ClusterProperty.IO_BALANCER_INTERVAL_SECONDS
The interval in seconds betweenIOBalancer
executions.static final HazelcastProperty
ClusterProperty.IO_INPUT_THREAD_COUNT
Controls the number of socket input threads.static final HazelcastProperty
ClusterProperty.IO_OUTPUT_THREAD_COUNT
Controls the number of socket output threads.static final HazelcastProperty
ClusterProperty.IO_THREAD_COUNT
The number of threads doing socket input and the number of threads doing socket output.static final HazelcastProperty
ClusterProperty.IO_WRITE_THROUGH_ENABLED
Optimization that allows sending of packets over the network to be done on the calling thread if the conditions are right.static final HazelcastProperty
ClusterProperty.JAR_UPLOAD_DIR_PATH
The directory path to be used for jar uploading.static final HazelcastProperty
ClusterProperty.JCACHE_PROVIDER_TYPE
Forces the JCache provider, which can have values client or server, to force the provider type.static final HazelcastProperty
ClusterProperty.JET_IDLE_COOPERATIVE_MAX_MICROSECONDS
The maximum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.static final HazelcastProperty
ClusterProperty.JET_IDLE_COOPERATIVE_MIN_MICROSECONDS
The minimum time in microseconds the cooperative worker threads will sleep if none of the tasklets made any progress.static final HazelcastProperty
ClusterProperty.JET_IDLE_NONCOOPERATIVE_MAX_MICROSECONDS
The maximum time in microseconds the non-cooperative worker threads will sleep if none of the tasklets made any progress.static final HazelcastProperty
ClusterProperty.JET_IDLE_NONCOOPERATIVE_MIN_MICROSECONDS
The minimum time in microseconds the non-cooperative worker threads will sleep if none of the tasklets made any progress.static final HazelcastProperty
ClusterProperty.JMX_UPDATE_INTERVAL_SECONDS
Some JMX MBeans are cached (e.g. map, multimap, queue and replicated map) to reduce the overhead of calculating statistics.static final HazelcastProperty
ClusterProperty.JOB_RESULTS_MAX_SIZE
Maximum number of job results to keep in the cluster, the oldest results will be automatically deleted after this size is reached.static final HazelcastProperty
ClusterProperty.JOB_RESULTS_TTL_SECONDS
Maximum number of time in seconds the job results will be kept in the cluster.static final HazelcastProperty
ClusterProperty.JOB_SCAN_PERIOD
Jet will periodically check for new jobs to start and perform cleanup of unused resources.static final HazelcastProperty
ClusterProperty.LOCK_MAX_LEASE_TIME_SECONDS
All locks which are acquired without an explicit lease time use this value (in seconds) as the lease time.static final HazelcastProperty
ClusterProperty.LOG_EMOJI_ENABLED
Controls whether cluster emojis can be used in log messages.static final HazelcastProperty
ClusterProperty.LOGGING_ENABLE_DETAILS
Controls whether cluster name, ip and version should be included in all log messages.static final HazelcastProperty
ClusterProperty.LOGGING_SHUTDOWN
Controls whether Hazelcast will explicitly shut down the logging implementation as part of Hazelcast graceful shutdown procedure.static final HazelcastProperty
ClusterProperty.LOGGING_TYPE
Name of logging framework type to send logging events.static final HazelcastProperty
ClusterProperty.MAP_EVICTION_BATCH_SIZE
Maximum number of IMap entries Hazelcast will evict during a single eviction cycle.static final HazelcastProperty
ClusterProperty.MAP_EXPIRY_DELAY_SECONDS
You can use MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.static final HazelcastProperty
ClusterProperty.MAP_INVALIDATION_MESSAGE_BATCH_ENABLED
Defines Near Cache invalidation event batch sending is enabled or not.static final HazelcastProperty
ClusterProperty.MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS
Defines the Near Cache invalidation event batch sending frequency in seconds.static final HazelcastProperty
ClusterProperty.MAP_INVALIDATION_MESSAGE_BATCH_SIZE
Defines the maximum number of Near Cache invalidation events to be drained and sent to the event Near Cache in a batch.static final HazelcastProperty
ClusterProperty.MAP_LOAD_CHUNK_SIZE
The 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 HazelcastProperty
ClusterProperty.MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS
Scheduler delay for map tasks those are executed on backup members.static final HazelcastProperty
ClusterProperty.MAP_WRITE_BEHIND_QUEUE_CAPACITY
Setting this capacity is valid if you setwriteCoalescing
tofalse
(seeMapStoreConfig.setWriteCoalescing(boolean)
).static final HazelcastProperty
ClusterProperty.MASTERSHIP_CLAIM_TIMEOUT_SECONDS
The timeout which defines when master candidate gives up waiting for response to its mastership claim.static final HazelcastProperty
ClusterProperty.MAX_JOIN_MERGE_TARGET_SECONDS
Split-brain merge timeout for a specific target.static final HazelcastProperty
ClusterProperty.MAX_JOIN_SECONDS
Join timeout, maximum time to try to join before giving up.static final HazelcastProperty
ClusterProperty.MAX_NO_HEARTBEAT_SECONDS
The timeout which defines when a cluster member is removed because it has not sent any heartbeats.static final HazelcastProperty
ClusterProperty.MAX_WAIT_SECONDS_BEFORE_JOIN
The maximum time that a newly-appointed master node waits before forming a cluster.static final HazelcastProperty
ClusterProperty.MC_EXECUTOR_THREAD_COUNT
The number of threads that the Management Center service has available for processing operations sent from connected Management Center instance.static final HazelcastProperty
ClusterProperty.MC_MAX_VISIBLE_SLOW_OPERATION_COUNT
Management Center maximum visible slow operations count.static final HazelcastProperty
ClusterProperty.MEMBER_LIST_PUBLISH_INTERVAL_SECONDS
The interval at which the master sends the member lists are sent to other non-master members.static final HazelcastProperty
ClusterProperty.MERGE_FIRST_RUN_DELAY_SECONDS
The delay until the first run of the split-brain handler.static final HazelcastProperty
ClusterProperty.MERGE_NEXT_RUN_DELAY_SECONDS
The interval between invocations of the split-brain handler.static final HazelcastProperty
ClusterProperty.METRICS_COLLECTION_FREQUENCY
Sets the metrics collection frequency in seconds.static final HazelcastProperty
ClusterProperty.METRICS_DATASTRUCTURES
Enables/disables collecting metrics from the distributed data structures.static final HazelcastProperty
ClusterProperty.METRICS_DEBUG
Enables collecting debug metrics.static final HazelcastProperty
ClusterProperty.METRICS_ENABLED
Enables/disables metrics collection altogether.static final HazelcastProperty
ClusterProperty.METRICS_JMX_ENABLED
Enables/disables exposing metrics on JMX.static final HazelcastProperty
ClusterProperty.METRICS_MC_ENABLED
Enables/disables collecting metrics for Management Center.static final HazelcastProperty
ClusterProperty.METRICS_MC_RETENTION
Sets the duration in seconds for which the collected metrics are retained and Management Center can consume them.static final HazelcastProperty
ClusterProperty.METRICS_USER_CODE_NAMESPACES
Enables/disables collecting metrics from user code namespaces.static final HazelcastProperty
ClusterProperty.MOBY_NAMING_ENABLED
Defines whether Moby Names should be used for instance name generating when it is not provided by user.static final HazelcastProperty
ClusterProperty.MULTICAST_GROUP
IP address of a multicast group.static final HazelcastProperty
ClusterProperty.MULTICAST_SOCKET_SET_INTERFACE
Allows explicitly control if theMulticastSocket.setInterface(java.net.InetAddress)
method is called in the Hazelcast multicast discovery service.static final HazelcastProperty
ClusterProperty.NETWORK_STATS_REFRESH_INTERVAL_SECONDS
The interval at which network stats (bytes sent and received) are re-calculated and published.static final HazelcastProperty
ClusterProperty.OPERATION_BACKUP_TIMEOUT_MILLIS
If an operation has backups, this property specifies how long the invocation will wait for acks from the backup replicas.static final HazelcastProperty
ClusterProperty.OPERATION_CALL_TIMEOUT_MILLIS
Timeout to wait for a response when a remote call is sent, in milliseconds.static final HazelcastProperty
The partial member disconnection resolution mechanism uses a graph algorithm that finds a max-clique in non-polynomial time.static final HazelcastProperty
ClusterProperty.PARTIAL_MEMBER_DISCONNECTION_RESOLUTION_HEARTBEAT_COUNT
The 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 HazelcastProperty
ClusterProperty.PARTITION_BACKUP_SYNC_INTERVAL
Interval for syncing backup replicas in seconds.static final HazelcastProperty
ClusterProperty.PARTITION_CHUNKED_MAX_MIGRATING_DATA_IN_MB
Total size of all chunks in bytes during a single partition migration.static final HazelcastProperty
ClusterProperty.PARTITION_CHUNKED_MIGRATION_ENABLED
Enable to subdivide fragments into chunks.static final HazelcastProperty
ClusterProperty.PARTITION_COUNT
Total number of partitions in the Hazelcast cluster.static final HazelcastProperty
ClusterProperty.PARTITION_FRAGMENTED_MIGRATION_ENABLED
When enabled, which is the default behavior, partitions are migrated/replicated in small fragments instead of one big chunk.static final HazelcastProperty
ClusterProperty.PARTITION_MAX_PARALLEL_MIGRATIONS
Maximum number of partition migrations to be executed concurrently on a member.static final HazelcastProperty
ClusterProperty.PARTITION_MAX_PARALLEL_REPLICATIONS
Maximum number of anti-entropy partition replications to be executed on a member.static final HazelcastProperty
ClusterProperty.PARTITION_MIGRATION_INTERVAL
Time in seconds to sleep after a migration task.static final HazelcastProperty
ClusterProperty.PARTITION_MIGRATION_TIMEOUT
Timeout in seconds for all migration operations.static final HazelcastProperty
ClusterProperty.PARTITION_OPERATION_THREAD_COUNT
The number of partition operation handler threads per member.static final HazelcastProperty
ClusterProperty.PARTITION_TABLE_SEND_INTERVAL
Interval for publishing partition table periodically to all cluster members in seconds.static final HazelcastProperty
ClusterProperty.PARTITIONING_STRATEGY_CLASS
Class name implementingPartitioningStrategy
, which defines key to partition mapping.static final HazelcastProperty
ClusterProperty.PERSISTENCE_AUTO_CLUSTER_STATE
Whentrue
, enables monitoring of the runtime environment to detect the intent of shutdown and automate cluster state management decisions.static final HazelcastProperty
ClusterProperty.PERSISTENCE_AUTO_CLUSTER_STATE_STRATEGY
Select which cluster state to use when dealing with missing members in a managed runtime environment.static final HazelcastProperty
ClusterProperty.PHONE_HOME_ENABLED
Enable or disable the sending of phone home data to Hazelcast’s phone home server.static final HazelcastProperty
ClusterProperty.PREFER_IPv4_STACK
Prefer IPv4 network interface when picking a local address.static final HazelcastProperty
ClusterProperty.PRIORITY_GENERIC_OPERATION_THREAD_COUNT
The number of priority generic operation handler threads per member.static final HazelcastProperty
ClusterProperty.PROCESSOR_CUSTOM_LIB_DIR
The directory containing jars, that can be used to specify custom classpath for a stage in a pipeline.static final HazelcastProperty
ClusterProperty.QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK
Maximum value of local partitions to trigger local pre-check forPredicates.alwaysTrue()
predicate query operations on maps.static final HazelcastProperty
ClusterProperty.QUERY_OPTIMIZER_TYPE
Type of Query Optimizer.static final HazelcastProperty
ClusterProperty.QUERY_PREDICATE_PARALLEL_EVALUATION
Run Query Evaluations for multiple partitions in parallel.static final HazelcastProperty
ClusterProperty.QUERY_RESULT_SIZE_LIMIT
Result size limit for query operations on maps.static final HazelcastProperty
ClusterProperty.RESPONSE_THREAD_COUNT
The number of threads that process responses.static final HazelcastProperty
ClusterProperty.SEARCH_DYNAMIC_CONFIG_FIRST
By 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 HazelcastProperty
ClusterProperty.SECURITY_RECOMMENDATIONS
When set to any not-null
value, security recommendations are logged on INFO level during the node start.static final HazelcastProperty
ClusterProperty.SERIALIZATION_VERSION
Hazelcast serialization version.static final HazelcastProperty
ClusterProperty.SHUTDOWNHOOK_ENABLED
Enable Hazelcast shutdownhook thread.static final HazelcastProperty
ClusterProperty.SHUTDOWNHOOK_POLICY
Behaviour when JVM is about to exit while Hazelcast instance is still running.static final HazelcastProperty
ClusterProperty.SLOW_OPERATION_DETECTOR_ENABLED
Enables or disables theSlowOperationDetector
.static final HazelcastProperty
ClusterProperty.SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
Purge interval for slow operation logs.static final HazelcastProperty
ClusterProperty.SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
This value defines the retention time of invocations in slow operation logs.static final HazelcastProperty
ClusterProperty.SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
Defines if the stacktraces of slow operations are logged in the log file.static final HazelcastProperty
ClusterProperty.SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS
Defines a threshold above which a running operation inOperationService
is considered to be slow.static final HazelcastProperty
ClusterProperty.SOCKET_BIND_ANY
Bind both server-socket and client-sockets to any local interface.static final HazelcastProperty
ClusterProperty.SOCKET_BUFFER_DIRECT
If the bytebuffers used in the socket should be a direct bytebuffer (true
) or a regular bytebuffer (false
).static final HazelcastProperty
ClusterProperty.SOCKET_CLIENT_BIND
Bind client socket to an interface when connecting to a remote server socket.static final HazelcastProperty
ClusterProperty.SOCKET_CLIENT_BIND_ANY
Bind client-sockets to any local interface.static final HazelcastProperty
ClusterProperty.SOCKET_CLIENT_BUFFER_DIRECT
If the bytebuffers used in the socket should be a direct bytebuffer (true
) or a regular bytebuffer (false
).static final HazelcastProperty
ClusterProperty.SOCKET_CLIENT_RECEIVE_BUFFER_SIZE
Overrides receive buffer size for connections opened by clients.static final HazelcastProperty
ClusterProperty.SOCKET_CLIENT_SEND_BUFFER_SIZE
Overrides send buffer size for connections opened by clients.static final HazelcastProperty
ClusterProperty.SOCKET_CONNECT_TIMEOUT_SECONDS
Socket connection timeout in seconds.static final HazelcastProperty
ClusterProperty.SOCKET_KEEP_ALIVE
Socket set keep alive (SO_KEEPALIVE).static final HazelcastProperty
ClusterProperty.SOCKET_KEEP_COUNT
Keep-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 HazelcastProperty
ClusterProperty.SOCKET_KEEP_IDLE
Keep-Alive idle time: the number of seconds of idle time before keep-alive initiates a probe.static final HazelcastProperty
ClusterProperty.SOCKET_KEEP_INTERVAL
Keep-Alive interval: the number of seconds between keep-alive probes.static final HazelcastProperty
ClusterProperty.SOCKET_LINGER_SECONDS
Set socket SO_LINGER option.static final HazelcastProperty
ClusterProperty.SOCKET_NO_DELAY
Socket set TCP no delay.static final HazelcastProperty
ClusterProperty.SOCKET_RECEIVE_BUFFER_SIZE
Socket receive buffer (SO_RCVBUF) size in KB.static final HazelcastProperty
ClusterProperty.SOCKET_SEND_BUFFER_SIZE
Socket send buffer (SO_SNDBUF) size in KB.static final HazelcastProperty
ClusterProperty.SOCKET_SERVER_BIND_ANY
Bind server-socket to any local interface.static final HazelcastProperty
ClusterProperty.SQL_CUSTOM_CYCLIC_TYPES_ENABLED
Enable experimental support for accessing cyclic nested fields by using custom types in SQL.static final HazelcastProperty
ClusterProperty.SQL_TSTORE_ENABLED
Enable experimental support for querying Tiered Storage IMaps via SQL.static final HazelcastProperty
ClusterProperty.TCP_JOIN_PORT_TRY_COUNT
The 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 HazelcastProperty
ClusterProperty.TCP_PREVIOUSLY_JOINED_MEMBER_ADDRESS_RETENTION_DURATION
Specifies 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 HazelcastProperty
ClusterProperty.TIERED_STORE_HYBRID_LOG_PAGE_SIZE_IN_MEGABYTES
Page size for every instance of Hybrid Log on member.static final HazelcastProperty
ClusterProperty.WAIT_SECONDS_BEFORE_JOIN
The time that a newly-appointed master node waits before forming a cluster.static final HazelcastProperty
ClusterProperty.WAN_CONSUMER_ACK_DELAY_BACKOFF_INIT_MS
Defines the initial backoff delay for the Enterprise WAN implementation's consumer.static final HazelcastProperty
ClusterProperty.WAN_CONSUMER_ACK_DELAY_BACKOFF_MAX_MS
Defines the maximum backoff delay for the Enterprise WAN implementation's consumer.static final HazelcastProperty
ClusterProperty.WAN_CONSUMER_ACK_DELAY_BACKOFF_MULTIPLIER
Defines the multiplier (the speed of the function) for the backoff delay for the Enterprise WAN implementation's consumer.static final HazelcastProperty
ClusterProperty.WAN_CONSUMER_INVOCATION_THRESHOLD
Defines the pending invocation threshold for the Enterprise WAN replication implementation.static final HazelcastProperty
ClusterProperty.WAN_REPLICATE_ICACHE_EVICTIONS
Defines whether WAN replication events should be fired when values are evicted fromICache
objects.static final HazelcastProperty
ClusterProperty.WAN_REPLICATE_IMAP_EVICTIONS
Defines whether WAN replication events should be fired when values are evicted fromIMap
objects.Modifier and TypeMethodDescriptionHazelcastProperty.getParent()
Returns the parentClusterProperty
of the property.HazelcastProperty.setDeprecatedName
(String deprecatedName) Sets the deprecated name of this property.Modifier and TypeMethodDescriptionboolean
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 aHazelcastProperty
.double
HazelcastProperties.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
.float
HazelcastProperties.getFloat
(HazelcastProperty property) Returns the configured float value of aHazelcastProperty
.int
HazelcastProperties.getInteger
(HazelcastProperty property) Returns the configured int value of aHazelcastProperty
.long
HazelcastProperties.getLong
(HazelcastProperty property) Returns the configured long value of aHazelcastProperty
.long
HazelcastProperties.getMillis
(HazelcastProperty property) Returns the configured value of aHazelcastProperty
converted to milliseconds.long
HazelcastProperties.getNanos
(HazelcastProperty property) Returns the configured value of aHazelcastProperty
converted to nanoseconds.long
HazelcastProperties.getPositiveMillisOrDefault
(HazelcastProperty property) Returns the configured value of aHazelcastProperty
converted to milliseconds if it is positive, otherwise returns its default value.long
HazelcastProperties.getPositiveMillisOrDefault
(HazelcastProperty property, long defaultValue) Returns the configured value of aHazelcastProperty
converted to milliseconds if it is positive, otherwise returns the passed default value.int
HazelcastProperties.getSeconds
(HazelcastProperty property) Returns the configured value of aHazelcastProperty
converted to seconds.HazelcastProperties.getString
(HazelcastProperty property) Returns the configured value of aHazelcastProperty
as String.ModifierConstructorDescriptionHazelcastProperty
(String name, HazelcastProperty property) HazelcastProperty
(String name, String defaultValue, TimeUnit timeUnit, HazelcastProperty parent)