All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.hazelcast.spi.properties.GroupProperty Maven / Gradle / Ivy

/*
 * Copyright (c) 2008-2016, Hazelcast, Inc. All Rights Reserved.
 *
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 *
 * http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */

package com.hazelcast.spi.properties;

import com.hazelcast.core.IMap;
import com.hazelcast.instance.BuildInfo;
import com.hazelcast.instance.BuildInfoProvider;
import com.hazelcast.internal.diagnostics.HealthMonitorLevel;
import com.hazelcast.map.QueryResultSizeExceededException;
import com.hazelcast.map.impl.query.QueryResultSizeLimiter;
import com.hazelcast.query.TruePredicate;
import com.hazelcast.query.impl.predicates.QueryOptimizerFactory;

import static java.util.concurrent.TimeUnit.MILLISECONDS;
import static java.util.concurrent.TimeUnit.SECONDS;

/**
 * Defines the name and default value for Hazelcast properties.
 */
@SuppressWarnings("checkstyle:javadocvariable")
public final class GroupProperty {

    /**
     * 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. */ public static final HazelcastProperty APPLICATION_VALIDATION_TOKEN = new HazelcastProperty("hazelcast.application.validation.token"); /** * Total number of partitions in the Hazelcast cluster. */ public static final HazelcastProperty PARTITION_COUNT = new HazelcastProperty("hazelcast.partition.count", 271); /** * The number of partition operation handler threads per Member. *

* If this is less than the number of partitions on a Member partition operations * will queue behind other operations of different partitions. *

* The default is -1, which means that the value is determined dynamically. */ public static final HazelcastProperty PARTITION_OPERATION_THREAD_COUNT = new HazelcastProperty("hazelcast.operation.thread.count", -1); /** * The number of generic operation handler threads per Member. *

* The default is -1, which means that the value is determined dynamically. */ public static final HazelcastProperty GENERIC_OPERATION_THREAD_COUNT = new HazelcastProperty("hazelcast.operation.generic.thread.count", -1); /** * The number of priority generic operation handler threads per Member. *

* The default is 1. * * Having at least 1 priority generic operation thread helps to improve cluster stability since a lot of the cluster * operations are generic priority operations and they should get executed as soon as possible. If there is a dedicated * generic operation thread, than these operations don't get delayed because the generic threads are busy executing regular * user operations. So unless memory consumption is an issue, make sure there is at least 1 thread. */ public static final HazelcastProperty PRIORITY_GENERIC_OPERATION_THREAD_COUNT = new HazelcastProperty("hazelcast.operation.priority.generic.thread.count", 1); /** * 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. */ public static final HazelcastProperty CLIENT_ENGINE_THREAD_COUNT = new HazelcastProperty("hazelcast.clientengine.thread.count", -1); public static final HazelcastProperty EVENT_THREAD_COUNT = new HazelcastProperty("hazelcast.event.thread.count", 5); public static final HazelcastProperty EVENT_QUEUE_CAPACITY = new HazelcastProperty("hazelcast.event.queue.capacity", 1000000); public static final HazelcastProperty EVENT_QUEUE_TIMEOUT_MILLIS = new HazelcastProperty("hazelcast.event.queue.timeout.millis", 250, MILLISECONDS); public static final HazelcastProperty HEALTH_MONITORING_LEVEL = new HazelcastProperty("hazelcast.health.monitoring.level", HealthMonitorLevel.SILENT.toString()); public static final HazelcastProperty HEALTH_MONITORING_DELAY_SECONDS = new HazelcastProperty("hazelcast.health.monitoring.delay.seconds", 20, SECONDS); public static final HazelcastProperty HEALTH_MONITORING_THRESHOLD_MEMORY_PERCENTAGE = new HazelcastProperty("hazelcast.health.monitoring.threshold.memory.percentage", 70); public static final HazelcastProperty HEALTH_MONITORING_THRESHOLD_CPU_PERCENTAGE = new HazelcastProperty("hazelcast.health.monitoring.threshold.cpu.percentage", 70); /** * The number of threads doing socket input and the number of threads doing socket output. *

* If e.g. 3 is configured, then you get 3 threads doing input and 3 doing output. For individual control * check {@link #IO_INPUT_THREAD_COUNT} and {@link #IO_OUTPUT_THREAD_COUNT}. *

* The default is 3 (so 6 threads). */ public static final HazelcastProperty IO_THREAD_COUNT = new HazelcastProperty("hazelcast.io.thread.count", 3); /** * Controls the number of socket input threads. By default it is the same as {@link #IO_THREAD_COUNT}. */ public static final HazelcastProperty IO_INPUT_THREAD_COUNT = new HazelcastProperty("hazelcast.io.input.thread.count", IO_THREAD_COUNT); /** * Controls the number of socket output threads. By default it is the same as {@link #IO_THREAD_COUNT}. */ public static final HazelcastProperty IO_OUTPUT_THREAD_COUNT = new HazelcastProperty("hazelcast.io.output.thread.count", IO_THREAD_COUNT); /** * The interval in seconds between {@link com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer IOBalancer} * executions. The shorter intervals will catch I/O Imbalance faster, but they will cause higher overhead. *

* Please see the documentation of {@link com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer IOBalancer} for a * detailed explanation of the problem. *

* The default is 20 seconds. A value smaller than 1 disables the balancer. */ public static final HazelcastProperty IO_BALANCER_INTERVAL_SECONDS = new HazelcastProperty("hazelcast.io.balancer.interval.seconds", 20, SECONDS); @SuppressWarnings("checkstyle:constantname") public static final HazelcastProperty PREFER_IPv4_STACK = new HazelcastProperty("hazelcast.prefer.ipv4.stack", true); @Deprecated public static final HazelcastProperty VERSION_CHECK_ENABLED = new HazelcastProperty("hazelcast.version.check.enabled", true); public static final HazelcastProperty PHONE_HOME_ENABLED = new HazelcastProperty("hazelcast.phone.home.enabled", true); public static final HazelcastProperty CONNECT_ALL_WAIT_SECONDS = new HazelcastProperty("hazelcast.connect.all.wait.seconds", 120, SECONDS); public static final HazelcastProperty MEMCACHE_ENABLED = new HazelcastProperty("hazelcast.memcache.enabled", false); public static final HazelcastProperty REST_ENABLED = new HazelcastProperty("hazelcast.rest.enabled", false); public static final HazelcastProperty MAP_LOAD_CHUNK_SIZE = new HazelcastProperty("hazelcast.map.load.chunk.size", 1000); public static final HazelcastProperty MERGE_FIRST_RUN_DELAY_SECONDS = new HazelcastProperty("hazelcast.merge.first.run.delay.seconds", 300, SECONDS); public static final HazelcastProperty MERGE_NEXT_RUN_DELAY_SECONDS = new HazelcastProperty("hazelcast.merge.next.run.delay.seconds", 120, SECONDS); public static final HazelcastProperty OPERATION_CALL_TIMEOUT_MILLIS = new HazelcastProperty("hazelcast.operation.call.timeout.millis", 60000, MILLISECONDS); /** * 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. */ public static final HazelcastProperty OPERATION_BACKUP_TIMEOUT_MILLIS = new HazelcastProperty("hazelcast.operation.backup.timeout.millis", 5000, MILLISECONDS); public static final HazelcastProperty SOCKET_BIND_ANY = new HazelcastProperty("hazelcast.socket.bind.any", true); public static final HazelcastProperty SOCKET_SERVER_BIND_ANY = new HazelcastProperty("hazelcast.socket.server.bind.any", SOCKET_BIND_ANY); public static final HazelcastProperty SOCKET_CLIENT_BIND_ANY = new HazelcastProperty("hazelcast.socket.client.bind.any", SOCKET_BIND_ANY); public static final HazelcastProperty SOCKET_CLIENT_BIND = new HazelcastProperty("hazelcast.socket.client.bind", true); // number of kilobytes public static final HazelcastProperty SOCKET_RECEIVE_BUFFER_SIZE = new HazelcastProperty("hazelcast.socket.receive.buffer.size", 32); // number of kilobytes public static final HazelcastProperty SOCKET_SEND_BUFFER_SIZE = new HazelcastProperty("hazelcast.socket.send.buffer.size", 32); /** * If the bytebuffers used in the socket should be a direct bytebuffer (true) or a regular bytebuffer (false). */ public static final HazelcastProperty SOCKET_BUFFER_DIRECT = new HazelcastProperty("hazelcast.socket.buffer.direct", false); /** * Overrides receive buffer size for connections opened by clients. *

* Hazelcast creates all connections with receive buffer size set according to #PROP_SOCKET_RECEIVE_BUFFER_SIZE. * When it detects a connection was opened by a client then it adjusts receive buffer size * according to this property. *

* Size is in kilobytes. *

* The default is -1 (same as receive buffer size for connections opened by members). */ public static final HazelcastProperty SOCKET_CLIENT_RECEIVE_BUFFER_SIZE = new HazelcastProperty("hazelcast.socket.client.receive.buffer.size", -1); /** * Overrides send buffer size for connections opened by clients. *

* Hazelcast creates all connections with send buffer size set according to #PROP_SOCKET_SEND_BUFFER_SIZE. * When it detects a connection was opened by a client then it adjusts send buffer size * according to this property. *

* Size is in kilobytes. *

* The default is -1 (same as receive buffer size for connections opened by members). */ public static final HazelcastProperty SOCKET_CLIENT_SEND_BUFFER_SIZE = new HazelcastProperty("hazelcast.socket.client.send.buffer.size", -1); public static final HazelcastProperty SOCKET_CLIENT_BUFFER_DIRECT = new HazelcastProperty("hazelcast.socket.client.buffer.direct", false); public static final HazelcastProperty SOCKET_LINGER_SECONDS = new HazelcastProperty("hazelcast.socket.linger.seconds", 0, SECONDS); public static final HazelcastProperty SOCKET_CONNECT_TIMEOUT_SECONDS = new HazelcastProperty("hazelcast.socket.connect.timeout.seconds", 0, SECONDS); public static final HazelcastProperty SOCKET_KEEP_ALIVE = new HazelcastProperty("hazelcast.socket.keep.alive", true); public static final HazelcastProperty SOCKET_NO_DELAY = new HazelcastProperty("hazelcast.socket.no.delay", true); public static final HazelcastProperty SHUTDOWNHOOK_ENABLED = new HazelcastProperty("hazelcast.shutdownhook.enabled", true); public static final HazelcastProperty WAIT_SECONDS_BEFORE_JOIN = new HazelcastProperty("hazelcast.wait.seconds.before.join", 5, SECONDS); public static final HazelcastProperty MAX_WAIT_SECONDS_BEFORE_JOIN = new HazelcastProperty("hazelcast.max.wait.seconds.before.join", 20, SECONDS); public static final HazelcastProperty MAX_JOIN_SECONDS = new HazelcastProperty("hazelcast.max.join.seconds", 300, SECONDS); public static final HazelcastProperty MAX_JOIN_MERGE_TARGET_SECONDS = new HazelcastProperty("hazelcast.max.join.merge.target.seconds", 20, SECONDS); public static final HazelcastProperty HEARTBEAT_INTERVAL_SECONDS = new HazelcastProperty("hazelcast.heartbeat.interval.seconds", 5, SECONDS); public static final HazelcastProperty MAX_NO_HEARTBEAT_SECONDS = new HazelcastProperty("hazelcast.max.no.heartbeat.seconds", 300, SECONDS); public static final HazelcastProperty MASTER_CONFIRMATION_INTERVAL_SECONDS = new HazelcastProperty("hazelcast.master.confirmation.interval.seconds", 30, SECONDS); public static final HazelcastProperty MAX_NO_MASTER_CONFIRMATION_SECONDS = new HazelcastProperty("hazelcast.max.no.master.confirmation.seconds", 350, SECONDS); public static final HazelcastProperty MEMBER_LIST_PUBLISH_INTERVAL_SECONDS = new HazelcastProperty("hazelcast.member.list.publish.interval.seconds", 300, SECONDS); public static final HazelcastProperty CLIENT_HEARTBEAT_TIMEOUT_SECONDS = new HazelcastProperty("hazelcast.client.max.no.heartbeat.seconds", 300, SECONDS); public static final HazelcastProperty CLUSTER_SHUTDOWN_TIMEOUT_SECONDS = new HazelcastProperty("hazelcast.cluster.shutdown.timeout.seconds", 900, SECONDS); public static final HazelcastProperty ICMP_ENABLED = new HazelcastProperty("hazelcast.icmp.enabled", false); public static final HazelcastProperty ICMP_TIMEOUT = new HazelcastProperty("hazelcast.icmp.timeout", 1000, MILLISECONDS); public static final HazelcastProperty ICMP_TTL = new HazelcastProperty("hazelcast.icmp.ttl", 0); public static final HazelcastProperty INITIAL_MIN_CLUSTER_SIZE = new HazelcastProperty("hazelcast.initial.min.cluster.size", 0); public static final HazelcastProperty INITIAL_WAIT_SECONDS = new HazelcastProperty("hazelcast.initial.wait.seconds", 0, SECONDS); /** * 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. */ public static final HazelcastProperty TCP_JOIN_PORT_TRY_COUNT = new HazelcastProperty("hazelcast.tcp.join.port.try.count", 3); public static final HazelcastProperty MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS = new HazelcastProperty("hazelcast.map.replica.scheduled.task.delay.seconds", 10, SECONDS); /** * You can use 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. */ public static final HazelcastProperty MAP_EXPIRY_DELAY_SECONDS = new HazelcastProperty("hazelcast.map.expiry.delay.seconds", 10, SECONDS); public static final HazelcastProperty LOGGING_TYPE = new HazelcastProperty("hazelcast.logging.type", "jdk"); public static final HazelcastProperty ENABLE_JMX = new HazelcastProperty("hazelcast.jmx", false); public static final HazelcastProperty ENABLE_JMX_DETAILED = new HazelcastProperty("hazelcast.jmx.detailed", false); public static final HazelcastProperty JMX_UPDATE_INTERVAL_SECONDS = new HazelcastProperty("hazelcast.jmx.update.interval.seconds", 5, SECONDS); public static final HazelcastProperty MC_MAX_VISIBLE_INSTANCE_COUNT = new HazelcastProperty("hazelcast.mc.max.visible.instance.count", 100); public static final HazelcastProperty MC_MAX_VISIBLE_SLOW_OPERATION_COUNT = new HazelcastProperty("hazelcast.mc.max.visible.slow.operations.count", 10); public static final HazelcastProperty MC_URL_CHANGE_ENABLED = new HazelcastProperty("hazelcast.mc.url.change.enabled", true); public static final HazelcastProperty CONNECTION_MONITOR_INTERVAL = new HazelcastProperty("hazelcast.connection.monitor.interval", 100, MILLISECONDS); public static final HazelcastProperty CONNECTION_MONITOR_MAX_FAULTS = new HazelcastProperty("hazelcast.connection.monitor.max.faults", 3); public static final HazelcastProperty PARTITION_MIGRATION_INTERVAL = new HazelcastProperty("hazelcast.partition.migration.interval", 0, SECONDS); public static final HazelcastProperty PARTITION_MIGRATION_TIMEOUT = new HazelcastProperty("hazelcast.partition.migration.timeout", 300, SECONDS); public static final HazelcastProperty PARTITION_MIGRATION_ZIP_ENABLED = new HazelcastProperty("hazelcast.partition.migration.zip.enabled", true); public static final HazelcastProperty DISABLE_STALE_READ_ON_PARTITION_MIGRATION = new HazelcastProperty("hazelcast.partition.migration.stale.read.disabled", false); public static final HazelcastProperty PARTITION_TABLE_SEND_INTERVAL = new HazelcastProperty("hazelcast.partition.table.send.interval", 15, SECONDS); public static final HazelcastProperty PARTITION_BACKUP_SYNC_INTERVAL = new HazelcastProperty("hazelcast.partition.backup.sync.interval", 30, SECONDS); public static final HazelcastProperty PARTITION_MAX_PARALLEL_REPLICATIONS = new HazelcastProperty("hazelcast.partition.max.parallel.replications", 5); public static final HazelcastProperty PARTITIONING_STRATEGY_CLASS = new HazelcastProperty("hazelcast.partitioning.strategy.class", ""); public static final HazelcastProperty GRACEFUL_SHUTDOWN_MAX_WAIT = new HazelcastProperty("hazelcast.graceful.shutdown.max.wait", 600, SECONDS); public static final HazelcastProperty SYSTEM_LOG_ENABLED = new HazelcastProperty("hazelcast.system.log.enabled", true); /** * Enables or disables the {@link com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector}. */ public static final HazelcastProperty SLOW_OPERATION_DETECTOR_ENABLED = new HazelcastProperty("hazelcast.slow.operation.detector.enabled", true); /** * Defines a threshold above which a running operation in {@link com.hazelcast.spi.OperationService} is considered to be slow. * These operations will log a warning and will be shown in the Management Center with detailed information, e.g. stacktrace. */ public static final HazelcastProperty SLOW_OPERATION_DETECTOR_THRESHOLD_MILLIS = new HazelcastProperty("hazelcast.slow.operation.detector.threshold.millis", 10000, MILLISECONDS); /** * This value defines the retention time of invocations in slow operation logs. *

* 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 #SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS */ public static final HazelcastProperty SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS = new HazelcastProperty("hazelcast.slow.operation.detector.log.retention.seconds", 3600, SECONDS); /** * Purge interval for slow operation logs. * * @see #SLOW_OPERATION_DETECTOR_LOG_RETENTION_SECONDS */ public static final HazelcastProperty SLOW_OPERATION_DETECTOR_LOG_PURGE_INTERVAL_SECONDS = new HazelcastProperty("hazelcast.slow.operation.detector.log.purge.interval.seconds", 300, SECONDS); /** * Defines if the stacktraces of slow operations are logged in the log file. Stacktraces will always be reported to the * Management Center, but by default they are not printed to keep the log size small. */ public static final HazelcastProperty SLOW_OPERATION_DETECTOR_STACK_TRACE_LOGGING_ENABLED = new HazelcastProperty("hazelcast.slow.operation.detector.stacktrace.logging.enabled", false); /** * Property isn't used anymore. */ @Deprecated public static final HazelcastProperty SLOW_INVOCATION_DETECTOR_THRESHOLD_MILLIS = new HazelcastProperty("hazelcast.slow.invocation.detector.threshold.millis", -1, MILLISECONDS); public static final HazelcastProperty LOCK_MAX_LEASE_TIME_SECONDS = new HazelcastProperty("hazelcast.lock.max.lease.time.seconds", Long.MAX_VALUE, SECONDS); public static final HazelcastProperty ENTERPRISE_LICENSE_KEY = new HazelcastProperty("hazelcast.enterprise.license.key"); /** * Setting this capacity is valid if you set {@link com.hazelcast.config.MapStoreConfig#writeCoalescing} to {@code 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 {@link Integer#MAX_VALUE} */ public static final HazelcastProperty MAP_WRITE_BEHIND_QUEUE_CAPACITY = new HazelcastProperty("hazelcast.map.write.behind.queue.capacity", 50000); /** * Defines cache invalidation event batch sending is enabled or not. */ public static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_ENABLED = new HazelcastProperty("hazelcast.cache.invalidation.batch.enabled", true); /** * Defines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch. */ public static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_SIZE = new HazelcastProperty("hazelcast.cache.invalidation.batch.size", 100); /** * Defines the cache invalidation event batch sending frequency in seconds. *

* When the number of events do not come up to {@link #CACHE_INVALIDATION_MESSAGE_BATCH_SIZE} in the given time period (which * is defined by this property); those events are gathered into a batch and sent to target. */ public static final HazelcastProperty CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS = new HazelcastProperty("hazelcast.cache.invalidation.batchfrequency.seconds", 10, SECONDS); /** * Defines near-cache invalidation event batch sending is enabled or not. */ public static final HazelcastProperty MAP_INVALIDATION_MESSAGE_BATCH_ENABLED = new HazelcastProperty("hazelcast.map.invalidation.batch.enabled", true); /** * Defines the maximum number of near-cache invalidation events to be drained and sent to the event near-caches in a batch. */ public static final HazelcastProperty MAP_INVALIDATION_MESSAGE_BATCH_SIZE = new HazelcastProperty("hazelcast.map.invalidation.batch.size", 100); /** * Defines the near-cache invalidation event batch sending frequency in seconds. *

* When the number of events do not come up to {@link #MAP_INVALIDATION_MESSAGE_BATCH_SIZE} in the given time period (which * is defined by this property); those events are gathered into a batch and sent to target. */ public static final HazelcastProperty MAP_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS = new HazelcastProperty("hazelcast.map.invalidation.batchfrequency.seconds", 10, SECONDS); /** * 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. */ public static final HazelcastProperty BACKPRESSURE_ENABLED = new HazelcastProperty("hazelcast.backpressure.enabled", false); /** * 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. */ public static final HazelcastProperty BACKPRESSURE_SYNCWINDOW = new HazelcastProperty("hazelcast.backpressure.syncwindow", 100); /** * 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 {@link com.hazelcast.core.HazelcastOverloadException}. *

* The value needs to be equal or larger than 0. */ public static final HazelcastProperty BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS = new HazelcastProperty("hazelcast.backpressure.backoff.timeout.millis", 60000, MILLISECONDS); /** * 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. */ public static final HazelcastProperty BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION = new HazelcastProperty("hazelcast.backpressure.max.concurrent.invocations.per.partition", 100); /** * 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. *

* The default is false. */ public static final HazelcastProperty QUERY_PREDICATE_PARALLEL_EVALUATION = new HazelcastProperty("hazelcast.query.predicate.parallel.evaluation", false); /** * 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 {@link 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 {@link TruePredicate}. This applies internally for the {@link IMap#values()}, {@link IMap#keySet()} * and {@link 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 {@value QueryResultSizeLimiter#MINIMUM_MAX_RESULT_LIMIT} defined in * {@link QueryResultSizeLimiter}. Configured values below the minimum will be increased to the minimum. *

* The feature can be disabled by setting its value to -1 (which is the default value). */ public static final HazelcastProperty QUERY_RESULT_SIZE_LIMIT = new HazelcastProperty("hazelcast.query.result.size.limit", -1); /** * Maximum value of local partitions to trigger local pre-check for {@link TruePredicate} query operations on maps. *

* To limit the result size of a query ({@see 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 #QUERY_RESULT_SIZE_LIMIT */ public static final HazelcastProperty QUERY_MAX_LOCAL_PARTITION_LIMIT_FOR_PRE_CHECK = new HazelcastProperty("hazelcast.query.max.local.partition.limit.for.precheck", 3); /** * Type of Query Optimizer. * Valid Values: *

    *
  • RULES - for optimizations based on static rules
  • *
  • NONE - optimization are disabled
  • *
*

* Values are case sensitive */ public static final HazelcastProperty QUERY_OPTIMIZER_TYPE = new HazelcastProperty("hazelcast.query.optimizer.type", QueryOptimizerFactory.Type.RULES.toString()); /** * Forces the JCache provider, which can have values client or server, to force the provider type. * If not provided, the provider will be client or server, whichever is found on the classpath first respectively. */ public static final HazelcastProperty JCACHE_PROVIDER_TYPE = new HazelcastProperty("hazelcast.jcache.provider.type"); /** *

Enables the Discovery SPI lookup over the old native implementations. This property is temporary and will * eventually be removed when the experimental marker is removed.

*

Discovery SPI is disabled by default

*/ public static final HazelcastProperty DISCOVERY_SPI_ENABLED = new HazelcastProperty("hazelcast.discovery.enabled", false); /** *

Enables the Discovery Joiner to use public ips from DiscoveredNode. This property is temporary and will * eventually be removed when the experimental marker is removed.

*

Discovery SPI is disabled by default

*/ public static final HazelcastProperty DISCOVERY_SPI_PUBLIC_IP_ENABLED = new HazelcastProperty("hazelcast.discovery.public.ip.enabled", false); /** * Hazelcast serialization version. This is single byte value between 1 and Max supported serialization version. * * @see BuildInfo#getSerializationVersion() */ public static final HazelcastProperty SERIALIZATION_VERSION = new HazelcastProperty("hazelcast.serialization.version", BuildInfoProvider.getBuildInfo().getSerializationVersion()); private GroupProperty() { } }




© 2015 - 2025 Weber Informatics LLC | Privacy Policy