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

org.jboss.as.clustering.infinispan.subsystem.LocalDescriptions.properties Maven / Gradle / Ivy

The newest version!
# suppress inspection "UnusedProperty" for whole file
# subsystem resource
datagrid-infinispan=The configuration of the infinispan subsystem.
datagrid-infinispan.add=Add the infinispan subsystem.
datagrid-infinispan.describe=Describe the infinispan subsystem
datagrid-infinispan.remove=Remove the infinispan subsystem
# cache container resource
datagrid-infinispan.cache-container=The configuration of an infinispan cache container
datagrid-infinispan.cache-container.async-executor=The executor used for asynchronous cache operations
datagrid-infinispan.cache-container.default-cache=The default infinispan cache
datagrid-infinispan.cache-container.listener-executor=The executor used for the replication queue
datagrid-infinispan.cache-container.eviction-executor=The scheduled executor used for eviction
datagrid-infinispan.cache-container.expiration-executor=The scheduled executor used for expiration
datagrid-infinispan.cache-container.replication-queue-executor=The executor used for asynchronous cache operations
datagrid-infinispan.cache-container.state-transfer-executor=The executor used by the state transfer to apply state
datagrid-infinispan.cache-container.jndi-name=The jndi name to which to bind this cache container
datagrid-infinispan.cache-container.module=The module whose class loader should be used when building this cache container's configuration.
datagrid-infinispan.cache-container.modules=The modules to add to the global class loader of this cache container.
datagrid-infinispan.cache-container.modules.add=Add the list of modules
datagrid-infinispan.cache-container.modules.remove=Remove the list of modules
datagrid-infinispan.cache-container.modules.module=A module to add to the global class loader of this cache container.
datagrid-infinispan.cache-container.modules.module.add=Add a module
datagrid-infinispan.cache-container.modules.module.remove=Remove a module
datagrid-infinispan.cache-container.modules.module.name=The name of the module
datagrid-infinispan.cache-container.modules.module.slot=The version slot of the module
datagrid-infinispan.cache-container.start=The cache container start mode, which can be EAGER (immediate start) or LAZY (on-demand start).
datagrid-infinispan.cache-container.statistics=If enabled, statistics will be collected for this cache container
datagrid-infinispan.cache-container.cluster-rebalance=Configures whether rebalancing is enabled/disabled for the cluster.

datagrid-infinispan.cache-container.cache=The list of caches available to this cache container
datagrid-infinispan.cache-container.aliases=The list of aliases for this cache container
datagrid-infinispan.cache-container.aliases.alias=An alias for this cache container
datagrid-infinispan.cache-container.alias=An alias for this cache container
datagrid-infinispan.cache-container.alias.name=Name of alias to add or remove
datagrid-infinispan.cache-container.alias.add-alias=Add an alias for this cache container
datagrid-infinispan.cache-container.alias.remove-alias=Remove an alias for this cache container
datagrid-infinispan.cache-container.add=Add a cache container to the infinispan subsystem
datagrid-infinispan.cache-container.cluster-rebalance.value=True to enable cluster rebalance (default), false to disable it.
datagrid-infinispan.cache-container.remove=Remove a cache container from the infinispan subsystem
datagrid-infinispan.cache-container.get-proto-schema-names=Get the names of the available Protobuf schemas
datagrid-infinispan.cache-container.get-proto-schema=Get the contents of a Protobuf schema
datagrid-infinispan.cache-container.get-proto-schema.file-name=The file name
datagrid-infinispan.cache-container.get-proto-schemas-with-errors=Get the names of the Protobuf schemas that have errors
datagrid-infinispan.cache-container.get-proto-schema-errors=Get the errors messages associated to a Protobuf schema file
datagrid-infinispan.cache-container.get-proto-schema-errors.file-name=The file name
datagrid-infinispan.cache-container.upload-proto-schemas=Registers one or more Protobuf schemas given the URLs, which should be reachable by the server
datagrid-infinispan.cache-container.upload-proto-schemas.file-names=Unique file names
datagrid-infinispan.cache-container.upload-proto-schemas.file-urls=The URLs for the schemas
datagrid-infinispan.cache-container.read-event-log=Returns a set of event logs
datagrid-infinispan.cache-container.read-event-log.lines=The number of events to return
datagrid-infinispan.cache-container.read-event-log.since=The instant in ISO-8601 format from which events should be returned
datagrid-infinispan.cache-container.read-event-log.category=The category of the events
datagrid-infinispan.cache-container.read-event-log.level=The level of the events
datagrid-infinispan.cache-container.register-proto-schemas=Registers one or more Protobuf schemas
datagrid-infinispan.cache-container.register-proto-schemas.file-names=Unique file names
datagrid-infinispan.cache-container.register-proto-schemas.file-contents=The contents of the Protobuf files corresponding to the provided names
datagrid-infinispan.cache-container.unregister-proto-schemas=Unregisters one or more Protobuf schemas
datagrid-infinispan.cache-container.unregister-proto-schemas.file-names=Unique file names
datagrid-infinispan.cache-container.take-site-offline=Takes a backup site offline on all caches.
datagrid-infinispan.cache-container.take-site-offline.site-name=The site name.
datagrid-infinispan.cache-container.bring-site-online=Brings a backup site online on all caches.
datagrid-infinispan.cache-container.bring-site-online.site-name=The site name.
datagrid-infinispan.cache-container.push-state=Pushes state to backup site of all caches.
datagrid-infinispan.cache-container.push-state.site-name=The site name.
datagrid-infinispan.cache-container.cancel-push-state=Cancels a current pushing state to backup site on all caches.
datagrid-infinispan.cache-container.cancel-push-state.site-name=The site name.
datagrid-infinispan.cache-container.script-add=Registers a named script.
datagrid-infinispan.cache-container.script-add.name=The name of the script
datagrid-infinispan.cache-container.script-add.code=The script's code.
datagrid-infinispan.cache-container.script-cat=Shows a script's code
datagrid-infinispan.cache-container.script-cat.name=The name of the script
datagrid-infinispan.cache-container.script-remove=Removes a script.
datagrid-infinispan.cache-container.script-remove.name=The name of the script
datagrid-infinispan.cache-container.task-list=Lists the available tasks in this cache container.
datagrid-infinispan.cache-container.task-execute=Executes a task.
datagrid-infinispan.cache-container.task-execute.name=Name of the task to execute.
datagrid-infinispan.cache-container.task-execute.cache-name=Name of the cache to place in the task execution context.
datagrid-infinispan.cache-container.task-execute.parameters=Named parameters to pass to the task.
datagrid-infinispan.cache-container.task-execute.async=Executes the task asynchronously.
datagrid-infinispan.cache-container.task-status=Lists the available tasks in this cache container.

# cache container children
datagrid-infinispan.cache-container.transport=A transport child of the cache container.
datagrid-infinispan.cache-container.local-cache=A replicated cache child of the cache container.
datagrid-infinispan.cache-container.invalidation-cache=An invalidation cache child of the cache container.
datagrid-infinispan.cache-container.replicated-cache=A replicated cache child of the cache container.
datagrid-infinispan.cache-container.distributed-cache=A distributed cache child of the cache container.
# thread-pool resources
datagrid-infinispan.thread-pool.transport=Defines a thread pool used for asynchronous transport communication.
datagrid-infinispan.thread-pool.expiration=Defines a thread pool used for for evictions.
datagrid-infinispan.thread-pool.listener=Defines a thread pool used for asynchronous cache listener notifications.
datagrid-infinispan.thread-pool.persistence=Defines a thread pool used for interacting with the persistent store.
datagrid-infinispan.thread-pool=A thread pool executor.
datagrid-infinispan.thread-pool.add=Adds a thread pool executor.
datagrid-infinispan.thread-pool.remove=Removes a thread pool executor.
datagrid-infinispan.thread-pool.min-threads=The core thread pool size which is smaller than the maximum pool size. If undefined, the core thread pool size is the same as the maximum thread pool size.
datagrid-infinispan.thread-pool.max-threads=The maximum thread pool size.
datagrid-infinispan.thread-pool.queue-length=The queue length.
datagrid-infinispan.thread-pool.keepalive-time=Used to specify the amount of milliseconds that pool threads should be kept running when idle; if not specified, threads will run until the executor is shut down.

# cache container read-only metrics
datagrid-infinispan.cache-container.cache-manager-status=The status of the cache manager component. May return null if the cache manager is not started.
datagrid-infinispan.cache-container.is-coordinator=Set to true if this node is the cluster's coordinator. May return null if the cache manager is not started.
datagrid-infinispan.cache-container.coordinator-address=The logical address of the cluster's coordinator. May return null if the cache manager is not started.
datagrid-infinispan.cache-container.local-address=The local address of the node. May return null if the cache manager is not started.
datagrid-infinispan.cache-container.cluster-name=The name of the cluster this node belongs to. May return null if the cache manager is not started.
datagrid-infinispan.cache-container.cluster-availability=The availability mode of the cluster.
datagrid-infinispan.cache-container.defined-cache-names=The defined caches configured for this container.
datagrid-infinispan.cache-container.defined-cache-count=The number of defined caches configured for this container.
datagrid-infinispan.cache-container.running-cache-count=The number of currently running caches in this container.
datagrid-infinispan.cache-container.created-cache-count=The number of created caches configured for this container.
datagrid-infinispan.cache-container.members=The members of the cluster that this manager is a part of.
datagrid-infinispan.cache-container.cluster-size=How many nodes are part of this cluster.
datagrid-infinispan.cache-container.version=Returns the version of Infinispan.
datagrid-infinispan.cache-container.cli-interpreter=CLI interpreter
datagrid-infinispan.cache-container.clusterwide-memory-available=The maximum amount of free memory in bytes across the cluster JVMs.
datagrid-infinispan.cache-container.clusterwide-memory-max=The maximum amount of memory that JVMs across the cluster will attempt to utilise in bytes.
datagrid-infinispan.cache-container.clusterwide-memory-total=The total amount of memory in the JVMs across the cluster in bytes.
datagrid-infinispan.cache-container.clusterwide-memory-used=The amount of memory used by JVMs across the cluster in bytes.
datagrid-infinispan.cache-container.clusterwide-stale-stats-threshold=Time (in ms), to wait before re-retrieving cluster wide stats

datagrid-infinispan.cache-container.average-read-time=Average time (in ms) for all cache reads in this container. Includes hits and misses.
datagrid-infinispan.cache-container.average-remove-time=Average time (in ms) for all cache removals in this container. Includes hits and misses.
datagrid-infinispan.cache-container.average-write-time=Average time (in ms) for all cache writes in this container.
datagrid-infinispan.cache-container.average-read-time-nanos=Average time (in ns) for all cache reads in this container. Includes hits and misses.
datagrid-infinispan.cache-container.average-remove-time-nanos=Average time (in ns) for all cache removals in this container. Includes hits and misses.
datagrid-infinispan.cache-container.average-write-time-nanos=Average time (in ns) for all cache writes in this container.
datagrid-infinispan.cache-container.data-memory-used=Amount of memory used by eviction caches in this container.
datagrid-infinispan.cache-container.time-since-start=Time (in secs) since first cache in this container started.
datagrid-infinispan.cache-container.evictions=The number of cache eviction operations in this container.
datagrid-infinispan.cache-container.hit-ratio=The total hit/miss ratio for all caches (hits/hits+misses) in this container.
datagrid-infinispan.cache-container.hits=The total number of cache attribute hits in this container.
datagrid-infinispan.cache-container.misses=The total number of cache attribute misses in this container
datagrid-infinispan.cache-container.number-of-entries=The total current number of entries, including passivated ones, in the caches of this container.
datagrid-infinispan.cache-container.number-of-entries-in-memory=The total current number of in-memory entries in the caches of this container.
datagrid-infinispan.cache-container.read-write-ratio=The total read/write ratio of the cache stores ((hits+misses)/stores) in this container.
datagrid-infinispan.cache-container.remove-hits=The total number of cache attribute remove hits in this container.
datagrid-infinispan.cache-container.remove-misses=The total number of cache attribute remove misses in this container.
datagrid-infinispan.cache-container.statistics-enabled=Whether statistics have been enabled for this container.
datagrid-infinispan.cache-container.stores=The total number of cache attribute put operations in this container.
datagrid-infinispan.cache-container.time-since-reset=Time (in secs) since cache container statistics were reset.

# transport resource
datagrid-infinispan.transport=The description of the transport used by this cache container
datagrid-infinispan.transport.add=Add the transport to the cache container
datagrid-infinispan.transport.remove=Remove the transport from the cache container
datagrid-infinispan.transport.channel=The channel of this cache container's transport.
datagrid-infinispan.transport.stack=The jgroups stack to use for the transport
datagrid-infinispan.transport.strict-peer-to-peer=Makes clustered operations fail if the named cache does not exist on remote nodes. Only for replicated caches.
datagrid-infinispan.transport.cluster=The name of the group communication cluster
datagrid-infinispan.transport.executor=The executor to use for the transport
datagrid-infinispan.transport.initial-cluster-size=The number of nodes that have to be in the initial cluster before starting
datagrid-infinispan.transport.initial-cluster-timeout=The timeout for the initial cluster to form
datagrid-infinispan.transport.lock-timeout=The timeout for locks for the transport
datagrid-infinispan.transport.machine=A machine identifier for the transport
datagrid-infinispan.transport.rack=A rack identifier for the transport
datagrid-infinispan.transport.remote-command-executor=The executor to use for processing (non-total order) remote commands
datagrid-infinispan.transport.site=A site identifier for the transport
datagrid-infinispan.transport.total-order-executor=The executor to use for processing total order remote commands
# (hierarchical) cache resource
datagrid-infinispan.cache.name=The name of the cache.
datagrid-infinispan.cache.configuration=The name of a cache configuration.
datagrid-infinispan.cache.mode=The cache mode. Internal use only.
datagrid-infinispan.cache.simple-cache=Use performance-optimized implementation that does support some feature (transactions, persistence, compatibility etc.)
datagrid-infinispan.cache.start=The cache start mode, which can be EAGER (immediate start) or LAZY (on-demand start).
datagrid-infinispan.cache.statistics=If enabled, statistics will be collected for this cache
datagrid-infinispan.cache.statistics-available=If set to false, statistics gathering cannot be enabled during runtime. Performance optimization.
datagrid-infinispan.cache.batching=If enabled, the invocation batching API will be made available for this cache.
datagrid-infinispan.cache.jndi-name=The jndi-name to which to bind this cache instance.
datagrid-infinispan.cache.module=The module whose class loader should be used when building this cache's configuration.
datagrid-infinispan.cache.remove=Remove a cache from this container.
datagrid-infinispan.cache.remote-cache=The name of the remote cache that backups data here.
datagrid-infinispan.cache.remote-site=The name of the remote site containing the cache that backups data here.
datagrid-infinispan.cache.template=Whether the configuration is a template or for a concrete cache.
# cache operations
datagrid-infinispan.cache.clear-cache=Clears the cache contents.
datagrid-infinispan.cache.flush-cache=Flushes the cache contents.
datagrid-infinispan.cache.start-cache=Starts the cache.
datagrid-infinispan.cache.stop-cache=Stops the cache.
datagrid-infinispan.cache.shutdown-cache=Cluster-wide shutdown of the cache.
datagrid-infinispan.cache.reset-statistics=Resets statistics gathered by this cache.
datagrid-infinispan.cache.reset-activation-statistics=Resets the cache activation statistics.
datagrid-infinispan.cache.reset-invalidation-statistics=Resets the cache invalidation statistics.
datagrid-infinispan.cache.reset-passivation-statistics=Resets the cache passivation statistics.
datagrid-infinispan.cache.reset-rpc-manager-statistics=Resets the cache's rpc manager statistics.
datagrid-infinispan.cache.synchronize-data=Synchronizes data from the old cluster to this using the specified migrator.
datagrid-infinispan.cache.synchronize-data.migrator-name=The migrator to synchronize to.
datagrid-infinispan.cache.synchronize-data.read-batch=The number of entries transferred at a time from the old cluster.
datagrid-infinispan.cache.synchronize-data.write-threads=The number of threads to write data to the new cluster, in each node.
datagrid-infinispan.cache.disconnect-source=Disconnects the target cluster from the source cluster according to the specified migrator.
datagrid-infinispan.cache.disconnect-source.migrator-name=The migrator to disconnect from.
datagrid-infinispan.cache.record-known-global-keyset=Dumps the global known keyset to a well-known key for retrieval by the upgrade process.
datagrid-infinispan.cache.mass-reindex=Initiates a mass reindex of the entries in the cache
# cache metrics
datagrid-infinispan.cache.cache-name=The name of this cache
datagrid-infinispan.cache.cache-status=The status of the cache component. May return null if the cache is not started.
datagrid-infinispan.cache.number-of-locks-available=The number of locks available to this cache. May return null if the cache is not started.
datagrid-infinispan.cache.number-of-locks-held=The number of locks currently in use by this cache. May return null if the cache is not started.
datagrid-infinispan.cache.concurrency-level=The estimated number of concurrently updating threads which this cache can support. May return null if the cache is not started.
datagrid-infinispan.cache.concurrent-updates=If enabled, the cache keeps data consistent in the case of concurrent updates. For non-transactional caches only.
datagrid-infinispan.cache.average-read-time=Average time (in ms) for cache reads. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.cache.average-remove-time=Average time (in ms) for a cache removal. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.cache.average-write-time=Average time (in ms) for cache writes. May return null if the cache is not started.
datagrid-infinispan.cache.average-read-time-nanos=Average time (in ns) for cache reads. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.cache.average-remove-time-nanos=Average time (in ns) for a cache removal. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.cache.average-write-time-nanos=Average time (in ns) for cache writes. May return null if the cache is not started.
datagrid-infinispan.cache.time-since-start=Time (in secs) since cache started. May return null if the cache is not started.
datagrid-infinispan.cache.evictions=The number of cache eviction operations. May return null if the cache is not started.
datagrid-infinispan.cache.hit-ratio=The hit/miss ratio for the cache (hits/hits+misses). May return null if the cache is not started.
datagrid-infinispan.cache.hits=The number of cache attribute hits. May return null if the cache is not started.
datagrid-infinispan.cache.minimum-required-nodes=The minimum number of nodes required to stay up to make sure data is not lost. This is calculated using only data from this cache on this node.
datagrid-infinispan.cache.misses=The number of cache attribute misses. May return null if the cache is not started.
datagrid-infinispan.cache.number-of-entries=The current number of entries in the cache, including passivated entries. May return null if the cache is not started.
datagrid-infinispan.cache.number-of-entries-in-memory=The current number of in-memory entries in the cache. May return null if the cache is not started.
datagrid-infinispan.cache.data-memory-used=The amount of memory in use by this cache when eviction is enabled.
datagrid-infinispan.cache.off-heap-memory-used=The amount of memory allocated for off heap data in this cache.
datagrid-infinispan.cache.read-write-ratio=The read/write ratio of the cache ((hits+misses)/stores). May return null if the cache is not started.
datagrid-infinispan.cache.remove-hits=The number of cache attribute remove hits. May return null if the cache is not started.
datagrid-infinispan.cache.remove-misses=The number of cache attribute remove misses. May return null if the cache is not started.
datagrid-infinispan.cache.statistics-enabled=Whether statistics have been enabled for this cache.
datagrid-infinispan.cache.stores=The number of cache attribute put operations. May return null if the cache is not started.
datagrid-infinispan.cache.time-since-reset=Time (in secs) since cache statistics were reset. May return null if the cache is not started.
datagrid-infinispan.cache.commits=The number of transaction commits. May return null if the cache is not started.
datagrid-infinispan.cache.prepares=The number of transaction prepares. May return null if the cache is not started.
datagrid-infinispan.cache.rollbacks=The number of transaction rollbacks. May return null if the cache is not started.
datagrid-infinispan.cache.invalidations=The number of cache invalidations. May return null if the cache is not started.
datagrid-infinispan.cache.version=Returns the version of Infinispan.
#backup metrics
datagrid-infinispan.cache.sites-mixed=List of site which are online and offline.
datagrid-infinispan.cache.sites-online=List of sites which are online.
datagrid-infinispan.cache.sites-offline=List of sites which are offline.

#
datagrid-infinispan.clustered-cache.average-replication-time=The average time spent in the transport layer, in milliseconds
datagrid-infinispan.clustered-cache.cache-availability=The availability status of the cache.
datagrid-infinispan.clustered-cache.cache-rebalance=The cache rebalancing behavior.
datagrid-infinispan.clustered-cache.cache-rebalancing-status=The cache rebalancing status.
datagrid-infinispan.clustered-cache.mode=Sets the clustered cache mode, ASYNC for asynchronous operation, or SYNC for synchronous operation.
datagrid-infinispan.clustered-cache.remote-timeout=In SYNC mode, the timeout (in ms) used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
datagrid-infinispan.clustered-cache.replication-count=Number of successful replications
datagrid-infinispan.clustered-cache.replication-failures=Number of failed replications
datagrid-infinispan.clustered-cache.success-ratio=Successful replications as a ratio of total replications in numeric double format
datagrid-infinispan.clustered-cache.average-xsite-replication-time=Average Cross-Site replication time, in milliseconds
datagrid-infinispan.clustered-cache.minimum-xsite-replication-time=Minimum Cross-Site replication time registered, in milliseconds
datagrid-infinispan.clustered-cache.maximum-xsite-replication-time=Maximum Cross-Site replication time registered, in milliseconds
datagrid-infinispan.clustered-cache.sync-xsite-replication-count=Number of synchronous Cross-Site replications
datagrid-infinispan.clustered-cache.async-xsite-replication-count=Number of asynchronous Cross-Site replications
datagrid-infinispan.clustered-cache.average-async-xsite-replication-time=Average async Cross-Site replication time, in milliseconds
datagrid-infinispan.clustered-cache.minimum-async-xsite-replication-time=Minimum async Cross-Site replication time registered, in milliseconds
datagrid-infinispan.clustered-cache.maximum-async-xsite-replication-time=Maximum async Cross-Site replication time registered, in milliseconds
datagrid-infinispan.clustered-cache.async-xsite-acks-count=Number of asynchronous Cross-Site acks

# Inbound handler
datagrid-infinispan.clustered-cache.sync-xsite-replication-received-count=Number of synchronous Cross-Site replications received
datagrid-infinispan.clustered-cache.async-xsite-replication-received-count=Number of asynchronous Cross-Site replications received
#shared cache operations
datagrid-infinispan.clustered-cache.cache-rebalance.value=True to enable rebalance for this cache (default), false otherwise.

# clustered cache wide stats. See ClusterCacheStats
datagrid-infinispan.clustered-cache.clusterwide-number-of-locks-available=The clusterwide number of locks available in this cache.
datagrid-infinispan.clustered-cache.clusterwide-number-of-locks-held=The clusterwide number of locks currently in use by this cache.
datagrid-infinispan.clustered-cache.clusterwide-average-read-time=Clusterwide average time (in ms) for cache reads. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-average-remove-time=Clusterwide average time (in ms) for a cache removal. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-average-write-time=Clusterwide average time (in ms) for cache writes. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-average-read-time-nanos=Clusterwide average time (in ns) for cache reads. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-average-remove-time-nanos=Clusterwide average time (in ns) for a cache removal. Includes hits and misses. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-average-write-time-nanos=Clusterwide average time (in ns) for cache writes. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-time-since-start=Time (in secs) since first cache node started. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-evictions=The clusterwide number of cache eviction operations. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-hit-ratio=The clusterwide hit/miss ratio for the cache (hits/hits+misses). May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-hits=The clusterwide number of cache attribute hits. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-minimum-required-nodes=The clusterwide minimum number of nodes required to stay up to make sure data is not lost in this cache.
datagrid-infinispan.clustered-cache.clusterwide-misses=The clusterwide number of cache attribute misses. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-number-of-entries=The clusterwide current number of entries in the cache, including passivated entries. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-number-of-entries-in-memory=The clusterwide current total of in-memory entries in the cache. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-data-memory-used=The clusterwide amount of memory in use for this cache with eviction.
datagrid-infinispan.clustered-cache.clusterwide-off-heap-memory-used=The clusterwide amount of memory allocated for off heap data for this cache.
datagrid-infinispan.clustered-cache.clusterwide-read-write-ratio=The clusterwide read/write ratio of the cache ((hits+misses)/stores). May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-remove-hits=The clusterwide number of cache attribute remove hits. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-remove-misses=The clusterwide number of cache attribute remove misses. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-statistics-enabled=Whether statistics have been enabled for this cache.
datagrid-infinispan.clustered-cache.clusterwide-stores=The clusterwide number of cache attribute put operations. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-time-since-reset=Time (in secs) since cache statistics were reset. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-stale-stats-threshold=Time (in ms), to wait before re-retrieving cluster wide stats

datagrid-infinispan.clustered-cache.clusterwide-invalidations=The clusterwide number of cache invalidations. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-passivations=The clusterwide number of cache invalidations. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-activations=The clusterwide number of cache invalidations. May return null if the cache is not started.

datagrid-infinispan.clustered-cache.clusterwide-cache-loader-loads=The clusterwide number of cache loader load operations. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-cache-loader-misses=The clusterwide number of cache loader misses. May return null if the cache is not started.
datagrid-infinispan.clustered-cache.clusterwide-cache-loader-stores=The clusterwide number of cache loader put operations. May return null if the cache is not started.

datagrid-infinispan.local-cache=A local cache
datagrid-infinispan.local-cache.add=Add a local cache to this cache container
datagrid-infinispan.local-cache.remove=Remove a local cache from this cache container

datagrid-infinispan.invalidation-cache=An invalidation cache
datagrid-infinispan.invalidation-cache.add=Add an invalidation cache to this cache container
datagrid-infinispan.invalidation-cache.remove=Remove an invalidation cache from this cache container

datagrid-infinispan.replicated-cache=A replicated cache
datagrid-infinispan.replicated-cache.add=Add a replicated cache to this cache container
datagrid-infinispan.replicated-cache.remove=Remove a replicated cache from this cache container

datagrid-infinispan.distributed-cache=A distributed cache
datagrid-infinispan.distributed-cache.add=Add a distributed cache to this cache container
datagrid-infinispan.distributed-cache.remove=Remove a distributed cache from this cache container


datagrid-infinispan.state-transfer=The state transfer configuration for distribution and replicated caches.
datagrid-infinispan.state-transfer.await-initial-transfer=Wait for the initial state transfer to complete before making a cache available.
datagrid-infinispan.state-transfer.enabled=If enabled, this will cause the cache to ask neighboring caches for state when it starts up, so the cache starts 'warm', although it will impact startup time.
datagrid-infinispan.state-transfer.timeout=The maximum amount of time (ms) to wait for state from neighboring caches, before throwing an exception and aborting startup.
datagrid-infinispan.state-transfer.chunk-size=The size, in bytes, in which to batch the transfer of cache entries.
datagrid-infinispan.state-transfer.add=Add a state transfer configuration.
datagrid-infinispan.state-transfer.remove=Remove a state transfer configuration.

datagrid-infinispan.partition-handling=The partition handling configuration for distribution and replicated caches
datagrid-infinispan.partition-handling.enabled=Configures the way this cache reacts to node crashes and split brains
datagrid-infinispan.partition-handling.enabled.deprecated=Deprecated. The type property should be utilised instead.
datagrid-infinispan.partition-handling.when-split=The PartitionHandling type, can be DENY_READ_WRITES, ALLOW_READS or ALLOW_READ_WRITES
datagrid-infinispan.partition-handling.merge-policy=The EntryMergePolicy to be used to resolve conflicts during partition merges. Options are NONE, PREFERRED_ALWAYS, PREFERRED_NON_NULL, REMOVE_ALL or the FQN of a custom EntryMergePolicy implementation.
datagrid-infinispan.partition-handling.add=Add a partition handling configuration
datagrid-infinispan.partition-handling.remove=Remove a partition handling configuration

datagrid-infinispan.distributed-cache-configuration.owners=Number of cluster-wide replicas for each cache entry.
datagrid-infinispan.distributed-cache-configuration.segments=Controls the number of hash space segments which is the granularity for key distribution in the cluster. Value must be strictly positive.
datagrid-infinispan.distributed-cache-configuration.capacity-factor=Controls the proportion of entries that will reside on the local node, \
  compared to the other nodes in the cluster. Value must be positive. This element is only used in 'distributed' \
  cache instances.
datagrid-infinispan.distributed-cache-configuration.l1-lifespan=Maximum lifespan of an entry placed in the L1 cache. This element configures the L1 cache behavior in 'distributed' caches instances. In any other cache modes, this element is ignored.

datagrid-infinispan.locking=The locking configuration of the cache.
datagrid-infinispan.locking.isolation=Sets the cache locking isolation level.
datagrid-infinispan.locking.striping=If true, a pool of shared locks is maintained for all entries that need to be locked. Otherwise, a lock is created per entry in the cache. Lock striping helps control memory footprint but may reduce concurrency in the system.
datagrid-infinispan.locking.acquire-timeout=Maximum time to attempt a particular lock acquisition.
datagrid-infinispan.locking.concurrency-level=Concurrency level for lock containers. Adjust this value according to the number of concurrent threads interacting with Infinispan.
datagrid-infinispan.locking.add=Adds a locking configuration element to the cache.
datagrid-infinispan.locking.remove=Removes a locking configuration element from the cache.
#
datagrid-infinispan.transaction=The cache transaction configuration.
datagrid-infinispan.transaction.mode=Sets the cache transaction mode to one of NONE, NON_XA, NON_DURABLE_XA, FULL_XA.
datagrid-infinispan.transaction.stop-timeout=If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish. The amount of time to wait for is defined by the cache stop timeout.
datagrid-infinispan.transaction.locking=The locking mode for this cache, one of OPTIMISTIC or PESSIMISTIC.
datagrid-infinispan.transaction.add=Adds a transaction configuration element to the cache.
datagrid-infinispan.transaction.remove=Removes a transaction configuration element from the cache.
datagrid-infinispan.transaction.notifications=Enables or disables triggering transactional notifications on cache listeners.
# transaction operations
datagrid-infinispan.transaction.reset-transaction-statistics=Reset transaction statistics.
datagrid-infinispan.transaction.list-in-doubt-transactions=Lists in-doubt transactions.
datagrid-infinispan.transaction.recovery.force-commit-transaction=Forces the commit of an in-doubt transaction by its internal ID.
datagrid-infinispan.transaction.recovery.force-commit-transaction.internal-id=The internal ID of the transaction to force commit.
datagrid-infinispan.transaction.recovery.force-rollback-transaction=Forces the rollback of an in-doubt transaction by its internal ID.
datagrid-infinispan.transaction.recovery.force-rollback-transaction.internal-id=The internal ID of the transaction to force rollback.
datagrid-infinispan.transaction.recovery.forget-transaction=Removes recovery info for the given transaction by its internal ID.
datagrid-infinispan.transaction.recovery.forget-transaction.internal-id=The internal ID of the transaction to forget.
#
datagrid-infinispan.eviction=The cache eviction configuration.
datagrid-infinispan.eviction.strategy=Sets the cache eviction strategy. Available options are 'UNORDERED', 'FIFO', 'LRU', 'LIRS' and 'NONE' (to disable eviction).
datagrid-infinispan.eviction.max-entries=Maximum number of entries in a cache instance. -1 means no limit. Also sets the type to COUNT.
datagrid-infinispan.eviction.size=Sets the maximum size for the eviction type.
datagrid-infinispan.eviction.type=Specifies whether to use entry count or memory-based approximation. When using MEMORY, size will be the amount in bytes approximately that the data container will use in memory. The approximation is tailored for the HotSpot JVM.
datagrid-infinispan.eviction.add=Adds an eviction configuration element to the cache.
datagrid-infinispan.eviction.remove=Removes an eviction configuration element from the cache.
#
datagrid-infinispan.expiration=The cache expiration configuration.
datagrid-infinispan.expiration.max-idle=Maximum idle time a cache entry will be maintained in the cache, in milliseconds. If the idle time is exceeded, the entry will be expired cluster-wide. -1 means the entries never expire.
datagrid-infinispan.expiration.lifespan=Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds. -1 means the entries never expire.
datagrid-infinispan.expiration.interval=Interval (in milliseconds) between subsequent runs to purge expired entries from memory and any cache stores. If you wish to disable the periodic eviction process altogether, set wakeupInterval to -1.
datagrid-infinispan.expiration.add=Adds an expiration configuration element to the cache.
datagrid-infinispan.expiration.remove=Removes an expiration configuration element from the cache.
#
datagrid-infinispan.indexing=The cache indexing configuration.
datagrid-infinispan.indexing.auto-config=If enabled, will configure indexing automatically based on cache type
datagrid-infinispan.indexing.indexing=If enabled, entries will be indexed when they are added to the cache. Indexes will be updated as entries change or are removed.
datagrid-infinispan.indexing.key-transformers=The Transformers used to stringify keys for indexing with Lucene
datagrid-infinispan.indexing.indexed-entities=The fully qualified names of the indexed entity classes.
datagrid-infinispan.indexing.indexing-properties=Properties to control indexing behaviour
datagrid-infinispan.indexing.add=Adds an indexing configuration element to the cache.
datagrid-infinispan.indexing.remove=Removes an indexing configuration element from the cache.

#
datagrid-infinispan.loader=The cache loader configuration.
datagrid-infinispan.loader.add=Adds a basic cache loader configuration element to the cache.
datagrid-infinispan.loader.remove=Removes a cache loader configuration element from the cache.
datagrid-infinispan.loader.segmented=This setting should be set to true when loader reads data stored that is segmented.
datagrid-infinispan.loader.shared=This setting should be set to true when multiple cache instances share the same cache loader.
datagrid-infinispan.loader.preload=If true, when the cache starts, data stored in the cache loader will be pre-loaded into memory. This is particularly useful when data in the cache loader will be needed immediately after startup and you want to avoid cache operations being delayed as a result of loading this data lazily. Can be used to provide a 'warm-cache' on startup, however there is a performance penalty as startup time is affected by this process.
datagrid-infinispan.loader.class=The custom loader implementation class to use for this cache loader.
#
datagrid-infinispan.persistence=Persistence configuration for a cache
datagrid-infinispan.persistence.add=Adds a persistence configuration element to the cache.
datagrid-infinispan.persistence.remove=Removes a persistence configuration element from the cache.
datagrid-infinispan.persistence.availability-interval=The time, in milliseconds, between availability checks to determine if the PersistenceManager is available. In other words, this interval sets how often stores/loaders are polled via their `org.infinispan.persistence.spi.CacheWriter#isAvailable` or `org.infinispan.persistence.spi.CacheLoader#isAvailable` implementation. If a single store/loader is not available, an exception is thrown during cache operations.
datagrid-infinispan.persistence.connection-attempts=The maximum number of unsuccessful attempts to start each of the configured CacheWriter/CacheLoader before an exception is thrown and the cache fails to start.
datagrid-infinispan.persistence.connection-interval=The time, in milliseconds, to wait between subsequent connection attempts on startup. A negative or zero value means no wait between connection attempts.
datagrid-infinispan.persistence.passivation=If true, data is only written to the cache store when it is evicted from memory, a phenomenon known as 'passivation'. Next time the data is requested, it will be 'activated' which means that data will be brought back to memory and removed from the persistent store. f false, the cache store contains a copy of the contents in memory, so writes to cache result in cache store writes. This essentially gives you a 'write-through' configuration.
# Cache loader metrics
datagrid-infinispan.loader.passivations=The number of cache node passivations (passivating a node from memory to a cache store). May return null if the cache is not started.
datagrid-infinispan.loader.activations=The number of cache node activations (bringing a node into memory from a cache store) . May return null if the cache is not started.
datagrid-infinispan.loader.cache-loader-loads=The number of cache loader node loads. May return null if the cache is not started.
datagrid-infinispan.loader.cache-loader-misses=The number of cache loader node misses. May return null if the cache is not started.
datagrid-infinispan.loader.cache-loader-stores=The number of cache loader node stores. May return null if the cache is not started.

datagrid-infinispan.loader.properties=A list of cache loader properties.
datagrid-infinispan.loader.properties.property=A cache loader property with name and value.

datagrid-infinispan.loader.reset-loader-statistics=Resets the cache loader statistics.

datagrid-infinispan.memory=The cache memory configuration.
datagrid-infinispan.memory.add=Adds a memory configuration element to the cache.
datagrid-infinispan.memory.remove=Removes a memory configuration element from the cache.
datagrid-infinispan.memory.size=The maximum size until entries are evicted.  If eviction type is COUNT this will be based on entry amount or if MEMORY it will be based on how much memory the entries are occupying.
datagrid-infinispan.memory.eviction=The type of eviction that is configured: COUNT or MEMORY
datagrid-infinispan.memory.strategy=Sets the cache eviction strategy. Available options are 'MANUAL', 'REMOVE', 'EXCEPTION' and 'NONE' (to disable eviction).
datagrid-infinispan.memory.address-count=Determines how many address pointers there are when using off heap memory.

datagrid-infinispan.encoding=The encoding configuration for the cache.
datagrid-infinispan.encoding.add=Adds an encoding configuration for keys and values of the cache.
datagrid-infinispan.encoding.remove=Removes an encoding configuration from the cache.
datagrid-infinispan.encoding.media-type=The media type for keys and values of the cache.

datagrid-infinispan.cluster-loader=The cluster cache loader configuration.
datagrid-infinispan.cluster-loader.add=Adds a cluster cache loader configuration element to the cache.
datagrid-infinispan.cluster-loader.remove=Removes a cluster cache loader configuration element from the cache.
datagrid-infinispan.cluster-loader.remote-timeout=Specifies the maximum time to wait for a response from remote nodes.

datagrid-infinispan.store=The cache store configuration.
datagrid-infinispan.store.add=Adds a basic cache store configuration element to the cache.
datagrid-infinispan.store.remove=Removes a cache store configuration element from the cache.
datagrid-infinispan.store.read-only=If true, the cache store will only be used to load entries. Any modifications made to the caches will not be applied to the store.
datagrid-infinispan.store.segmented=This setting should be set to true when store reads data stored that is segmented.
datagrid-infinispan.store.shared=This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times. If enabled, only the node where the modification originated will write to the cache store. If disabled, each individual cache reacts to a potential remote update by storing the data to the cache store.
datagrid-infinispan.store.max-batch-size=The maximum size of a batch to be inserted/deleted from the store. If the value is less than one, then no upper limit is placed on the number of operations in a batch.
datagrid-infinispan.store.preload=If true, when the cache starts, data stored in the cache store will be pre-loaded into memory. This is particularly useful when data in the cache store will be needed immediately after startup and you want to avoid cache operations being delayed as a result of loading this data lazily. Can be used to provide a 'warm-cache' on startup, however there is a performance penalty as startup time is affected by this process.
datagrid-infinispan.store.passivation=If true, data is only written to the cache store when it is evicted from memory, a phenomenon known as 'passivation'. Next time the data is requested, it will be 'activated' which means that data will be brought back to memory and removed from the persistent store. f false, the cache store contains a copy of the contents in memory, so writes to cache result in cache store writes. This essentially gives you a 'write-through' configuration.
datagrid-infinispan.store.passivation.deprecated=Deprecated please use the passivation attribute on the persistence model.
datagrid-infinispan.store.fetch-state=If true, fetch persistent state when joining a cluster. If multiple cache stores are chained, only one of them can have this property enabled.
datagrid-infinispan.store.purge=If true, purges this cache store when it starts up.
datagrid-infinispan.store.class=The custom store implementation class to use for this cache store.
datagrid-infinispan.store.write-behind=Child to configure a cache store as write-behind instead of write-through.
datagrid-infinispan.store.properties=A list of cache store properties.
datagrid-infinispan.store.properties.property=A cache store property with name and value.
datagrid-infinispan.store.property=A cache store property with name and value.

datagrid-infinispan.write-behind=Configures a cache store as write-behind instead of write-through.
datagrid-infinispan.write-behind.flush-lock-timeout=Timeout to acquire the lock which guards the state to be flushed to the cache store periodically.
datagrid-infinispan.write-behind.modification-queue-size=Maximum number of entries in the asynchronous queue. When the queue is full, the store becomes write-through until it can accept new entries.
datagrid-infinispan.write-behind.shutdown-timeout=Timeout in milliseconds to stop the cache store.
datagrid-infinispan.write-behind.thread-pool-size=Size of the thread pool whose threads are responsible for applying the modifications to the cache store.
datagrid-infinispan.write-behind.add=Adds a write-behind configuration element to the store.
datagrid-infinispan.write-behind.remove=Removes a write-behind configuration element from the store.

datagrid-infinispan.properties=A list of cache store properties.
datagrid-infinispan.properties.property=A cache store property with name and value.
datagrid-infinispan.property=A cache store property with name and value.
datagrid-infinispan.property.value=The value of the cache store property.
datagrid-infinispan.property.add=Adds a cache store property.
datagrid-infinispan.property.remove=Removes a cache store property.

datagrid-infinispan.file-store=The cache file store configuration.
datagrid-infinispan.file-store.max-entries=The maximum number of entries.
datagrid-infinispan.file-store.relative-to=The path this is relative to
datagrid-infinispan.file-store.path=An absolute path if relativeTo is null, otherwise the relative path to relativeTo
datagrid-infinispan.file-store.add=Adds a file cache store configuration element to the cache.
datagrid-infinispan.file-store.remove=Removes a cache file store configuration element from the cache.

datagrid-infinispan.jdbc-store=The cache JDBC store configuration.
datagrid-infinispan.jdbc-store.add=Adds a JDBC cache store configuration element to the cache.
datagrid-infinispan.jdbc-store.datasource=A datasource reference for this datastore.
datagrid-infinispan.jdbc-store.dialect=The dialect of this datastore.
datagrid-infinispan.jdbc-store.db-major-version=The major version of this datastore.
datagrid-infinispan.jdbc-store.db-minor-version=The minor version of this datastore.
datagrid-infinispan.jdbc-store.entry-table=The database table used to store cache entries.
datagrid-infinispan.jdbc-store.string-keyed-table=The database table used to store cache entries.
datagrid-infinispan.jdbc-store.string-keyed-table.table.prefix=The prefix for the database table name.
datagrid-infinispan.jdbc-store.string-keyed-table.table.batch-size=For DB inserts, the batch size determines how many inserts are batched together.
datagrid-infinispan.jdbc-store.string-keyed-table.table.batch-size.deprecated=Deprecated. The store's max-batch-size property should be set instead.
datagrid-infinispan.jdbc-store.string-keyed-table.table.fetch-size=For DB queries, the fetch size will be used to set the fetch size on ResultSets.
datagrid-infinispan.jdbc-store.string-keyed-table.table.create-on-start=Determines whether database tables should be created by the store on startup.
datagrid-infinispan.jdbc-store.string-keyed-table.table.drop-on-exit=Determines whether database tables should be dropped by the store on shutdown.
datagrid-infinispan.jdbc-store.string-keyed-table.table.id-column=A database column to hold cache entry ids.
datagrid-infinispan.jdbc-store.string-keyed-table.table.data-column=A database column to hold cache entry data.
datagrid-infinispan.jdbc-store.string-keyed-table.table.timestamp-column=A database column to hold cache entry timestamps.
datagrid-infinispan.jdbc-store.string-keyed-table.table.column.name=The name of the database column.
datagrid-infinispan.jdbc-store.string-keyed-table.table.column.type=The type of the database column.

datagrid-infinispan.string-keyed-jdbc-store=The string keyed cache JDBC store configuration.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table=The database table used to store cache entries.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.prefix=The prefix for the database table name.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.batch-size=For DB inserts, the batch size determines how many inserts are batched together.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.batch-size.deprecated=Deprecated. The store's max-batch-size property should be set instead.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.fetch-size=For DB queries, the fetch size will be used to set the fetch size on ResultSets.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.create-on-start=Determines whether database tables should be created by the store on startup.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.drop-on-exit=Determines whether database tables should be dropped by the store on shutdown.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.id-column=A database column to hold cache entry ids.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.data-column=A database column to hold cache entry data.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.timestamp-column=A database column to hold cache entry timestamps.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.column.name=The name of the database column.
datagrid-infinispan.string-keyed-jdbc-store.string-keyed-table.table.column.type=The type of the database column.
datagrid-infinispan.string-keyed-jdbc-store.add=Adds a JDBC cache store configuration element to the cache.
datagrid-infinispan.string-keyed-jdbc-store.remove=Removes a JDBC cache store configuration element from the cache.

datagrid-infinispan.remote-store=The cache remote store configuration.
datagrid-infinispan.remote-store.cache=The name of the remote cache to use for this remote store.
datagrid-infinispan.remote-store.hotrod-wrapping=Enables wrapping of entries into a form usable by a HotRod server
datagrid-infinispan.remote-store.raw-values=Stores information on the remote cache in a raw format suitable for interoperability with other RemoteCacheManagers
datagrid-infinispan.remote-store.tcp-no-delay=A TCP_NODELAY value for remote cache communication.
datagrid-infinispan.remote-store.socket-timeout=A socket timeout for remote cache communication.
datagrid-infinispan.remote-store.protocol-version=The protocol version to use for remote cache communication.
datagrid-infinispan.remote-store.remote-servers=A list of remote servers for this cache store.
datagrid-infinispan.remote-store.remote.servers.remote-server=A remote server, defined by its outbound socket binding.
datagrid-infinispan.remote-store.remote-servers.remote-server.outbound-socket-binding=An outbound socket binding for a remote server.
datagrid-infinispan.remote-store.add=Adds a remote cache store configuration element to the cache.
datagrid-infinispan.remote-store.remove=Removes a remote cache store configuration element from the cache.

datagrid-infinispan.remote-store.authentication=Enables authentication to the remote store
datagrid-infinispan.remote-store.authentication.password=The password if required by the SASL mechanism
datagrid-infinispan.remote-store.authentication.username=The username if required by the SASL mechanism
datagrid-infinispan.remote-store.authentication.realm=The SASL realm
datagrid-infinispan.remote-store.authentication.mechanism=The SASL mechanism
datagrid-infinispan.remote-store.authentication.server-name=The SASL server name
datagrid-infinispan.remote-store.authentication.add=
datagrid-infinispan.remote-store.authentication.remove=
datagrid-infinispan.remote-store.encryption=Enables encrypted communication to the remote store
datagrid-infinispan.remote-store.encryption.sni-hostname=
datagrid-infinispan.remote-store.encryption.security-realm=The Security Realm that provides the truststore
datagrid-infinispan.remote-store.encryption.add=
datagrid-infinispan.remote-store.encryption.remove=


datagrid-infinispan.rest-store=The cache REST store configuration.
datagrid-infinispan.rest-store.path=The path portion of the URI of the remote REST endpoint.
datagrid-infinispan.rest-store.append-cache-name-to-path=Whether to append the name of the cache to the path.
datagrid-infinispan.rest-store.max-content-length=The maximum allowed size for requests.
datagrid-infinispan.rest-store.connection-pool=The configuration of the HTTP connection pool
datagrid-infinispan.rest-store.connection-pool.connection-timeout=A connection timeout for remote cache communication.
datagrid-infinispan.rest-store.connection-pool.max-connections-per-host=The maximum number of connections per host.
datagrid-infinispan.rest-store.connection-pool.max-total-connections=The maximum number of total connections.
datagrid-infinispan.rest-store.connection-pool.buffer-size=The size of the socket buffer.
datagrid-infinispan.rest-store.connection-pool.socket-timeout=A socket timeout for remote cache communication.
datagrid-infinispan.rest-store.connection-pool.tcp-no-delay=A TCP_NODELAY value for remote cache communication.
datagrid-infinispan.rest-store.remote-servers=A list of remote servers for this cache store.
datagrid-infinispan.rest-store.remote.servers.remote-server=A remote server, defined by its outbound socket binding.
datagrid-infinispan.rest-store.remote-servers.remote-server.outbound-socket-binding=An outbound socket binding for a remote server.
datagrid-infinispan.rest-store.add=Adds a REST cache store configuration element to the cache.
datagrid-infinispan.rest-store.remove=Removes a REST cache store configuration element from the cache.

datagrid-infinispan.backup=The backup site configuration for the cache.
datagrid-infinispan.backup.add=Add the backup configuration to the cache.
datagrid-infinispan.backup.remove=Remove the backup configuration from the cache.
datagrid-infinispan.backup.strategy=The strategy to use for the cache backup.
datagrid-infinispan.backup.failure-policy=The failure policy to use for the cache backup.
datagrid-infinispan.backup.enabled=If enabled, the cache will be backed-up to the remote site.
datagrid-infinispan.backup.timeout=The time to wait for responses from the backup site.
datagrid-infinispan.backup.after-failures=The number of failed request operations after which this site should be taken offline.
datagrid-infinispan.backup.min-wait=The minimal number of millis to wait before taking this site offline, even in the case 'after-failures' is reached.
datagrid-infinispan.backup.take-site-offline=Determines whether this backup is taken offline (ignored) after a certain number of tries.
# cross-site backup operations
datagrid-infinispan.backup.ops.site-status=Displays the current status of the backup site.
datagrid-infinispan.backup.ops.bring-site-online=Re-enables a previously disabled backup site.
datagrid-infinispan.backup.ops.take-site-offline=Disables backup to a remote site.

datagrid-infinispan.backup.state-transfer=The backup site state transfer configuration for the cache.
datagrid-infinispan.backup.state-transfer.add=Add the backup site state transfer configuration to the cache.
datagrid-infinispan.backup.state-transfer.remove=Remove the backup site state transfer configuration from the cache.
datagrid-infinispan.backup.state-transfer.chunk-size=The number of entries to batch to transfer.
datagrid-infinispan.backup.state-transfer.timeout=The timeout, in milliseconds, to wait from the remote site reply.
datagrid-infinispan.backup.state-transfer.wait-time=The waiting time, in milliseconds, before retrying.
datagrid-infinispan.backup.state-transfer.max-retries=The maximum number of retries.
datagrid-infinispan.backup.ops.push-state=Pushes the state of this cache to the remote site.
datagrid-infinispan.backup.ops.cancel-push=Cancels the push state to remote site.
datagrid-infinispan.backup.ops.cancel-receive=Cancels the push state to this site.
datagrid-infinispan.backup.ops.clear-push-state-status=Clears the push state status.
datagrid-infinispan.backup.ops.get-sending-site=Returns the site name from which this site is receiving state.
datagrid-infinispan.backup.ops.push-state-status=Shows a map with destination site name and the push state status.

datagrid-infinispan.compatibility=Compatibility-mode configuration for the cache.
datagrid-infinispan.compatibility.add=Adds compatibility-mode configuration to a cache.
datagrid-infinispan.compatibility.remove=Removes compatibility-mode configuration from a cache.
datagrid-infinispan.compatibility.enabled=Enables compatibility mode for the cache.
datagrid-infinispan.compatibility.marshaller=The marshaller to use for compatibility mode.

datagrid-infinispan.rocksdb-store=The RocksDB store configuration.
datagrid-infinispan.rocksdb-store.relative-to=The path this is relative to
datagrid-infinispan.rocksdb-store.path=An absolute path if relativeTo is null, otherwise the relative path to relativeTo
datagrid-infinispan.rocksdb-store.add=Adds a RocksDB cache store configuration element to the cache
datagrid-infinispan.rocksdb-store.remove=Removes a RocksDB cache store configuration element from the cache
datagrid-infinispan.rocksdb-store.block-size=The cache store block size
datagrid-infinispan.rocksdb-store.cache-size=Cache size for the cache store
datagrid-infinispan.rocksdb-store.clear-threshold=Cache store cache clear threshold

datagrid-infinispan.rocksdb-store.expiration-db=The expiration configuration to the store
datagrid-infinispan.rocksdb-store.expiration-db.add=Adds the expiration configuration to the store
datagrid-infinispan.rocksdb-store.expiration-db.remove=Removes the expiration configuration from the store
datagrid-infinispan.rocksdb-store.expiration-db.path=Path for cache store expiration data.
datagrid-infinispan.rocksdb-store.expiration-db.queue-size=Store expiration queue size

datagrid-infinispan.rocksdb-store.compression=The cache store data compression mechanism
datagrid-infinispan.rocksdb-store.compression.type=Type of data compression to use in store
datagrid-infinispan.rocksdb-store.compression.add=Adds a compression configuration element to the store
datagrid-infinispan.rocksdb-store.compression.remove=Removes the compression configuration element from the store

datagrid-infinispan.cache-container.global-state=The global state configuration of a cache container
datagrid-infinispan.cache-container.global-state.add=Add global state configuration to a cache container
datagrid-infinispan.cache-container.global-state.remove=Remove global state configuration from a cache container
datagrid-infinispan.cache-container.global-state.temporary-location=The filesystem location where temporary data will be stored
datagrid-infinispan.cache-container.global-state.temporary-location.path=The path portion of the temporary location
datagrid-infinispan.cache-container.global-state.temporary-location.relative-to=The relative-to portion of the temporary location
datagrid-infinispan.cache-container.global-state.persistent-location=The filesystem location where persistent state data will be stored
datagrid-infinispan.cache-container.global-state.persistent-location.path=The path portion of the persistent state location
datagrid-infinispan.cache-container.global-state.persistent-location.relative-to=The relative-to portion of the persistent state location
datagrid-infinispan.cache-container.global-state.shared-persistent-location=The filesystem location where shared persistent state data will be stored
datagrid-infinispan.cache-container.global-state.shared-persistent-location.path=The path portion of the shared persistent state location
datagrid-infinispan.cache-container.global-state.shared-persistent-location.relative-to=The relative-to portion of the shared persistent state location
datagrid-infinispan.cache-container.global-state.configuration-storage=The type of configuration storage for runtime-defined caches
datagrid-infinispan.cache-container.global-state.configuration-storage-class=The class for a custom configuration storage

datagrid-infinispan.cache-container.security=The security configuration of a cache container
datagrid-infinispan.cache-container.security.add=Add security configuration to a cache container
datagrid-infinispan.cache-container.security.remove=Remove security configuration from a cache container

datagrid-infinispan.cache-container.security.authorization=The authorization configuration of a cache container
datagrid-infinispan.cache-container.security.authorization.add=Add authorization configuration to a cache container
datagrid-infinispan.cache-container.security.authorization.remove=Remove authorization configuration from a cache container
datagrid-infinispan.cache-container.security.authorization.audit-logger=Specify logger to be used for auditing messages
datagrid-infinispan.cache-container.security.authorization.mapper=Specify a principal to role mapper
datagrid-infinispan.cache-container.security.authorization.enabled=Enables authorization checks for the cache container
datagrid-infinispan.cache-container.security.authorization.role=Describes a role and the access permissions it has
datagrid-infinispan.cache-container.security.authorization.role.add=Adds a role to the authorization configuration
datagrid-infinispan.cache-container.security.authorization.role.remove=Removes a role from the authorization configuration
datagrid-infinispan.cache-container.security.authorization.role.permissions=Specifies the set of permissions assigned to a role

datagrid-infinispan.cache-container.sites-view=The view containing site membership

datagrid-infinispan.cache.security=The security configuration of a cache
datagrid-infinispan.cache.security.add=Adds security configuration to a cache
datagrid-infinispan.cache.security.remove=Remove security configuration from a cache

datagrid-infinispan.cache.security.authorization=The authorization configuration of a cache
datagrid-infinispan.cache.security.authorization.add=Adds authorization configuration to a cache
datagrid-infinispan.cache.security.authorization.remove=Removes authorization configuration from a cache
datagrid-infinispan.cache.security.authorization.enabled=Enables authorization checks for a cache
datagrid-infinispan.cache.security.authorization.roles=The list of roles which are allowed to access a cache

datagrid-infinispan.cache-container.configurations=Configuration definitions
datagrid-infinispan.cache-container.configurations.add=Adds configuration definitions
datagrid-infinispan.cache-container.configurations.remove=Removes configuration definitions

datagrid-infinispan.local-cache-configuration=A local cache configuration
datagrid-infinispan.local-cache-configuration.add=Add a local cache configuration to this cache container
datagrid-infinispan.local-cache-configuration.remove=Remove a local cache configuration from this cache container

datagrid-infinispan.invalidation-cache-configuration=An invalidation cache configuration
datagrid-infinispan.invalidation-cache-configuration.add=Add an invalidation cache configuration to this cache container
datagrid-infinispan.invalidation-cache-configuration.remove=Remove an invalidation cache configuration from this cache container

datagrid-infinispan.replicated-cache-configuration=A replicated cache configuration
datagrid-infinispan.replicated-cache-configuration.add=Add a replicated cache configuration to this cache container
datagrid-infinispan.replicated-cache-configuration.remove=Remove a replicated cache configuration from this cache container

datagrid-infinispan.distributed-cache-configuration=A distributed cache configuration
datagrid-infinispan.distributed-cache-configuration.add=Add a distributed cache configuration to this cache container
datagrid-infinispan.distributed-cache-configuration.remove=Remove a distributed cache configuration from this cache container

datagrid-infinispan.cache-container.configurations.local-cache-configuration=
datagrid-infinispan.cache-container.configurations.invalidation-cache-configuration=
datagrid-infinispan.cache-container.configurations.replicated-cache-configuration=
datagrid-infinispan.cache-container.configurations.distributed-cache-configuration=

datagrid-infinispan.cache-container.health=Health check API
datagrid-infinispan.cache-container.health.cache-health=Cache health
datagrid-infinispan.cache-container.health.free-memory=Free memory in KB
datagrid-infinispan.cache-container.health.total-memory=Total memory in KB
datagrid-infinispan.cache-container.health.cluster-name=Cluster name
datagrid-infinispan.cache-container.health.number-of-cpus=Number of CPUs
datagrid-infinispan.cache-container.health.cluster-health=Cluster health (UNHEALTHY, REBALANCING or HEALTHY)
datagrid-infinispan.cache-container.health.number-of-nodes=Number of nodes in the cluster
datagrid-infinispan.cache-container.health.add=Add Health Check API
datagrid-infinispan.cache-container.health.remove=Removed Health Check API
datagrid-infinispan.cache-container.health.log-tail=Last 10 lines of the log file

# counters
datagrid-infinispan.counter = A cluster counter
datagrid-infinispan.cache-container.counter = A cluster counter

datagrid-infinispan.cache-container.configurations.counters = Cluster counters
datagrid-infinispan.cache-container.configurations.counters.add = Add new counter
datagrid-infinispan.cache-container.configurations.counters.remove = Remove counter

datagrid-infinispan.cache-container.counters.num-owners = "Number of counter copies to keep cluster-wide"
datagrid-infinispan.cache-container.counters.reliability = "Counter update behavior in a network partition"

datagrid-infinispan.cache-container.counters = Cluster counters
datagrid-infinispan.cache-container.counters.add = Add new counter
datagrid-infinispan.cache-container.counters.remove = Remove counter

datagrid-infinispan.cache-container.counters.name=The counter's name
datagrid-infinispan.cache-container.counters.type=The counter's type (weak, strong bounded or strong unbounded)
datagrid-infinispan.cache-container.counters.storage=The counter's storage mode (volatile or persistent)
datagrid-infinispan.cache-container.counters.initial-value=The counter's initial value
datagrid-infinispan.cache-container.counters.upper-bound=The counter's upper-bound, if strong and bounded
datagrid-infinispan.cache-container.counters.lower-bound=The counter's lower-bound, if strong and bounded
datagrid-infinispan.cache-container.counters.concurrency-level=The counter's concurrency-level, if weak
datagrid-infinispan.cache-container.counters.value=The counter's value
datagrid-infinispan.cache-container.counters.counter-reset=Resets the counter value to initial value
datagrid-infinispan.cache-container.counters.counter-increase=Increase the counter value by 1
datagrid-infinispan.cache-container.counters.counter-decrease=Decrease the counter value by 1
datagrid-infinispan.cache-container.counters.counter-set=Set counter value
datagrid-infinispan.cache-container.counters.strong-counter="A strong counter"
datagrid-infinispan.cache-container.counters.weak-counter="A weak counter"

datagrid-infinispan.counters = Cluster counters
datagrid-infinispan.counters.add = Add new counter
datagrid-infinispan.counters.remove = Remove counter

datagrid-infinispan.counters.name=The counter's name
datagrid-infinispan.counters.type=The counter's type (weak, strong bounded or strong unbounded)
datagrid-infinispan.counters.storage=The counter's storage mode (volatile or persistent)
datagrid-infinispan.counters.initial-value=The counter's initial value
datagrid-infinispan.counters.upper-bound=The counter's upper-bound, if strong and bounded
datagrid-infinispan.counters.lower-bound=The counter's lower-bound, if strong and bounded
datagrid-infinispan.counters.concurrency-level=The counter's concurrency-level, if weak
datagrid-infinispan.counters.value=The counter's value
datagrid-infinispan.counters.counter-reset=Resets the counter value to initial value
datagrid-infinispan.counters.counter-increase=Increase the counter value by 1
datagrid-infinispan.counters.counter-decrease=Decrease the counter value by 1
datagrid-infinispan.counters.counter-set=Set counter value
datagrid-infinispan.counters.strong-counter="A strong counter"
datagrid-infinispan.counters.weak-counter="A weak counter"

# TODO
datagrid-infinispan.soft-index-file-store=The SoftIndexFileStore
datagrid-infinispan.soft-index-file-store.add=Adds a SoftIndexFileStore configuration element to the cache.
datagrid-infinispan.soft-index-file-store.remove=Remove a SoftIndexFileStore configuration element from the cache.
datagrid-infinispan.soft-index-file-store.compaction-threshold=If amount of unused space in some data file gets above this threshold, the file is compacted - entries from that file are copied to a new file and the old file is deleted.
datagrid-infinispan.soft-index-file-store.open-files-limit=Max number of data files opened for reading (current log file, compaction output and index segments are not included here).
datagrid-infinispan.soft-index-file-store.data=Configure where and how should be the entries stored - this is the persistent location.
datagrid-infinispan.soft-index-file-store.data.add=Add configuration element for SoftIndexFileStore data
datagrid-infinispan.soft-index-file-store.data.remove=Remove configuration element for SoftIndexFileStore data
datagrid-infinispan.soft-index-file-store.data.path=A location on disk where the store writes entries. Files are written sequentially, reads are random.
datagrid-infinispan.soft-index-file-store.data.max-file-size=Max size of single file with entries, in bytes.
datagrid-infinispan.soft-index-file-store.data.sync-writes=If true, the write is confirmed only after the entry is fsynced on disk.
datagrid-infinispan.soft-index-file-store.index=Configure where and how should be the index stored.
datagrid-infinispan.soft-index-file-store.index.add=Add configuration element for SoftIndexFileStore indexes
datagrid-infinispan.soft-index-file-store.index.remove=Remove configuration element for SoftIndexFileStore indexes
datagrid-infinispan.soft-index-file-store.index.path=A location where the store keeps index - this does not have be persistent across restarts, and SSD storage is recommended (the index is accessed randomly).
datagrid-infinispan.soft-index-file-store.index.max-queue-length=Max number of entry writes that are waiting to be written to the index, per index segment.
datagrid-infinispan.soft-index-file-store.index.max-node-size=Max size of node (continuous block on filesystem used in index implementation), in bytes.
datagrid-infinispan.soft-index-file-store.index.min-node-size=If the size of node (continuous block on filesystem used in index implementation) drops below this threshold, the node will try to balance its size with some neighbour node, possibly causing join of multiple nodes.
datagrid-infinispan.soft-index-file-store.index.segments=Number of index segment files. Increasing this value improves throughput but requires more threads to be spawned.




© 2015 - 2025 Weber Informatics LLC | Privacy Policy