Package | Description |
---|---|
org.apache.ignite.cache.eviction.fifo |
Contains cache FIFO eviction policy implementations.
|
org.apache.ignite.cache.eviction.lru |
Contains cache LRU eviction policy implementations.
|
org.apache.ignite.cache.eviction.sorted |
Contains cache sorted eviction policy implementation.
|
org.apache.ignite.mxbean |
Contains annotations for Dynamic MBeans.
|
org.apache.ignite.spi |
Contains common classes and interfaces for SPI implementations.
|
org.apache.ignite.spi.checkpoint.cache |
Contains cache-based implementation for checkpoint SPI.
|
org.apache.ignite.spi.checkpoint.jdbc |
Contains JDBC implementation for checkpoint SPI.
|
org.apache.ignite.spi.checkpoint.s3 |
Contains S3-based implementation for checkpoint SPI.
|
org.apache.ignite.spi.checkpoint.sharedfs |
Contains shared file system implementation for checkpoint SPI.
|
org.apache.ignite.spi.collision.fifoqueue |
Contains FIFO based collision SPI implementation.
|
org.apache.ignite.spi.collision.jobstealing |
Contains job stealing collision SPI implementation.
|
org.apache.ignite.spi.collision.priorityqueue |
Contains priority based collision SPI implementation.
|
org.apache.ignite.spi.communication.tcp |
Contains default TCP/IP-based implementation for communication SPI.
|
org.apache.ignite.spi.deployment.local |
Contains default local deployment SPI implementation.
|
org.apache.ignite.spi.deployment.uri |
Contains URI-based deployment SPI implementation.
|
org.apache.ignite.spi.discovery |
Contains APIs for topology manager SPI.
|
org.apache.ignite.spi.discovery.tcp |
Contains default TCP/IP implementation for discovery SPI.
|
org.apache.ignite.spi.discovery.zk |
Contains Zookeeper Discovery Spi classes and interfaces.
|
org.apache.ignite.spi.eventstorage.memory |
Contains default in-memory implementation for event storage SPI.
|
org.apache.ignite.spi.failover.always |
Contains default "always" failover SPI.
|
org.apache.ignite.spi.failover.jobstealing |
Contains job stealing failover SPI.
|
org.apache.ignite.spi.failover.never |
Contains "never" failover SPI.
|
org.apache.ignite.spi.loadbalancing.adaptive |
Contains adaptive load balancing SPI.
|
org.apache.ignite.spi.loadbalancing.roundrobin |
Contains default round-robin implementation for load balancing SPI.
|
org.apache.ignite.spi.loadbalancing.weightedrandom |
Contains weighted random-base implementation for load balancing SPI.
|
org.gridgain.grid.cache.dr |
Contains cache data center replication API classes.
|
org.gridgain.grid.dr |
Contains data center replication API classes.
|
org.gridgain.grid.persistentstore |
Contains base GridGain database interfaces.
|
org.gridgain.grid.ru |
This package contains classes related to Rolling Upgrade process.
|
org.gridgain.grid.security.jaas |
Contains JAAS API classes.
|
org.gridgain.grid.security.passcode |
Contains passcode API classes.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FifoEvictionPolicyMBean
MBean for
FIFO eviction policy. |
Modifier and Type | Method and Description |
---|---|
int |
FifoEvictionPolicyMBean.getBatchSize()
Gets batch size.
|
long |
FifoEvictionPolicyMBean.getCurrentMemorySize()
Gets current queue size in bytes.
|
int |
FifoEvictionPolicyMBean.getCurrentSize()
Gets current queue size.
|
long |
FifoEvictionPolicyMBean.getMaxMemorySize()
Gets maximum allowed cache size in bytes.
|
int |
FifoEvictionPolicyMBean.getMaxSize()
Gets maximum allowed cache size.
|
void |
FifoEvictionPolicyMBean.setBatchSize(int batchSize)
Sets batch size.
|
void |
FifoEvictionPolicyMBean.setMaxMemorySize(long maxMemSize)
Sets maximum allowed cache size in bytes.
|
void |
FifoEvictionPolicyMBean.setMaxSize(int max)
Sets maximum allowed cache size.
|
Modifier and Type | Interface and Description |
---|---|
interface |
LruEvictionPolicyMBean
MBean for
LRU eviction policy. |
Modifier and Type | Method and Description |
---|---|
int |
LruEvictionPolicyMBean.getBatchSize()
Gets batch size.
|
long |
LruEvictionPolicyMBean.getCurrentMemorySize()
Gets current queue size in bytes.
|
int |
LruEvictionPolicyMBean.getCurrentSize()
Gets current queue size.
|
long |
LruEvictionPolicyMBean.getMaxMemorySize()
Gets maximum allowed cache size in bytes.
|
int |
LruEvictionPolicyMBean.getMaxSize()
Gets maximum allowed cache size.
|
void |
LruEvictionPolicyMBean.setBatchSize(int batchSize)
Sets batch size.
|
void |
LruEvictionPolicyMBean.setMaxMemorySize(long maxMemSize)
Sets maximum allowed cache size in bytes.
|
void |
LruEvictionPolicyMBean.setMaxSize(int max)
Sets maximum allowed cache size.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SortedEvictionPolicyMBean
MBean for sorted eviction policy.
|
Modifier and Type | Method and Description |
---|---|
int |
SortedEvictionPolicyMBean.getBatchSize()
Gets batch size.
|
long |
SortedEvictionPolicyMBean.getCurrentMemorySize()
Gets current sorted entries queue size in bytes.
|
int |
SortedEvictionPolicyMBean.getCurrentSize()
Gets current size.
|
long |
SortedEvictionPolicyMBean.getMaxMemorySize()
Gets maximum allowed cache size in bytes.
|
int |
SortedEvictionPolicyMBean.getMaxSize()
Gets maximum allowed cache size.
|
void |
SortedEvictionPolicyMBean.setBatchSize(int batchSize)
Sets batch size.
|
void |
SortedEvictionPolicyMBean.setMaxMemorySize(long maxMemSize)
Sets maximum allowed cache size in bytes.
|
void |
SortedEvictionPolicyMBean.setMaxSize(int max)
Sets maximum allowed cache size.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CacheGroupMetricsMXBean
Deprecated.
Use
GridMetricManager instead. |
interface |
CacheMetricsMXBean
Deprecated.
Use
GridMetricManager instead. |
interface |
ClientProcessorMXBean
MXBean interface that provides access to ODBC\JDBC\Thin client connections.
|
interface |
ClusterMetricsMXBean
Cluster metrics MBean.
|
interface |
DataRegionMetricsMXBean
Deprecated.
Use
GridMetricManager instead. |
interface |
DefragmentationMXBean
JMX bean for defragmentation manager.
|
interface |
EncryptionMXBean
Encryption features MBean.
|
interface |
FailureHandlingMxBean
MBean that controls critical failure handling.
|
interface |
IgniteClusterMXBean
MX Bean allows to access information about cluster ID and tag and change tag.
|
interface |
IgniteMXBean
This interface defines JMX view on kernal.
|
interface |
IgnitionMXBean
This interface defines JMX view on
Ignition . |
interface |
IoStatisticsMetricsMXBean
This interface defines JMX view for IO statistics.
|
interface |
MemoryMetricsMXBean
Deprecated.
Part of old API. Metrics are accessible through
DataRegionMetricsMXBean . |
interface |
MetricsMxBean
Metrics MXBean interface.
|
interface |
StripedExecutorMXBean
MBean that provides access to information about striped executor service.
|
interface |
ThreadPoolMXBean
Deprecated.
Use
GridMetricManager instead. |
interface |
TransactionMetricsMxBean
Deprecated.
Use
GridMetricManager instead. |
interface |
TransactionsMXBean
Transactions MXBean interface.
|
interface |
WarmUpMXBean
Warm-up MXBean interface.
|
interface |
WorkersControlMXBean
MBean that provides ability to terminate worker that registered in the workers registry.
|
Modifier and Type | Method and Description |
---|---|
boolean |
IgniteMXBean.active()
Deprecated.
Use
GridMetricManager instead. |
void |
IgniteMXBean.active(boolean active) |
Set<String> |
ClusterMetricsMXBean.attributeNames()
Get distinct attribute names for given nodes projection.
|
Set<String> |
ClusterMetricsMXBean.attributeValues(String attrName)
Get distinct attribute values for given nodes projection.
|
boolean |
DefragmentationMXBean.cancel()
Cancel defragmentation.
|
void |
QueryMXBean.cancelContinuous(String originNodeId,
String routineId)
Kills continuous query by the identifier.
|
void |
QueryMXBean.cancelSQL(String id)
Kills SQL query by the identifier.
|
void |
EncryptionMXBean.changeCacheGroupKey(String cacheOrGrpName)
Starts cache group encryption key change process.
|
void |
EncryptionMXBean.changeMasterKey(String masterKeyName)
Starts master key change process.
|
void |
IgniteClusterMXBean.checkpoint() |
void |
StripedExecutorMXBean.checkStarvation()
Deprecated.
Will be removed at 3.0.
|
void |
CacheMetricsMXBean.clear()
Deprecated.
|
void |
IgniteMXBean.clearNodeLocalMap()
Clears node local map.
|
String |
IgniteMXBean.clusterState()
Deprecated.
Use
IgniteMXBean.getClusterState() instead. |
void |
IgniteMXBean.clusterState(String state)
Changes current cluster state.
|
long |
TransactionMetricsMxBean.commitTime()
Deprecated.
The last time, when transaction was commited.
|
void |
MetricsMxBean.configureHistogramMetric(String name,
long[] bounds)
Change
HistogramMetric configuration. |
void |
MetricsMxBean.configureHitRateMetric(String name,
long rateTimeInterval)
Change
HitRateMetric configuration. |
boolean |
StripedExecutorMXBean.detectStarvation() |
void |
DataRegionMetricsMXBean.disableMetrics()
Deprecated.
Disables memory metrics collection on an Apache Ignite node.
|
void |
MemoryMetricsMXBean.disableMetrics()
Deprecated.
Disables memory metrics collection on an Apache Ignite node.
|
void |
DataStorageMetricsMXBean.disableMetrics()
Deprecated.
Disables persistence metrics collection on an Apache Ignite node.
|
void |
PersistenceMetricsMXBean.disableMetrics()
Deprecated.
Disables persistence metrics collection on an Apache Ignite node.
|
void |
CacheMetricsMXBean.disableStatistics()
Deprecated.
Disable statistic collection for the cache.
|
void |
ClientProcessorMXBean.dropAllConnections()
Drop all active connections.
|
boolean |
ClientProcessorMXBean.dropConnection(long id)
Drops client connection by
id , if exists. |
void |
IgniteMXBean.dumpDebugInfo()
Dumps debug information for the current node.
|
void |
DataRegionMetricsMXBean.enableMetrics()
Deprecated.
Enables memory metrics collection on an Apache Ignite node.
|
void |
MemoryMetricsMXBean.enableMetrics()
Deprecated.
Enables memory metrics collection on an Apache Ignite node.
|
void |
DataStorageMetricsMXBean.enableMetrics()
Deprecated.
Enables persistence metrics collection on an Apache Ignite node.
|
void |
PersistenceMetricsMXBean.enableMetrics()
Deprecated.
Enables persistence metrics collection on an Apache Ignite node.
|
void |
CacheMetricsMXBean.enableStatistics()
Deprecated.
Enable statistic collection for the cache.
|
String |
IgniteMXBean.executeTask(String taskName,
String arg)
A shortcut method that executes given task assuming single
java.lang.String argument
and java.lang.String return type. |
int |
ClusterMetricsMXBean.getActiveBaselineNodes()
Get count of active baseline nodes.
|
int |
StripedExecutorMXBean.getActiveCount() |
int |
ThreadPoolMXBean.getActiveCount()
Deprecated.
Returns the approximate number of threads that are actively executing tasks.
|
String |
TransactionsMXBean.getActiveTransactions(Long minDuration,
Integer minSize,
String prj,
String consistentIds,
String xid,
String lbRegex,
Integer limit,
String order,
boolean detailed,
boolean kill) |
Map<Integer,List<String>> |
CacheGroupMetricsMXBean.getAffinityPartitionsAssignmentMap()
Deprecated.
Gets affinity partitions assignment map.
|
float |
DataRegionMetricsMXBean.getAllocationRate()
Deprecated.
Gets pages allocation rate of a memory region.
|
float |
MemoryMetricsMXBean.getAllocationRate()
Deprecated.
Gets pages allocation rate of a memory region.
|
Map<String,String> |
TransactionMetricsMxBean.getAllOwnerTransactions()
Deprecated.
All near transactions
|
long |
BaselineAutoAdjustMXBean.getAutoAdjustmentTimeout() |
float |
ClusterMetricsMXBean.getAverageActiveJobs()
Gets average number of active jobs concurrently executing on the node.
|
float |
ClusterMetricsMXBean.getAverageCancelledJobs()
Gets average number of cancelled jobs this node ever had running
concurrently.
|
double |
ClusterMetricsMXBean.getAverageCpuLoad()
Gets average of CPU load values over all metrics kept in the history.
|
float |
CacheMetricsMXBean.getAverageGetTime()
Deprecated.
The mean time to execute gets.
|
double |
ClusterMetricsMXBean.getAverageJobExecuteTime()
Gets average time a job takes to execute on the node.
|
double |
ClusterMetricsMXBean.getAverageJobWaitTime()
Gets average time jobs spend waiting in the queue to be executed.
|
float |
CacheMetricsMXBean.getAveragePutTime()
Deprecated.
The mean time to execute puts.
|
float |
ClusterMetricsMXBean.getAverageRejectedJobs()
Gets average number of jobs this node rejects during collision resolution operations.
|
float |
CacheMetricsMXBean.getAverageRemoveTime()
Deprecated.
The mean time to execute removes.
|
float |
CacheMetricsMXBean.getAverageTxCommitTime()
Deprecated.
The mean time to execute tx commit.
|
float |
CacheMetricsMXBean.getAverageTxRollbackTime()
Deprecated.
The mean time to execute tx rollbacks.
|
float |
ClusterMetricsMXBean.getAverageWaitingJobs()
Gets average number of waiting jobs this node had queued.
|
int |
CacheGroupMetricsMXBean.getBackups()
Deprecated.
Gets count of backups configured for this cache group.
|
float |
ClusterMetricsMXBean.getBusyTimePercentage()
Gets percentage of time this node is busy executing jobs vs. idling.
|
long |
CacheMetricsMXBean.getCacheEvictions()
Deprecated.
The total number of evictions from the cache.
|
long |
CacheMetricsMXBean.getCacheGets()
Deprecated.
The total number of requests to the cache.
|
Long |
IoStatisticsMetricsMXBean.getCacheGroupLogicalReads(String cacheGrpName)
Gets number of logical page reads for given cache group.
|
Long |
IoStatisticsMetricsMXBean.getCacheGroupPhysicalReads(String cacheGrpName)
Gets number of physical page reads for given cache group.
|
String |
IoStatisticsMetricsMXBean.getCacheGroupStatistics(String cacheGrpName)
Gets string presentation of cache group IO statistics for given cache group.
|
float |
CacheMetricsMXBean.getCacheHitPercentage()
Deprecated.
This is a measure of cache efficiency.
|
long |
CacheMetricsMXBean.getCacheHits()
Deprecated.
The number of get requests that were satisfied by the cache.
|
long |
CacheMetricsMXBean.getCacheMisses()
Deprecated.
A miss is a get request that is not satisfied.
|
float |
CacheMetricsMXBean.getCacheMissPercentage()
Deprecated.
Returns the percentage of cache accesses that did not find a requested entry
in the cache.
|
long |
CacheMetricsMXBean.getCachePuts()
Deprecated.
The total number of puts to the cache.
|
long |
CacheMetricsMXBean.getCacheRemovals()
Deprecated.
The total number of removals from the cache.
|
List<String> |
CacheGroupMetricsMXBean.getCaches()
Deprecated.
Gets list of cache names of this cache group.
|
long |
CacheMetricsMXBean.getCacheSize()
Deprecated.
Cache size.
|
long |
CacheMetricsMXBean.getCacheTxCommits()
Deprecated.
Gets total number of transaction commits.
|
long |
CacheMetricsMXBean.getCacheTxRollbacks()
Deprecated.
Gets total number of transaction rollbacks.
|
long |
DataRegionMetricsMXBean.getCheckpointBufferSize()
Deprecated.
Gets checkpoint buffer size in bytes.
|
long |
DataStorageMetricsMXBean.getCheckpointBufferSize()
Deprecated.
Checkpoint buffer size in bytes.
|
long |
FailureHandlingMxBean.getCheckpointReadLockTimeout() |
String |
IgniteMXBean.getCheckpointSpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
long |
DataStorageMetricsMXBean.getCheckpointTotalTime()
Deprecated.
Total checkpoint time from last restart.
|
int |
CacheGroupMetricsMXBean.getClusterMovingPartitionsCount()
Deprecated.
Gets count of partitions with state MOVING for this cache group in the entire cluster.
|
int |
CacheGroupMetricsMXBean.getClusterOwningPartitionsCount()
Deprecated.
Gets count of partitions with state OWNING for this cache group in the entire cluster.
|
String |
IgniteMXBean.getClusterState()
Checks cluster state.
|
String |
IgniteMXBean.getCollisionSpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getCommunicationSpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
long |
ThreadPoolMXBean.getCompletedTaskCount()
Deprecated.
Returns the approximate total number of tasks that have completed execution.
|
List<String> |
ClientProcessorMXBean.getConnections()
Returns list of active connections.
|
String |
IgniteMXBean.getCopyright()
Deprecated.
Use
GridMetricManager instead. |
int |
ThreadPoolMXBean.getCorePoolSize()
Deprecated.
Returns the core number of threads.
|
int |
ClusterMetricsMXBean.getCurrentActiveJobs()
Gets number of currently active jobs concurrently executing on the node.
|
int |
ClusterMetricsMXBean.getCurrentCancelledJobs()
Gets number of cancelled jobs that are still running.
|
String |
IgniteMXBean.getCurrentCoordinatorFormatted()
Deprecated.
Use
GridMetricManager instead. |
double |
ClusterMetricsMXBean.getCurrentCpuLoad()
Returns the CPU usage in
[0, 1] range. |
int |
ClusterMetricsMXBean.getCurrentDaemonThreadCount()
Returns the current number of live daemon threads.
|
double |
ClusterMetricsMXBean.getCurrentGcCpuLoad()
Returns average time spent in CG since the last update.
|
long |
ClusterMetricsMXBean.getCurrentIdleTime()
Gets time this node spend idling since executing last job.
|
long |
ClusterMetricsMXBean.getCurrentJobExecuteTime()
Gets longest time a current job has been executing for.
|
long |
ClusterMetricsMXBean.getCurrentJobWaitTime()
Gets current time an oldest jobs has spent waiting to be executed.
|
long |
ClusterMetricsMXBean.getCurrentPmeDuration()
Gets execution duration for current partition map exchange in milliseconds.
|
int |
ClusterMetricsMXBean.getCurrentRejectedJobs()
Gets number of jobs rejected after more recent collision resolution operation.
|
int |
ClusterMetricsMXBean.getCurrentThreadCount()
Returns the current number of live threads including both
daemon and non-daemon threads.
|
int |
ClusterMetricsMXBean.getCurrentWaitingJobs()
Gets number of queued jobs currently waiting to be executed.
|
String |
IgniteMXBean.getDeploymentSpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
int |
CacheMetricsMXBean.getDhtEvictQueueCurrentSize()
Deprecated.
Gets current size of evict queue used to batch up evictions.
|
long |
DataRegionMetricsMXBean.getDirtyPages()
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
|
long |
MemoryMetricsMXBean.getDirtyPages()
Deprecated.
Gets the number of dirty pages (pages which contents is different from the current persistent storage state).
|
long |
DataStorageMetricsMXBean.getDirtyPages()
Deprecated.
Total dirty pages for the next checkpoint.
|
String |
IgniteMXBean.getDiscoverySpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
float |
CacheMetricsMXBean.getEntryProcessorAverageInvocationTime()
Deprecated.
The mean time to execute cache invokes.
|
float |
CacheMetricsMXBean.getEntryProcessorHitPercentage()
Deprecated.
The percentage of invocations on keys, which exist in cache.
|
long |
CacheMetricsMXBean.getEntryProcessorHits()
Deprecated.
The total number of invocations on keys, which exist in cache.
|
long |
CacheMetricsMXBean.getEntryProcessorInvocations()
Deprecated.
The total number of cache invocations.
|
float |
CacheMetricsMXBean.getEntryProcessorMaxInvocationTime()
Deprecated.
So far, the maximum time to execute cache invokes.
|
float |
CacheMetricsMXBean.getEntryProcessorMinInvocationTime()
Deprecated.
So far, the minimum time to execute cache invokes.
|
long |
CacheMetricsMXBean.getEntryProcessorMisses()
Deprecated.
The total number of invocations on keys, which don't exist in cache.
|
float |
CacheMetricsMXBean.getEntryProcessorMissPercentage()
Deprecated.
The percentage of invocations on keys, which don't exist in cache.
|
long |
CacheMetricsMXBean.getEntryProcessorPuts()
Deprecated.
The total number of cache invocations, caused update.
|
long |
CacheMetricsMXBean.getEntryProcessorReadOnlyInvocations()
Deprecated.
The total number of cache invocations, caused no updates.
|
long |
CacheMetricsMXBean.getEntryProcessorRemovals()
Deprecated.
The total number of cache invocations, caused removal.
|
long |
CacheMetricsMXBean.getEstimatedRebalancingFinishTime()
Deprecated.
|
long |
CacheMetricsMXBean.getEstimatedRebalancingKeys()
Deprecated.
|
String |
IgniteMXBean.getEventStorageSpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
float |
DataRegionMetricsMXBean.getEvictionRate()
Deprecated.
Gets eviction rate of a given memory region.
|
float |
MemoryMetricsMXBean.getEvictionRate()
Deprecated.
Gets eviction rate of a given memory region.
|
String |
IgniteMXBean.getExecutorServiceFormatted()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getFailoverSpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getFullVersion()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getGridLoggerFormatted()
Deprecated.
Use
GridMetricManager instead. |
int |
CacheGroupMetricsMXBean.getGroupId()
Deprecated.
Gets cache group id.
|
String |
CacheGroupMetricsMXBean.getGroupName()
Deprecated.
Gets cache group name.
|
long |
CacheMetricsMXBean.getHeapEntriesCount()
Deprecated.
Gets the number of cache entries in heap memory, including entries held by active transactions, entries in
onheap cache and near entries.
|
long |
ClusterMetricsMXBean.getHeapMemoryCommitted()
Returns the amount of heap memory in bytes that is committed for
the JVM to use.
|
long |
ClusterMetricsMXBean.getHeapMemoryInitialized()
Returns the amount of heap memory in bytes that the JVM
initially requests from the operating system for memory management.
|
long |
ClusterMetricsMXBean.getHeapMemoryMaximum()
Returns the maximum amount of heap memory in bytes that can be
used for memory management.
|
long |
ClusterMetricsMXBean.getHeapMemoryTotal()
Returns the total amount of heap memory in bytes.
|
long |
ClusterMetricsMXBean.getHeapMemoryUsed()
Returns the current heap size that is used for object allocation.
|
UUID |
IgniteClusterMXBean.getId()
Gets cluster ID.
|
float |
ClusterMetricsMXBean.getIdleTimePercentage()
Gets percentage of time this node is idling vs. executing jobs.
|
String |
IgniteMXBean.getIgniteHome()
Deprecated.
Use
GridMetricManager instead. |
long |
CacheGroupMetricsMXBean.getIndexBuildCountPartitionsLeft()
Deprecated.
|
Long |
IoStatisticsMetricsMXBean.getIndexInnerLogicalReads(String cacheGrpName,
String idxName)
Gets number of logical inner index's page reads for given cache group and index.
|
Long |
IoStatisticsMetricsMXBean.getIndexInnerPhysicalReads(String cacheGrpName,
String idxName)
Gets number of physical inner index's page reads for given cache group and index.
|
Long |
IoStatisticsMetricsMXBean.getIndexLeafLogicalReads(String cacheGrpName,
String idxName)
Gets number of logical leaf index's page reads for given cache group and index.
|
Long |
IoStatisticsMetricsMXBean.getIndexLeafPhysicalReads(String cacheGrpName,
String idxName)
Gets number of physical leaf index's page reads for given cache group and index.
|
Long |
IoStatisticsMetricsMXBean.getIndexLogicalReads(String cacheGrpName,
String idxName)
Gets number of logical index page reads for given cache group and index.
|
Long |
IoStatisticsMetricsMXBean.getIndexPhysicalReads(String cacheGrpName,
String idxName)
Gets number of physical index page reads for given cache group and index.
|
long |
CacheMetricsMXBean.getIndexRebuildKeysProcessed()
Deprecated.
Return number of keys processed during index rebuilding.
|
String |
IoStatisticsMetricsMXBean.getIndexStatistics(String cacheGrpName,
String idxName)
Gets string presentation of index IO statistics for given cache group and index.
|
int |
DataRegionMetricsMXBean.getInitialSize()
Deprecated.
Gets initial memory region size defined by its
DataRegionConfiguration . |
int |
MemoryMetricsMXBean.getInitialSize()
Deprecated.
Gets initial memory region size defined by its
MemoryPolicyConfiguration . |
String |
IgniteMXBean.getInstanceName()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getJdkInformation()
Deprecated.
Use
GridMetricManager instead. |
long |
ThreadPoolMXBean.getKeepAliveTime()
Deprecated.
Returns the thread keep-alive time, which is the amount of time which threads
in excess of the core pool size may remain idle before being terminated.
|
int |
CacheMetricsMXBean.getKeySize()
Deprecated.
Gets number of keys in the cache, possibly with
null values. |
long |
CacheMetricsMXBean.getKeysToRebalanceLeft()
Deprecated.
|
String |
CacheMetricsMXBean.getKeyType()
Deprecated.
Determines the required type of keys for this
Cache , if any. |
float |
DataRegionMetricsMXBean.getLargeEntriesPagesPercentage()
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
|
float |
MemoryMetricsMXBean.getLargeEntriesPagesPercentage()
Deprecated.
Gets percentage of pages that are fully occupied by large entries that go beyond page size.
|
int |
ThreadPoolMXBean.getLargestPoolSize()
Deprecated.
Returns the largest number of threads that have ever
simultaneously been in the pool.
|
long |
DataStorageMetricsMXBean.getLastCheckpointCopiedOnWritePagesNumber()
Deprecated.
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
|
long |
PersistenceMetricsMXBean.getLastCheckpointCopiedOnWritePagesNumber()
Deprecated.
Gets the number of pages copied to a temporary checkpoint buffer during the last checkpoint.
|
long |
DataStorageMetricsMXBean.getLastCheckpointDataPagesNumber()
Deprecated.
Gets the number of data pages written during the last checkpoint.
|
long |
PersistenceMetricsMXBean.getLastCheckpointDataPagesNumber()
Deprecated.
Gets the number of data pages written during the last checkpoint.
|
long |
DataStorageMetricsMXBean.getLastCheckpointDuration()
Deprecated.
Gets the duration of the last checkpoint in milliseconds.
|
long |
DataStorageMetricsMXBean.getLastCheckpointFsyncDuration()
Deprecated.
Gets the duration of the sync phase of the last checkpoint in milliseconds.
|
long |
PersistenceMetricsMXBean.getLastCheckpointFsyncDuration()
Deprecated.
Gets the duration of the sync phase of the last checkpoint in milliseconds.
|
long |
PersistenceMetricsMXBean.getLastCheckpointingDuration()
Deprecated.
Gets the duration of the last checkpoint in milliseconds.
|
long |
DataStorageMetricsMXBean.getLastCheckpointLockWaitDuration()
Deprecated.
Gets the duration of last checkpoint lock wait in milliseconds.
|
long |
PersistenceMetricsMXBean.getLastCheckpointLockWaitDuration()
Deprecated.
Gets the duration of last checkpoint lock wait in milliseconds.
|
long |
DataStorageMetricsMXBean.getLastCheckpointMarkDuration()
Deprecated.
Gets the duration of last checkpoint mark phase in milliseconds.
|
long |
PersistenceMetricsMXBean.getLastCheckpointMarkDuration()
Deprecated.
Gets the duration of last checkpoint mark phase in milliseconds.
|
long |
DataStorageMetricsMXBean.getLastCheckpointPagesWriteDuration()
Deprecated.
Gets the duration of last checkpoint pages write phase in milliseconds.
|
long |
PersistenceMetricsMXBean.getLastCheckpointPagesWriteDuration()
Deprecated.
Gets the duration of last checkpoint pages write phase in milliseconds.
|
long |
DataStorageMetricsMXBean.getLastCheckpointStarted()
Deprecated.
Returns time when the last checkpoint was started.
|
long |
DataStorageMetricsMXBean.getLastCheckpointTotalPagesNumber()
Deprecated.
Gets the total number of pages written during the last checkpoint.
|
long |
PersistenceMetricsMXBean.getLastCheckpointTotalPagesNumber()
Deprecated.
Gets the total number of pages written during the last checkpoint.
|
long |
ClusterMetricsMXBean.getLastDataVersion()
In-Memory Data Grid assigns incremental versions to all cache operations.
|
long |
ClusterMetricsMXBean.getLastUpdateTime()
Gets last update time of this node metrics.
|
List<String> |
IgniteMXBean.getLifecycleBeansFormatted()
Deprecated.
Use
GridMetricManager instead. |
boolean |
FailureHandlingMxBean.getLivenessCheckEnabled() |
String |
IgniteMXBean.getLoadBalancingSpiFormatted()
Deprecated.
Use
GridMetricManager instead. |
UUID |
IgniteMXBean.getLocalNodeId()
Deprecated.
Use
GridMetricManager instead. |
int |
CacheGroupMetricsMXBean.getLocalNodeMovingPartitionsCount()
Deprecated.
Gets count of partitions with state MOVING for this cache group located on this node.
|
int |
CacheGroupMetricsMXBean.getLocalNodeOwningPartitionsCount()
Deprecated.
Gets count of partitions with state OWNING for this cache group located on this node.
|
long |
CacheGroupMetricsMXBean.getLocalNodeRentingEntriesCount()
Deprecated.
Gets count of entries remains to evict in RENTING partitions located on this node for this cache group.
|
int |
CacheGroupMetricsMXBean.getLocalNodeRentingPartitionsCount()
Deprecated.
Gets count of partitions with state RENTING for this cache group located on this node.
|
long |
TransactionMetricsMxBean.getLockedKeysNumber()
Deprecated.
The number of keys locked on the node.
|
Map<Long,Long> |
IgniteMXBean.getLongJVMPauseLastEvents()
Deprecated.
Use
GridMetricManager instead. |
long |
IgniteMXBean.getLongJVMPausesCount()
Deprecated.
Use
GridMetricManager instead. |
long |
IgniteMXBean.getLongJVMPausesTotalDuration()
Deprecated.
Use
GridMetricManager instead. |
long |
TransactionsMXBean.getLongOperationsDumpTimeout()
Returns a timeout (in millis) for printing to log long-running
transactions as well as transactions that cannot receive locks for all
their keys for a long time.
|
Map<String,String> |
TransactionMetricsMxBean.getLongRunningOwnerTransactions(int duration)
Deprecated.
Long running near transactions
|
long |
TransactionsMXBean.getLongTransactionTimeDumpThreshold()
Returns threshold timeout in milliseconds for long transactions, if transaction exceeds it,
it will be dumped in log with information about how much time did
it spent in system time (time while aquiring locks, preparing, commiting, etc.)
|
String |
EncryptionMXBean.getMasterKeyName()
Gets the current master key name.
|
int |
ClientProcessorMXBean.getMaxConnectionsPerNode() |
int |
ClusterMetricsMXBean.getMaximumActiveJobs()
Gets maximum number of jobs that ever ran concurrently on this node.
|
int |
ClusterMetricsMXBean.getMaximumCancelledJobs()
Gets maximum number of cancelled jobs this node ever had running
concurrently.
|
long |
ClusterMetricsMXBean.getMaximumJobExecuteTime()
Gets time it took to execute the longest job on the node.
|
long |
ClusterMetricsMXBean.getMaximumJobWaitTime()
Gets maximum time a job ever spent waiting in a queue to be executed.
|
int |
CacheGroupMetricsMXBean.getMaximumNumberOfPartitionCopies()
Deprecated.
Calculates maximum number of partitions copies for all partitions of this cache group.
|
int |
ThreadPoolMXBean.getMaximumPoolSize()
Deprecated.
Returns the maximum allowed number of threads.
|
int |
ClusterMetricsMXBean.getMaximumRejectedJobs()
Gets maximum number of jobs rejected at once during a single collision resolution
operation.
|
int |
ClusterMetricsMXBean.getMaximumThreadCount()
Returns the maximum live thread count since the JVM
started or peak was reset.
|
int |
ClusterMetricsMXBean.getMaximumWaitingJobs()
Gets maximum number of waiting jobs this node had.
|
int |
DataRegionMetricsMXBean.getMaxSize()
Deprecated.
Maximum memory region size defined by its
DataRegionConfiguration . |
int |
MemoryMetricsMXBean.getMaxSize()
Deprecated.
Maximum memory region size defined by its
MemoryPolicyConfiguration . |
String |
IgniteMXBean.getMBeanServerFormatted()
Deprecated.
Use
GridMetricManager instead. |
int |
CacheGroupMetricsMXBean.getMinimumNumberOfPartitionCopies()
Deprecated.
Calculates minimum number of partitions copies for all partitions of this cache group.
|
Map<Integer,Set<String>> |
CacheGroupMetricsMXBean.getMovingPartitionsAllocationMap()
Deprecated.
Gets allocation map of partitions with state MOVING in the cluster.
|
String |
DataRegionMetricsMXBean.getName()
Deprecated.
A name of a memory region the metrics are collected for.
|
String |
MemoryMetricsMXBean.getName()
Deprecated.
A name of a memory region the metrics are collected for.
|
long |
ClusterMetricsMXBean.getNodeStartTime()
Returns the start time of grid node in milliseconds.
|
long |
ClusterMetricsMXBean.getNonHeapMemoryCommitted()
Returns the amount of non-heap memory in bytes that is committed for
the JVM to use.
|
long |
ClusterMetricsMXBean.getNonHeapMemoryInitialized()
Returns the amount of non-heap memory in bytes that the JVM
initially requests from the operating system for memory management.
|
long |
ClusterMetricsMXBean.getNonHeapMemoryMaximum()
Returns the maximum amount of non-heap memory in bytes that can be
used for memory management.
|
long |
ClusterMetricsMXBean.getNonHeapMemoryTotal()
Returns the total amount of non-heap memory in bytes that can be
used for memory management.
|
long |
ClusterMetricsMXBean.getNonHeapMemoryUsed()
Returns the current non-heap memory size that is used by Java VM.
|
long |
CacheMetricsMXBean.getOffHeapAllocatedSize()
Deprecated.
Gets memory size allocated in off-heap.
|
long |
CacheMetricsMXBean.getOffHeapBackupEntriesCount()
Deprecated.
Gets number of backup entries stored in off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapEntriesCount()
Deprecated.
Gets number of entries stored in off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapEvictions()
Deprecated.
The total number of evictions from the off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapGets()
Deprecated.
The total number of get requests to the off-heap memory.
|
float |
CacheMetricsMXBean.getOffHeapHitPercentage()
Deprecated.
Gets the percentage of hits on off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapHits()
Deprecated.
The number of get requests that were satisfied by the off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapMisses()
Deprecated.
A miss is a get request that is not satisfied by off-heap memory.
|
float |
CacheMetricsMXBean.getOffHeapMissPercentage()
Deprecated.
Gets the percentage of misses on off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapPrimaryEntriesCount()
Deprecated.
Gets number of primary entries stored in off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapPuts()
Deprecated.
The total number of put requests to the off-heap memory.
|
long |
CacheMetricsMXBean.getOffHeapRemovals()
Deprecated.
The total number of removals from the off-heap memory.
|
long |
DataRegionMetricsMXBean.getOffHeapSize()
Deprecated.
Total offheap size in bytes.
|
long |
DataStorageMetricsMXBean.getOffHeapSize()
Deprecated.
Total offheap size in bytes.
|
long |
DataRegionMetricsMXBean.getOffheapUsedSize()
Deprecated.
Total used offheap size in bytes.
|
long |
DataStorageMetricsMXBean.getOffheapUsedSize()
Deprecated.
Total used offheap size in bytes.
|
String |
IgniteMXBean.getOsInformation()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getOsUser()
Deprecated.
Use
GridMetricManager instead. |
int |
ClusterMetricsMXBean.getOutboundMessagesQueueSize()
Gets outbound messages queue size.
|
long |
TransactionMetricsMxBean.getOwnerTransactionsNumber()
Deprecated.
The number of active transactions for which this node is the initiator.
|
Map<Integer,Set<String>> |
CacheGroupMetricsMXBean.getOwningPartitionsAllocationMap()
Deprecated.
Gets allocation map of partitions with state OWNING in the cluster.
|
float |
DataRegionMetricsMXBean.getPagesFillFactor()
Deprecated.
Returns the ratio of space occupied by user and system data to the size of all pages that contain this data.
|
float |
MemoryMetricsMXBean.getPagesFillFactor()
Deprecated.
Gets the percentage of space that is still free and can be filled in.
|
int |
DataRegionMetricsMXBean.getPageSize()
Deprecated.
Gets memory page size.
|
long |
DataRegionMetricsMXBean.getPagesRead()
Deprecated.
The number of read pages from last restart.
|
long |
DataStorageMetricsMXBean.getPagesRead()
Deprecated.
The number of read pages from last restart.
|
float |
DataRegionMetricsMXBean.getPagesReplaceAge()
Deprecated.
Gets average age (in milliseconds) for the pages being replaced from the disk storage.
|
long |
DataRegionMetricsMXBean.getPagesReplaced()
Deprecated.
The number of replaced pages from last restart .
|
long |
DataStorageMetricsMXBean.getPagesReplaced()
Deprecated.
The number of replaced pages from last restart.
|
float |
DataRegionMetricsMXBean.getPagesReplaceRate()
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
|
float |
MemoryMetricsMXBean.getPagesReplaceRate()
Deprecated.
Gets rate (pages per second) at which pages get replaced with other pages from persistent storage.
|
long |
DataRegionMetricsMXBean.getPagesWritten()
Deprecated.
The number of written pages from last restart.
|
long |
DataStorageMetricsMXBean.getPagesWritten()
Deprecated.
The number of written pages from last restart.
|
List<Integer> |
CacheGroupMetricsMXBean.getPartitionIds()
Deprecated.
Local partition ids.
|
int |
CacheGroupMetricsMXBean.getPartitions()
Deprecated.
Gets count of partitions for this cache group.
|
long |
DataRegionMetricsMXBean.getPhysicalMemoryPages()
Deprecated.
Gets total number of pages currently loaded to the RAM.
|
long |
MemoryMetricsMXBean.getPhysicalMemoryPages()
Deprecated.
Gets total number of pages currently loaded to the RAM.
|
long |
DataRegionMetricsMXBean.getPhysicalMemorySize()
Deprecated.
Gets total size of pages loaded to the RAM.
|
int |
ThreadPoolMXBean.getPoolSize()
Deprecated.
Returns the current number of threads in the pool.
|
int |
IgniteMXBean.getPublicThreadPoolSize()
Gets a public thread pool size to be used in grid.
|
int |
ThreadPoolMXBean.getQueueSize()
Deprecated.
Gets current size of the execution queue.
|
long |
CacheMetricsMXBean.getRebalanceClearingPartitionsLeft()
Deprecated.
|
long |
CacheMetricsMXBean.getRebalancedKeys()
Deprecated.
|
long |
CacheMetricsMXBean.getRebalancingBytesRate()
Deprecated.
|
long |
CacheMetricsMXBean.getRebalancingKeysRate()
Deprecated.
|
int |
CacheMetricsMXBean.getRebalancingPartitionsCount()
Deprecated.
|
long |
CacheMetricsMXBean.getRebalancingStartTime()
Deprecated.
|
long |
ClusterMetricsMXBean.getReceivedBytesCount()
Gets received bytes count.
|
int |
ClusterMetricsMXBean.getReceivedMessagesCount()
Gets received messages count.
|
String |
ThreadPoolMXBean.getRejectedExecutionHandlerClass()
Deprecated.
The class name of the handler for tasks that cannot be executed.
|
long |
ClusterMetricsMXBean.getSentBytesCount()
Gets sent bytes count.
|
int |
ClusterMetricsMXBean.getSentMessagesCount()
Gets sent messages count.
|
int |
CacheMetricsMXBean.getSize()
Deprecated.
Gets number of non-
null values in the cache. |
long |
CacheGroupMetricsMXBean.getSparseStorageSize()
Deprecated.
Storage space allocated for group adjusted for possible sparsity, in bytes.
|
long |
DataStorageMetricsMXBean.getSparseStorageSize()
Deprecated.
Storage space allocated adjusted for possible sparsity in bytes.
|
long |
ClusterMetricsMXBean.getStartTime()
Returns the start time of the JVM in milliseconds.
|
long |
IoStatisticsMetricsMXBean.getStartTime() |
String |
IoStatisticsMetricsMXBean.getStartTimeLocal() |
long |
IgniteMXBean.getStartTimestamp()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getStartTimestampFormatted()
Deprecated.
Use
GridMetricManager instead. |
String |
IgnitionMXBean.getState()
Gets state of default grid instance.
|
String |
IgnitionMXBean.getState(String name)
Gets state for a given grid instance.
|
long |
CacheGroupMetricsMXBean.getStorageSize()
Deprecated.
Storage space allocated for group, in bytes.
|
long |
DataStorageMetricsMXBean.getStorageSize()
Deprecated.
Storage space allocated in bytes.
|
boolean[] |
StripedExecutorMXBean.getStripesActiveStatuses() |
long[] |
StripedExecutorMXBean.getStripesCompletedTasksCounts() |
int |
StripedExecutorMXBean.getStripesCount() |
int[] |
StripedExecutorMXBean.getStripesQueueSizes() |
String |
MemoryMetricsMXBean.getSwapFilePath()
Deprecated.
A path to the memory-mapped files the memory region defined by
MemoryPolicyConfiguration will be
mapped to. |
String |
DataRegionMetricsMXBean.getSwapPath()
Deprecated.
A path to the memory-mapped files the memory region defined by
DataRegionConfiguration will be
mapped to. |
long |
FailureHandlingMxBean.getSystemWorkerBlockedTimeout() |
String |
IgniteClusterMXBean.getTag()
Gets current cluster tag.
|
long |
ThreadPoolMXBean.getTaskCount()
Deprecated.
Returns the approximate total number of tasks that have been scheduled
for execution.
|
String |
BaselineAutoAdjustMXBean.getTaskState() |
String |
ThreadPoolMXBean.getThreadFactoryClass()
Deprecated.
Returns the class name of thread factory used to create new threads.
|
long |
BaselineAutoAdjustMXBean.getTimeUntilAutoAdjust() |
long |
ClusterMetricsMXBean.getTopologyVersion()
Get current topology version.
|
long |
CacheGroupMetricsMXBean.getTotalAllocatedPages()
Deprecated.
Cache group total allocated pages.
|
long |
DataRegionMetricsMXBean.getTotalAllocatedPages()
Deprecated.
Gets a total number of allocated pages related to the data region.
|
long |
MemoryMetricsMXBean.getTotalAllocatedPages()
Deprecated.
Gets a total number of allocated pages related to the memory policy.
|
long |
CacheGroupMetricsMXBean.getTotalAllocatedSize()
Deprecated.
Total size of memory allocated for group, in bytes.
|
long |
DataRegionMetricsMXBean.getTotalAllocatedSize()
Deprecated.
Gets a total size of memory allocated in the data region.
|
long |
DataStorageMetricsMXBean.getTotalAllocatedSize()
Deprecated.
Total size of memory allocated in bytes.
|
int |
ClusterMetricsMXBean.getTotalBaselineNodes()
Get count of total baseline nodes.
|
long |
ClusterMetricsMXBean.getTotalBusyTime()
Gets total time this node spent executing jobs.
|
int |
ClusterMetricsMXBean.getTotalCancelledJobs()
Gets number of cancelled jobs since node startup.
|
int |
ClusterMetricsMXBean.getTotalClientNodes()
Get count of client nodes.
|
long |
StripedExecutorMXBean.getTotalCompletedTasksCount() |
int |
ClusterMetricsMXBean.getTotalCpus()
Returns the number of CPUs available to the Java Virtual Machine.
|
int |
ClusterMetricsMXBean.getTotalExecutedJobs()
Gets total number of jobs handled by the node since node startup.
|
int |
ClusterMetricsMXBean.getTotalExecutedTasks()
Gets total number of tasks handled by the node.
|
long |
ClusterMetricsMXBean.getTotalIdleTime()
Gets total time this node spent idling (not executing any jobs).
|
long |
ClusterMetricsMXBean.getTotalJobsExecutionTime()
Gets total time all finished jobs takes to execute on the node since node startup.
|
int |
ClusterMetricsMXBean.getTotalNodes()
Gets total number of nodes.
|
int |
CacheMetricsMXBean.getTotalPartitionsCount()
Deprecated.
|
int |
StripedExecutorMXBean.getTotalQueueSize() |
int |
ClusterMetricsMXBean.getTotalRejectedJobs()
Gets total number of jobs this node rejects during collision resolution operations since node startup.
|
int |
ClusterMetricsMXBean.getTotalServerNodes()
Get count of server nodes.
|
long |
ClusterMetricsMXBean.getTotalStartedThreadCount()
Returns the total number of threads created and also started
since the JVM started.
|
long |
DataRegionMetricsMXBean.getTotalUsedPages()
Deprecated.
Gets a total number of pages used for storing the data.
|
long |
DataRegionMetricsMXBean.getTotalUsedSize()
Deprecated.
Returns the total amount of bytes occupied by the non-empty pages.
|
long |
TransactionMetricsMxBean.getTransactionsCommittedNumber()
Deprecated.
The number of transactions which were committed.
|
long |
TransactionMetricsMxBean.getTransactionsHoldingLockNumber()
Deprecated.
The number of active transactions holding at least one key lock.
|
long |
TransactionMetricsMxBean.getTransactionsRolledBackNumber()
Deprecated.
The number of transactions which were rollback.
|
double |
TransactionsMXBean.getTransactionTimeDumpSamplesCoefficient()
Returns the coefficient for samples of completed transactions that will be dumped in log.
|
int |
TransactionsMXBean.getTransactionTimeDumpSamplesPerSecondLimit()
Returns the limit of samples of completed transactions that will be dumped in log per second,
if
TransactionsMXBean.getTransactionTimeDumpSamplesCoefficient() is above 0.0 . |
int |
CacheMetricsMXBean.getTxCommitQueueSize()
Deprecated.
Gets committed transaction queue size.
|
int |
CacheMetricsMXBean.getTxCommittedVersionsSize()
Deprecated.
Gets number of cached committed transaction IDs.
|
int |
CacheMetricsMXBean.getTxDhtCommitQueueSize()
Deprecated.
Gets committed DHT transaction queue size.
|
int |
CacheMetricsMXBean.getTxDhtCommittedVersionsSize()
Deprecated.
Gets number of cached committed DHT transaction IDs.
|
int |
CacheMetricsMXBean.getTxDhtPrepareQueueSize()
Deprecated.
Gets prepared DHT transaction queue size.
|
int |
CacheMetricsMXBean.getTxDhtRolledbackVersionsSize()
Deprecated.
Gets number of cached rolled back DHT transaction IDs.
|
int |
CacheMetricsMXBean.getTxDhtStartVersionCountsSize()
Deprecated.
Gets DHT start version counts map size.
|
int |
CacheMetricsMXBean.getTxDhtThreadMapSize()
Deprecated.
Gets transaction DHT per-thread map size.
|
int |
CacheMetricsMXBean.getTxDhtXidMapSize()
Deprecated.
Gets transaction DHT per-Xid map size.
|
String |
CacheMetricsMXBean.getTxKeyCollisions()
Deprecated.
Checks if there were any tx key collisions last time.
|
int |
TransactionsMXBean.getTxKeyCollisionsInterval() |
boolean |
TransactionsMXBean.getTxOwnerDumpRequestsAllowed()
Shows if dump requests from local node to near node are allowed, when long running transaction
is found.
|
int |
CacheMetricsMXBean.getTxPrepareQueueSize()
Deprecated.
Gets prepared transaction queue size.
|
int |
CacheMetricsMXBean.getTxRolledbackVersionsSize()
Deprecated.
Gets number of cached rolled back transaction IDs.
|
int |
CacheMetricsMXBean.getTxStartVersionCountsSize()
Deprecated.
Gets start version counts map size.
|
int |
CacheMetricsMXBean.getTxThreadMapSize()
Deprecated.
Gets transaction per-thread map size.
|
long |
TransactionsMXBean.getTxTimeoutOnPartitionMapExchange()
Gets transaction timeout on partition map exchange.
|
int |
CacheMetricsMXBean.getTxXidMapSize()
Deprecated.
Gets transaction per-Xid map size.
|
String |
CacheGroupMetricsMXBean.getType()
Deprecated.
Cache group type.
|
long |
ClusterMetricsMXBean.getUpTime()
Returns the uptime of the JVM in milliseconds.
|
long |
IgniteMXBean.getUpTime()
Deprecated.
Use
GridMetricManager instead. |
String |
IgniteMXBean.getUpTimeFormatted()
Deprecated.
Use
GridMetricManager instead. |
long |
DataRegionMetricsMXBean.getUsedCheckpointBufferPages()
Deprecated.
Gets used checkpoint buffer size in pages.
|
long |
DataStorageMetricsMXBean.getUsedCheckpointBufferPages()
Deprecated.
Gets used checkpoint buffer size in pages.
|
long |
DataRegionMetricsMXBean.getUsedCheckpointBufferSize()
Deprecated.
Gets used checkpoint buffer size in bytes.
|
long |
DataStorageMetricsMXBean.getUsedCheckpointBufferSize()
Deprecated.
Gets used checkpoint buffer size in bytes.
|
List<String> |
IgniteMXBean.getUserAttributesFormatted()
Deprecated.
Use
GridMetricManager instead. |
String |
CacheMetricsMXBean.getValueType()
Deprecated.
Determines the required type of values for this
Cache , if any. |
String |
IgniteMXBean.getVmName()
Deprecated.
Use
GridMetricManager instead. |
int |
DataStorageMetricsMXBean.getWalArchiveSegments()
Deprecated.
Gets the current number of WAL segments in the WAL archive.
|
int |
PersistenceMetricsMXBean.getWalArchiveSegments()
Deprecated.
Gets the current number of WAL segments in the WAL archive.
|
long |
DataStorageMetricsMXBean.getWalBuffPollSpinsRate()
Deprecated.
Returns WAL buffer poll spins number over the last time interval.
|
int |
DataStorageMXBean.getWalCompactionLevel() |
long |
DataStorageMetricsMXBean.getWalCompressedBytes()
Deprecated.
Getting the total size of the compressed segments in bytes.
|
float |
DataStorageMetricsMXBean.getWalFsyncTimeAverage()
Deprecated.
Gets the average WAL fsync duration in microseconds over the last time interval.
|
float |
PersistenceMetricsMXBean.getWalFsyncTimeAverage()
Deprecated.
Gets the average WAL fsync duration in microseconds over the last time interval.
|
long |
DataStorageMetricsMXBean.getWalLastRollOverTime()
Deprecated.
Time of the last WAL segment rollover.
|
float |
DataStorageMetricsMXBean.getWalLoggingRate()
Deprecated.
Gets the average number of WAL records per second written during the last time interval.
|
float |
PersistenceMetricsMXBean.getWalLoggingRate()
Deprecated.
Gets the average number of WAL records per second written during the last time interval.
|
long |
DataStorageMetricsMXBean.getWalTotalSize()
Deprecated.
Total size in bytes for storage wal files.
|
float |
DataStorageMetricsMXBean.getWalWritingRate()
Deprecated.
Gets the average number of bytes per second written during the last time interval.
|
float |
PersistenceMetricsMXBean.getWalWritingRate()
Deprecated.
Gets the average number of bytes per second written during the last time interval.
|
long |
DataStorageMetricsMXBean.getWalWrittenBytes()
Deprecated.
Getting the total number of logged bytes into the WAL.
|
List<String> |
WorkersControlMXBean.getWorkerNames()
Returns names of all registered workers.
|
int |
CacheMetricsMXBean.getWriteBehindBufferSize()
Deprecated.
Gets count of entries that were processed by the write-behind store and have not been
flushed to the underlying store yet.
|
int |
CacheMetricsMXBean.getWriteBehindCriticalOverflowCount()
Deprecated.
Gets count of write buffer overflow events in progress at the moment.
|
int |
CacheMetricsMXBean.getWriteBehindErrorRetryCount()
Deprecated.
Gets count of cache entries that are in a store-retry state.
|
long |
CacheMetricsMXBean.getWriteBehindFlushFrequency()
Deprecated.
Gets the cache flush frequency.
|
int |
CacheMetricsMXBean.getWriteBehindFlushSize()
Deprecated.
Gets the maximum size of the write-behind buffer.
|
int |
CacheMetricsMXBean.getWriteBehindFlushThreadCount()
Deprecated.
Gets the number of flush threads that will perform store update operations.
|
int |
CacheMetricsMXBean.getWriteBehindStoreBatchSize()
Deprecated.
Gets the maximum count of similar (put or remove) operations that can be grouped to a single batch.
|
int |
CacheMetricsMXBean.getWriteBehindTotalCriticalOverflowCount()
Deprecated.
Gets count of write buffer overflow events since initialization.
|
void |
IgniteClusterMXBean.id(UUID newId)
Changes cluster ID to provided value.
|
boolean |
DefragmentationMXBean.inProgress()
Get defragmentation status.
|
boolean |
BaselineAutoAdjustMXBean.isAutoAdjustmentEnabled() |
boolean |
CacheMetricsMXBean.isEmpty()
Deprecated.
Returns
true if this cache is empty. |
boolean |
CacheMetricsMXBean.isIndexRebuildInProgress()
Deprecated.
Return
true if index rebuild is in progress. |
boolean |
CacheMetricsMXBean.isManagementEnabled()
Deprecated.
Checks whether cache management via MBean is enabled.
|
boolean |
IgniteMXBean.isNodeInBaseline()
Deprecated.
Use
GridMetricManager instead. |
boolean |
IgniteMXBean.isPeerClassLoadingEnabled()
Deprecated.
Use
GridMetricManager instead. |
boolean |
CacheMetricsMXBean.isReadThrough()
Deprecated.
Determines if a
Cache should operate in read-through mode. |
boolean |
IgniteMXBean.isRebalanceEnabled()
Deprecated.
Use
GridMetricManager instead. |
boolean |
StripedExecutorMXBean.isShutdown() |
boolean |
ThreadPoolMXBean.isShutdown()
Deprecated.
Returns
true if this executor has been shut down. |
boolean |
CacheMetricsMXBean.isStatisticsEnabled()
Deprecated.
Checks whether statistics collection is enabled in this cache.
|
boolean |
CacheMetricsMXBean.isStoreByValue()
Deprecated.
Whether storeByValue
true or storeByReference false . |
boolean |
StripedExecutorMXBean.isTerminated()
Note that
isTerminated() is never true unless either shutdown() or
shutdownNow() was called first. |
boolean |
ThreadPoolMXBean.isTerminated()
Deprecated.
Returns
true if all tasks have completed following shut down. |
boolean |
ThreadPoolMXBean.isTerminating()
Deprecated.
Returns
true if this executor is in the process of terminating after
shutdown() or shutdownNow() but has not completely terminated. |
boolean |
CacheMetricsMXBean.isValidForReading()
Deprecated.
Checks whether cache topology is valid for read operations.
|
boolean |
CacheMetricsMXBean.isValidForWriting()
Deprecated.
Checks whether cache topology is valid for write operations.
|
boolean |
CacheMetricsMXBean.isWriteBehindEnabled()
Deprecated.
Returns
true if write-behind is enabled. |
boolean |
CacheMetricsMXBean.isWriteThrough()
Deprecated.
Determines if a
Cache should operate in "write-through"
mode. |
long |
IgniteMXBean.lastClusterStateChangeTime()
Gets last cluster state change operation.
|
String |
CacheMetricsMXBean.name()
Deprecated.
Gets name of this cache.
|
Set<UUID> |
ClusterMetricsMXBean.nodeIdsForAttribute(String attrName,
String attrVal,
boolean includeSrvs,
boolean includeClients)
Get node IDs with the given attribute value.
|
boolean |
IgniteMXBean.pingNode(String nodeId)
Pings node with given node ID to see whether it is alive.
|
boolean |
IgniteMXBean.pingNodeByAddress(String host)
Pings node with given host name to see if it is alive.
|
void |
IgniteMXBean.printLastErrors()
Prints errors.
|
int |
DefragmentationMXBean.processedPartitions()
Get count of processed partitions.
|
void |
DataRegionMetricsMXBean.rateTimeInterval(long rateTimeInterval)
Deprecated.
Use
MetricsMxBean.configureHitRateMetric(String, long) instead. |
void |
MemoryMetricsMXBean.rateTimeInterval(long rateTimeInterval)
Deprecated.
Sets time interval for
MemoryMetricsMXBean.getAllocationRate() and MemoryMetricsMXBean.getEvictionRate() monitoring purposes. |
void |
DataStorageMetricsMXBean.rateTimeInterval(long rateTimeInterval)
Deprecated.
Use
MetricsMxBean.configureHitRateMetric(String, long) instead. |
void |
PersistenceMetricsMXBean.rateTimeInterval(long rateTimeInterval)
Deprecated.
Sets time interval for rate-based metrics.
|
boolean |
IgniteMXBean.removeCheckpoint(String key)
This method allows manually remove the checkpoint with given
key . |
void |
IoStatisticsMetricsMXBean.reset()
Reset all IO statistics.
|
void |
IgniteMXBean.resetMetrics(String registry)
Resets metrics for of a given registry.
|
void |
MetricsMxBean.resetMetrics(String registry)
Resets metrics for of a given registry.
|
void |
IgnitionMXBean.restart(boolean cancel)
Restart JVM.
|
long |
TransactionMetricsMxBean.rollbackTime()
Deprecated.
The last time, when transaction was rollbacked.
|
void |
IgniteMXBean.runIoTest(long warmup,
long duration,
int threads,
long maxLatency,
int rangesCnt,
int payLoadSize,
boolean procFromNioThread)
Runs IO latency test against all remote server nodes in cluster.
|
boolean |
DefragmentationMXBean.schedule(String cacheNames)
Schedule defragmentation for given caches.
|
void |
BaselineAutoAdjustMXBean.setAutoAdjustmentEnabled(boolean enabled) |
void |
BaselineAutoAdjustMXBean.setAutoAdjustmentTimeout(long timeout) |
void |
TransactionsMXBean.setLongOperationsDumpTimeout(long timeout)
Setting a timeout (in millis) for printing to log long-running
transactions as well as transactions that cannot receive locks for all
their keys for a long time.
|
void |
TransactionsMXBean.setLongTransactionTimeDumpThreshold(long threshold)
Sets threshold timeout in milliseconds for long transactions, if transaction exceeds it,
it will be dumped in log with information about how much time did
it spent in system time (time while aquiring locks, preparing, commiting, etc.)
|
void |
ClientProcessorMXBean.setMaxConnectionsPerNode(int maxConnectionsPerNode)
Sets maximum allowed number of active client connections per node.
|
void |
TransactionsMXBean.setTransactionTimeDumpSamplesCoefficient(double coefficient)
Sets the coefficient for samples of completed transactions that will be dumped in log.
|
void |
TransactionsMXBean.setTransactionTimeDumpSamplesPerSecondLimit(int limit)
Sets the limit of samples of completed transactions that will be dumped in log per second,
if
TransactionsMXBean.getTransactionTimeDumpSamplesCoefficient() is above 0.0 . |
void |
TransactionsMXBean.setTxKeyCollisionsInterval(int timeout)
Set timeout interval for tx key contention analysis.
|
void |
TransactionsMXBean.setTxOwnerDumpRequestsAllowed(boolean allowed)
Sets if dump requests from local node to near node are allowed, when long running transaction
is found.
|
void |
TransactionsMXBean.setTxTimeoutOnPartitionMapExchange(long timeout)
Sets transaction timeout on partition map exchange.
0 means transactions will never be rolled back on partition map exchange.
|
void |
DataStorageMXBean.setWalCompactionLevel(int walCompactionLevel)
Sets ZIP compression level to WAL compaction.
|
void |
ClientProcessorMXBean.showFullStackOnClientSide(boolean show)
If sets to
true shows full stack trace otherwise highlevel short error message. |
long |
DefragmentationMXBean.startTime()
Get defragmentation's start time.
|
boolean |
IgnitionMXBean.stop(boolean cancel)
Stops default grid instance.
|
boolean |
IgnitionMXBean.stop(String name,
boolean cancel)
Stops named Ignite instance.
|
void |
IgnitionMXBean.stopAll(boolean cancel)
Stops all started grids.
|
boolean |
WorkersControlMXBean.stopThreadById(long id)
Stops thread by
id , if exists. |
boolean |
WorkersControlMXBean.stopThreadByUniqueName(String name)
Stops thread by
name , if exists and unique. |
void |
WarmUpMXBean.stopWarmUp()
Stop warm-up.
|
void |
DataRegionMetricsMXBean.subIntervals(int subInts)
Deprecated.
Use
MetricsMxBean.configureHitRateMetric(String, long) instead. |
void |
MemoryMetricsMXBean.subIntervals(int subInts)
Deprecated.
Sets a number of sub-intervals the whole
MemoryMetricsMXBean.rateTimeInterval(long) will be split into to calculate
MemoryMetricsMXBean.getAllocationRate() and MemoryMetricsMXBean.getEvictionRate() rates (5 by default). |
void |
DataStorageMetricsMXBean.subIntervals(int subInts)
Deprecated.
Use
MetricsMxBean.configureHitRateMetric(String, long) instead. |
void |
PersistenceMetricsMXBean.subIntervals(int subInts)
Deprecated.
Sets a number of sub-intervals the whole
PersistenceMetricsMXBean.rateTimeInterval(long) will be split into to calculate
rate-based metrics. |
void |
IgniteClusterMXBean.tag(String newTag)
Changes cluster tag to provided value.
|
boolean |
WorkersControlMXBean.terminateWorker(String name)
Terminates worker.
|
int |
DefragmentationMXBean.totalPartitions()
Get total count of partitions.
|
int |
TransactionMetricsMxBean.txCommits()
Deprecated.
The total number of commited transactions.
|
int |
TransactionMetricsMxBean.txRollbacks()
Deprecated.
Tne total number of rollbacked transactions.
|
void |
IgniteMXBean.undeployTaskFromGrid(String taskName)
Makes the best attempt to undeploy a task from the whole grid.
|
Modifier and Type | Method and Description |
---|---|
String |
IgniteSpiManagementMBean.getIgniteHome()
Gets Ignite installation home folder (i.e.
|
UUID |
IgniteSpiManagementMBean.getLocalNodeId()
Gets ID of the local node.
|
String |
IgniteSpiManagementMBean.getName()
Gets name of the SPI.
|
long |
IgniteSpiManagementMBean.getStartTimestamp()
Get start timestamp of this SPI.
|
String |
IgniteSpiManagementMBean.getStartTimestampFormatted()
Gets string presentation of the start timestamp.
|
long |
IgniteSpiManagementMBean.getUpTime()
Gets up-time of this SPI in ms.
|
String |
IgniteSpiManagementMBean.getUpTimeFormatted()
Gets string presentation of up-time for this SPI.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CacheCheckpointSpiMBean
Management bean that provides general administrative and configuration information
about cache checkpoint SPI.
|
Modifier and Type | Method and Description |
---|---|
String |
CacheCheckpointSpiMBean.getCacheName()
Gets cache name to be used by this SPI..
|
Modifier and Type | Interface and Description |
---|---|
interface |
JdbcCheckpointSpiMBean
Management bean that provides general administrative and configuration information
about jdbc checkpoint SPI.
|
Modifier and Type | Method and Description |
---|---|
String |
JdbcCheckpointSpiMBean.getCheckpointTableName()
Gets checkpoint table name.
|
String |
JdbcCheckpointSpiMBean.getDataSourceInfo()
Gets data source description.
|
String |
JdbcCheckpointSpiMBean.getExpireDateFieldName()
Gets expiration date field name for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getExpireDateFieldType()
Gets expiration date field type for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getKeyFieldName()
Gets key field name for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getKeyFieldType()
Gets key field type for checkpoint table.
|
int |
JdbcCheckpointSpiMBean.getNumberOfRetries()
Gets number of retries in case of DB failure.
|
String |
JdbcCheckpointSpiMBean.getPwd()
Gets checkpoint jdbc password.
|
String |
JdbcCheckpointSpiMBean.getUser()
Gets checkpoint jdbc user name.
|
String |
JdbcCheckpointSpiMBean.getValueFieldName()
Gets value field name for checkpoint table.
|
String |
JdbcCheckpointSpiMBean.getValueFieldType()
Gets value field type for checkpoint table.
|
Modifier and Type | Interface and Description |
---|---|
interface |
S3CheckpointSpiMBean
Management bean for
S3CheckpointSpi . |
Modifier and Type | Method and Description |
---|---|
String |
S3CheckpointSpiMBean.getAccessKey() |
String |
S3CheckpointSpiMBean.getBucketEndpoint() |
String |
S3CheckpointSpiMBean.getBucketName()
Gets S3 bucket name to use.
|
String |
S3CheckpointSpiMBean.getProxyHost() |
int |
S3CheckpointSpiMBean.getProxyPort() |
String |
S3CheckpointSpiMBean.getProxyUsername() |
String |
S3CheckpointSpiMBean.getSSEAlgorithm() |
Modifier and Type | Interface and Description |
---|---|
interface |
SharedFsCheckpointSpiMBean
Management bean that provides general administrative and configuration information
about shared file system checkpoints.
|
Modifier and Type | Method and Description |
---|---|
String |
SharedFsCheckpointSpiMBean.getCurrentDirectoryPath()
Gets path to the directory where all checkpoints are saved.
|
Collection<String> |
SharedFsCheckpointSpiMBean.getDirectoryPaths()
Gets collection of all configured paths where checkpoints can be saved.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FifoQueueCollisionSpiMBean
Management bean that provides access to the FIFO queue collision SPI configuration.
|
Modifier and Type | Method and Description |
---|---|
int |
FifoQueueCollisionSpiMBean.getCurrentActiveJobsNumber()
Gets current number of jobs that are active, i.e.
|
int |
FifoQueueCollisionSpiMBean.getCurrentHeldJobsNumber()
Gets number of currently
'held' jobs. |
int |
FifoQueueCollisionSpiMBean.getCurrentRunningJobsNumber()
Gets number of currently running (not
'held ) jobs. |
int |
FifoQueueCollisionSpiMBean.getCurrentWaitJobsNumber()
Gets current number of jobs that wait for the execution.
|
int |
FifoQueueCollisionSpiMBean.getParallelJobsNumber()
Gets number of jobs that can be executed in parallel.
|
int |
FifoQueueCollisionSpiMBean.getWaitingJobsNumber()
Maximum number of jobs that are allowed to wait in waiting queue.
|
void |
FifoQueueCollisionSpiMBean.setParallelJobsNumber(int num)
Sets number of jobs that can be executed in parallel.
|
void |
FifoQueueCollisionSpiMBean.setWaitingJobsNumber(int num)
Sets maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JobStealingCollisionSpiMBean
Management MBean for job stealing based collision SPI.
|
Modifier and Type | Method and Description |
---|---|
int |
JobStealingCollisionSpiMBean.getActiveJobsThreshold()
Gets number of jobs that can be executed in parallel.
|
int |
JobStealingCollisionSpiMBean.getCurrentActiveJobsNumber()
Gets current number of jobs that are being executed.
|
int |
JobStealingCollisionSpiMBean.getCurrentHeldJobsNumber()
Gets number of currently
'held' jobs. |
int |
JobStealingCollisionSpiMBean.getCurrentJobsToStealNumber()
Gets current number of jobs to be stolen.
|
int |
JobStealingCollisionSpiMBean.getCurrentRunningJobsNumber()
Gets number of currently running (not
'held ) jobs. |
int |
JobStealingCollisionSpiMBean.getCurrentWaitJobsNumber()
Gets current number of jobs that wait for the execution.
|
int |
JobStealingCollisionSpiMBean.getMaximumStealingAttempts()
Gets maximum number of attempts to steal job by another node.
|
long |
JobStealingCollisionSpiMBean.getMessageExpireTime()
Message expire time configuration parameter.
|
Map<String,? extends Serializable> |
JobStealingCollisionSpiMBean.getStealingAttributes()
Configuration parameter to enable stealing to/from only nodes that
have these attributes set (see
ClusterNode.attribute(String) and
IgniteConfiguration.getUserAttributes() methods). |
int |
JobStealingCollisionSpiMBean.getTotalStolenJobsNumber()
Gets total number of stolen jobs.
|
int |
JobStealingCollisionSpiMBean.getWaitJobsThreshold()
Gets job count threshold at which this node will
start stealing jobs from other nodes.
|
boolean |
JobStealingCollisionSpiMBean.isStealingEnabled()
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
|
void |
JobStealingCollisionSpiMBean.setActiveJobsThreshold(int activeJobsThreshold)
Sets number of jobs that can be executed in parallel.
|
void |
JobStealingCollisionSpiMBean.setMaximumStealingAttempts(int maximumStealingAttempts)
Gets maximum number of attempts to steal job by another node.
|
void |
JobStealingCollisionSpiMBean.setMessageExpireTime(long msgExpireTime)
Message expire time configuration parameter.
|
void |
JobStealingCollisionSpiMBean.setStealingEnabled(boolean stealingEnabled)
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
|
void |
JobStealingCollisionSpiMBean.setWaitJobsThreshold(int waitJobsThreshold)
Sets job count threshold at which this node will
start stealing jobs from other nodes.
|
Modifier and Type | Interface and Description |
---|---|
interface |
PriorityQueueCollisionSpiMBean
Management bean that provides access to the priority queue collision SPI configuration.
|
Modifier and Type | Method and Description |
---|---|
int |
PriorityQueueCollisionSpiMBean.getCurrentActiveJobsNumber()
Gets current number of jobs that are active, i.e.
|
int |
PriorityQueueCollisionSpiMBean.getCurrentHeldJobsNumber()
Gets number of currently
'held' jobs. |
int |
PriorityQueueCollisionSpiMBean.getCurrentRunningJobsNumber()
Gets number of currently running (not
'held ) jobs. |
int |
PriorityQueueCollisionSpiMBean.getCurrentWaitJobsNumber()
Gets current number of jobs that wait for the execution.
|
int |
PriorityQueueCollisionSpiMBean.getDefaultPriority()
Gets default priority to use if a job does not have priority attribute
set.
|
String |
PriorityQueueCollisionSpiMBean.getJobPriorityAttributeKey()
Gets key name of job priority attribute.
|
int |
PriorityQueueCollisionSpiMBean.getParallelJobsNumber()
Gets number of jobs that can be executed in parallel.
|
String |
PriorityQueueCollisionSpiMBean.getPriorityAttributeKey()
Gets key name of task priority attribute.
|
int |
PriorityQueueCollisionSpiMBean.getStarvationIncrement()
Gets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
|
int |
PriorityQueueCollisionSpiMBean.getWaitingJobsNumber()
Maximum number of jobs that are allowed to wait in waiting queue.
|
boolean |
PriorityQueueCollisionSpiMBean.isStarvationPreventionEnabled()
Gets flag indicating whether job starvation prevention is enabled.
|
void |
PriorityQueueCollisionSpiMBean.setDefaultPriority(int priority)
Sets default priority to use if a job does not have priority attribute set.
|
void |
PriorityQueueCollisionSpiMBean.setParallelJobsNumber(int num)
Sets number of jobs that can be executed in parallel.
|
void |
PriorityQueueCollisionSpiMBean.setStarvationIncrement(int increment)
Sets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
|
void |
PriorityQueueCollisionSpiMBean.setStarvationPreventionEnabled(boolean preventStarvation)
Sets flag indicating whether job starvation prevention is enabled.
|
void |
PriorityQueueCollisionSpiMBean.setWaitingJobsNumber(int num)
Maximum number of jobs that are allowed to wait in waiting queue.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TcpCommunicationSpiMBean
MBean provide access to TCP-based communication SPI.
|
Modifier and Type | Method and Description |
---|---|
void |
TcpCommunicationSpiMBean.dumpStats()
Dumps SPI per-connection stats to logs.
|
int |
TcpCommunicationSpiMBean.getAckSendThreshold()
Gets number of received messages per connection to node after which acknowledgment message is sent.
|
long |
TcpCommunicationSpiMBean.getAckSendThresholdBytes()
Gets accrued size of received messages per connection to node after which acknowledgment message is sent.
|
long |
TcpCommunicationSpiMBean.getAckSendThresholdMillis()
Gets number of milliseconds after which acknowledgment is sent (if there are unacked messages).
|
int |
TcpCommunicationSpiMBean.getConnectionsPerNode()
Gets number of connections to each remote node. if
TcpCommunicationSpiMBean.isUsePairedConnections()
is true then number of connections is doubled and half is used for incoming and
half for outgoing messages. |
long |
TcpCommunicationSpiMBean.getConnectTimeout()
Gets connect timeout used when establishing connection
with remote nodes.
|
long |
TcpCommunicationSpiMBean.getIdleConnectionTimeout()
Gets maximum idle connection time upon which idle connections
will be closed.
|
String |
TcpCommunicationSpiMBean.getLocalAddress()
Gets local host address for socket binding.
|
int |
TcpCommunicationSpiMBean.getLocalPort()
Gets local port for socket binding.
|
int |
TcpCommunicationSpiMBean.getLocalPortRange()
Gets maximum number of local ports tried if all previously
tried ports are occupied.
|
long |
TcpCommunicationSpiMBean.getMaxConnectTimeout()
Gets maximum connect timeout.
|
int |
TcpCommunicationSpiMBean.getMessageQueueLimit()
Gets message queue limit for incoming and outgoing messages.
|
int |
TcpCommunicationSpiMBean.getOutboundMessagesQueueSize()
Gets outbound messages queue size.
|
long |
TcpCommunicationSpiMBean.getReceivedBytesCount()
Gets received bytes count.
|
Map<UUID,Long> |
TcpCommunicationSpiMBean.getReceivedMessagesByNode()
Gets received messages counts (grouped by node).
|
Map<String,Long> |
TcpCommunicationSpiMBean.getReceivedMessagesByType()
Gets received messages counts (grouped by type).
|
int |
TcpCommunicationSpiMBean.getReceivedMessagesCount()
Gets received messages count.
|
int |
TcpCommunicationSpiMBean.getReconnectCount()
Gets maximum number of reconnect attempts used when establishing connection
with remote nodes.
|
int |
TcpCommunicationSpiMBean.getSelectorsCount()
Gets count of selectors used in TCP server.
|
long |
TcpCommunicationSpiMBean.getSelectorSpins()
Defines how many non-blocking
selector.selectNow() should be made before
falling into selector.select(long) in NIO server. |
long |
TcpCommunicationSpiMBean.getSentBytesCount()
Gets sent bytes count.
|
Map<UUID,Long> |
TcpCommunicationSpiMBean.getSentMessagesByNode()
Gets sent messages counts (grouped by node).
|
Map<String,Long> |
TcpCommunicationSpiMBean.getSentMessagesByType()
Gets sent messages counts (grouped by type).
|
int |
TcpCommunicationSpiMBean.getSentMessagesCount()
Gets sent messages count.
|
int |
TcpCommunicationSpiMBean.getSharedMemoryPort()
Gets local port for shared memory communication.
|
int |
TcpCommunicationSpiMBean.getSlowClientQueueLimit()
Gets slow client queue limit.
|
int |
TcpCommunicationSpiMBean.getSocketReceiveBuffer()
Gets receive buffer size for sockets created or accepted by this SPI.
|
int |
TcpCommunicationSpiMBean.getSocketSendBuffer()
Gets send buffer size for sockets created or accepted by this SPI.
|
long |
TcpCommunicationSpiMBean.getSocketWriteTimeout()
Gets socket write timeout for TCP connections.
|
int |
TcpCommunicationSpiMBean.getUnacknowledgedMessagesBufferSize()
Gets maximum number of stored unacknowledged messages per connection to node.
|
boolean |
TcpCommunicationSpiMBean.isDirectBuffer()
Gets flag that indicates whether direct or heap allocated buffer is used.
|
boolean |
TcpCommunicationSpiMBean.isDirectSendBuffer()
Gets flag defining whether direct send buffer should be used.
|
boolean |
TcpCommunicationSpiMBean.isTcpNoDelay()
Gets value for
TCP_NODELAY socket option. |
boolean |
TcpCommunicationSpiMBean.isUsePairedConnections()
Returns
true if TcpCommunicationSpi should
maintain connection for outgoing and incoming messages separately. |
Modifier and Type | Interface and Description |
---|---|
interface |
LocalDeploymentSpiMBean
Management MBean for
LocalDeploymentSpi SPI. |
Modifier and Type | Interface and Description |
---|---|
interface |
UriDeploymentSpiMBean
Management bean for
UriDeploymentSpi . |
Modifier and Type | Method and Description |
---|---|
String |
UriDeploymentSpiMBean.getTemporaryDirectoryPath()
Gets temporary directory path.
|
List<String> |
UriDeploymentSpiMBean.getUriList()
Gets list of URIs that are processed by SPI.
|
boolean |
UriDeploymentSpiMBean.isCheckMd5()
Indicates if this SPI should check new deployment units md5 for redundancy.
|
Modifier and Type | Method and Description |
---|---|
void |
DiscoverySpiMBean.excludeNode(String nodeId)
Exclude node from discovery.
|
UUID |
DiscoverySpiMBean.getCoordinator()
Deprecated.
Use
DiscoverySpiMBean.getCoordinatorNodeFormatted() instead. |
String |
DiscoverySpiMBean.getCoordinatorNodeFormatted()
Gets current coordinator node formatted as a string.
|
String |
DiscoverySpiMBean.getLocalNodeFormatted()
Gets local node formatted as a string.
|
long |
DiscoverySpiMBean.getNodesFailed()
Gets failed nodes count.
|
long |
DiscoverySpiMBean.getNodesJoined()
Gets joined nodes count.
|
long |
DiscoverySpiMBean.getNodesLeft()
Gets left nodes count.
|
String |
DiscoverySpiMBean.getSpiState()
Gets current SPI state.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TcpDiscoverySpiMBean
Management bean for
TcpDiscoverySpi . |
Modifier and Type | Method and Description |
---|---|
void |
TcpDiscoverySpiMBean.checkRingLatency(int maxHops)
Diagnosis method for determining ring message latency.
|
void |
TcpDiscoverySpiMBean.dumpDebugInfo()
Dumps debug info using configured logger.
|
void |
TcpDiscoverySpiMBean.dumpRingStructure()
Dumps ring structure to log.
|
long |
TcpDiscoverySpiMBean.getAckTimeout()
Gets message acknowledgement timeout.
|
long |
TcpDiscoverySpiMBean.getAvgMessageProcessingTime()
Gets avg message processing time.
|
long |
TcpDiscoverySpiMBean.getConnectionCheckInterval()
Gets connection check interval in ms.
|
UUID |
TcpDiscoverySpiMBean.getCoordinator()
Gets current coordinator.
|
long |
TcpDiscoverySpiMBean.getCoordinatorSinceTimestamp()
Gets time local node has been coordinator since.
|
long |
TcpDiscoverySpiMBean.getCurrentTopologyVersion()
Current topology version.
|
long |
TcpDiscoverySpiMBean.getIpFinderCleanFrequency()
Gets frequency with which coordinator cleans IP finder and keeps it in the correct state, unregistering addresses
of the nodes that have left the topology.
|
String |
TcpDiscoverySpiMBean.getIpFinderFormatted()
Gets
TcpDiscoveryIpFinder (string representation). |
long |
TcpDiscoverySpiMBean.getJoinTimeout()
The join timeout, in milliseconds.
|
int |
TcpDiscoverySpiMBean.getLocalPort()
Gets local TCP port SPI listens to.
|
int |
TcpDiscoverySpiMBean.getLocalPortRange()
Gets local TCP port range.
|
long |
TcpDiscoverySpiMBean.getMaxAckTimeout()
Gets maximum message acknowledgement timeout.
|
long |
TcpDiscoverySpiMBean.getMaxMessageProcessingTime()
Gets max message processing time.
|
int |
TcpDiscoverySpiMBean.getMessageWorkerQueueSize()
Gets message worker queue current size.
|
long |
TcpDiscoverySpiMBean.getNetworkTimeout()
Gets network timeout.
|
long |
TcpDiscoverySpiMBean.getNodesFailed()
Gets failed nodes count.
|
long |
TcpDiscoverySpiMBean.getNodesJoined()
Gets joined nodes count.
|
long |
TcpDiscoverySpiMBean.getNodesLeft()
Gets left nodes count.
|
long |
TcpDiscoverySpiMBean.getPendingMessagesDiscarded()
Gets pending messages discarded count.
|
long |
TcpDiscoverySpiMBean.getPendingMessagesRegistered()
Gets pending messages registered count.
|
Map<String,Integer> |
TcpDiscoverySpiMBean.getProcessedMessages()
Gets processed messages counts (grouped by type).
|
Map<String,Integer> |
TcpDiscoverySpiMBean.getReceivedMessages()
Gets received messages counts (grouped by type).
|
int |
TcpDiscoverySpiMBean.getReconnectCount()
Gets number of connection attempts.
|
long |
TcpDiscoverySpiMBean.getSocketTimeout()
Gets socket timeout.
|
String |
TcpDiscoverySpiMBean.getSpiState()
Gets current SPI state.
|
long |
TcpDiscoverySpiMBean.getStatisticsPrintFrequency()
Gets statistics print frequency.
|
int |
TcpDiscoverySpiMBean.getThreadPriority()
Gets thread priority.
|
int |
TcpDiscoverySpiMBean.getTotalProcessedMessages()
Gets total processed messages count.
|
int |
TcpDiscoverySpiMBean.getTotalReceivedMessages()
Gets total received messages count.
|
boolean |
TcpDiscoverySpiMBean.isClientMode()
Whether or not discovery is started in client mode.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ZookeeperDiscoverySpiMBean
Management bean for
ZookeeperDiscoverySpi . |
Modifier and Type | Method and Description |
---|---|
long |
ZookeeperDiscoverySpiMBean.getCommErrorProcNum()
Gets number of communication resolver called.
|
long |
ZookeeperDiscoverySpiMBean.getNodeOrder()
Gets node join order.
|
String |
ZookeeperDiscoverySpiMBean.getZkConnectionString()
Gets connection string used to connect to ZooKeeper cluster.
|
String |
ZookeeperDiscoverySpiMBean.getZkRootPath()
Gets root path in ZooKeeper cluster Zk client uses to put data to.
|
String |
ZookeeperDiscoverySpiMBean.getZkSessionId()
Gets session id of Zk client established with ZooKeeper cluster.
|
long |
ZookeeperDiscoverySpiMBean.getZkSessionTimeout()
Gets session timeout used by Zk client of local Ignite node.
|
Modifier and Type | Interface and Description |
---|---|
interface |
MemoryEventStorageSpiMBean
Management bean for
MemoryEventStorageSpi . |
Modifier and Type | Method and Description |
---|---|
void |
MemoryEventStorageSpiMBean.clearAll()
Removes all events from the event queue.
|
long |
MemoryEventStorageSpiMBean.getExpireAgeMs()
Gets event time-to-live value.
|
long |
MemoryEventStorageSpiMBean.getExpireCount()
Gets maximum event queue size.
|
long |
MemoryEventStorageSpiMBean.getQueueSize()
Gets current queue size of the event queue.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AlwaysFailoverSpiMBean
Management bean for
AlwaysFailoverSpi . |
Modifier and Type | Method and Description |
---|---|
int |
AlwaysFailoverSpiMBean.getMaximumFailoverAttempts()
Gets maximum number of attempts to execute a failed job on another node.
|
int |
AlwaysFailoverSpiMBean.getTotalFailoverJobsCount()
Get total number of jobs that were failed over.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JobStealingFailoverSpiMBean
Management bean for
JobStealingFailoverSpi . |
Modifier and Type | Method and Description |
---|---|
int |
JobStealingFailoverSpiMBean.getMaximumFailoverAttempts()
Gets maximum number of attempts to execute a failed job on another node.
|
int |
JobStealingFailoverSpiMBean.getTotalFailedOverJobsCount()
Get total number of jobs that were failed over including stolen ones.
|
int |
JobStealingFailoverSpiMBean.getTotalStolenJobsCount()
Get total number of jobs that were stolen.
|
Modifier and Type | Interface and Description |
---|---|
interface |
NeverFailoverSpiMBean
Management bean for
NeverFailoverSpi . |
Modifier and Type | Interface and Description |
---|---|
interface |
AdaptiveLoadBalancingSpiMBean
Management MBean for
AdaptiveLoadBalancingSpi SPI. |
Modifier and Type | Method and Description |
---|---|
String |
AdaptiveLoadBalancingSpiMBean.getLoadProbeFormatted()
Gets text description of current load probing implementation used.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RoundRobinLoadBalancingSpiMBean
Management bean for
RoundRobinLoadBalancingSpi SPI. |
Modifier and Type | Method and Description |
---|---|
boolean |
RoundRobinLoadBalancingSpiMBean.isPerTask()
Configuration parameter indicating whether a new round robin order should be
created for every task.
|
Modifier and Type | Interface and Description |
---|---|
interface |
WeightedRandomLoadBalancingSpiMBean
Management MBean for
WeightedRandomLoadBalancingSpi SPI. |
Modifier and Type | Method and Description |
---|---|
int |
WeightedRandomLoadBalancingSpiMBean.getNodeWeight()
Gets weight of this node.
|
boolean |
WeightedRandomLoadBalancingSpiMBean.isUseWeights()
Checks whether node weights are considered when doing
random load balancing.
|
Modifier and Type | Method and Description |
---|---|
void |
CacheDrMBean.disableAdaptiveThrottling()
Disables adaptive DR throttling.
|
void |
CacheDrMBean.enableAdaptiveThrottling()
Enables adaptive DR throttling.
|
int |
CacheDrMBean.getDrBackupQueueSize()
Gets size of data center replication backup queue.
|
int |
CacheDrMBean.getDrBatchWaitingAcknowledgeCount()
Gets count of data center replication batches awaiting acknowledge from sender hub.
|
int |
CacheDrMBean.getDrBatchWaitingSendCount()
Gets count of data center replication batches awaiting to be send.
|
int |
CacheDrMBean.getDrQueuedKeysCount()
Gets count of keys enqueued for data center replication.
|
String |
CacheDrMBean.getDrSenderGroup()
Gets sender group for this cache.
|
int |
CacheDrMBean.getDrSenderHubsCount()
Gets count of available data center replication sender hubs.
|
String |
CacheDrMBean.getDrStatus()
Gets current status of data center replication.
|
long |
CacheDrMBean.getStateTransferThrottle()
Gets state transfer throttle.
|
void |
CacheDrMBean.pause()
Pauses data center replication for this cache.
|
void |
CacheDrMBean.resume()
Starts data center replication for this cache.
|
void |
CacheDrMBean.setStateTransferThrottle(long stateTransferThrottle)
Sets state transfer throttle.
|
void |
CacheDrMBean.start()
Starts data center replication for this cache.
|
void |
CacheDrMBean.stop()
Stops data center replication for this cache.
|
void |
CacheDrMBean.transferTo(byte dataCenterId)
Performs full state data transfer of this cache to the specified data center.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DrReceiverMBean
This interface defines JMX view on data center replication receiver hub.
|
interface |
DrSenderMBean
This interface defines JMX view on data center replication sender hub.
|
Modifier and Type | Method and Description |
---|---|
String |
DrSenderMBean.getCacheNames()
Gets cache names this sender hub works with.
|
long |
DrReceiverMBean.getFlushFrequency()
Gets data center replication data loader flush frequency.
|
long |
DrSenderMBean.getHealthCheckFrequency()
Gets health check frequency in milliseconds.
|
long |
DrReceiverMBean.getIdleTimeout()
Gets idle timeout for sender hub socket connection.
|
String |
DrReceiverMBean.getLocalInboundHost()
Gets local host name receiving hub server is bound to.
|
int |
DrReceiverMBean.getLocalInboundPort()
Gets local port receiver hub is bound to.
|
int |
DrSenderMBean.getMaxErrors()
Maximum amount of errors received from remote data center sender hub node.
|
int |
DrSenderMBean.getMaxFailedConnectAttempts()
Gets maximum failed connection attempts.
|
int |
DrSenderMBean.getMaxQueueSize()
Gets maximum wait queue size.
|
int |
DrReceiverMBean.getMessageQueueLimit()
Gets message queue limit for incoming and outgoing messages.
|
int |
DrReceiverMBean.getPerNodeBufferSize()
Gets data center replication data loader per node buffer size.
|
int |
DrReceiverMBean.getPerNodeParallelLoadOperations()
Gets per node parallel load operations.
|
long |
DrSenderMBean.getReadTimeout()
Gets read timeout in milliseconds.
|
long |
DrSenderMBean.getReconnectOnFailureTimeout()
Timeout after which node can be reconnected in case it was previously disconnected due to a failure.
|
int |
DrReceiverMBean.getSelectorCount()
Gets number of selector threads in receiver hub's TCP server.
|
String |
DrSenderMBean.getSenderGroups()
Gets group names this sender hub participate in.
|
long |
DrSenderMBean.getSystemRequestTimeout()
Gets system request timeout.
|
int |
DrReceiverMBean.getWorkerThreads()
Gets number of threads responsible for sender hub requests processing.
|
long |
DrReceiverMBean.getWriteTimeout()
Gets write timeout for sender hub socket connection.
|
boolean |
DrReceiverMBean.isDirectBuffer()
Whether to use direct buffer when processing sender hub requests.
|
boolean |
DrReceiverMBean.isTcpNodelay()
Whether to use TCP_NODELAY mode.
|
String |
DrSenderMBean.metricsFormatted()
Gets metrics (statistics) for this sender hub.
|
String |
DrReceiverMBean.metricsFormatted()
Get metrics (statistics) for this receiver hub.
|
void |
DrSenderMBean.pause()
Pause replication to all remote DCs.
|
void |
DrSenderMBean.pause(byte dcId)
Pause replication for given DC.
|
boolean |
DrSenderMBean.paused(byte dcId)
Returns DC pause flag.
|
String |
DrSenderMBean.remoteDataCentersFormatted()
Gets formatted remote data centers configuration info.
|
void |
DrSenderMBean.resume()
Resume replication for all remote DCs.
|
void |
DrSenderMBean.resume(byte dcId)
Resume replication for given DC.
|
Modifier and Type | Interface and Description |
---|---|
interface |
SnapshotMetricsMXBean
Snapshot metrics used to obtain statistics on snapshots.
|
interface |
SnapshotMXBean
Snapshot metrics used to obtain statistics on snapshots.
|
Modifier and Type | Method and Description |
---|---|
int |
SnapshotMetricsMXBean.getAvailableSnapshotMetrics()
Gets the number of recorded snapshot metrics.
|
long |
SnapshotMetricsMXBean.getBytesWritten()
Total size of all pages in bytes during snapshot creation (before/without compression).
|
long |
SnapshotMetricsMXBean.getBytesWritten(int index)
Total size of bytes during snapshot creation.
|
long |
SnapshotMetricsMXBean.getFreeSpace()
Gets free space in default configured snapshot directory (in bytes).
|
long |
SnapshotMetricsMXBean.getLastSnapshotFinishTime()
Gets the last snapshot finish time.
|
long |
SnapshotMetricsMXBean.getLastSnapshotId()
Gets the last snapshot IDs
|
String |
SnapshotMetricsMXBean.getLastSnapshotOperation()
Gets the last snapshot operation type.
|
long |
SnapshotMetricsMXBean.getLastSnapshotStartTime()
Gets the last snapshot start time.
|
long |
SnapshotMetricsMXBean.getPartitionsWritten()
Partitions written during snapshot creation.
|
long |
SnapshotMetricsMXBean.getPartitionsWritten(int index)
Partitions written during snapshot creation.
|
long |
SnapshotMetricsMXBean.getTotalBytesWrittenOnStorage()
Total bytes written on storage during snapshot creation (including snapshot metadata).
|
long |
SnapshotMetricsMXBean.getTotalBytesWrittenOnStorage(int index)
Total bytes written on storage during snapshot creation.
|
long |
SnapshotMetricsMXBean.getWriteThrottlingTime()
Time in milliseconds when snapshot writer thread was parked.
|
long |
SnapshotMetricsMXBean.getWriteThrottlingTime(int index)
Time in milliseconds when snapshot writer thread was parked.
|
boolean |
SnapshotMetricsMXBean.isSnapshotInProgress()
Gets flag indicating if there is an ongoing snapshot operation.
|
boolean |
SnapshotMXBean.resetRestartingCaches()
Reset restarting caches.
|
long |
SnapshotMetricsMXBean.snapshotFinishTime(int index)
Gets one of the last snapshot finish times by it's relative index.
|
long |
SnapshotMetricsMXBean.snapshotId(int index)
Gets one of the last snapshot IDs by it's relative index.
|
String |
SnapshotMetricsMXBean.snapshotOperation(int index)
Gets one of the last snapshot operation types by it's relative index.
|
long |
SnapshotMetricsMXBean.snapshotStartTime(int index)
Gets one of the last snapshot start times by it's relative index.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RollingUpgradeMXBean
This interface defines JMX view on
RollingUpgrade . |
Modifier and Type | Method and Description |
---|---|
void |
RollingUpgradeMXBean.finish()
Allows disable rolling upgrade mode.
|
void |
RollingUpgradeMXBean.force()
Allows enable force rolling upgrade mode.
|
List<String> |
RollingUpgradeMXBean.getInitialNodes()
Returns a list of alive nodes in the cluster that are not updated yet.
|
String |
RollingUpgradeMXBean.getInitialVersion()
Returns the version that is used as starting point for Rolling Upgrade.
|
String |
RollingUpgradeMXBean.getTargetVersion()
Returns target cluster version.
|
List<String> |
RollingUpgradeMXBean.getUpdatedNodes()
Returns a list of alive nodes in the cluster that are upgraded.
|
boolean |
RollingUpgradeMXBean.isEnabled()
Returns
true if Rolling Upgrade is enabled and is in progress. |
void |
RollingUpgradeMXBean.start()
Allows to enable rolling upgrade mode.
|
Modifier and Type | Interface and Description |
---|---|
interface |
JaasAuthenticatorMBean
Management bean for
JaasAuthenticator . |
Modifier and Type | Method and Description |
---|---|
String |
JaasAuthenticatorMBean.getCallbackHandlerFactoryFormatted()
Gets JAAS-authentication callback handler factory name.
|
String |
JaasAuthenticatorMBean.getLoginContextName()
Gets login context name.
|
void |
JaasAuthenticatorMBean.setLoginContextName(String loginCtxName)
Sets new login context name.
|
Modifier and Type | Interface and Description |
---|---|
interface |
PasscodeAuthenticatorMBean
Management bean for
PasscodeAuthenticator . |
Modifier and Type | Method and Description |
---|---|
String |
PasscodeAuthenticatorMBean.getPasscodesFormatted()
Gets text presentation of the valid passcodes collection.
|
GridGain In-Memory Computing Platform : ver. 8.9.14 Release Date : November 5 2024