Available Metrics
This topic lists all metrics available in GridGain 9.
client.handler
The metrics provided by the client handler and related to active clients.
Metric name | Description |
---|---|
BytesReceived |
Total bytes received. |
BytesSent |
Total bytes sent. |
ConnectionsInitiated |
Total initiated connections. |
CursorsActive |
Active cursors. |
RequestsActive |
Requests in progress. |
RequestsProcessed |
Total processed requests. |
RequestsFailed |
Total failed requests. |
SessionsAccepted |
Total accepted sessions. |
SessionsActive |
The number of currently active sessions. |
SessionsRejected |
Total sessions rejected due to handshake errors. |
SessionsRejectedTls |
Total sessions rejected due to TLS handshake errors. |
SessionsRejectedTimeout |
Total sessions rejected due to timeout. |
TransactionsActive |
Active transactions. |
clock.service
Metric name | Description |
---|---|
ClockSkewExceedingMaxClockSkew |
Observed clock skew that exceeded max clock skew. |
expiration
Metric name | Description |
---|---|
DetailedExpirationMetrics |
Detailed expiration metrics. |
TotalDeletedExpiredRowsCount |
Total number of deleted expired rows. |
dcr
Metric name | Description |
---|---|
EntriesObserved |
The number of entries received from the source cluster. |
EntriesSent |
The number of entries sent to receiver clusters. |
ReplicationLag |
Estimated lag between entry being sent by the source cluster and received on the target cluster, in milliseconds. |
jvm
The metrics for GridGain Java Virtual Machine resource use.
Metric name | Description |
---|---|
UpTime |
The uptime of the Java virtual machine in milliseconds. |
gc.CollectionTime |
Approximate total time spent on garbage collection in milliseconds, summed across all collectors. |
memory.heap.Committed |
Committed amount of heap memory. |
memory.heap.Init |
Initial amount of heap memory. |
memory.heap.Max |
Maximum amount of heap memory. |
memory.heap.Used |
Currently used amount of heap memory. |
memory.non-heap.Committed |
Committed amount of non-heap memory. |
memory.non-heap.Init |
Initial amount of non-heap memory. |
memory.non-heap.Max |
Maximum amount of non-heap memory. |
memory.non-heap.Used |
Used amount of non-heap memory. |
license
Metric name | Description |
---|---|
license.DaysToLicenseExpiration |
The number of days left until the license expires. |
license.MaxNumberOfCores |
Maximum number of cores allowed. Represents a sum of cores used for all cluster nodes (0 is unlimited). |
license.MaxNumberOfNodes |
Maximum number of nodes allowed. Represents a total number nodes in cluster topology (0 is unlimited). |
license.MaxNumberOfHosts |
The maximum number of hosts allowed. Represents a number of hosts where cluster nodes are located (0 is unlimited). |
license.MaxHeapSize |
Maximum heap size allowed. Represents a sum of configured maximum heap sizes on cluster nodes (0 is unlimited). |
license.MaxOffheapSize |
Maximum off-heap size allowed. Represents a sum of all storage profiles sizes on cluster nodes (0 is unlimited). |
license.MaxRamSize |
The maximum RAM size allowed. Represents a sum of available RAM on all hosts (0 is unlimited). |
metastorage
Metric name | Description |
---|---|
IdempotentCacheSize |
The current size of the cache of idempotent commands' results. |
SafeTimeLag |
Number of milliseconds the local MetaStorage SafeTime lags behind the local logical clock. |
os
Metric name | Description |
---|---|
CpuLoad |
CPU load. The value is between 0.0 and 1.0, where 0.0 means no CPU load and 1.0 means 100% CPU load. If the CPU load information is not available, a negative value is returned. |
LoadAverage |
System load average for the last minute. System load average is the sum of the number of runnable entities queued to the available processors and the number of runnable entities running on the available processors averaged over a period of time. The way in which the load average is calculated depends on the operating system. If the load average is not available, a negative value is returned. |
placement-driver
Metric name | Description |
---|---|
ActiveLeasesCount |
Number of currently active leases. |
CurrentPendingAssignmentsSize |
Current size of pending assignments over all partitions. |
CurrentStableAssignmentsSize |
Current size of stable assignments over all partitions. |
LeasesCreated |
Total number of created leases. |
LeasesProlonged |
Total number of prolonged leases. |
LeasesPublished |
Total number of published leases. |
LeasesWithoutCandidates |
Total number of prolonged leases. |
raft
Metric name | Description |
---|---|
raft.fsmcaller.disruptor.Stripes |
The histogram of distribution data by stripes in the state machine for partitions |
raft.fsmcaller.disruptor.Batch |
The histogram of the batch size to handle in the state machine for partitions |
raft.logmanager.disruptor.Batch |
The histogram of the batch size to handle in the log for partitions |
raft.logmanager.disruptor.Stripes |
The histogram of distribution data by stripes in the log for partitions |
raft.nodeimpl.disruptor.Batch |
The histogram of the batch size to handle node operations for partitions |
raft.nodeimpl.disruptor.Stripes |
The histogram of distribution data by stripes for node operations for partitions |
raft.readonlyservice.disruptor.Stripes |
The histogram of distribution data by stripes readonly operations for partitions |
raft.readonlyservice.disruptor.Batch |
The histogram of the batch size to handle readonly operations for partitions |
resource.vacuum
Metric name | Description |
---|---|
MarkedForVacuumTransactionMetaCount |
Count of transaction metas that have been marked for vacuum. |
SkippedForFurtherProcessingUnfinishedTransactionCount |
The current number of unfinished transactions that are skipped by vacuumizer for further processing. |
VacuumizedPersistentTransactionMetaCount |
Count of persistent transaction metas that have been vacuumized. |
VacuumizedVolatileTxnMetaCount |
Count of volatile transaction metas that have been vacuumized. |
storage.aipersist.{profile}
Metric name | Description |
---|---|
CpTotalPages |
Number of pages in the current checkpoint. |
CpEvictedPages |
Number of evicted pages in the current checkpoint. |
CpWrittenPages |
Number of written pages in the current checkpoint. |
CpSyncedPages |
Number of fsynced pages in the current checkpoint. |
CpWriteSpeed |
Checkpoint write speed, in pages per second. Value is averaged over the last 3 checkpoints plus the current one. |
CurrDirtyRatio |
Current ratio of dirty pages (dirty vs total), expressed as a fraction. The fraction is computed for each segment in the current region, and the highest value becomes "current." |
LastEstimatedSpeedForMarkAll |
Last estimated speed of marking all clean pages dirty to the end of a checkpoint, in pages/second. |
MaxSize |
Maximum in-memory region size in bytes. |
MarkDirtySpeed |
Speed of marking pages dirty, in pages/second. Value is averaged over the last 3 fragments, 0.25 sec each, plus the current fragment, 0-0.25 sec (0.75-1.0 sec total). |
SpeedBasedThrottlingPercentage |
Fraction of throttling time within average marking time (e.g., "quarter" = 0.25). |
TargetDirtyRatio |
Ratio of dirty pages (dirty vs total), expressed as a fraction. Throttling starts when this ratio is reached. |
ThrottleParkTime |
Park (sleep) time for the Write operation, in nanoseconds. Value is averaged over the last 3 fragments, 0.25 sec each, plus the current fragment, 0-0.25 sec (0.75-1.0 sec total). It defines park periods for either the checkpoint buffer protection or the clean page pool protection. |
TotalAllocatedSize |
Total size of allocated pages on disk in bytes. |
TotalUsedSize |
Total size of non-empty allocated pages on disk in bytes. |
sql.client
SQL client metrics.
Metric name | Description |
---|---|
OpenCursors |
Number of currently open cursors. |
sql.memory
Metric name | Description |
---|---|
Limit |
SQL memory limit (bytes) |
MaxReserved |
Maximum memory usage by SQL so far (bytes) |
Reserved |
Current memory usage by SQL (bytes) |
StatementLimit |
Memory limit per SQL statement (bytes) |
sql.offloading
Metric name | Description |
---|---|
DataLimit |
SQL offloading data limit in bytes. |
DiskUsage |
The amount of space currently used by the offloading in bytes. |
MaxDiskUsage |
The maximum amount of space used by the offloading in bytes. |
OpenedFilesCount |
The number of open files used for offloading. |
OffloadedActiveQueries |
The number of active queries that have been spilled to disk. |
TotalOffloadedQueries |
The total number of queries that have been spilled to disk. |
TotalBytesRead |
The total number of bytes read from disk by the offloading. |
TotalBytesWritten |
The total number of bytes written to disk by the offloading. |
TotalWriteOperationsCount |
The total number of read operations performed by the offloading. |
TotalReadOperationsCount |
The total number of write operations performed by the offloading. |
sql.plan.cache
Metrics for SQL cache planning.
Metric name | Description |
---|---|
Hits |
Cache plan hits. |
Misses |
Cache plan misses. |
sql.queries
Metric name | Description |
---|---|
Canceled |
Total number of canceled queries. |
ExceededMemoryQuota |
Total number of queries that failed due to exceeding memory quota. |
Failed |
Total number of failed queries. This metric includes all unsuccessful queries, regardless of reason. |
Succeeded |
Total number of successful queries. |
TimedOut |
Total number of queries that failed due to time-out. |
thread.pools.{thread-pool-executor-name}
Metric name | Description |
---|---|
ActiveCount |
Approximate number of threads that are actively executing tasks. |
CompletedTaskCount |
Approximate total number of tasks that have completed execution. |
CorePoolSize |
The core number of threads. |
KeepAliveTime |
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. |
LargestPoolSize |
Largest number of threads that have ever simultaneously been in the pool. |
MaximumPoolSize |
The maximum allowed number of threads. |
PoolSize |
Current number of threads in the pool. |
TaskCount |
Approximate total number of tasks that have been scheduled for execution. |
QueueSize |
Current size of the execution queue. |
topology.cluster
Metrics for the cluster topology.
Metric name | Description |
---|---|
ClusterId |
Unique identifier of the cluster. |
ClusterName |
Unique name of the cluster. |
TotalNodes |
Number of nodes in the logical topology. |
topology.local
Metrics with node information.
Metric name | Description |
---|---|
NodeName |
Unique name of the node. |
NodeId |
Unique identifier of the node. |
NodeVersion |
GridGain version on the node. |
transactions
Transaction metrics.
Metric name | Description |
---|---|
RwCommits |
Total number of read-write transaction commits. |
RoCommits |
Total number of read-only transaction commits. |
RwRollbacks |
Total number of read-write transaction rollbacks. |
RoRollbacks |
Total number of read-only transaction rollbacks. |
RwDuration |
Histogram representation of read-write transaction latency. |
RoDuration |
Histogram representation of read-only transaction latency. |
TotalRollbacks |
Total number of transactions rollbacks. |
TotalCommits |
Total number of transaction commits. |
zones
Metric name | Description |
---|---|
LocalUnrebalancedPartitionsCount |
The number of partitions that should be moved to this node. |
TotalUnrebalancedPartitionsCount |
The total number of partitions that should be moved to a new owner. |
© 2025 GridGain Systems, Inc. All Rights Reserved. Privacy Policy | Legal Notices. GridGain® is a registered trademark of GridGain Systems, Inc.
Apache, Apache Ignite, the Apache feather and the Apache Ignite logo are either registered trademarks or trademarks of The Apache Software Foundation.