XtremeCloud Data Grid-web JMX Components

JMX Components for XtremeCloud Data Grid-web

JMX Components Available


**Component AbstractClusterStats** (Class [org.infinispan.stats.impl.AbstractClusterStats](org/infinispan/stats/impl/AbstractClusterStats.html))
**_Attributes_**
**Name** **Description** **Type** **Writable**
StaleStatsThreshold Gets the threshold for cluster wide stats refresh (milliseconds) long true
StatisticsEnabled Enables or disables the gathering of statistics by this component boolean true
TimeSinceReset Number of seconds since the cluster-wide statistics were last reset long false
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component AbstractDelegatingCache** (Class [org.infinispan.cache.impl.AbstractDelegatingCache](org/infinispan/cache/impl/AbstractDelegatingCache.html))
**_Attributes_**
**Name** **Description** **Type** **Writable**
CacheName Returns the cache name String false
CacheStatus Returns the cache status String false
ConfigurationAsProperties Returns the cache configuration in form of properties Properties false
Version Returns the version of Infinispan String false
**_Operations_**
**Name** **Description** **Signature**
clear Clears the cache void clear()
shutdown Shuts down the cache across the cluster void shutdown()
start Starts the cache. void start()
stop Stops the cache. void stop()

</a>

**Component Activation** (Class [org.infinispan.eviction.impl.ActivationManagerImpl](org/infinispan/eviction/impl/ActivationManagerImpl.html)) _Component that handles activating entries that have been passivated to a CacheStore by loading them into memory._
**_Attributes_**
**Name** **Description** **Type** **Writable**
Activations Number of activation events String false
statisticsEnabled Enables or disables the gathering of statistics by this component boolean true
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component Cache** (Class [org.infinispan.cache.impl.SimpleCacheImpl](org/infinispan/cache/impl/SimpleCacheImpl.html)) _Component that represents a simplified cache instance._
**_Attributes_**
**Name** **Description** **Type** **Writable**
CacheName Returns the cache name String false
CacheStatus Returns the cache status String false
ConfigurationAsProperties Returns the cache configuration in form of properties Properties false
Version Returns the version of Infinispan String false
**_Operations_**
**Name** **Description** **Signature**
clear Clears the cache void clear()
start Starts the cache. void start()
stop Stops the cache. void stop()

</a>

**Component Cache** (Class [org.infinispan.cache.impl.CacheImpl](org/infinispan/cache/impl/CacheImpl.html)) _Component that represents an individual cache instance._
**_Attributes_**
**Name** **Description** **Type** **Writable**
CacheAvailability Returns the cache availability String true
CacheName Returns the cache name String false
CacheStatus Returns the cache status String false
ConfigurationAsProperties Returns the cache configuration in form of properties Properties false
RebalancingEnabled Returns whether cache rebalancing is enabled boolean true
Version Returns the version of Infinispan String false
**_Operations_**
**Name** **Description** **Signature**
clear Clears the cache void clear()
shutdown Shuts down the cache across the cluster void shutdown()
start Starts the cache. void start()
stop Stops the cache. void stop()

</a>

**Component Cache** (Class [org.infinispan.cache.impl.AbstractDelegatingAdvancedCache](org/infinispan/cache/impl/AbstractDelegatingAdvancedCache.html)) _Component that represents an individual cache instance._
**_Attributes_**
**Name** **Description** **Type** **Writable**
CacheAvailability Returns the cache availability String true
RebalancingEnabled Returns whether cache rebalancing is enabled boolean true

</a>

**Component CacheContainerHealth** (Class [org.infinispan.health.impl.jmx.HealthJMXExposerImpl](org/infinispan/health/impl/jmx/HealthJMXExposerImpl.html)) _Health Check API_
**_Attributes_**
**Name** **Description** **Type** **Writable**
CacheHealth Per Cache statuses String false
ClusterHealth Cluster health status String false
ClusterName Cluster name String false
FreeMemoryKb The amount of free memory (KB) in the host long false
NumberOfCpus Number of CPUs in the host int false
NumberOfNodes Total nodes in the cluster int false
TotalMemoryKb The amount of total memory (KB) in the host long false

</a>

**Component CacheContainerStats** (Class [org.infinispan.stats.impl.CacheContainerStatsImpl](org/infinispan/stats/impl/CacheContainerStatsImpl.html)) _General cache container statistics such as timings, hit/miss ratio, etc._
**_Attributes_**
**Name** **Description** **Type** **Writable**
AverageReadTime Cache container total average number of milliseconds for all read operation in this cache container long false
AverageRemoveTime Cache container total average number of milliseconds for all remove operation in this cache container long false
AverageWriteTime Cache container average number of milliseconds for all write operation in this cache container long false
CurrentNumberOfEntriesInMemory Cache container total number of entries currently in-memory for all caches in this cache container int false
Evictions Cache container total number of cache eviction operations long false
HitRatio Cache container total percentage hit/(hit+miss) ratio for this cache double false
Hits Cache container total number of cache attribute hits long false
Misses Cache container total number of cache attribute misses long false
NumberOfEntries Cache container total number of entries currently in all caches from this cache container int false
OffHeapMemoryUsed Amount in bytes of off-heap memory used by this cache container long false
ReadWriteRatio Cache container read/writes ratio in all caches from this cache container double false
RemoveHits Cache container total number of cache removal hits long false
RemoveMisses Cache container total number of cache removals where keys were not found long false
StatisticsEnabled Enables or disables the gathering of statistics by this component boolean true
Stores Cache container total number of cache attribute put operations long false
TimeSinceReset Number of seconds since the cache container statistics were last reset long false

</a>

**Component CacheLoader** (Class [org.infinispan.interceptors.impl.CacheLoaderInterceptor](org/infinispan/interceptors/impl/CacheLoaderInterceptor.html)) _Component that handles loading entries from a CacheStore into memory._
**_Attributes_**
**Name** **Description** **Type** **Writable**
CacheLoaderLoads Number of entries loaded from cache store long false
CacheLoaderMisses Number of entries that did not exist in cache store long false
Stores Returns a collection of cache loader types which are configured and enabled Collection false
**_Operations_**
**Name** **Description** **Signature**
disableStore Disable all stores of a given type, where type is a fully qualified class name of the cache loader to disable void disableStore(String p0)
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component CacheManager** (Class [org.infinispan.manager.DefaultCacheManager](org/infinispan/manager/DefaultCacheManager.html)) _Component that acts as a manager, factory and container for caches in the system._
**_Attributes_**
**Name** **Description** **Type** **Writable**
CacheManagerStatus The status of the cache manager instance. String false
ClusterMembers List of members in the cluster String false
ClusterName Cluster name String false
ClusterSize Size of the cluster in number of nodes int false
Coordinator Indicates whether this node is coordinator boolean false
CoordinatorAddress The logical address of the cluster's coordinator String false
CreatedCacheCount The total number of created caches, including the default cache. String false
DefinedCacheConfigurationNames The defined cache configuration names. String false
DefinedCacheCount The total number of defined cache configurations. String false
DefinedCacheNames The defined cache names and their statuses. The default cache is not included in this representation. String false
GlobalConfigurationAsProperties Global configuration properties Properties false
Name The name of this cache manager String false
NodeAddress The network address associated with this instance String false
PhysicalAddresses The physical network addresses associated with this instance String false
RunningCacheCount The total number of running caches, including the default cache. String false
Version Returns the version of Infinispan String false
**_Operations_**
**Name** **Description** **Signature**
startCache Starts the default cache associated with this cache manager void startCache()
startCache Starts a named cache from this cache manager void startCache(String p0)

</a>

**Component CacheStore** (Class [org.infinispan.interceptors.impl.CacheWriterInterceptor](org/infinispan/interceptors/impl/CacheWriterInterceptor.html)) _Component that handles storing of entries to a CacheStore from memory._
**_Attributes_**
**Name** **Description** **Type** **Writable**
NumberOfPersistedEntries Number of entries currently persisted excluding expired entries int false
WritesToTheStores Number of writes to the store long false
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component CacheUsageStatistics** (Class [org.infinispan.stats.topK.CacheUsageInterceptor](org/infinispan/stats/topK/CacheUsageInterceptor.html)) _Keeps tracks of the accessed keys_
**_Attributes_**
**Name** **Description** **Type** **Writable**
Capacity Shows the current capacity for top-K values int false
LocalTopGets Show the top 10 keys most read locally by this instance Map false
LocalTopPuts Show the top 10 keys most write locally by this instance Map false
RemoteTopGets Show the top 10 keys most read remotely by this instance Map false
RemoteTopPuts Show the top 10 keys most write remotely by this instance Map false
TopContendedKeys Show the top 10 keys most contended Map false
TopLockFailedKeys Show the top 10 keys whose lock acquisition failed by timeout Map false
TopLockedKeys Show the top 10 keys most locked Map false
TopWriteSkewFailedKeys Show the top 10 keys whose write skew check was failed Map false
**_Operations_**
**Name** **Description** **Signature**
getNLocalTopGets Show the top n keys most read locally by this instance Map getNLocalTopGets(int p0)
getNLocalTopPuts Show the top n keys most write locally by this instance Map getNLocalTopPuts(int p0)
getNRemoteTopGets Show the top n keys most read remotely by this instance Map getNRemoteTopGets(int p0)
getNRemoteTopPuts Show the top n keys most write remotely by this instance Map getNRemoteTopPuts(int p0)
getNTopContendedKeys Show the top n keys most contended Map getNTopContendedKeys(int p0)
getNTopLockFailedKeys Show the top n keys whose lock acquisition failed Map getNTopLockFailedKeys(int p0)
getNTopLockedKeys Show the top n keys most locked Map getNTopLockedKeys(int p0)
getNTopWriteSkewFailedKeys Show the top n keys whose write skew check was failed Map getNTopWriteSkewFailedKeys(int p0)
resetStatistics Resets statistics gathered by this component void resetStatistics()
setStatisticsEnabled Show the top n keys whose write skew check was failed void setStatisticsEnabled(boolean p0)
setTopKValue Set K for the top-K values void setTopKValue(int p0)

</a>

**Component ClusterCacheStats** (Class [org.infinispan.stats.impl.ClusterCacheStatsImpl](org/infinispan/stats/impl/ClusterCacheStatsImpl.html)) _General cluster statistics such as timings, hit/miss ratio, etc._
**_Attributes_**
**Name** **Description** **Type** **Writable**
Activations The total number of activations in the cluster long false
AverageReadTime Cluster wide total average number of milliseconds for a read operation on the cache long false
AverageRemoveTime Cluster wide total average number of milliseconds for a remove operation in the cache long false
AverageWriteTime Cluster wide average number of milliseconds for a write operation in the cache long false
CacheLoaderLoads The total number of cacheloader load operations in the cluster long false
CacheLoaderMisses The total number of cacheloader load misses in the cluster long false
CurrentNumberOfEntriesInMemory Cluster wide total number of entries currently stored in-memory int false
Evictions Cluster wide total number of cache eviction operations long false
HitRatio Cluster wide total percentage hit/(hit+miss) ratio for this cache double false
Hits Cluster wide total number of cache attribute hits long false
Invalidations The total number of invalidations in the cluster long false
Misses Cluster wide total number of cache attribute misses long false
NumberOfEntries Cluster wide total number of entries currently in the cache, including passivated entries int false
NumberOfLocksAvailable Total number of exclusive locks available in the cluster int false
NumberOfLocksHeld Total number of locks held in the cluster int false
OffHeapMemoryUsed Amount in bytes of off-heap memory used across the cluster for this cache long false
Passivations The total number of passivations in the cluster long false
ReadWriteRatio Cluster wide read/writes ratio for the cache double false
RemoveHits Cluster wide total number of cache removal hits long false
RemoveMisses Cluster wide total number of cache removals where keys were not found long false
StoreWrites The total number of cachestore store operations in the cluster long false
Stores Cluster wide total number of cache attribute put operations long false
TimeSinceStart Number of seconds since the first cache node started long false

</a>

**Component ClusterContainerStats** (Class [org.infinispan.stats.impl.ClusterContainerStatsImpl](org/infinispan/stats/impl/ClusterContainerStatsImpl.html)) _General container statistics aggregated across the cluster._
**_Attributes_**
**Name** **Description** **Type** **Writable**
MemoryAvailable The maximum amount of free memory in bytes across the cluster JVMs long false
MemoryMax The maximum amount of memory that JVMs across the cluster will attempt to utilise in bytes long false
MemoryTotal The total amount of memory in the JVMs across the cluster in bytes long false
MemoryUsed The amount of memory used by JVMs across the cluster in bytes long false

</a>

**Component ClusteredLockManager** (Class [org.infinispan.lock.impl.manager.EmbeddedClusteredLockManager](org/infinispan/lock/impl/manager/EmbeddedClusteredLockManager.html)) _Component to manage clustered locks_
**_Operations_**
**Name** **Description** **Signature**
forceRelease Forces a release of the lock if such exist boolean forceRelease(String p0)
isDefined Returns true if the lock is defined boolean isDefined(String p0)
isLocked Returns true if the lock exists and is acquired boolean isLocked(String p0)
remove Removes the lock from the cluster. The lock has to be recreated to access next time. boolean remove(String p0)

</a>

**Component Configuration** (Class [org.infinispan.cache.impl.CacheConfigurationMBean](org/infinispan/cache/impl/CacheConfigurationMBean.html)) _Runtime cache configuration attributes_
**_Attributes_**
**Name** **Description** **Type** **Writable**
EvictionSize Gets the eviction size for the cache long true

</a>

**Component CounterManager** (Class [org.infinispan.counter.impl.manager.EmbeddedCounterManager](org/infinispan/counter/impl/manager/EmbeddedCounterManager.html)) _Component to manage counters_
**_Operations_**
**Name** **Description** **Signature**
configuration Returns the counter's configuration Properties configuration(String p0)
counters Returns a collection of defined counter's name. Collection counters()
remove Removes the counter's value from the cluster. The counter will be re-created when access next time. void remove(String p0)
reset Resets the counter's value void reset(String p0)
value Returns the current counter's value long value(String p0)

</a>

**Component DistributionManager** (Class [org.infinispan.distribution.impl.DistributionManagerImpl](org/infinispan/distribution/impl/DistributionManagerImpl.html)) _Component that handles distribution of content across a cluster_
**_Operations_**
**Name** **Description** **Signature**
isAffectedByRehash Determines whether a given key is affected by an ongoing rehash, if any. boolean isAffectedByRehash(Object p0)
isLocatedLocally Tells you whether a given key would be written to this instance of the cache according to the consistent hashing algorithm. Only works with String keys. boolean isLocatedLocally(String p0)
locateKey Shows the addresses of the nodes where a write operation would store the entry associated with the specified key. Only works with String keys. List locateKey(String p0)

</a>

**Component ExtendedStatistics** (Class [org.infinispan.stats.wrappers.ExtendedStatisticInterceptor](org/infinispan/stats/wrappers/ExtendedStatisticInterceptor.html)) _Component that manages and exposes extended statistics relevant to transactions._
**_Attributes_**
**Name** **Description** **Type** **Writable**
AbortRate Abort Rate double false
AvailableExtendedStatistics Returns all the available statistics String false
AvgAbortedWriteTxDuration Average aborted write transaction duration (in microseconds) double false
AvgClusteredGetCommandSize Average clustered get command size (in bytes) double false
AvgCommitCommandSize Average commit command size (in bytes) double false
AvgCommitRtt Average Commit Round-Trip Time duration (in microseconds) double false
AvgCommitTime Average local commit duration time (2nd phase only) (in microseconds) double false
AvgCompleteNotificationAsync Average asynchronous Complete Notification duration (in microseconds) double false
AvgGetsPerROTransaction Average number of get operations per (local) read-only transaction double false
AvgGetsPerWrTransaction Average number of get operations per (local) read-write transaction double false
AvgLocalCommitTime Average time it takes to execute the commit command locally (in microseconds) double false
AvgLocalGetTime Average Local processing Get time (in microseconds) double false
AvgLocalLockHoldTime Average lock local holding time (in microseconds) double false
AvgLocalPrepareTime Average time it takes to execute the prepare command locally (in microseconds) double false
AvgLocalRollbackTime Average time it takes to execute the rollback command locally (in microseconds) double false
AvgLockHoldTime Average lock holding time (in microseconds) double false
AvgLockWaitingTime Average time waiting for the lock acquisition (in microseconds) double false
AvgNumNodesCommit Average number of nodes in Commit destination set double false
AvgNumNodesCompleteNotification Average number of nodes in Complete Notification destination set double false
AvgNumNodesPrepare Average number of nodes in Prepare destination set double false
AvgNumNodesRemoteGet Average number of nodes in Remote Get destination set double false
AvgNumNodesRollback Average number of nodes in Rollback destination set double false
AvgNumOfLockLocalTx Average number of locks per write local transaction double false
AvgNumOfLockRemoteTx Average number of locks per write remote transaction double false
AvgNumOfLockSuccessLocalTx Average number of locks per successfully write local transaction double false
AvgPrepareCommandSize Average prepare command size (in bytes) double false
AvgPrepareRtt Average Prepare Round-Trip Time duration (in microseconds) double false
AvgPutsPerWrTransaction Average number of put operations per (local) read-write transaction double false
AvgReadOnlyTxDuration Average successful read-only transaction duration (in microseconds) double false
AvgRemoteCommitTime Average time it takes to execute the commit command remotely (in microseconds) double false
AvgRemoteGetRtt Average Remote Get Round-Trip Time duration (in microseconds) double false
AvgRemoteGetsPerROTransaction Average number of remote get operations per (local) read-only transaction double false
AvgRemoteGetsPerWrTransaction Average number of remote get operations per (local) read-write transaction double false
AvgRemoteLockHoldTime Average lock remote holding time (in microseconds) double false
AvgRemotePrepareTime Average time it takes to execute the prepare command remotely (in microseconds) double false
AvgRemotePutsPerWrTransaction Average number of remote put operations per (local) read-write transaction double false
AvgRemoteRollbackTime Average time it takes to execute the rollback command remotely (in microseconds) double false
AvgResponseTime Average Response Time double false
AvgRollbackRtt Average Rollback Round-Trip Time duration (in microseconds) double false
AvgRollbackTime Average local rollback duration time (2nd phase only) (in microseconds) double false
AvgTxArrivalRate Average transaction arrival rate, originated locally and remotely (in transaction per second) double false
AvgWriteTxDuration Average successful write transaction duration (in microseconds) double false
LocalActiveTransactions Number of concurrent transactions executing on the current node double false
LocalExecutionTimeWithoutLock Local execution time of a transaction without the time waiting for lock acquisition double false
NumAbortedTxDueDeadlock The number of aborted transactions due to deadlock double false
NumAbortedTxDueTimeout The number of aborted transactions due to timeout in lock acquisition double false
NumNodes Number of nodes in the cluster double false
NumberOfCommits Number of committed transactions since last reset double false
NumberOfGets Number of gets performed since last reset double false
NumberOfLocalCommits Number of local committed transactions since last reset double false
NumberOfPuts Number of puts performed since last reset double false
NumberOfRemoteGets Number of remote gets performed since last reset double false
NumberOfRemotePuts Number of remote puts performed since last reset double false
PercentageSuccessWriteTransactions Percentage of Write transaction executed in all successfully executed transactions (local transaction only) double false
PercentageWriteTransactions Percentage of Write transaction executed locally (committed and aborted) double false
RemoteGetExecutionTime Average cost of a remote get double false
RemotePutExecutionTime Average cost of a remote put double false
ReplicationDegree Number of replicas for each key double false
Throughput Throughput (in transactions per second) double false
WriteSkewProbability Write skew probability double false
**_Operations_**
**Name** **Description** **Signature**
dumpStatisticToFile Dumps the current cache statistic values to a file void dumpStatisticToFile(String p0)
dumpStatistics Dumps the current cache statistic values String dumpStatistics()
dumpStatisticsToSystemOut Dumps the current cache statistic values to System.out void dumpStatisticsToSystemOut()
getPercentileLocalRWriteTransaction K-th percentile of local write transactions execution time double getPercentileLocalRWriteTransaction(int p0)
getPercentileLocalReadOnlyTransaction K-th percentile of local read-only transactions execution time double getPercentileLocalReadOnlyTransaction(int p0)
getPercentileRemoteReadOnlyTransaction K-th percentile of remote read-only transactions execution time double getPercentileRemoteReadOnlyTransaction(int p0)
getPercentileRemoteWriteTransaction K-th percentile of remote write transactions execution time double getPercentileRemoteWriteTransaction(int p0)
getStatisticValue Returns the raw value for the statistic double getStatisticValue(String p0)
resetStatistics Reset all the statistics collected void resetStatistics()

</a>

**Component GlobalSecurityManager** (Class [org.infinispan.security.impl.GlobalSecurityManagerImpl](org/infinispan/security/impl/GlobalSecurityManagerImpl.html)) _Controls global ACL caches_
**_Operations_**
**Name** **Description** **Signature**
Flush ACL Cache Flushes the global ACL cache for this node void Flush ACL Cache()

</a>

**Component GlobalXSiteAdminOperations** (Class [org.infinispan.xsite.GlobalXSiteAdminOperations](org/infinispan/xsite/GlobalXSiteAdminOperations.html)) _Exposes tooling for handling backing up data to remote sites._
**_Operations_**
**Name** **Description** **Signature**
CancelPushState Cancels the push state on all the caches to remote site. String CancelPushState(String p0)
bringSiteOnline Brings the given site back online on all the caches. String bringSiteOnline(String p0)
pushState Pushes the state of all caches to the corresponding remote site if the cache backups to it. The remote site will be bring back online String pushState(String p0)
takeSiteOffline Takes this site offline in all caches in the cluster. String takeSiteOffline(String p0)

</a>

**Component Invalidation** (Class [org.infinispan.interceptors.impl.InvalidationInterceptor](org/infinispan/interceptors/impl/InvalidationInterceptor.html)) _Component responsible for invalidating entries on remote caches when entries are written to locally._
**_Attributes_**
**Name** **Description** **Type** **Writable**
Invalidations Number of invalidations long false
StatisticsEnabled Enables or disables the gathering of statistics by this component boolean true
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component JmxStatsCommandInterceptor** (Class [org.infinispan.interceptors.impl.JmxStatsCommandInterceptor](org/infinispan/interceptors/impl/JmxStatsCommandInterceptor.html))
**_Attributes_**
**Name** **Description** **Type** **Writable**
statisticsEnabled Enables or disables the gathering of statistics by this component boolean true
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component LocalTopologyManager** (Class [org.infinispan.topology.LocalTopologyManagerImpl](org/infinispan/topology/LocalTopologyManagerImpl.html)) _Controls the cache membership and state transfer_
**_Attributes_**
**Name** **Description** **Type** **Writable**
ClusterAvailability Cluster availability String false
RebalancingEnabled Rebalancing enabled boolean true

</a>

**Component LockManager** (Class [org.infinispan.util.concurrent.locks.impl.DefaultLockManager](org/infinispan/util/concurrent/locks/impl/DefaultLockManager.html)) _Manager that handles MVCC locks for entries_
**_Attributes_**
**Name** **Description** **Type** **Writable**
ConcurrencyLevel The concurrency level that the MVCC Lock Manager has been configured with. int false
NumberOfLocksAvailable The number of exclusive locks that are available. int false
NumberOfLocksHeld The number of exclusive locks that are held. int false

</a>

**Component MassIndexer** (Class [org.infinispan.query.MassIndexer](org/infinispan/query/MassIndexer.html)) _Component that rebuilds the index from the cached data_
**_Operations_**
**Name** **Description** **Signature**
start Starts rebuilding the index void start()

</a>

**Component Passivation** (Class [org.infinispan.eviction.PassivationManager](org/infinispan/eviction/PassivationManager.html)) _Component that handles passivating entries to a CacheStore on eviction._
**_Attributes_**
**Name** **Description** **Type** **Writable**
Passivations Number of passivation events long false
**_Operations_**
**Name** **Description** **Signature**
passivateAll Passivate all entries to the CacheStore void passivateAll()
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component ProtobufMetadataManager** (Class [org.infinispan.query.remote.impl.ProtobufMetadataManagerImpl](org/infinispan/query/remote/impl/ProtobufMetadataManagerImpl.html)) _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**
FilesWithErrors The names of the files that have errors, if any String false
ProtofileNames The names of all Protobuf files String false
**_Operations_**
**Name** **Description** **Signature**
getFileErrors Obtains the errors associated with a protobuf definition file String getFileErrors(String p0)
getProtofile Get the contents of a protobuf definition file String getProtofile(String p0)
registerProtofile Registers a Protobuf definition file void registerProtofile(String p0, String p1)
registerProtofiles Registers multiple Protobuf definition files void registerProtofiles(String p0, String p1)
unregisterProtofile Unregisters a Protobuf definition files void unregisterProtofile(String p0)
unregisterProtofiles Unregisters multiple Protobuf definition files void unregisterProtofiles(String p0)

</a>

**Component RecoveryAdmin** (Class [org.infinispan.transaction.xa.recovery.RecoveryAdminOperations](org/infinispan/transaction/xa/recovery/RecoveryAdminOperations.html)) _Exposes tooling for handling transaction recovery._
**_Operations_**
**Name** **Description** **Signature**
forceCommit Forces the commit of an in-doubt transaction String forceCommit(long p0)
forceCommit Forces the commit of an in-doubt transaction String forceCommit(int p0, byte p1, byte p2)
forceRollback Forces the rollback of an in-doubt transaction String forceRollback(long p0)
forceRollback Forces the rollback of an in-doubt transaction String forceRollback(int p0, byte p1, byte p2)
forget Removes recovery info for the given transaction. String forget(int p0, byte p1, byte p2)
forget Removes recovery info for the given transaction. String forget(long p0)
showInDoubtTransactions Shows all the prepared transactions for which the originating node crashed String showInDoubtTransactions()

</a>

**Component RollingUpgradeManager** (Class [org.infinispan.upgrade.RollingUpgradeManager](org/infinispan/upgrade/RollingUpgradeManager.html)) _This component handles the control hooks to handle migrating data from one version of Infinispan to another_
**_Operations_**
**Name** **Description** **Signature**
disconnectSource Disconnects the target cluster from the source cluster according to the specified migrator void disconnectSource(String p0)
synchronizeData Synchronizes data from the old cluster to this using the specified migrator long synchronizeData(String p0)
synchronizeData Synchronizes data from the old cluster to this using the specified migrator long synchronizeData(String p0, int p1, int p2)

</a>

**Component RpcManager** (Class [org.infinispan.remoting.rpc.RpcManagerImpl](org/infinispan/remoting/rpc/RpcManagerImpl.html)) _Manages all remote calls to remote cache instances in the cluster._
**_Attributes_**
**Name** **Description** **Type** **Writable**
AverageReplicationTime The average time spent in the transport layer, in milliseconds long false
CommittedViewAsString Retrieves the committed view. String false
PendingViewAsString Retrieves the pending view. String false
ReplicationCount Number of successful replications long false
ReplicationFailures Number of failed replications long false
SitesView Retrieves the x-site view. String false
StatisticsEnabled Enables or disables the gathering of statistics by this component boolean true
SuccessRatio Successful replications as a ratio of total replications String false
SuccessRatioFloatingPoint Successful replications as a ratio of total replications in numeric double format double false
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()
setStatisticsEnabled void setStatisticsEnabled(boolean p0)

</a>

**Component StateTransferManager** (Class [org.infinispan.statetransfer.StateTransferManager](org/infinispan/statetransfer/StateTransferManager.html)) _Component that handles state transfer_
**_Attributes_**
**Name** **Description** **Type** **Writable**
JoinComplete If true, the node has successfully joined the grid and is considered to hold state. If false, the join process is still in progress. boolean false
RebalancingStatus Retrieves the rebalancing status for this cache. Possible values are PENDING, SUSPENDED, IN_PROGRESS, BALANCED String false
StateTransferInProgress Checks whether there is a pending inbound state transfer on this cluster member. boolean false

</a>

**Component Statistics** (Class [org.infinispan.interceptors.impl.CacheMgmtInterceptor](org/infinispan/interceptors/impl/CacheMgmtInterceptor.html)) _General statistics such as timings, hit/miss ratio, etc._
**_Attributes_**
**Name** **Description** **Type** **Writable**
AverageReadTime Average number of milliseconds for a read operation on the cache long false
AverageRemoveTime Average number of milliseconds for a remove operation in the cache long false
AverageWriteTime Average number of milliseconds for a write operation in the cache long false
ElapsedTime Number of seconds since cache started long false
Evictions Number of cache eviction operations long false
HitRatio Percentage hit/(hit+miss) ratio for the cache double false
Hits Number of cache attribute hits long false
Misses Number of cache attribute misses long false
NumberOfEntries Number of entries in the cache including passivated entries int false
NumberOfEntriesInMemory Number of entries currently in-memory excluding expired entries int false
OffHeapMemoryUsed Amount of memory in bytes allocated in off-heap long false
ReadWriteRatio read/writes ratio for the cache double false
RemoveHits Number of cache removal hits long false
RemoveMisses Number of cache removals where keys were not found long false
RequiredMinimumNumberOfNodes Amount of nodes required to guarantee data consistency int false
Stores number of cache attribute put operations long false
TimeSinceReset Number of seconds since the cache statistics were last reset long false
TimeSinceStart Number of seconds since cache started long false
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component Statistics** (Class [org.infinispan.stats.impl.StatsCollector](org/infinispan/stats/impl/StatsCollector.html)) _General statistics such as timings, hit/miss ratio, etc._
**_Attributes_**
**Name** **Description** **Type** **Writable**
AverageReadTime Average number of milliseconds for a read operation on the cache long false
AverageRemoveTime Average number of milliseconds for a remove operation in the cache long false
AverageWriteTime Average number of milliseconds for a write operation in the cache long false
CurrentNumberOfEntriesInMemory Number of entries currently in-memory excluding expired entries int false
Evictions Number of cache eviction operations long false
HitRatio Percentage hit/(hit+miss) ratio for the cache double false
Hits Number of cache attribute hits long false
Misses Number of cache attribute misses long false
NumberOfEntries Number of entries currently in the cache int false
OffHeapMemoryUsed Amount in bytes of off-heap memory used by this cache long false
ReadWriteRatio read/writes ratio for the cache double false
RemoveHits Number of cache removal hits long false
RemoveMisses Number of cache removals where keys were not found long false
Stores number of cache attribute put operations long false
TimeSinceReset Number of seconds since the cache statistics were last reset long false
TimeSinceStart Number of seconds since cache started long false
statisticsEnabled Enables or disables the gathering of statistics by this component boolean true
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component Transactions** (Class [org.infinispan.interceptors.impl.TxInterceptor](org/infinispan/interceptors/impl/TxInterceptor.html)) _Component that manages the cache's participation in JTA transactions._
**_Attributes_**
**Name** **Description** **Type** **Writable**
Commits Number of transaction commits performed since last reset long false
Prepares Number of transaction prepares performed since last reset long false
Rollbacks Number of transaction rollbacks performed since last reset long false
StatisticsEnabled boolean true
**_Operations_**
**Name** **Description** **Signature**
resetStatistics Resets statistics gathered by this component void resetStatistics()

</a>

**Component Transport** (Class [org.infinispan.server.core.transport.Transport](org/infinispan/server/core/transport/Transport.html)) _Transport component manages read and write operations to/from server._
**_Attributes_**
**Name** **Description** **Type** **Writable**
HostName Returns the host to which the transport binds. String false
IdleTimeout Returns the idle timeout. String false
NumberOfGlobalConnections Returns 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. Integer false
NumberOfLocalConnections Returns a count of active connections this server. Integer false
NumberWorkerThreads Returns the number of worker threads. String false
Port Returns the port to which the transport binds. Integer false
ReceiveBufferSize Returns the receive buffer size. String false
SendBufferSize Returns the send buffer size. String false
TcpNoDelay Returns whether TCP no delay was configured or not. String false
TotalBytesRead Returns the total number of bytes read by the server from clients which includes both protocol and user information. String false
TotalBytesWritten Returns the total number of bytes written by the server back to clients which includes both protocol and user information. String false

</a><table width="100%" cellspacing="1" cellpadding="0" border="1">

**Component XSiteAdmin** (Class [org.infinispan.xsite.XSiteAdminOperations](org/infinispan/xsite/XSiteAdminOperations.html)) _Exposes tooling for handling backing up data to remote sites._ **_Operations_**
**Name** **Description** **Signature**
CancelPushState Cancels the push state to remote site. String CancelPushState(String p0)
CancelReceiveState Cancels the push state to this site. All the state received from state transfer will be ignored. String CancelReceiveState(String p0)
ClearPushStateStatus Clears the state transfer status. String ClearPushStateStatus()
PushStateStatus Shows a map with destination site name and the state transfer status. Map PushStateStatus()
SendingSiteName Returns the site name from which this site is receiving state. String SendingSiteName()
amendTakeOffline Amends the values for 'TakeOffline' functionality on all the nodes in the cluster. String amendTakeOffline(String p0, int p1, long p2)
bringSiteOnline Brings the given site back online on all the cluster. String bringSiteOnline(String p0)
getTakeOfflineAfterFailures Returns the value of the 'afterFailures' for the 'TakeOffline' functionality. String getTakeOfflineAfterFailures(String p0)
getTakeOfflineMinTimeToWait Returns the value of the 'minTimeToWait' for the 'TakeOffline' functionality. String getTakeOfflineMinTimeToWait(String p0)
pushState Pushes the state of this cache to the remote site. The remote site will be bring back online String pushState(String p0)
setTakeOfflineAfterFailures Amends the values for 'afterFailures' for the 'TakeOffline' functionality on all the nodes in the cluster. String setTakeOfflineAfterFailures(String p0, int p1)
setTakeOfflineMinTimeToWait Amends the values for 'minTimeToWait' for the 'TakeOffline' functionality on all the nodes in the cluster. String setTakeOfflineMinTimeToWait(String p0, long p1)
siteStatus Check whether the given backup site is offline or not. String siteStatus(String p0)
status Returns the the status(offline/online) of all the configured backup sites. String status()
takeSiteOffline Takes this site offline in all nodes in the cluster. String takeSiteOffline(String p0)

</table>


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