schema
stringclasses
471 values
key
stringlengths
0
203
description
stringlengths
0
4.37k
object
stringlengths
2
322k
hazelcast-config-5.3.json
time-to-live-seconds
The maximum number of seconds for each entry to stay in the map.
{"type": "integer", "minimum": 0, "default": 0}
hazelcast-config-5.3.json
read-backup-data
Sets if read-backup-data (reading local backup entries) is enabled for this map.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
enabled
Sets whether hot restart is enabled on related data structure.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
fsync
Sets whether disk write should be followed by an fsync() system call.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
enabled
Sets whether persistence is enabled on related data structure.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
fsync
Sets whether disk write should be followed by an fsync() system call.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
capacity
The capacity is the total number of items that the event journal can hold at any moment. The actual number of items contained in the journal can be lower. NOTE: The capacity is shared equally between all partitions. This is done by assigning each partition {capacity / partitionCount} available slots in the event journal. Because of this, the effective total capacity may be somewhat lower and you must make sure that the configured capacity is at least greater than the partition count.
{"type": "integer", "minimum": 1, "default": 10000}
hazelcast-config-5.3.json
time-to-live-seconds
Time to live is the time the event journal retains items before removing them from the journal. The events are removed on journal read and write actions, not while the journal is idle. Time to live can be disabled by setting timeToLiveSeconds to 0. This means that the events never expire but they can be overwritten when the capacity of the journal is exceeded.
{"type": "integer", "minimum": 0, "default": 0}
hazelcast-config-5.3.json
initial-mode
LAZY: Default load mode where load is async; EAGER: load mode where load is blocked till all partitions are loaded.
{"enum": ["LAZY", "EAGER"], "default": "LAZY"}
hazelcast-config-5.3.json
offload
Set true to offload map-store interacting code parts from partition threads, otherwise interaction is executed inside partition thread
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
write-delay-seconds
The number of seconds to delay before writing (storing) the dirty records.
{"type": "integer", "minimum": 0, "default": 0}
hazelcast-config-5.3.json
write-batch-size
The number of operations to be included in each batch processing round.
{"type": "integer", "minimum": 1, "default": 1}
hazelcast-config-5.3.json
write-coalescing
Setting writeCoalescing is meaningful if you are using write-behind MapStore. When writeCoalescing is true, only the latest store operation on a key in the writeDelaySeconds time-window will be reflected to MapStore.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
class-name
The name for the MapStore implementation class
{"type": "string"}
hazelcast-config-5.3.json
factory-class-name
The name for the MapStoreFactory implementation class
{"type": "string"}
hazelcast-config-5.3.json
time-to-live-seconds
The maximum number of seconds for each entry to stay in the Near Cache (time to live). Entries that are older than timeToLiveSeconds will automatically be evicted from the Near Cache.
{"type": "integer", "minimum": 0, "default": 0}
hazelcast-config-5.3.json
max-idle-seconds
The maximum number of seconds each entry can stay in the Near Cache as untouched (not-read). Entries that are not read (touched) more than maxIdleSeconds value will get removed from the Near Cache. Accepts any integer between 0 and Integer#MAX_VALUE. The value 0 means Integer#MAX_VALUE. The default is 0.
{"type": "integer", "minimum": 0, "default": 0}
hazelcast-config-5.3.json
invalidate-on-change
Sets if Near Cache entries are invalidated when the entries in the backing data structure are changed. When this setting is enabled, a Hazelcast instance with a Near Cache listens for cluster-wide changes on the entries of the backing data structure and invalidates its corresponding Near Cache entries. Changes done on the local Hazelcast instance always invalidate the Near Cache immediately.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
cache-local-entries
Sets if local entries are also cached in the Near Cache. This is useful when the in-memory format of the Near Cache is different from the backing data structure. This setting has no meaning on Hazelcast clients, since they have no local entries.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
local-update-policy
Defines how to reflect local updates to the Near Cache. Possible values:\n * INVALIDATE: Local put and local remove immediately invalidate Near Cache.\n * CACHE_ON_UPDATE: While local remove immediately invalidates Near Cache, local put adds new value to it.
{"enum": ["INVALIDATE", "CACHE_ON_UPDATE"], "default": "INVALIDATE"}
hazelcast-config-5.3.json
republishing-enabled
Sets if incoming WAN events to this member should be republished (forwarded) to this WAN replication reference.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
filters
Array of class names implementing the CacheWanEventFilter or MapWanEventFilter for filtering outbound WAN replication events. NOTE: EE only
{"type": "array", "items": {"type": "string"}}
hazelcast-config-5.3.json
additionalProperties
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
{"type": "object", "additionalProperties": false, "properties": {"extractor-class-name": {"type": "string"}}, "required": ["extractor-class-name"]}
hazelcast-config-5.3.json
extractor-class-name
Fully qualified class name of the extractor used to extract the value of the attribute.
{"type": "string"}
hazelcast-config-5.3.json
entry-listeners
Adds listeners (listener classes) for the map entries using the "entry-listener" sub-elements
{"type": "array", "items": {}}
hazelcast-config-5.3.json
map-name
In client configurations it is used to identify the map to which this query cache belongs to.
{"type": "string"}
hazelcast-config-5.3.json
include-value
Enables value caching.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
predicate
Predicate to filter events which will be applied to the query cache.
{"type": "object", "additionalProperties": false, "properties": {"class-name": {"type": "string"}, "sql": {"type": "string"}}, "oneOf": [{"required": ["class-name"]}, {"required": ["sql"]}]}
hazelcast-config-5.3.json
populate
Flag to enable/disable initial population of the QueryCache.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
serialize-keys
Defines if the Query Cache keys should be serialized or not. Keys are better to be serialized if they are mutable and need to be cloned via serialization. Default value is false.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
delay-seconds
Minimum time in seconds that an event waits in the member's buffer.
{"type": "integer", "minimum": 0, "default": 0}
hazelcast-config-5.3.json
batch-size
The batch size which will be used to determine number of events to be sent in a batch to QueryCache.
{"type": "integer", "minimum": 1, "default": 1}
hazelcast-config-5.3.json
buffer-size
Maximum number of events which can be stored in a buffer of partition.
{"type": "integer", "minimum": 1, "default": 16}
hazelcast-config-5.3.json
enabled
True if Tiered-Store is enabled, false otherwise.
{"type": "boolean"}
hazelcast-config-5.3.json
memory-tier
Memory tier.
{"type": "object", "additionalProperties": false, "properties": {"capacity": {}}}
hazelcast-config-5.3.json
capacity
Memory tier capacity, i.e., how much main memory should this tier consume at most. The default is 256 megabytes.
{}
hazelcast-config-5.3.json
disk-tier
Disk tier.
{"type": "object", "additionalProperties": false, "properties": {"enabled": {"type": "boolean"}, "device-name": {"type": "string", "default": "default-tiered-store-device"}}, "required": ["enabled"]}
hazelcast-config-5.3.json
enabled
True to enable using disk as the second memory tier, false otherwise.
{"type": "boolean"}
hazelcast-config-5.3.json
device-name
Name of the device for a given disk tier.
{"type": "string", "default": "default-tiered-store-device"}
hazelcast-config-5.3.json
partition-attributes
List of key attributes to use for partitioning the data in the maps. Providing this list automatically sets the strategy to `com.hazelcast.partition.strategy.AttributePartitioningStrategy` regardless of the class name provided in the `partition-strategy` property.
{"type": "array", "items": {}, "minItems": 1}
hazelcast-config-5.3.json
include-value
True if you want the entry event to contain the item values.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
local
True if you want to listen to the entries on the local member.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
max-size
Maximum size of the set (item count). Its default value is 0, meaning Integer.MAX_VALUE.
{"type": "integer", "minimum": 0}
hazelcast-config-5.3.json
statistics-enabled
True if statistics gathering is enabled on the set, false otherwise.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
global-ordering-enabled
When it is set to true, all cluster members that listen to a topic will receive the messages in the same order they were published by all members. This way, Hazelcast guarantees that all members will see the in the same order. Its default value is false.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
statistics-enabled
When you enable it, you can retrieve topic statistics such as total number of published and received messages. Its default value is true.
{"type": "boolean", "default": "true"}
hazelcast-config-5.3.json
multi-threading-enabled
Enable multi-threaded message handling. When enabled any thread from events thread pool can be used for incoming message processing. Otherwise only one dedicated thread will be used to handle topic messages. Note: it can be enabled only in case when global ordering is disabled. Moreover, the local message ordering is not supported in this mode also. This means the messages produced by local publisher can be processed by several threads with no ordering guarantee.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
statistics-enabled
Enables or disables statistics for this reliable topic. Collects the creation time, total number of published and received messages for each member locally.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
topic-overload-policy
A policy to deal with an overloaded topic; so topic where there is no place to store new messages. This policy can only be used in combination with the com.hazelcast.core.HazelcastInstance#getReliableTopic(String). The reliable topic uses a com.hazelcast.ringbuffer.Ringbuffer to store the messages. A ringbuffer doesn't track where readers are, so it has no concept of a slow consumers. This provides many advantages like high performance reads, but it also gives the ability to the reader to re-read the same message multiple times in case of an error. A ringbuffer has a limited, fixed capacity. A fast producer may overwrite old messages that are still being read by a slow consumer. To prevent this, we may configure a time-to-live on the ringbuffer (see com.hazelcast.config.RingbufferConfig#setTimeToLiveSeconds(int). Once the time-to-live is configured, the TopicOverloadPolicy controls how the publisher is going to deal with the situation that a ringbuffer is full and the oldest item in the ringbuffer is not old enough to get overwritten. Keep in mind that this retention period (time-to-live) can keep messages from being overwritten, even though all readers might have already completed reading. Its default value is BLOCK. Available values are as follows: - DISCARD_OLDEST: Using this policy, a message that has not expired can be overwritten. No matter the retention period set, the overwrite will just overwrite the item. This can be a problem for slow consumers because they were promised a certain time window to process messages. But it will benefit producers and fast consumers since they are able to continue. This policy sacrifices the slow producer in favor of fast producers/consumers. - DISCARD_NEWEST: Message that was to be published is discarded. - BLOCK: The caller will wait until there is space in the Ringbuffer. - ERROR: The publish call fails immediately.
{"enum": ["DISCARD_OLDEST", "DISCARD_NEWEST", "BLOCK", "ERROR"], "default": "BLOCK"}
hazelcast-config-5.3.json
read-batch-size
Sets the read batch size. The ReliableTopic tries to read a batch of messages from the ringbuffer. It will get at least one, but if there are more available, then it will try to get more to increase throughput. The maximum read batch size can be influenced using the read batch size. Apart from influencing the number of messages to retrieve, the readBatchSize also determines how many messages will be processed by the thread running the MessageListener before it returns back to the pool to look for other MessageListeners that need to be processed. The problem with returning to the pool and looking for new work is that interacting with an executor is quite expensive due to contention on the work-queue. The more work that can be done without retuning to the pool, the smaller the overhead. If the readBatchSize is 10 and there are 50 messages available, 10 items are retrieved and processed consecutively before the thread goes back to the pool and helps out with the processing of other messages. If the readBatchSize is 10 and there are 2 items available, 2 items are retrieved and processed consecutively. If the readBatchSize is an issue because a thread will be busy too long with processing a single MessageListener and it can't help out other MessageListeners, increase the size of the threadpool so the other MessageListeners don't need to wait for a thread, but can be processed in parallel.
{"type": "integer", "default": 10, "minimum": 1}
hazelcast-config-5.3.json
capacity
Number of items in the Ringbuffer. If no "time-to-live-seconds" is set, this value will always be equal to the capacity after the head completes the first loop around the ring. This is because no items are being expired.
{"type": "integer", "minimum": 1, "default": 10000}
hazelcast-config-5.3.json
time-to-live-seconds
Sets the time to live in seconds which is the maximum number of seconds for each item to stay in the ringbuffer before being removed. Entries that are older than time-to-live-seconds are removed from the ringbuffer on the next ringbuffer operation (read or write). Time to live can be disabled by setting time-to-live-seconds to 0. It means that items won't get removed because they expire. They may only be overwritten. When time-to-live-seconds is disabled and after the tail does a full loop in the ring, the ringbuffer size will always be equal to the capacity. The time-to-live-seconds can be any integer between 0 and Integer#MAX_VALUE. 0 means infinite. The default is 0.
{"type": "integer", "default": 0}
hazelcast-config-5.3.json
in-memory-format
Sets the in-memory format. Setting the in-memory format controls the format of the stored item in the ringbuffer: - OBJECT: the item is stored in deserialized format (a regular object) - BINARY (default): the item is stored in serialized format (a binary blob) The object in-memory format is useful when: - the object stored in object format has a smaller footprint than in binary format - if there are readers using a filter. Since for every filter invocation, the object needs to be available in object format.
{"enum": ["OBJECT", "BINARY"], "default": "BINARY"}
hazelcast-config-5.3.json
class-name
Fully qualified class name.
{"type": "string"}
hazelcast-config-5.3.json
factory-class-name
Fully qualified name of the RingbufferStoreFactory implementation class.
{"type": "string"}
hazelcast-config-5.3.json
split-brain-protection-ref
Adds the Split Brain Protection for this data-structure which you configure using the "split-brain-protection" element. You should set the "split-brain-protection-ref"'s value as the "split-brain-protection"'s name.
{"type": "string"}
hazelcast-config-5.3.json
prefetch-count
Sets how many IDs are pre-fetched on the background when one call to FlakeIdGenerator.newId() is made. Value must be in the range 1..100,000. This setting pertains only to newId() calls made on the member that configured it.
{"type": "integer", "default": 100, "minimum": 1, "maximum": 100000}
hazelcast-config-5.3.json
prefetch-validity-millis
Sets for how long the pre-fetched IDs can be used. If this time elapses, a new batch of IDs will be fetched. Time unit is milliseconds, default is 10 minutes. The IDs contain timestamp component, which ensures rough global ordering of IDs. If an ID is assigned to an object that was created much later, it will be much out of order. If you don't care about ordering, set this value to 0. This setting pertains only to newId() calls made on the member that configured it.
{"type": "integer", "default": 600000, "minimum": 0}
hazelcast-config-5.3.json
epoch-start
Sets the offset of timestamp component. Time unit is milliseconds, default is 1.1.2018 0:00 UTC. If you set the epoch start to a future instant, negative IDs will be generated until that time occurs.
{"type": "integer", "default": 1514764800000}
hazelcast-config-5.3.json
node-id-offset
Sets the offset that will be added to the node ID assigned to cluster member for this generator. Might be useful in A/B deployment scenarios where you have cluster A which you want to upgrade. You create cluster B and for some time both will generate IDs and you want to have them unique. In this case, configure node ID offset for generators on cluster B.
{"type": "integer", "minimum": 0, "default": 0}
hazelcast-config-5.3.json
bits-sequence
Sets the bit-length of the sequence component
{"type": "integer", "default": 6, "minimum": 0, "maximum": 63}
hazelcast-config-5.3.json
bits-node-id
Sets the bit-length of node id component.
{"type": "integer", "minimum": 0, "maximum": 63, "default": 16}
hazelcast-config-5.3.json
allowed-future-millis
Sets how far to the future is the generator allowed to go to generate IDs without blocking.
{"type": "integer", "default": 15000, "minimum": 0}
hazelcast-config-5.3.json
statistics-enabled
When you enable it, you can retrieve the Flake ID generators statistics.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
statistics-enabled
When you enable it, you can retrieve queue statistics.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
max-size
Maximum size of the queue. When a JVM's local queue size reaches the maximum, all put/offer operations will be blocked until the queue size of the JVM goes below this maximum. Its default value is 0, meaning Integer.MAX_VALUE
{"type": "integer", "minimum": 0}
hazelcast-config-5.3.json
empty-queue-ttl
Used to purge unused or empty queues. If you define a value (time in seconds) for this element, then your queue will be destroyed if it stays empty or unused for that time.
{"type": "integer", "default": -1}
hazelcast-config-5.3.json
queue-store
Includes configuration elements and attributes for your queue store implementation. When you want to load/store the distributed queue items from/to a persistent datastore, first implement Hazelcast's QueueStore interface and then configure it using this element
{"type": "object", "additionalProperties": false, "properties": {"enabled": {"type": "boolean", "default": true}, "class-name": {"type": "string"}, "factory-class-name": {"type": "string"}, "properties": {"type": "object", "properties": {"binary": {"type": "boolean", "default": false}, "memory-limit": {"type": "integer", "default": 1000}, "bulk-load": {"type": "integer", "default": 250}}}}}
hazelcast-config-5.3.json
class-name
The fully qualified name of the QueueStore implementation you want to use
{"type": "string"}
hazelcast-config-5.3.json
factory-class-name
The fully qualified name of the QueueStoreFactory which will be created by Hazelcast to instantiate QueueStores.
{"type": "string"}
hazelcast-config-5.3.json
binary
If you do not reach the queue store from an external application, you might prefer to insert the items in binary form. To do so, set this property to true and skip the deserialization step, which is a performance optimization.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
memory-limit
Number of items after which Hazelcast will store items only to datastore. For example, if the memory limit is 1000, then the 1001st item will be put only to datastore. This feature is useful when you want to avoid out-of-memory conditions. If you want to always use memory, you can set it to Integer.MAX_VALUE.
{"type": "integer", "default": 1000}
hazelcast-config-5.3.json
bulk-load
Size of the bulks loaded from QueueStore when the queue is initialized.
{"type": "integer", "default": 250}
hazelcast-config-5.3.json
priority-comparator-class-name
Fully-qualified comparator's class name to be used for the priority queue. If nothing is provided, then queue behaves as a FIFO queue.
{"type": "string"}
hazelcast-config-5.3.json
include-value
Set to true if you want the item event to contain the item values.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
binary
The in-memory format being used for representing the multimap. If it is false, the OBJECT in-memory format will be used.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
async-fillup
Specifies whether the replicated map is available for reads before the initial replication is completed. If false, no Exception will be thrown when the replicated map is not yet ready, but call is blocked until the initial replication is completed.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
statistics-enabled
When you enable it, you can retrieve replicated map entry statistics such as creation time, expiration time, number of hits, key, value, etc.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
statistics-enabled
When you enable it, you can retrieve cache entry statistics such as creation time, expiration time, number of hits, key, value, etc.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
management-enabled
If set to true, JMX beans are enabled and collected statistics are provided. It doesn't automatically enable statistics collection.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
read-through
If set to true, enables read-through behavior of the cache to an underlying configured javax.cache.integration.CacheLoader which is also known as lazy-loading.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
write-through
If set to true, enables write-through behavior of the cache to an underlying configured javax.cache.integration.CacheWriter which passes any changed value to the external backend resource.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
cache-loader-factory
Fully qualified class name of the javax.cache.configuration.Factory implementation providing a javax.cache.integration.CacheLoader instance to the cache.
{}
hazelcast-config-5.3.json
cache-loader
Name of the cache loader class.
{"type": "string"}
hazelcast-config-5.3.json
cache-writer-factory
Fully qualified class name of the javax.cache.configuration.Factory implementation providing a javax.cache.integration.CacheWriter instance to the cache.
{}
hazelcast-config-5.3.json
cache-writer
Name of the cache writer class.
{"type": "string"}
hazelcast-config-5.3.json
expiry-policy-factory
Fully qualified class name of the javax.cache.configuration.Factory implementation providing a javax.cache.expiry.ExpiryPolicy instance to the cache.
{}
hazelcast-config-5.3.json
cache-entry-listeners
List of cache entry listeners.
{"type": "array", "items": {"type": "object", "additionalProperties": false, "properties": {"old-value-required": {"type": "boolean", "default": false}, "synchronous": {"type": "boolean", "default": false}, "cache-entry-listener-factory": {}, "cache-entry-event-filter-factory": {}}}}
hazelcast-config-5.3.json
old-value-required
If set to true, previously assigned values for the affected keys will be sent to the javax.cache.event.CacheEntryListener implementation. Setting this attribute to true creates additional traffic.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
synchronous
If set to true, the javax.cache.event.CacheEntryListener implementation will be called in a synchronous manner.
{"type": "boolean", "default": false}
hazelcast-config-5.3.json
cache-entry-listener-factory
Fully qualified class name of the javax.cache.configuration.Factory implementation providing a javax.cache.event.CacheEntryListener instance.
{}
hazelcast-config-5.3.json
cache-entry-event-filter-factory
Fully qualified class name of the javax.cache.configuration.Factory implementation providing a javax.cache.event.CacheEntryEventFilter instance.
{}
hazelcast-config-5.3.json
name
Name of the WAN replication configuration
{"type": "string"}
hazelcast-config-5.3.json
republishing-enabled
When enabled, an incoming event to a member is forwarded to target cluster of that member.
{"type": "boolean", "default": true}
hazelcast-config-5.3.json
filters
Filters to intercept WAN replication events before they are placed to WAN event replication queues by providing a filtering API. Just implement Hazelcast's CacheWanEventFilter interface to create your filters.
{"type": "array", "items": {"type": "string"}}
hazelcast-config-5.3.json
merge-policy-class-name
Resolve conflicts that occurred when target cluster already has the replicated entry key.
{"enum": ["HigherHitsMergePolicy", "PassThroughMergePolicy"]}
hazelcast-config-5.3.json
split-brain-protection-ref
Adds the split brain protection for this cache. The value should be a "split-brain-protection"'s name.
{"type": "string"}
hazelcast-config-5.3.json
partition-lost-listeners
Adds the partition lost listeners that you created by implementing Hazelcast's PartitionLostListener interface.
{"type": "array", "items": {"type": "string"}}
hazelcast-config-5.3.json
hot-restart
Used to enable Hazelcast's Hot Restart Persistence feature for the cache. It is available only in Hazelcast Enterprise HD. Set its "enabled" to true to enable the feature. By default, it is disabled.
{"type": "object", "additionalProperties": false, "properties": {"enabled": {"type": "boolean", "default": false}, "fsync": {"type": "boolean", "default": false}}}
hazelcast-config-5.3.json
fsync
Set as true if the writing to disk should be followed by an fsync() system call.
{"type": "boolean", "default": false}