JMX Components available






Component Activation (Class org.infinispan.eviction.impl.ActivationManagerImpl)
Component that handles activating entries that have been passivated to a CacheStore by loading them into memory.
Attributes
Name Description Type Writable
ActivationsNumber of activation eventsStringfalse
statisticsEnabledEnables or disables the gathering of statistics by this componentbooleantrue
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component Cache (Class org.infinispan.cache.impl.SimpleCacheImpl)
Component that represents a simplified cache instance.
Attributes
Name Description Type Writable
CacheNameReturns the cache nameStringfalse
CacheStatusReturns the cache statusStringfalse
ConfigurationAsPropertiesReturns the cache configuration in form of propertiesPropertiesfalse
VersionReturns the version of InfinispanStringfalse
Operations
Name Description Signature
clearClears the cachevoid clear()
startStarts the cache.void start()
stopStops the cache.void stop()


Component Cache (Class org.infinispan.cache.impl.CacheImpl)
Component that represents an individual cache instance.
Attributes
Name Description Type Writable
CacheAvailabilityReturns the cache availabilityStringtrue
CacheNameReturns the cache nameStringfalse
CacheStatusReturns the cache statusStringfalse
ConfigurationAsPropertiesReturns the cache configuration in form of propertiesPropertiesfalse
RebalancingEnabledReturns whether cache rebalancing is enabledbooleantrue
VersionReturns the version of InfinispanStringfalse
Operations
Name Description Signature
clearClears the cachevoid clear()
startStarts the cache.void start()
stopStops the cache.void stop()


Component CacheContainerStats (Class org.infinispan.stats.impl.CacheContainerStatsImpl)
General cache container statistics such as timings, hit/miss ratio, etc.
Attributes
Name Description Type Writable
AverageReadTimeCache container total average number of milliseconds for all read operation in this cache containerlongfalse
AverageRemoveTimeCache container total average number of milliseconds for all remove operation in this cache containerlongfalse
AverageWriteTimeCache container average number of milliseconds for all write operation in this cache containerlongfalse
EvictionsCache container total number of cache eviction operationslongfalse
HitRatioCache container total percentage hit/(hit+miss) ratio for this cachedoublefalse
HitsCache container total number of cache attribute hitslongfalse
MissesCache container total number of cache attribute misseslongfalse
NumberOfEntriesCache container total number of entries currently in all caches from this cache containerintfalse
ReadWriteRatioCache container read/writes ratio in all caches from this cache containerdoublefalse
RemoveHitsCache container total number of cache removal hitslongfalse
RemoveMissesCache container total number of cache removals where keys were not foundlongfalse
StatisticsEnabledEnables or disables the gathering of statistics by this componentbooleantrue
StoresCache container total number of cache attribute put operationslongfalse
TimeSinceResetNumber of seconds since the cache container statistics were last resetlongfalse


Component CacheLoader (Class org.infinispan.interceptors.CacheLoaderInterceptor)
Component that handles loading entries from a CacheStore into memory.
Attributes
Name Description Type Writable
CacheLoaderLoadsNumber of entries loaded from cache storelongfalse
CacheLoaderMissesNumber of entries that did not exist in cache storelongfalse
StoresReturns a collection of cache loader types which are configured and enabledCollectionfalse
Operations
Name Description Signature
disableStoreDisable all stores of a given type, where type is a fully qualified class name of the cache loader to disablevoid disableStore(String p0)
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component CacheManager (Class org.infinispan.manager.DefaultCacheManager)
Component that acts as a manager, factory and container for caches in the system.
Attributes
Name Description Type Writable
CacheManagerStatusThe status of the cache manager instance.Stringfalse
ClusterMembersList of members in the clusterStringfalse
ClusterNameCluster nameStringfalse
ClusterSizeSize of the cluster in number of nodesintfalse
CoordinatorIndicates whether this node is coordinatorbooleanfalse
CoordinatorAddressThe logical address of the cluster's coordinatorStringfalse
CreatedCacheCountThe total number of created caches, including the default cache.Stringfalse
DefinedCacheConfigurationNamesThe defined cache configuration names.Stringfalse
DefinedCacheCountThe total number of defined cache configurations.Stringfalse
DefinedCacheNamesThe defined cache names and their statuses. The default cache is not included in this representation.Stringfalse
GlobalConfigurationAsPropertiesGlobal configuration propertiesPropertiesfalse
NameThe name of this cache managerStringfalse
NodeAddressThe network address associated with this instanceStringfalse
PhysicalAddressesThe physical network addresses associated with this instanceStringfalse
RunningCacheCountThe total number of running caches, including the default cache.Stringfalse
VersionReturns the version of InfinispanStringfalse
Operations
Name Description Signature
startCacheStarts the default cache associated with this cache managervoid startCache()
startCacheStarts a named cache from this cache managervoid startCache(String p0)


Component CacheStore (Class org.infinispan.interceptors.CacheWriterInterceptor)
Component that handles storing of entries to a CacheStore from memory.
Attributes
Name Description Type Writable
WritesToTheStoresNumber of writes to the storelongfalse
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component CacheUsageStatistics (Class org.infinispan.stats.topK.CacheUsageInterceptor)
Keeps tracks of the accessed keys
Attributes
Name Description Type Writable
CapacityShows the current capacity for top-K valuesintfalse
LocalTopGetsShow the top 10 keys most read locally by this instanceMapfalse
LocalTopPutsShow the top 10 keys most write locally by this instanceMapfalse
RemoteTopGetsShow the top 10 keys most read remotely by this instanceMapfalse
RemoteTopPutsShow the top 10 keys most write remotely by this instanceMapfalse
TopContendedKeysShow the top 10 keys most contendedMapfalse
TopLockFailedKeysShow the top 10 keys whose lock acquisition failed by timeoutMapfalse
TopLockedKeysShow the top 10 keys most lockedMapfalse
TopWriteSkewFailedKeysShow the top 10 keys whose write skew check was failedMapfalse
Operations
Name Description Signature
getNLocalTopGetsShow the top n keys most read locally by this instanceMap getNLocalTopGets(int p0)
getNLocalTopPutsShow the top n keys most write locally by this instanceMap getNLocalTopPuts(int p0)
getNRemoteTopGetsShow the top n keys most read remotely by this instanceMap getNRemoteTopGets(int p0)
getNRemoteTopPutsShow the top n keys most write remotely by this instanceMap getNRemoteTopPuts(int p0)
getNTopContendedKeysShow the top n keys most contendedMap getNTopContendedKeys(int p0)
getNTopLockFailedKeysShow the top n keys whose lock acquisition failed Map getNTopLockFailedKeys(int p0)
getNTopLockedKeysShow the top n keys most lockedMap getNTopLockedKeys(int p0)
getNTopWriteSkewFailedKeysShow the top n keys whose write skew check was failedMap getNTopWriteSkewFailedKeys(int p0)
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()
setStatisticsEnabledShow the top n keys whose write skew check was failedvoid setStatisticsEnabled(boolean p0)
setTopKValueSet K for the top-K valuesvoid setTopKValue(int p0)


Component ClusterCacheStats (Class org.infinispan.stats.impl.ClusterCacheStatsImpl)
General cluster statistics such as timings, hit/miss ratio, etc.
Attributes
Name Description Type Writable
ActivationsThe total number of activations in the clusterlongfalse
AverageReadTimeCluster wide total average number of milliseconds for a read operation on the cachelongfalse
AverageRemoveTimeCluster wide total average number of milliseconds for a remove operation in the cachelongfalse
AverageWriteTimeCluster wide average number of milliseconds for a write operation in the cachelongfalse
CacheLoaderLoadsThe total number of cacheloader load operations in the clusterlongfalse
CacheLoaderMissesThe total number of cacheloader load misses in the clusterlongfalse
EvictionsCluster wide total number of cache eviction operationslongfalse
HitRatioCluster wide total percentage hit/(hit+miss) ratio for this cachedoublefalse
HitsCluster wide total number of cache attribute hitslongfalse
InvalidationsThe total number of invalidations in the clusterlongfalse
MissesCluster wide total number of cache attribute misseslongfalse
NumberOfEntriesCluster wide total number of entries currently in the cacheintfalse
NumberOfLocksAvailableTotal number of exclusive locks available in the clusterintfalse
NumberOfLocksHeldTotal number of locks held in the clusterintfalse
PassivationsThe total number of passivations in the clusterlongfalse
ReadWriteRatioCluster wide read/writes ratio for the cachedoublefalse
RemoveHitsCluster wide total number of cache removal hitslongfalse
RemoveMissesCluster wide total number of cache removals where keys were not foundlongfalse
StatisticsEnabledEnables or disables the gathering of statistics by this componentbooleantrue
StoreWritesThe total number of cachestore store operations in the clusterlongfalse
StoresCluster wide total number of cache attribute put operationslongfalse
TimeSinceResetNumber of seconds since the cluster-wide cache statistics were last resetlongfalse
TimeSinceStartNumber of seconds since the first cache node startedlongfalse
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()
setStaleStatsTresholdSets the treshold for cluster wide stats refresh (miliseconds)void setStaleStatsTreshold(long p0)


Component Configuration (Class org.infinispan.cache.impl.CacheConfigurationMBean)
Runtime cache configuration attributes
Attributes
Name Description Type Writable
EvictionSizeGets the eviction size for the cachelongtrue


Component DeadlockDetectingLockManager (Class org.infinispan.util.concurrent.locks.DeadlockDetectingLockManager)
Information about the number of deadlocks that were detected
Attributes
Name Description Type Writable
DetectedLocalDeadlocksNumber of local transactions that were rolled-back due to deadlockslongfalse
DetectedRemoteDeadlocksNumber of remote transactions that were rolled-back due to deadlockslongfalse
OverlapWithNotDeadlockAwareLockOwnersNumber of situations when we try to determine a deadlock and the other lock owner is NOT a transaction. In this scenario we cannot run the deadlock detection mechanismlongfalse
TotalNumberOfDetectedDeadlocksTotal number of local detected deadlockslongfalse
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component DistributionManager (Class org.infinispan.distribution.impl.DistributionManagerImpl)
Component that handles distribution of content across a cluster
Operations
Name Description Signature
isAffectedByRehashDetermines whether a given key is affected by an ongoing rehash, if any.boolean isAffectedByRehash(Object p0)
isLocatedLocallyTells you whether a given key is local to this instance of the cache according to the consistent hashing algorithm. Only works with String keys. This operation might return true even if the object does not exist in the cache.boolean isLocatedLocally(String p0)
locateKeyShows the addresses of the nodes where a put operation would store the entry associated with the specified key. Only works with String keys. The list of potential owners is returned even if the object does not exist in the cache.List locateKey(String p0)


Component ExtendedStatistics (Class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor)
Component that manages and exposes extended statistics relevant to transactions.
Attributes
Name Description Type Writable
AbortRateAbort Ratedoublefalse
AvailableExtendedStatisticsReturns all the available statisticsStringfalse
AvgAbortedWriteTxDurationAverage aborted write transaction duration (in microseconds)doublefalse
AvgClusteredGetCommandSizeAverage clustered get command size (in bytes)doublefalse
AvgCommitAsyncAverage asynchronous Commit duration (in microseconds)doublefalse
AvgCommitCommandSizeAverage commit command size (in bytes)doublefalse
AvgCommitRttAverage Commit Round-Trip Time duration (in microseconds)doublefalse
AvgCommitTimeAverage local commit duration time (2nd phase only) (in microseconds)doublefalse
AvgCompleteNotificationAsyncAverage asynchronous Complete Notification duration (in microseconds)doublefalse
AvgGetsPerROTransactionAverage number of get operations per (local) read-only transactiondoublefalse
AvgGetsPerWrTransactionAverage number of get operations per (local) read-write transactiondoublefalse
AvgLocalCommitTimeAverage time it takes to execute the commit command locally (in microseconds)doublefalse
AvgLocalGetTimeAverage Local processing Get time (in microseconds)doublefalse
AvgLocalLockHoldTimeAverage lock local holding time (in microseconds)doublefalse
AvgLocalPrepareTimeAverage time it takes to execute the prepare command locally (in microseconds)doublefalse
AvgLocalRollbackTimeAverage time it takes to execute the rollback command locally (in microseconds)doublefalse
AvgLockHoldTimeAverage lock holding time (in microseconds)doublefalse
AvgLockWaitingTimeAverage time waiting for the lock acquisition (in microseconds)doublefalse
AvgNumNodesCommitAverage number of nodes in Commit destination setdoublefalse
AvgNumNodesCompleteNotificationAverage number of nodes in Complete Notification destination setdoublefalse
AvgNumNodesPrepareAverage number of nodes in Prepare destination setdoublefalse
AvgNumNodesRemoteGetAverage number of nodes in Remote Get destination setdoublefalse
AvgNumNodesRollbackAverage number of nodes in Rollback destination setdoublefalse
AvgNumOfLockLocalTxAverage number of locks per write local transactiondoublefalse
AvgNumOfLockRemoteTxAverage number of locks per write remote transactiondoublefalse
AvgNumOfLockSuccessLocalTxAverage number of locks per successfully write local transactiondoublefalse
AvgPrepareAsyncAverage asynchronous Prepare duration (in microseconds)doublefalse
AvgPrepareCommandSizeAverage prepare command size (in bytes)doublefalse
AvgPrepareRttAverage Prepare Round-Trip Time duration (in microseconds)doublefalse
AvgPutsPerWrTransactionAverage number of put operations per (local) read-write transactiondoublefalse
AvgReadOnlyTxDurationAverage successful read-only transaction duration (in microseconds)doublefalse
AvgRemoteCommitTimeAverage time it takes to execute the commit command remotely (in microseconds)doublefalse
AvgRemoteGetRttAverage Remote Get Round-Trip Time duration (in microseconds)doublefalse
AvgRemoteGetsPerROTransactionAverage number of remote get operations per (local) read-only transactiondoublefalse
AvgRemoteGetsPerWrTransactionAverage number of remote get operations per (local) read-write transactiondoublefalse
AvgRemoteLockHoldTimeAverage lock remote holding time (in microseconds)doublefalse
AvgRemotePrepareTimeAverage time it takes to execute the prepare command remotely (in microseconds)doublefalse
AvgRemotePutsPerWrTransactionAverage number of remote put operations per (local) read-write transactiondoublefalse
AvgRemoteRollbackTimeAverage time it takes to execute the rollback command remotely (in microseconds)doublefalse
AvgResponseTimeAverage Response Timedoublefalse
AvgRollbackAsyncAverage asynchronous Rollback duration (in microseconds)doublefalse
AvgRollbackRttAverage Rollback Round-Trip Time duration (in microseconds)doublefalse
AvgRollbackTimeAverage local rollback duration time (2nd phase only) (in microseconds)doublefalse
AvgTxArrivalRateAverage transaction arrival rate, originated locally and remotely (in transaction per second)doublefalse
AvgWriteTxDurationAverage successful write transaction duration (in microseconds)doublefalse
LocalActiveTransactionsNumber of concurrent transactions executing on the current nodedoublefalse
LocalExecutionTimeWithoutLockLocal execution time of a transaction without the time waiting for lock acquisitiondoublefalse
NumAbortedTxDueDeadlockThe number of aborted transactions due to deadlockdoublefalse
NumAbortedTxDueTimeoutThe number of aborted transactions due to timeout in lock acquisitiondoublefalse
NumNodesNumber of nodes in the clusterdoublefalse
NumberOfCommitsNumber of committed transactions since last resetdoublefalse
NumberOfGetsNumber of gets performed since last resetdoublefalse
NumberOfLocalCommitsNumber of local committed transactions since last resetdoublefalse
NumberOfPutsNumber of puts performed since last resetdoublefalse
NumberOfRemoteGetsNumber of remote gets performed since last resetdoublefalse
NumberOfRemotePutsNumber of remote puts performed since last resetdoublefalse
PercentageSuccessWriteTransactionsPercentage of Write transaction executed in all successfully executed transactions (local transaction only)doublefalse
PercentageWriteTransactionsPercentage of Write transaction executed locally (committed and aborted)doublefalse
RemoteGetExecutionTimeAverage cost of a remote getdoublefalse
RemotePutExecutionTimeAverage cost of a remote putdoublefalse
ReplicationDegreeNumber of replicas for each keydoublefalse
ThroughputThroughput (in transactions per second)doublefalse
WriteSkewProbabilityWrite skew probabilitydoublefalse
Operations
Name Description Signature
dumpStatisticToFileDumps the current cache statistic values to a filevoid dumpStatisticToFile(String p0)
dumpStatisticsDumps the current cache statistic valuesString dumpStatistics()
dumpStatisticsToSystemOutDumps the current cache statistic values to System.outvoid dumpStatisticsToSystemOut()
getPercentileLocalRWriteTransactionK-th percentile of local write transactions execution timedouble getPercentileLocalRWriteTransaction(int p0)
getPercentileLocalReadOnlyTransactionK-th percentile of local read-only transactions execution timedouble getPercentileLocalReadOnlyTransaction(int p0)
getPercentileRemoteReadOnlyTransactionK-th percentile of remote read-only transactions execution timedouble getPercentileRemoteReadOnlyTransaction(int p0)
getPercentileRemoteWriteTransactionK-th percentile of remote write transactions execution timedouble getPercentileRemoteWriteTransaction(int p0)
getStatisticValueReturns the raw value for the statisticdouble getStatisticValue(String p0)
resetStatisticsReset all the statistics collectedvoid resetStatistics()


Component GlobalSecurityManager (Class org.infinispan.security.impl.GlobalSecurityManagerImpl)
Controls global ACL caches
Operations
Name Description Signature
Flush ACL CacheFlushes the global ACL cache for this nodevoid Flush ACL Cache()


Component GlobalXSiteAdminOperations (Class org.infinispan.xsite.GlobalXSiteAdminOperations)
Exposes tooling for handling backing up data to remote sites.
Operations
Name Description Signature
CancelPushStateCancels the push state on all the caches to remote site.String CancelPushState(String p0)
bringSiteOnlineBrings the given site back online on all the caches.String bringSiteOnline(String p0)
pushStatePushes the state of all caches to the corresponding remote site if the cache backups to it. The remote site will be bring back onlineString pushState(String p0)
takeSiteOfflineTakes this site offline in all caches in the cluster.String takeSiteOffline(String p0)


Component Invalidation (Class org.infinispan.interceptors.InvalidationInterceptor)
Component responsible for invalidating entries on remote caches when entries are written to locally.
Attributes
Name Description Type Writable
InvalidationsNumber of invalidationslongfalse
StatisticsEnabledEnables or disables the gathering of statistics by this componentbooleantrue
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component JmxStatsCommandInterceptor (Class org.infinispan.interceptors.base.JmxStatsCommandInterceptor)
Attributes
Name Description Type Writable
statisticsEnabledEnables or disables the gathering of statistics by this componentbooleantrue
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component LocalTopologyManager (Class org.infinispan.topology.LocalTopologyManagerImpl)
Controls the cache membership and state transfer
Attributes
Name Description Type Writable
ClusterAvailabilityCluster availabilityStringfalse
RebalancingEnabledRebalancing enabledbooleantrue


Component LockManager (Class org.infinispan.util.concurrent.locks.impl.DefaultLockManager)
Manager that handles MVCC locks for entries
Attributes
Name Description Type Writable
ConcurrencyLevelThe concurrency level that the MVCC Lock Manager has been configured with.intfalse
NumberOfLocksAvailableThe number of exclusive locks that are available.intfalse
NumberOfLocksHeldThe number of exclusive locks that are held.intfalse


Component MassIndexer (Class org.infinispan.query.MassIndexer)
Component that rebuilds the index from the cached data
Operations
Name Description Signature
startStarts rebuilding the indexvoid start()


Component Passivation (Class org.infinispan.eviction.PassivationManager)
Component that handles passivating entries to a CacheStore on eviction.
Attributes
Name Description Type Writable
PassivationsNumber of passivation eventslongfalse
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component ProtobufMetadataManager (Class org.infinispan.query.remote.impl.ProtobufMetadataManagerImpl)
Component that acts as a manager and container for Protocol Buffers message type definitions in the scope of a CacheManger.
Attributes
Name Description Type Writable
FilesWithErrorsThe names of the files that have errors, if anyStringfalse
ProtofileNamesThe names of all Protobuf filesStringfalse
Operations
Name Description Signature
getFileErrorsObtains the errors associated with a protobuf definition fileString getFileErrors(String p0)
getProtofileGet the contents of a protobuf definition fileString getProtofile(String p0)
registerProtofileRegisters a Protobuf definition filevoid registerProtofile(String p0, String p1)
registerProtofilesRegisters multiple Protobuf definition filesvoid registerProtofiles(String p0, String p1)
unregisterProtofileUnregisters a Protobuf definition filesvoid unregisterProtofile(String p0)
unregisterProtofilesUnregisters multiple Protobuf definition filesvoid unregisterProtofiles(String p0)


Component RecoveryAdmin (Class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations)
Exposes tooling for handling transaction recovery.
Operations
Name Description Signature
forceCommitForces the commit of an in-doubt transactionString forceCommit(long p0)
forceCommitForces the commit of an in-doubt transactionString forceCommit(int p0, byte p1, byte p2)
forceRollbackForces the rollback of an in-doubt transactionString forceRollback(long p0)
forceRollbackForces the rollback of an in-doubt transactionString forceRollback(int p0, byte p1, byte p2)
forgetRemoves recovery info for the given transaction.String forget(int p0, byte p1, byte p2)
forgetRemoves recovery info for the given transaction.String forget(long p0)
showInDoubtTransactionsShows all the prepared transactions for which the originating node crashedString showInDoubtTransactions()


Component RollingUpgradeManager (Class org.infinispan.upgrade.RollingUpgradeManager)
This component handles the control hooks to handle migrating data from one version of Infinispan to another
Operations
Name Description Signature
disconnectSourceDisconnects the target cluster from the source cluster according to the specified migratorvoid disconnectSource(String p0)
recordKnownGlobalKeysetDumps the global known keyset to a well-known key for retrieval by the upgrade processvoid recordKnownGlobalKeyset()
synchronizeDataSynchronizes data from the old cluster to this using the specified migratorlong synchronizeData(String p0)
synchronizeDataSynchronizes data from the old cluster to this using the specified migratorlong synchronizeData(String p0, int p1, int p2)


Component RpcManager (Class org.infinispan.remoting.rpc.RpcManagerImpl)
Manages all remote calls to remote cache instances in the cluster.
Attributes
Name Description Type Writable
AverageReplicationTimeThe average time spent in the transport layer, in millisecondslongfalse
CommittedViewAsStringRetrieves the committed view.Stringfalse
PendingViewAsStringRetrieves the pending view.Stringfalse
ReplicationCountNumber of successful replicationslongfalse
ReplicationFailuresNumber of failed replicationslongfalse
StatisticsEnabledEnables or disables the gathering of statistics by this componentbooleantrue
SuccessRatioSuccessful replications as a ratio of total replicationsStringfalse
SuccessRatioFloatingPointSuccessful replications as a ratio of total replications in numeric double formatdoublefalse
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()
setStatisticsEnabledvoid setStatisticsEnabled(boolean p0)


Component StateTransferManager (Class org.infinispan.statetransfer.StateTransferManager)
Component that handles state transfer
Attributes
Name Description Type Writable
JoinCompleteIf true, the node has successfully joined the grid and is considered to hold state. If false, the join process is still in progress.booleanfalse
RebalancingStatusRetrieves the rebalancing status for this cache. Possible values are PENDING, SUSPENDED, IN_PROGRESS, BALANCEDStringfalse
StateTransferInProgressChecks whether there is a pending inbound state transfer on this cluster member.booleanfalse


Component Statistics (Class org.infinispan.interceptors.CacheMgmtInterceptor)
General statistics such as timings, hit/miss ratio, etc.
Attributes
Name Description Type Writable
AverageReadTimeAverage number of milliseconds for a read operation on the cachelongfalse
AverageRemoveTimeAverage number of milliseconds for a remove operation in the cachelongfalse
AverageWriteTimeAverage number of milliseconds for a write operation in the cachelongfalse
ElapsedTimeNumber of seconds since cache startedlongfalse
EvictionsNumber of cache eviction operationslongfalse
HitRatioPercentage hit/(hit+miss) ratio for the cachedoublefalse
HitsNumber of cache attribute hitslongfalse
MissesNumber of cache attribute misseslongfalse
NumberOfEntriesNumber of entries currently in memory including expired entriesintfalse
ReadWriteRatioread/writes ratio for the cachedoublefalse
RemoveHitsNumber of cache removal hitslongfalse
RemoveMissesNumber of cache removals where keys were not foundlongfalse
Storesnumber of cache attribute put operationslongfalse
TimeSinceResetNumber of seconds since the cache statistics were last resetlongfalse
TimeSinceStartNumber of seconds since cache startedlongfalse
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component Statistics (Class org.infinispan.stats.impl.StatsCollector)
General statistics such as timings, hit/miss ratio, etc.
Attributes
Name Description Type Writable
AverageReadTimeAverage number of milliseconds for a read operation on the cachelongfalse
AverageRemoveTimeAverage number of milliseconds for a remove operation in the cachelongfalse
AverageWriteTimeAverage number of milliseconds for a write operation in the cachelongfalse
EvictionsNumber of cache eviction operationslongfalse
HitRatioPercentage hit/(hit+miss) ratio for the cachedoublefalse
HitsNumber of cache attribute hitslongfalse
MissesNumber of cache attribute misseslongfalse
NumberOfEntriesNumber of entries currently in the cacheintfalse
ReadWriteRatioread/writes ratio for the cachedoublefalse
RemoveHitsNumber of cache removal hitslongfalse
RemoveMissesNumber of cache removals where keys were not foundlongfalse
Storesnumber of cache attribute put operationslongfalse
TimeSinceResetNumber of seconds since the cache statistics were last resetlongfalse
TimeSinceStartNumber of seconds since cache startedlongfalse
statisticsEnabledEnables or disables the gathering of statistics by this componentbooleantrue
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component Transactions (Class org.infinispan.interceptors.TxInterceptor)
Component that manages the cache's participation in JTA transactions.
Attributes
Name Description Type Writable
CommitsNumber of transaction commits performed since last resetlongfalse
PreparesNumber of transaction prepares performed since last resetlongfalse
RollbacksNumber of transaction rollbacks performed since last resetlongfalse
StatisticsEnabledbooleantrue
Operations
Name Description Signature
resetStatisticsResets statistics gathered by this componentvoid resetStatistics()


Component Transport (Class org.infinispan.server.core.transport.Transport)
Transport component manages read and write operations to/from server.
Attributes
Name Description Type Writable
HostNameReturns the host to which the transport binds.Stringfalse
IdleTimeoutReturns the idle timeout.Stringfalse
NumberOfGlobalConnectionsReturns a count of active connections in the cluster. This operation will make remote calls to aggregate results, so latency might have an impact on the speed of calculation of this attribute.Integerfalse
NumberOfLocalConnectionsReturns a count of active connections this server.Integerfalse
NumberWorkerThreadsReturns the number of worker threads.Stringfalse
PortReturns the port to which the transport binds.Stringfalse
ReceiveBufferSizeReturns the receive buffer size.Stringfalse
SendBufferSizeReturns the send buffer size.Stringfalse
TcpNoDelayReturns whether TCP no delay was configured or not.Stringfalse
TotalBytesReadReturns the total number of bytes read by the server from clients which includes both protocol and user information.Stringfalse
TotalBytesWrittenReturns the total number of bytes written by the server back to clients which includes both protocol and user information.Stringfalse


Component XSiteAdmin (Class org.infinispan.xsite.XSiteAdminOperations)
Exposes tooling for handling backing up data to remote sites.
Operations
Name Description Signature
CancelPushStateCancels the push state to remote site.String CancelPushState(String p0)
CancelReceiveStateCancels the push state to this site. All the state received from state transfer will be ignored.String CancelReceiveState(String p0)
ClearPushStateStatusClears the state transfer status.String ClearPushStateStatus()
PushStateStatusShows a map with destination site name and the state transfer status.Map PushStateStatus()
SendingSiteNameReturns the site name from which this site is receiving state.String SendingSiteName()
amendTakeOfflineAmends the values for 'TakeOffline' functionality on all the nodes in the cluster.String amendTakeOffline(String p0, int p1, long p2)
bringSiteOnlineBrings the given site back online on all the cluster.String bringSiteOnline(String p0)
getTakeOfflineAfterFailuresReturns the value of the 'afterFailures' for the 'TakeOffline' functionality.String getTakeOfflineAfterFailures(String p0)
getTakeOfflineMinTimeToWaitReturns the value of the 'minTimeToWait' for the 'TakeOffline' functionality.String getTakeOfflineMinTimeToWait(String p0)
pushStatePushes the state of this cache to the remote site. The remote site will be bring back onlineString pushState(String p0)
setTakeOfflineAfterFailuresAmends the values for 'afterFailures' for the 'TakeOffline' functionality on all the nodes in the cluster.String setTakeOfflineAfterFailures(String p0, int p1)
setTakeOfflineMinTimeToWaitAmends the values for 'minTimeToWait' for the 'TakeOffline' functionality on all the nodes in the cluster.String setTakeOfflineMinTimeToWait(String p0, long p1)
siteStatusCheck whether the given backup site is offline or not.String siteStatus(String p0)
statusReturns the the status(offline/online) of all the configured backup sites.String status()
takeSiteOfflineTakes this site offline in all nodes in the cluster.String takeSiteOffline(String p0)



Copyright © 2018
JBoss, a division of Red Hat. All rights reserved. ---> -