com.hazelcast.instance
Class GroupProperties
java.lang.Object
com.hazelcast.instance.GroupProperties
public class GroupProperties
- extends Object
The GroupProperties contain the Hazelcast properties. They can be set as an environmental variable, or
directly on the Config using Config.setProperty(String, String)
or from the XML.
Methods inherited from class java.lang.Object |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait |
PROP_APPLICATION_VALIDATION_TOKEN
public static final String PROP_APPLICATION_VALIDATION_TOKEN
- Use this property to verify that Hazelcast nodes only join the cluster when their 'application' level configuration is the
same.
If you have multiple machines, and you want to make sure that each machine that joins the cluster
has exactly the same 'application level' settings (such as settings that are not part of the Hazelcast configuration,
maybe some filepath). To prevent these machines with potential different application level configuration from forming
a cluster, you can set this property.
You could use actual values, such as string paths, but you can also use an md5 hash. We'll give the guarantee
that nodes will form a cluster (become a member) only where the token is an exact match. If this token is different, the
member can't be started and therefore you will get the guarantee that all members in the cluster will have exactly the same
application validation token.
This validation-token will be checked before member join the cluster.
- See Also:
- Constant Field Values
PROP_HEALTH_MONITORING_LEVEL
public static final String PROP_HEALTH_MONITORING_LEVEL
- See Also:
- Constant Field Values
PROP_HEALTH_MONITORING_DELAY_SECONDS
public static final String PROP_HEALTH_MONITORING_DELAY_SECONDS
- See Also:
- Constant Field Values
PROP_PERFORMANCE_MONITORING_ENABLED
public static final String PROP_PERFORMANCE_MONITORING_ENABLED
- Use the performance monitor to see internal performance metrics. Currently this is quite
limited since it will only show read/write events per selector and operations executed per operation-thread. But in
the future, all kinds of new metrics will be added.
The performance monitor logs all metrics into the log file.
- See Also:
- Constant Field Values
PROP_PERFORMANCE_MONITORING_DELAY_SECONDS
public static final String PROP_PERFORMANCE_MONITORING_DELAY_SECONDS
- The delay in seconds between monitoring of the performance.
- See Also:
- Constant Field Values
PROP_VERSION_CHECK_ENABLED
public static final String PROP_VERSION_CHECK_ENABLED
- See Also:
- Constant Field Values
PROP_PREFER_IPv4_STACK
public static final String PROP_PREFER_IPv4_STACK
- See Also:
- Constant Field Values
PROP_IO_THREAD_COUNT
public static final String PROP_IO_THREAD_COUNT
- See Also:
- Constant Field Values
PROP_IO_BALANCER_INTERVAL_SECONDS
public static final String PROP_IO_BALANCER_INTERVAL_SECONDS
- The interval in seconds between
IOBalancer
executions. The shorter intervals will catch I/O Imbalance faster, but they will cause higher overhead.
Please see the documentation of IOBalancer
for a
detailed explanation of the problem.
Default value is 20 seconds. A negative value disables the balancer.
- See Also:
- Constant Field Values
PROP_PARTITION_OPERATION_THREAD_COUNT
public static final String PROP_PARTITION_OPERATION_THREAD_COUNT
- The number of partition threads per Member. If this is less than the number of partitions on a Member, then
partition operations will queue behind other operations of different partitions. The default is 4.
- See Also:
- Constant Field Values
PROP_GENERIC_OPERATION_THREAD_COUNT
public static final String PROP_GENERIC_OPERATION_THREAD_COUNT
- See Also:
- Constant Field Values
PROP_EVENT_THREAD_COUNT
public static final String PROP_EVENT_THREAD_COUNT
- See Also:
- Constant Field Values
PROP_EVENT_QUEUE_CAPACITY
public static final String PROP_EVENT_QUEUE_CAPACITY
- See Also:
- Constant Field Values
PROP_EVENT_QUEUE_TIMEOUT_MILLIS
public static final String PROP_EVENT_QUEUE_TIMEOUT_MILLIS
- See Also:
- Constant Field Values
PROP_CONNECT_ALL_WAIT_SECONDS
public static final String PROP_CONNECT_ALL_WAIT_SECONDS
- See Also:
- Constant Field Values
PROP_MEMCACHE_ENABLED
public static final String PROP_MEMCACHE_ENABLED
- See Also:
- Constant Field Values
PROP_REST_ENABLED
public static final String PROP_REST_ENABLED
- See Also:
- Constant Field Values
PROP_MAP_LOAD_CHUNK_SIZE
public static final String PROP_MAP_LOAD_CHUNK_SIZE
- See Also:
- Constant Field Values
PROP_MERGE_FIRST_RUN_DELAY_SECONDS
public static final String PROP_MERGE_FIRST_RUN_DELAY_SECONDS
- See Also:
- Constant Field Values
PROP_MERGE_NEXT_RUN_DELAY_SECONDS
public static final String PROP_MERGE_NEXT_RUN_DELAY_SECONDS
- See Also:
- Constant Field Values
PROP_OPERATION_CALL_TIMEOUT_MILLIS
public static final String PROP_OPERATION_CALL_TIMEOUT_MILLIS
- See Also:
- Constant Field Values
PROP_OPERATION_BACKUP_TIMEOUT_MILLIS
public static final String PROP_OPERATION_BACKUP_TIMEOUT_MILLIS
- If an operation has backups and the backups don't complete in time, then some cleanup logic can be executed. This
property specifies that timeout for backups to complete.
- See Also:
- Constant Field Values
PROP_SOCKET_BIND_ANY
public static final String PROP_SOCKET_BIND_ANY
- See Also:
- Constant Field Values
PROP_SOCKET_SERVER_BIND_ANY
public static final String PROP_SOCKET_SERVER_BIND_ANY
- See Also:
- Constant Field Values
PROP_SOCKET_CLIENT_BIND_ANY
public static final String PROP_SOCKET_CLIENT_BIND_ANY
- See Also:
- Constant Field Values
PROP_SOCKET_CLIENT_BIND
public static final String PROP_SOCKET_CLIENT_BIND
- See Also:
- Constant Field Values
PROP_CLIENT_ENGINE_THREAD_COUNT
public static final String PROP_CLIENT_ENGINE_THREAD_COUNT
- The number of threads that the client engine has available for processing requests that are not partition specific.
Most of the requests, such as map.put and map.get, are partition specific and will use a partition-operation-thread, but
there are also requests that can't be executed on a partition-specific operation-thread, such as multimap.contain(value),
because they need to access all partitions on a given member.
- See Also:
- Constant Field Values
PROP_SOCKET_RECEIVE_BUFFER_SIZE
public static final String PROP_SOCKET_RECEIVE_BUFFER_SIZE
- See Also:
- Constant Field Values
PROP_SOCKET_SEND_BUFFER_SIZE
public static final String PROP_SOCKET_SEND_BUFFER_SIZE
- See Also:
- Constant Field Values
PROP_SOCKET_LINGER_SECONDS
public static final String PROP_SOCKET_LINGER_SECONDS
- See Also:
- Constant Field Values
PROP_SOCKET_CONNECT_TIMEOUT_SECONDS
public static final String PROP_SOCKET_CONNECT_TIMEOUT_SECONDS
- See Also:
- Constant Field Values
PROP_SOCKET_KEEP_ALIVE
public static final String PROP_SOCKET_KEEP_ALIVE
- See Also:
- Constant Field Values
PROP_SOCKET_NO_DELAY
public static final String PROP_SOCKET_NO_DELAY
- See Also:
- Constant Field Values
PROP_SHUTDOWNHOOK_ENABLED
public static final String PROP_SHUTDOWNHOOK_ENABLED
- See Also:
- Constant Field Values
PROP_WAIT_SECONDS_BEFORE_JOIN
public static final String PROP_WAIT_SECONDS_BEFORE_JOIN
- See Also:
- Constant Field Values
PROP_MAX_WAIT_SECONDS_BEFORE_JOIN
public static final String PROP_MAX_WAIT_SECONDS_BEFORE_JOIN
- See Also:
- Constant Field Values
PROP_MAX_JOIN_SECONDS
public static final String PROP_MAX_JOIN_SECONDS
- See Also:
- Constant Field Values
PROP_MAX_JOIN_MERGE_TARGET_SECONDS
public static final String PROP_MAX_JOIN_MERGE_TARGET_SECONDS
- See Also:
- Constant Field Values
PROP_HEARTBEAT_INTERVAL_SECONDS
public static final String PROP_HEARTBEAT_INTERVAL_SECONDS
- See Also:
- Constant Field Values
PROP_MAX_NO_HEARTBEAT_SECONDS
public static final String PROP_MAX_NO_HEARTBEAT_SECONDS
- See Also:
- Constant Field Values
PROP_MAX_NO_MASTER_CONFIRMATION_SECONDS
public static final String PROP_MAX_NO_MASTER_CONFIRMATION_SECONDS
- See Also:
- Constant Field Values
PROP_MASTER_CONFIRMATION_INTERVAL_SECONDS
public static final String PROP_MASTER_CONFIRMATION_INTERVAL_SECONDS
- See Also:
- Constant Field Values
PROP_MEMBER_LIST_PUBLISH_INTERVAL_SECONDS
public static final String PROP_MEMBER_LIST_PUBLISH_INTERVAL_SECONDS
- See Also:
- Constant Field Values
PROP_ICMP_ENABLED
public static final String PROP_ICMP_ENABLED
- See Also:
- Constant Field Values
PROP_ICMP_TIMEOUT
public static final String PROP_ICMP_TIMEOUT
- See Also:
- Constant Field Values
PROP_ICMP_TTL
public static final String PROP_ICMP_TTL
- See Also:
- Constant Field Values
PROP_INITIAL_MIN_CLUSTER_SIZE
public static final String PROP_INITIAL_MIN_CLUSTER_SIZE
- See Also:
- Constant Field Values
PROP_INITIAL_WAIT_SECONDS
public static final String PROP_INITIAL_WAIT_SECONDS
- See Also:
- Constant Field Values
PROP_TCP_JOIN_PORT_TRY_COUNT
public static final String PROP_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.
- See Also:
- Constant Field Values
PROP_MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS
public static final String PROP_MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS
- See Also:
- Constant Field Values
PROP_MAP_EXPIRY_DELAY_SECONDS
public static final String PROP_MAP_EXPIRY_DELAY_SECONDS
- YOu can use PROP_MAP_EXPIRY_DELAY_SECONDS to deal with some possible edge cases, such as using EntryProcessor.
Without this delay, you may see that an EntryProcessor running on the owner partition found a key, but
EntryBackupProcessor did not find it on backup, and as a result when backup promotes to owner
you will end up with an unprocessed key.
- See Also:
- Constant Field Values
PROP_PARTITION_COUNT
public static final String PROP_PARTITION_COUNT
- See Also:
- Constant Field Values
PROP_LOGGING_TYPE
public static final String PROP_LOGGING_TYPE
- See Also:
- Constant Field Values
PROP_ENABLE_JMX
public static final String PROP_ENABLE_JMX
- See Also:
- Constant Field Values
PROP_ENABLE_JMX_DETAILED
public static final String PROP_ENABLE_JMX_DETAILED
- See Also:
- Constant Field Values
PROP_MC_MAX_VISIBLE_INSTANCE_COUNT
public static final String PROP_MC_MAX_VISIBLE_INSTANCE_COUNT
- See Also:
- Constant Field Values
PROP_MC_MAX_VISIBLE_SLOW_OPERATION_COUNT
public static final String PROP_MC_MAX_VISIBLE_SLOW_OPERATION_COUNT
- See Also:
- Constant Field Values
PROP_MC_URL_CHANGE_ENABLED
public static final String PROP_MC_URL_CHANGE_ENABLED
- See Also:
- Constant Field Values
PROP_CONNECTION_MONITOR_INTERVAL
public static final String PROP_CONNECTION_MONITOR_INTERVAL
- See Also:
- Constant Field Values
PROP_CONNECTION_MONITOR_MAX_FAULTS
public static final String PROP_CONNECTION_MONITOR_MAX_FAULTS
- See Also:
- Constant Field Values
PROP_PARTITION_MIGRATION_INTERVAL
public static final String PROP_PARTITION_MIGRATION_INTERVAL
- See Also:
- Constant Field Values
PROP_PARTITION_MIGRATION_TIMEOUT
public static final String PROP_PARTITION_MIGRATION_TIMEOUT
- See Also:
- Constant Field Values
PROP_PARTITION_MIGRATION_ZIP_ENABLED
public static final String PROP_PARTITION_MIGRATION_ZIP_ENABLED
- See Also:
- Constant Field Values
PROP_PARTITION_TABLE_SEND_INTERVAL
public static final String PROP_PARTITION_TABLE_SEND_INTERVAL
- See Also:
- Constant Field Values
PROP_PARTITION_BACKUP_SYNC_INTERVAL
public static final String PROP_PARTITION_BACKUP_SYNC_INTERVAL
- See Also:
- Constant Field Values
PROP_PARTITION_MAX_PARALLEL_REPLICATIONS
public static final String PROP_PARTITION_MAX_PARALLEL_REPLICATIONS
- See Also:
- Constant Field Values
PROP_PARTITIONING_STRATEGY_CLASS
public static final String PROP_PARTITIONING_STRATEGY_CLASS
- See Also:
- Constant Field Values
PROP_GRACEFUL_SHUTDOWN_MAX_WAIT
public static final String PROP_GRACEFUL_SHUTDOWN_MAX_WAIT
- See Also:
- Constant Field Values
PROP_SYSTEM_LOG_ENABLED
public static final String PROP_SYSTEM_LOG_ENABLED
- See Also:
- Constant Field Values
PROP_SLOW_OPERATION_DETECTOR_ENABLED
public static final String PROP_SLOW_OPERATION_DETECTOR_ENABLED
- Enables or disables the
SlowOperationDetector
.
- See Also:
- Constant Field Values
PROP_SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS
public static final String PROP_SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS
- Defines a threshold above which a running operation in
OperationService
is considered to be slow.
These operations will log a warning and will be shown in the Management Center with detailed information, e.g. stack trace.
- See Also:
- Constant Field Values
PROP_SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
public static final String PROP_SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
- This value defines the retention time of slow operation log invocations.
If an invocation is older than this value, it will be purged from the log to prevent unlimited memory usage.
When all invocations are purged from a log, the log itself will be deleted.
- See Also:
PROP_SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
,
Constant Field Values
PROP_SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
public static final String PROP_SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
- Purge interval for slow operation logs.
- See Also:
PROP_SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
,
Constant Field Values
PROP_SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
public static final String PROP_SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
- Defines if the stack traces of slow operations are logged in the log file. Stack traces will always be reported to the
Management Center, but by default they are not printed to keep the log size small.
- See Also:
- Constant Field Values
PROP_ELASTIC_MEMORY_ENABLED
public static final String PROP_ELASTIC_MEMORY_ENABLED
- See Also:
- Constant Field Values
PROP_ELASTIC_MEMORY_TOTAL_SIZE
public static final String PROP_ELASTIC_MEMORY_TOTAL_SIZE
- See Also:
- Constant Field Values
PROP_ELASTIC_MEMORY_CHUNK_SIZE
public static final String PROP_ELASTIC_MEMORY_CHUNK_SIZE
- See Also:
- Constant Field Values
PROP_ELASTIC_MEMORY_SHARED_STORAGE
public static final String PROP_ELASTIC_MEMORY_SHARED_STORAGE
- See Also:
- Constant Field Values
PROP_ELASTIC_MEMORY_UNSAFE_ENABLED
public static final String PROP_ELASTIC_MEMORY_UNSAFE_ENABLED
- See Also:
- Constant Field Values
PROP_ENTERPRISE_LICENSE_KEY
public static final String PROP_ENTERPRISE_LICENSE_KEY
- See Also:
- Constant Field Values
PROP_MAP_WRITE_BEHIND_QUEUE_CAPACITY
public static final String PROP_MAP_WRITE_BEHIND_QUEUE_CAPACITY
- See Also:
- Constant Field Values
PROP_ENTERPRISE_WAN_REP_QUEUE_CAPACITY
public static final String PROP_ENTERPRISE_WAN_REP_QUEUE_CAPACITY
- Defines event queue capacity for WAN replication. Replication Events are dropped when queue capacity is reached.
Having too big queue capacity may lead to OOME problems,only valid for Hazelcast Enterprise
- See Also:
- Constant Field Values
PROP_ENTERPRISE_WAN_REP_BATCH_SIZE
public static final String PROP_ENTERPRISE_WAN_REP_BATCH_SIZE
- Defines the maximum number of WAN replication events to be drained and sent to the target cluster in a batch.
Batches are sent in sequence to make sure of the order of events,
only one batch of events is sent to a target wan member at a time. After the batch is sent, an acknowledgement is awaited
from the target cluster.
If no-ack is received, the same set of events is sent again to the target cluster until the ack is received.
Until this process is complete, wan replication events are stored in the wan replication event queue.
This queue's size is limited by
PROP_ENTERPRISE_WAN_REP_QUEUE_CAPACITY
. If the queued event count
exceeds queue capacity, no back-pressure is applied and older events in the queue will start dropping.
Only valid for Hazelcast Enterprise.
- See Also:
- Constant Field Values
PROP_ENTERPRISE_WAN_REP_BATCH_FREQUENCY_SECONDS
public static final String PROP_ENTERPRISE_WAN_REP_BATCH_FREQUENCY_SECONDS
- Defines batch sending frequency in seconds,
When event size does not reach to
PROP_ENTERPRISE_WAN_REP_BATCH_SIZE
in the given time period
(which is defined by PROP_ENTERPRISE_WAN_REP_BATCH_FREQUENCY_SECONDS
),
those events are gathered into a batch and sent to target.
Only valid for Hazelcast Enterprise
- See Also:
- Constant Field Values
PROP_ENTERPRISE_WAN_REP_OP_TIMEOUT_MILLIS
public static final String PROP_ENTERPRISE_WAN_REP_OP_TIMEOUT_MILLIS
- Defines timeout duration (in milliseconds) for a WAN replication event before retry.
If confirmation is not received in the period of timeout duration, event is resent to target cluster.
Only valid for Hazelcast Enterprise
- See Also:
- Constant Field Values
PROP_CLIENT_MAX_NO_HEARTBEAT_SECONDS
public static final String PROP_CLIENT_MAX_NO_HEARTBEAT_SECONDS
- See Also:
- Constant Field Values
PROP_MIGRATION_MIN_DELAY_ON_MEMBER_REMOVED_SECONDS
public static final String PROP_MIGRATION_MIN_DELAY_ON_MEMBER_REMOVED_SECONDS
- See Also:
- Constant Field Values
PROP_BACKPRESSURE_ENABLED
public static final String PROP_BACKPRESSURE_ENABLED
- Using back pressure, you can prevent an overload of pending asynchronous backups. With a map with a
single asynchronous backup, producing asynchronous backups could happen at a higher rate than
the consumption of the backup. This can eventually lead to an OOME (especially if the backups are slow).
With back-pressure enabled, this can't happen.
Back pressure is implemented by making asynchronous backups operations synchronous. This prevents the internal queues from
overflowing because the invoker will wait for the primary and for the backups to complete. The frequency of this is
determined by the sync-window.
- See Also:
- Constant Field Values
PROP_BACKPRESSURE_SYNCWINDOW
public static final String PROP_BACKPRESSURE_SYNCWINDOW
- Controls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups. This is needed
to prevent an accumulation of asynchronous backups and eventually running into stability issues.
A sync window of 10 means that 1 in 10 BackupAwareOperations get their async backups convert to sync backups.
A sync window of 1 means that every BackupAwareOperation get their async backups converted to sync backups. 1
is also the smallest legal value for the sync window.
There is some randomization going on to prevent resonance. Therefore, with a sync window of n, not every Nth
BackupAwareOperation operation gets its async backups converted to sync.
This property only has meaning when backpressure is enabled.
- See Also:
- Constant Field Values
PROP_BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
public static final String PROP_BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
- Control the maximum timeout in millis to wait for an invocation space to be available.
If an invocation can't be made because there are too many pending invocations, then an exponential backoff is done
to give the system time to deal with the backlog of invocations. This property controls how long an invocation is
allowed to wait before getting a
HazelcastOverloadException
.
The value need to be equal or larger than 0.
- See Also:
- Constant Field Values
PROP_BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
public static final String PROP_BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
- The maximum number of concurrent invocations per partition.
To prevent the system from overloading, HZ can apply a constraint on the number of concurrent invocations. If the maximum
number of concurrent invocations has been exceeded and a new invocation comes in, then an exponential back-off is applied
till eventually a timeout happens or there is room for the invocation.
By default it is configured as 100. With 271 partitions, that would give (271+1)*100=27200 concurrent invocations from a
single member. The +1 is for generic operations. The reasons why 100 is chosen are:
- there can be concurrent operations that touch a lot of partitions which consume more than 1 invocation, and
- certain methods like those from the IExecutor or ILock are also invocations and they can be very long running.
No promise is made for the invocations being tracked per partition, or if there is a general pool of invocations.
- See Also:
- Constant Field Values
PROP_QUERY_PREDICATE_PARALLEL_EVALUATION
public static final String PROP_QUERY_PREDICATE_PARALLEL_EVALUATION
- Run Query Evaluations for multiple partitions in parallel.
Each Hazelcast member evaluates query predicates using a single thread by default. In most cases the overhead of
inter-thread communication overweight benefit of parallel execution.
When you have a large dataset and/or slow predicate you may benefit from parallel predicate evaluations.
Set to true if you are using slow predicates or have > 100,000s entries per member.
Default: false
- See Also:
- Constant Field Values
PROP_JCACHE_PROVIDER_TYPE
public static final String PROP_JCACHE_PROVIDER_TYPE
- Forces the jcache provider, which can have values client or server, to force the provider type.
Tf not provided, the provider will be client or server, whichever is found on the classPath first respectively.
- See Also:
- Constant Field Values
PROP_QUERY_RESULT_SIZE_LIMIT
public static final String PROP_QUERY_RESULT_SIZE_LIMIT
- Result size limit for query operations on maps.
This value defines the maximum number of returned elements for a single query result. If a query exceeds this number of
elements, a
QueryResultSizeExceededException
will be thrown.
This feature prevents an OOME if a single node is requesting the whole data set of the cluster, such as by
executing a query with TruePredicate
. This applies internally for the IMap.values()
, IMap.keySet()
and IMap.entrySet()
methods, which are good candidates for OOME in large clusters.
This feature depends on an equal distribution of the data on the cluster nodes to calculate the result size limit per node.
Therefore, there is a minimum value of defined in
QueryResultSizeLimiter
. Configured values below the minimum will be increased to the minimum.
The feature can be disabled by setting its value to -1 (which is the default value).
- See Also:
- Constant Field Values
PROP_QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK
public static final String PROP_QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK
- Maximum value of local partitions to trigger local pre-check for
TruePredicate
query operations on maps.
To limit the result size of a query (PROP_QUERY_RESULT_SIZE_LIMIT
), a local pre-check on the requesting node can be
done before the query is sent to the cluster. Since this may increase the latency, the pre-check is limited to a maximum
number of local partitions.
By increasing this parameter, you can prevent the execution of the query on the cluster. Increasing this parameter
increases the latency due to the prolonged local pre-check.
The pre-check can be disabled by setting the value to -1.
- See Also:
PROP_QUERY_RESULT_SIZE_LIMIT
,
Constant Field Values
CLIENT_ENGINE_THREAD_COUNT
public final GroupProperties.GroupProperty CLIENT_ENGINE_THREAD_COUNT
PARTITION_OPERATION_THREAD_COUNT
public final GroupProperties.GroupProperty PARTITION_OPERATION_THREAD_COUNT
GENERIC_OPERATION_THREAD_COUNT
public final GroupProperties.GroupProperty GENERIC_OPERATION_THREAD_COUNT
EVENT_THREAD_COUNT
public final GroupProperties.GroupProperty EVENT_THREAD_COUNT
HEALTH_MONITORING_LEVEL
public final GroupProperties.GroupProperty HEALTH_MONITORING_LEVEL
HEALTH_MONITORING_DELAY_SECONDS
public final GroupProperties.GroupProperty HEALTH_MONITORING_DELAY_SECONDS
PERFORMANCE_MONITORING_ENABLED
public final GroupProperties.GroupProperty PERFORMANCE_MONITORING_ENABLED
PERFORMANCE_MONITORING_DELAY_SECONDS
public final GroupProperties.GroupProperty PERFORMANCE_MONITORING_DELAY_SECONDS
IO_THREAD_COUNT
public final GroupProperties.GroupProperty IO_THREAD_COUNT
IO_BALANCER_INTERVAL_SECONDS
public final GroupProperties.GroupProperty IO_BALANCER_INTERVAL_SECONDS
EVENT_QUEUE_CAPACITY
public final GroupProperties.GroupProperty EVENT_QUEUE_CAPACITY
EVENT_QUEUE_TIMEOUT_MILLIS
public final GroupProperties.GroupProperty EVENT_QUEUE_TIMEOUT_MILLIS
PREFER_IPv4_STACK
public final GroupProperties.GroupProperty PREFER_IPv4_STACK
CONNECT_ALL_WAIT_SECONDS
public final GroupProperties.GroupProperty CONNECT_ALL_WAIT_SECONDS
VERSION_CHECK_ENABLED
public final GroupProperties.GroupProperty VERSION_CHECK_ENABLED
MEMCACHE_ENABLED
public final GroupProperties.GroupProperty MEMCACHE_ENABLED
REST_ENABLED
public final GroupProperties.GroupProperty REST_ENABLED
MAP_LOAD_CHUNK_SIZE
public final GroupProperties.GroupProperty MAP_LOAD_CHUNK_SIZE
MERGE_FIRST_RUN_DELAY_SECONDS
public final GroupProperties.GroupProperty MERGE_FIRST_RUN_DELAY_SECONDS
MERGE_NEXT_RUN_DELAY_SECONDS
public final GroupProperties.GroupProperty MERGE_NEXT_RUN_DELAY_SECONDS
OPERATION_CALL_TIMEOUT_MILLIS
public final GroupProperties.GroupProperty OPERATION_CALL_TIMEOUT_MILLIS
OPERATION_BACKUP_TIMEOUT_MILLIS
public final GroupProperties.GroupProperty OPERATION_BACKUP_TIMEOUT_MILLIS
SOCKET_SERVER_BIND_ANY
public final GroupProperties.GroupProperty SOCKET_SERVER_BIND_ANY
SOCKET_CLIENT_BIND_ANY
public final GroupProperties.GroupProperty SOCKET_CLIENT_BIND_ANY
SOCKET_CLIENT_BIND
public final GroupProperties.GroupProperty SOCKET_CLIENT_BIND
SOCKET_RECEIVE_BUFFER_SIZE
public final GroupProperties.GroupProperty SOCKET_RECEIVE_BUFFER_SIZE
SOCKET_SEND_BUFFER_SIZE
public final GroupProperties.GroupProperty SOCKET_SEND_BUFFER_SIZE
SOCKET_LINGER_SECONDS
public final GroupProperties.GroupProperty SOCKET_LINGER_SECONDS
SOCKET_CONNECT_TIMEOUT_SECONDS
public final GroupProperties.GroupProperty SOCKET_CONNECT_TIMEOUT_SECONDS
SOCKET_KEEP_ALIVE
public final GroupProperties.GroupProperty SOCKET_KEEP_ALIVE
SOCKET_NO_DELAY
public final GroupProperties.GroupProperty SOCKET_NO_DELAY
SHUTDOWNHOOK_ENABLED
public final GroupProperties.GroupProperty SHUTDOWNHOOK_ENABLED
WAIT_SECONDS_BEFORE_JOIN
public final GroupProperties.GroupProperty WAIT_SECONDS_BEFORE_JOIN
MAX_WAIT_SECONDS_BEFORE_JOIN
public final GroupProperties.GroupProperty MAX_WAIT_SECONDS_BEFORE_JOIN
MAX_JOIN_SECONDS
public final GroupProperties.GroupProperty MAX_JOIN_SECONDS
MAX_JOIN_MERGE_TARGET_SECONDS
public final GroupProperties.GroupProperty MAX_JOIN_MERGE_TARGET_SECONDS
MAX_NO_HEARTBEAT_SECONDS
public final GroupProperties.GroupProperty MAX_NO_HEARTBEAT_SECONDS
HEARTBEAT_INTERVAL_SECONDS
public final GroupProperties.GroupProperty HEARTBEAT_INTERVAL_SECONDS
MASTER_CONFIRMATION_INTERVAL_SECONDS
public final GroupProperties.GroupProperty MASTER_CONFIRMATION_INTERVAL_SECONDS
MAX_NO_MASTER_CONFIRMATION_SECONDS
public final GroupProperties.GroupProperty MAX_NO_MASTER_CONFIRMATION_SECONDS
MEMBER_LIST_PUBLISH_INTERVAL_SECONDS
public final GroupProperties.GroupProperty MEMBER_LIST_PUBLISH_INTERVAL_SECONDS
ICMP_ENABLED
public final GroupProperties.GroupProperty ICMP_ENABLED
ICMP_TIMEOUT
public final GroupProperties.GroupProperty ICMP_TIMEOUT
ICMP_TTL
public final GroupProperties.GroupProperty ICMP_TTL
INITIAL_WAIT_SECONDS
public final GroupProperties.GroupProperty INITIAL_WAIT_SECONDS
INITIAL_MIN_CLUSTER_SIZE
public final GroupProperties.GroupProperty INITIAL_MIN_CLUSTER_SIZE
TCP_JOIN_PORT_TRY_COUNT
public final GroupProperties.GroupProperty TCP_JOIN_PORT_TRY_COUNT
MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS
public final GroupProperties.GroupProperty MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS
MAP_EXPIRY_DELAY_SECONDS
public final GroupProperties.GroupProperty MAP_EXPIRY_DELAY_SECONDS
PARTITION_COUNT
public final GroupProperties.GroupProperty PARTITION_COUNT
LOGGING_TYPE
public final GroupProperties.GroupProperty LOGGING_TYPE
ENABLE_JMX
public final GroupProperties.GroupProperty ENABLE_JMX
ENABLE_JMX_DETAILED
public final GroupProperties.GroupProperty ENABLE_JMX_DETAILED
MC_MAX_INSTANCE_COUNT
public final GroupProperties.GroupProperty MC_MAX_INSTANCE_COUNT
MC_MAX_SLOW_OPERATION_COUNT
public final GroupProperties.GroupProperty MC_MAX_SLOW_OPERATION_COUNT
MC_URL_CHANGE_ENABLED
public final GroupProperties.GroupProperty MC_URL_CHANGE_ENABLED
CONNECTION_MONITOR_INTERVAL
public final GroupProperties.GroupProperty CONNECTION_MONITOR_INTERVAL
CONNECTION_MONITOR_MAX_FAULTS
public final GroupProperties.GroupProperty CONNECTION_MONITOR_MAX_FAULTS
PARTITION_MIGRATION_INTERVAL
public final GroupProperties.GroupProperty PARTITION_MIGRATION_INTERVAL
PARTITION_MIGRATION_TIMEOUT
public final GroupProperties.GroupProperty PARTITION_MIGRATION_TIMEOUT
PARTITION_MIGRATION_ZIP_ENABLED
public final GroupProperties.GroupProperty PARTITION_MIGRATION_ZIP_ENABLED
PARTITION_TABLE_SEND_INTERVAL
public final GroupProperties.GroupProperty PARTITION_TABLE_SEND_INTERVAL
PARTITION_BACKUP_SYNC_INTERVAL
public final GroupProperties.GroupProperty PARTITION_BACKUP_SYNC_INTERVAL
PARTITION_MAX_PARALLEL_REPLICATIONS
public final GroupProperties.GroupProperty PARTITION_MAX_PARALLEL_REPLICATIONS
PARTITIONING_STRATEGY_CLASS
public final GroupProperties.GroupProperty PARTITIONING_STRATEGY_CLASS
GRACEFUL_SHUTDOWN_MAX_WAIT
public final GroupProperties.GroupProperty GRACEFUL_SHUTDOWN_MAX_WAIT
SYSTEM_LOG_ENABLED
public final GroupProperties.GroupProperty SYSTEM_LOG_ENABLED
SLOW_OPERATION_DETECTOR_ENABLED
public final GroupProperties.GroupProperty SLOW_OPERATION_DETECTOR_ENABLED
SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS
public final GroupProperties.GroupProperty SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS
SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
public final GroupProperties.GroupProperty SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS
SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
public final GroupProperties.GroupProperty SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS
SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
public final GroupProperties.GroupProperty SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED
ELASTIC_MEMORY_ENABLED
public final GroupProperties.GroupProperty ELASTIC_MEMORY_ENABLED
ELASTIC_MEMORY_TOTAL_SIZE
public final GroupProperties.GroupProperty ELASTIC_MEMORY_TOTAL_SIZE
ELASTIC_MEMORY_CHUNK_SIZE
public final GroupProperties.GroupProperty ELASTIC_MEMORY_CHUNK_SIZE
ELASTIC_MEMORY_SHARED_STORAGE
public final GroupProperties.GroupProperty ELASTIC_MEMORY_SHARED_STORAGE
ELASTIC_MEMORY_UNSAFE_ENABLED
public final GroupProperties.GroupProperty ELASTIC_MEMORY_UNSAFE_ENABLED
ENTERPRISE_LICENSE_KEY
public final GroupProperties.GroupProperty ENTERPRISE_LICENSE_KEY
MAP_WRITE_BEHIND_QUEUE_CAPACITY
public final GroupProperties.GroupProperty MAP_WRITE_BEHIND_QUEUE_CAPACITY
- Setting this capacity is valid if you set
MapStoreConfig.writeCoalescing
to false
. Otherwise
its value will not be taken into account.
The per node maximum write-behind queue capacity is the total of all write-behind queue sizes in a node,
including backups.
The maximum value which can be set is Integer.MAX_VALUE
ENTERPRISE_WAN_REP_QUEUE_CAPACITY
public final GroupProperties.GroupProperty ENTERPRISE_WAN_REP_QUEUE_CAPACITY
ENTERPRISE_WAN_REP_BATCH_SIZE
public final GroupProperties.GroupProperty ENTERPRISE_WAN_REP_BATCH_SIZE
ENTERPRISE_WAN_REP_BATCH_FREQUENCY_SECONDS
public final GroupProperties.GroupProperty ENTERPRISE_WAN_REP_BATCH_FREQUENCY_SECONDS
ENTERPRISE_WAN_REP_OP_TIMEOUT_MILLIS
public final GroupProperties.GroupProperty ENTERPRISE_WAN_REP_OP_TIMEOUT_MILLIS
CLIENT_HEARTBEAT_TIMEOUT_SECONDS
public final GroupProperties.GroupProperty CLIENT_HEARTBEAT_TIMEOUT_SECONDS
MIGRATION_MIN_DELAY_ON_MEMBER_REMOVED_SECONDS
public final GroupProperties.GroupProperty MIGRATION_MIN_DELAY_ON_MEMBER_REMOVED_SECONDS
BACKPRESSURE_ENABLED
public final GroupProperties.GroupProperty BACKPRESSURE_ENABLED
BACKPRESSURE_SYNCWINDOW
public final GroupProperties.GroupProperty BACKPRESSURE_SYNCWINDOW
BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
public final GroupProperties.GroupProperty BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS
BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
public final GroupProperties.GroupProperty BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION
QUERY_RESULT_SIZE_LIMIT
public final GroupProperties.GroupProperty QUERY_RESULT_SIZE_LIMIT
QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK
public final GroupProperties.GroupProperty QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK
QUERY_PREDICATE_PARALLEL_EVALUATION
public final GroupProperties.GroupProperty QUERY_PREDICATE_PARALLEL_EVALUATION
GroupProperties
public GroupProperties(Config config)
Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.